Uses of Class
io.fluxcapacitor.common.api.SerializedMessage
Packages that use SerializedMessage
Package
Description
-
Uses of SerializedMessage in io.fluxcapacitor.common.api
Methods in io.fluxcapacitor.common.api that return SerializedMessageModifier and TypeMethodDescription -
Uses of SerializedMessage in io.fluxcapacitor.common.api.tracking
Methods in io.fluxcapacitor.common.api.tracking with parameters of type SerializedMessage -
Uses of SerializedMessage in io.fluxcapacitor.common.tracking
Methods in io.fluxcapacitor.common.tracking that return SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessage
DefaultTrackingStrategy.ensureMessageSegment
(SerializedMessage message) Methods in io.fluxcapacitor.common.tracking that return types with arguments of type SerializedMessageModifier and TypeMethodDescriptionprotected List
<SerializedMessage> DefaultTrackingStrategy.filter
(List<SerializedMessage> messages, int[] segmentRange, Position position, Tracker tracker) protected List
<SerializedMessage> default List
<SerializedMessage> Retrieves a batch of messages starting from the givenlastIndex
(exclusive).Retrieves a batch of messages starting from the givenminIndex
.Methods in io.fluxcapacitor.common.tracking with parameters of type SerializedMessageModifier and TypeMethodDescriptiondefault CompletableFuture
<Void> MessageStore.append
(SerializedMessage... messages) Appends the given messages to the store.default boolean
Tracker.canHandle
(SerializedMessage message, int[] segmentRange) Checks if the given message can be handled by this tracker based on segment range and type filtering.protected SerializedMessage
DefaultTrackingStrategy.ensureMessageSegment
(SerializedMessage message) Method parameters in io.fluxcapacitor.common.tracking with type arguments of type SerializedMessageModifier and TypeMethodDescriptionMessageStore.append
(List<SerializedMessage> messages) Appends a list of messages to the store.protected List
<SerializedMessage> DefaultTrackingStrategy.filter
(List<SerializedMessage> messages, int[] segmentRange, Position position, Tracker tracker) protected void
DefaultTrackingStrategy.onUpdate
(List<SerializedMessage> messages) -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.common
Methods in io.fluxcapacitor.javaclient.common that return SerializedMessageModifier and TypeMethodDescriptionMessage.serialize
(Serializer serializer) Serializes this message to aSerializedMessage
using the providedSerializer
. -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.common.serialization
Methods in io.fluxcapacitor.javaclient.common.serialization that return SerializedMessageMethods in io.fluxcapacitor.javaclient.common.serialization with parameters of type SerializedMessageModifier and TypeMethodDescriptiondefault DeserializingMessage
Serializer.deserializeMessage
(SerializedMessage message, MessageType messageType) Deserializes a singleSerializedMessage
into aDeserializingMessage
.Method parameters in io.fluxcapacitor.javaclient.common.serialization with type arguments of type SerializedMessageModifier and TypeMethodDescriptiondefault Stream
<DeserializingMessage> Serializer.deserializeMessages
(Stream<SerializedMessage> dataStream, MessageType messageType) Deserializes a stream ofSerializedMessage
intoDeserializingMessage
instances with the specifiedMessageType
.default Stream
<DeserializingMessage> Serializer.deserializeMessages
(Stream<SerializedMessage> dataStream, MessageType messageType, UnknownTypeStrategy unknownTypeStrategy) Deserializes a stream ofSerializedMessage
intoDeserializingMessage
instances with the specifiedMessageType
.default Stream
<DeserializingMessage> Serializer.deserializeMessages
(Stream<SerializedMessage> dataStream, MessageType messageType, String topic) Deserializes a stream ofSerializedMessage
intoDeserializingMessage
instances with the specifiedMessageType
.default Stream
<DeserializingMessage> Serializer.deserializeMessages
(Stream<SerializedMessage> dataStream, MessageType messageType, String topic, UnknownTypeStrategy unknownTypeStrategy) Deserializes a stream ofSerializedMessage
intoDeserializingMessage
instances with the specifiedMessageType
.Constructors in io.fluxcapacitor.javaclient.common.serialization with parameters of type SerializedMessageModifierConstructorDescriptionDeserializingMessage
(SerializedMessage message, Function<Type, Object> payload, MessageType messageType, String topic, Serializer serializer) Constructor parameters in io.fluxcapacitor.javaclient.common.serialization with type arguments of type SerializedMessageModifierConstructorDescriptionDeserializingMessage
(DeserializingObject<byte[], SerializedMessage> delegate, MessageType messageType, String topic, Serializer serializer) -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.configuration.client
Method parameters in io.fluxcapacitor.javaclient.configuration.client with type arguments of type SerializedMessageModifier and TypeMethodDescriptionvoid
ClientDispatchMonitor.accept
(MessageType messageType, String topic, List<SerializedMessage> messages) Called when a batch of messages is dispatched by the client. -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.persisting.eventsourcing.client
Methods in io.fluxcapacitor.javaclient.persisting.eventsourcing.client that return types with arguments of type SerializedMessageModifier and TypeMethodDescriptiondefault AggregateEventStream
<SerializedMessage> Retrieves the full event stream for a given aggregate.default AggregateEventStream
<SerializedMessage> Retrieves the event stream for an aggregate starting after the given sequence number.Retrieves the event stream for an aggregate with control over size and offset.Retrieves events for a specific aggregate starting after a given sequence number, optionally limiting the result size.Method parameters in io.fluxcapacitor.javaclient.persisting.eventsourcing.client with type arguments of type SerializedMessageModifier and TypeMethodDescriptiondefault CompletableFuture
<Void> EventStoreClient.storeEvents
(String aggregateId, List<SerializedMessage> events, boolean storeOnly) Stores a list of serialized events for a given aggregate identifier.EventStoreClient.storeEvents
(String aggregateId, List<SerializedMessage> events, boolean storeOnly, Guarantee guarantee) Stores events for a given aggregate with an explicit guarantee.InMemoryEventStore.storeEvents
(String aggregateId, List<SerializedMessage> events, boolean storeOnly, Guarantee guarantee) WebSocketEventStoreClient.storeEvents
(String aggregateId, List<SerializedMessage> events, boolean storeOnly, Guarantee guarantee) Stores events for a specific aggregate, with control over store-only mode and delivery guarantee. -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.persisting.repository
Method parameters in io.fluxcapacitor.javaclient.persisting.repository with type arguments of type SerializedMessageModifier and TypeMethodDescriptionprotected void
CachingAggregateRepository.handleEvents
(List<SerializedMessage> messages) -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.persisting.search.client
Methods in io.fluxcapacitor.javaclient.persisting.search.client that return SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessage
InMemorySearchStore.asSerializedMessage
(SerializedDocument document) Methods in io.fluxcapacitor.javaclient.persisting.search.client that return types with arguments of type SerializedMessageModifier and TypeMethodDescriptionInMemorySearchStore.openStream
(String collection, Long lastIndex, int maxSize) Method parameters in io.fluxcapacitor.javaclient.persisting.search.client with type arguments of type SerializedMessageModifier and TypeMethodDescriptionCollectionMessageStore.append
(List<SerializedMessage> messages) protected void
InMemorySearchStore.notifyMonitors
(String collection, List<SerializedMessage> messages) CollectionMessageStore.registerMonitor
(Consumer<List<SerializedMessage>> monitor) InMemorySearchStore.registerMonitor
(String collection, Consumer<List<SerializedMessage>> monitor) InMemorySearchStore.registerMonitor
(BiConsumer<String, List<SerializedMessage>> monitor) -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.publishing
Methods in io.fluxcapacitor.javaclient.publishing that return SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessage
DefaultResultGateway.interceptDispatch
(Object payload, Metadata metadata) AdhocDispatchInterceptor.modifySerializedMessage
(SerializedMessage serializedMessage, Message message, MessageType messageType, String topic) Optionally modifies the serialized message before dispatch, delegating to any registered ad hoc interceptor for the current thread.default SerializedMessage
DispatchInterceptor.modifySerializedMessage
(SerializedMessage serializedMessage, Message message, MessageType messageType, String topic) Allows modifications to the serialized representation of the message before it is actually published.Methods in io.fluxcapacitor.javaclient.publishing that return types with arguments of type SerializedMessageModifier and TypeMethodDescriptionDefaultRequestHandler.ResponseCallback.finalCallback()
Returns the value of thefinalCallback
record component.DefaultRequestHandler.ResponseCallback.intermediateCallback()
Returns the value of theintermediateCallback
record component.protected CompletableFuture
<SerializedMessage> DefaultRequestHandler.prepareRequest
(SerializedMessage request, Duration timeout, Consumer<SerializedMessage> intermediateCallback) DefaultRequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout) Sends a request and processes the response, combining intermediate responses (if any) with the final response data.DefaultRequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout, Consumer<SerializedMessage> intermediateCallback) default CompletableFuture
<SerializedMessage> RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender) Sends a single request and returns a future that completes when the corresponding response is received.RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout) Sends a single request with a custom timeout and returns a future for the corresponding response.RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout, Consumer<SerializedMessage> intermediateCallback) default CompletableFuture
<SerializedMessage> RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Consumer<SerializedMessage> intermediateCallback) DefaultRequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender) DefaultRequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender, Duration timeout) RequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender) Sends multiple requests and returns a list of futures for their corresponding responses.RequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender, Duration timeout) Sends multiple requests with a custom timeout and returns a list of futures for their responses.Methods in io.fluxcapacitor.javaclient.publishing with parameters of type SerializedMessageModifier and TypeMethodDescriptionAdhocDispatchInterceptor.modifySerializedMessage
(SerializedMessage serializedMessage, Message message, MessageType messageType, String topic) Optionally modifies the serialized message before dispatch, delegating to any registered ad hoc interceptor for the current thread.default SerializedMessage
DispatchInterceptor.modifySerializedMessage
(SerializedMessage serializedMessage, Message message, MessageType messageType, String topic) Allows modifications to the serialized representation of the message before it is actually published.protected CompletableFuture
<SerializedMessage> DefaultRequestHandler.prepareRequest
(SerializedMessage request, Duration timeout, Consumer<SerializedMessage> intermediateCallback) DefaultRequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout) Sends a request and processes the response, combining intermediate responses (if any) with the final response data.DefaultRequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout, Consumer<SerializedMessage> intermediateCallback) default CompletableFuture
<SerializedMessage> RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender) Sends a single request and returns a future that completes when the corresponding response is received.RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout) Sends a single request with a custom timeout and returns a future for the corresponding response.RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout, Consumer<SerializedMessage> intermediateCallback) default CompletableFuture
<SerializedMessage> RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Consumer<SerializedMessage> intermediateCallback) Method parameters in io.fluxcapacitor.javaclient.publishing with type arguments of type SerializedMessageModifier and TypeMethodDescriptionprotected void
DefaultRequestHandler.handleResults
(List<SerializedMessage> messages) protected CompletableFuture
<SerializedMessage> DefaultRequestHandler.prepareRequest
(SerializedMessage request, Duration timeout, Consumer<SerializedMessage> intermediateCallback) DefaultRequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout) Sends a request and processes the response, combining intermediate responses (if any) with the final response data.DefaultRequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout, Consumer<SerializedMessage> intermediateCallback) default CompletableFuture
<SerializedMessage> RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender) Sends a single request and returns a future that completes when the corresponding response is received.RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout) Sends a single request with a custom timeout and returns a future for the corresponding response.RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Duration timeout, Consumer<SerializedMessage> intermediateCallback) default CompletableFuture
<SerializedMessage> RequestHandler.sendRequest
(SerializedMessage request, Consumer<SerializedMessage> requestSender, Consumer<SerializedMessage> intermediateCallback) DefaultRequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender) DefaultRequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender) DefaultRequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender, Duration timeout) DefaultRequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender, Duration timeout) RequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender) Sends multiple requests and returns a list of futures for their corresponding responses.RequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender) Sends multiple requests and returns a list of futures for their corresponding responses.RequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender, Duration timeout) Sends multiple requests with a custom timeout and returns a list of futures for their responses.RequestHandler.sendRequests
(List<SerializedMessage> requests, Consumer<List<SerializedMessage>> requestSender, Duration timeout) Sends multiple requests with a custom timeout and returns a list of futures for their responses.Constructor parameters in io.fluxcapacitor.javaclient.publishing with type arguments of type SerializedMessageModifierConstructorDescriptionprotected
ResponseCallback
(Consumer<SerializedMessage> intermediateCallback, CompletableFuture<SerializedMessage> finalCallback) Creates an instance of aResponseCallback
record class.protected
ResponseCallback
(Consumer<SerializedMessage> intermediateCallback, CompletableFuture<SerializedMessage> finalCallback) Creates an instance of aResponseCallback
record class. -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.publishing.client
Methods in io.fluxcapacitor.javaclient.publishing.client with parameters of type SerializedMessageModifier and TypeMethodDescriptionGatewayClient.append
(Guarantee guarantee, SerializedMessage... messages) Append the given messages to the gateway, applying the given deliveryGuarantee
.WebsocketGatewayClient.append
(Guarantee guarantee, SerializedMessage... messages) Method parameters in io.fluxcapacitor.javaclient.publishing.client with type arguments of type SerializedMessageModifier and TypeMethodDescriptionWebsocketGatewayClient.registerMonitor
(Consumer<List<SerializedMessage>> monitor) -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.publishing.correlation
Methods in io.fluxcapacitor.javaclient.publishing.correlation with parameters of type SerializedMessageModifier and TypeMethodDescriptionCorrelationDataProvider.getCorrelationData
(Client client, SerializedMessage currentMessage, MessageType messageType) Returns correlation metadata derived from a serialized message and optional context. -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.publishing.routing
Methods in io.fluxcapacitor.javaclient.publishing.routing that return SerializedMessageModifier and TypeMethodDescriptionMessageRoutingInterceptor.modifySerializedMessage
(SerializedMessage serializedMessage, Message m, MessageType messageType, String topic) Computes and sets the routing segment on the serialized message if not already present.Methods in io.fluxcapacitor.javaclient.publishing.routing with parameters of type SerializedMessageModifier and TypeMethodDescriptionMessageRoutingInterceptor.modifySerializedMessage
(SerializedMessage serializedMessage, Message m, MessageType messageType, String topic) Computes and sets the routing segment on the serialized message if not already present. -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.scheduling.client
Methods in io.fluxcapacitor.javaclient.scheduling.client that return types with arguments of type SerializedMessageModifier and TypeMethodDescriptionprotected Collection
<SerializedMessage> InMemoryScheduleStore.filterMessages
(Collection<SerializedMessage> messages) Methods in io.fluxcapacitor.javaclient.scheduling.client with parameters of type SerializedMessageMethod parameters in io.fluxcapacitor.javaclient.scheduling.client with type arguments of type SerializedMessageModifier and TypeMethodDescriptionInMemoryScheduleStore.append
(List<SerializedMessage> messages) protected Collection
<SerializedMessage> InMemoryScheduleStore.filterMessages
(Collection<SerializedMessage> messages) -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.tracking
Methods in io.fluxcapacitor.javaclient.tracking that return types with arguments of type SerializedMessageModifier and TypeMethodDescriptionprotected Consumer
<List<SerializedMessage>> DefaultTracking.createConsumer
(ConsumerConfiguration config, List<Handler<DeserializingMessage>> handlers) -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.tracking.client
Methods in io.fluxcapacitor.javaclient.tracking.client that return SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessage
InMemoryMessageStore.getMessage
(long index) Methods in io.fluxcapacitor.javaclient.tracking.client that return types with arguments of type SerializedMessageModifier and TypeMethodDescriptionprotected List
<SerializedMessage> CachingTrackingClient.filterMessages
(List<SerializedMessage> messages, int[] segmentRange, Position position, ConsumerConfiguration config) protected Collection
<SerializedMessage> InMemoryMessageStore.filterMessages
(Collection<SerializedMessage> messages) CachingTrackingClient.readFromIndex
(long minIndex, int maxSize) LocalTrackingClient.readFromIndex
(long minIndex, int maxSize) TrackingClient.readFromIndex
(long minIndex, int maxSize) Fetches messages starting from the given index up to the provided max size.WebsocketTrackingClient.readFromIndex
(long minIndex, int maxSize) Methods in io.fluxcapacitor.javaclient.tracking.client with parameters of type SerializedMessageModifier and TypeMethodDescriptionLocalTrackingClient.append
(Guarantee guarantee, SerializedMessage... messages) Method parameters in io.fluxcapacitor.javaclient.tracking.client with type arguments of type SerializedMessageModifier and TypeMethodDescriptionInMemoryMessageStore.append
(List<SerializedMessage> messages) protected void
CachingTrackingClient.cacheNewMessages
(List<SerializedMessage> messages) protected List
<SerializedMessage> CachingTrackingClient.filterMessages
(List<SerializedMessage> messages, int[] segmentRange, Position position, ConsumerConfiguration config) protected Collection
<SerializedMessage> InMemoryMessageStore.filterMessages
(Collection<SerializedMessage> messages) protected void
InMemoryMessageStore.notifyMonitors
(List<SerializedMessage> messages) InMemoryMessageStore.registerMonitor
(Consumer<List<SerializedMessage>> monitor) LocalTrackingClient.registerMonitor
(Consumer<List<SerializedMessage>> monitor) static Registration
DefaultTracker.start
(Consumer<List<SerializedMessage>> consumer, MessageType messageType, ConsumerConfiguration config, Client client) Starts one or more trackers.static Registration
DefaultTracker.start
(Consumer<List<SerializedMessage>> consumer, MessageType messageType, ConsumerConfiguration config, FluxCapacitor fluxCapacitor) Starts one or more trackers.static Registration
DefaultTracker.start
(Consumer<List<SerializedMessage>> consumer, MessageType messageType, String topic, ConsumerConfiguration config, Client client) Starts one or more trackers.static Registration
DefaultTracker.start
(Consumer<List<SerializedMessage>> consumer, MessageType messageType, String topic, ConsumerConfiguration config, FluxCapacitor fluxCapacitor) Starts one or more trackers.static Registration
DefaultTracker.start
(Consumer<List<SerializedMessage>> consumer, ConsumerConfiguration config, TrackingClient trackingClient) Starts one or more trackers that consume messages using the provided trackingClient and process them using the provided consumer. -
Uses of SerializedMessage in io.fluxcapacitor.javaclient.web
Methods in io.fluxcapacitor.javaclient.web that return SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessage
WebResponseCompressingInterceptor.compress
(SerializedMessage response) Applies GZIP compression to the response payload and updates the metadata to indicate theContent-Encoding
used.WebResponseCompressingInterceptor.modifySerializedMessage
(SerializedMessage response, Message message, MessageType type, String topic) Compresses the given response message using GZIP if the request supports compression and the response meets compression criteria.WebRequest.serialize
(Serializer serializer) Serializes the request using the content type if applicable.WebResponse.serialize
(Serializer serializer) Serializes the response using the content type if applicable.protected SerializedMessage
protected SerializedMessage
ForwardingWebConsumer.toMessage
(HttpResponse<byte[]> response, Map<String, String> correlationData) Methods in io.fluxcapacitor.javaclient.web with parameters of type SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessage
WebResponseCompressingInterceptor.compress
(SerializedMessage response) Applies GZIP compression to the response payload and updates the metadata to indicate theContent-Encoding
used.protected HttpRequest
ForwardingWebConsumer.createRequest
(SerializedMessage m) ForwardingWebConsumer.getCorrelationData
(SerializedMessage m) WebResponseCompressingInterceptor.modifySerializedMessage
(SerializedMessage response, Message message, MessageType type, String topic) Compresses the given response message using GZIP if the request supports compression and the response meets compression criteria.protected boolean
WebResponseCompressingInterceptor.shouldCompress
(SerializedMessage response) Determines whether the given serialized message should be compressed based on specific criteria.Method parameters in io.fluxcapacitor.javaclient.web with type arguments of type SerializedMessageModifier and TypeMethodDescriptionprotected CompletableFuture
<Void> WebResponseGateway.sendResponse
(WebResponse response, Function<SerializedMessage, CompletableFuture<Void>> dispatcher) -
Uses of SerializedMessage in io.fluxcapacitor.proxy
Methods in io.fluxcapacitor.proxy with parameters of type SerializedMessageModifier and TypeMethodDescriptionprotected HttpRequest
ForwardProxyConsumer.asHttpRequest
(SerializedMessage request, URI uri, WebRequestSettings settings) protected String
ForwardProxyConsumer.formatType
(SerializedMessage request) protected HttpRequest.BodyPublisher
ForwardProxyConsumer.getBodyPublisher
(SerializedMessage request) protected WebRequestSettings
ForwardProxyConsumer.getSettings
(SerializedMessage request) protected void
ForwardProxyConsumer.handle
(SerializedMessage request, URI uri, WebRequestSettings settings) protected void
ProxyRequestHandler.handleResponse
(SerializedMessage responseMessage, WebRequest webRequest, io.undertow.server.HttpServerExchange se) protected io.undertow.server.HttpServerExchange
ProxyRequestHandler.prepareForSending
(SerializedMessage responseMessage, io.undertow.server.HttpServerExchange se, int statusCode) protected void
ForwardProxyConsumer.publishHandleMessageMetrics
(SerializedMessage request, boolean exceptionalResult, Instant start) protected void
ForwardProxyConsumer.sendResponse
(WebResponse response, SerializedMessage request) protected void
ProxyRequestHandler.sendResponse
(SerializedMessage responseMessage, io.undertow.server.HttpServerExchange se) Method parameters in io.fluxcapacitor.proxy with type arguments of type SerializedMessageModifier and TypeMethodDescriptionvoid
ForwardProxyConsumer.accept
(List<SerializedMessage> serializedMessages) protected void
WebsocketEndpoint.handleDisconnects
(List<SerializedMessage> resultMessages) protected void
WebsocketEndpoint.handleResultMessages
(List<SerializedMessage> resultMessages) -
Uses of SerializedMessage in io.fluxcapacitor.testserver.scheduling
Methods in io.fluxcapacitor.testserver.scheduling that return types with arguments of type SerializedMessageModifier and TypeMethodDescription