Uses of Class
io.fluxzero.common.api.SerializedMessage
Packages that use SerializedMessage
Package
Description
-
Uses of SerializedMessage in io.fluxzero.common.api
Methods in io.fluxzero.common.api that return SerializedMessageModifier and TypeMethodDescription -
Uses of SerializedMessage in io.fluxzero.common.api.tracking
Methods in io.fluxzero.common.api.tracking with parameters of type SerializedMessage -
Uses of SerializedMessage in io.fluxzero.common.tracking
Subinterfaces with type arguments of type SerializedMessage in io.fluxzero.common.trackingModifier and TypeInterfaceDescriptioninterfaceA low-level store for serialized messages.Methods in io.fluxzero.common.tracking that return SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessageDefaultTrackingStrategy.ensureMessageSegment(SerializedMessage message) Methods in io.fluxzero.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.fluxzero.common.tracking with parameters of type SerializedMessageModifier and TypeMethodDescriptiondefault CompletableFuture<Void> MessageStore.append(SerializedMessage... messages) Appends the given messages to the store.default booleanTracker.canHandle(SerializedMessage message, int[] segmentRange) Checks if the given message can be handled by this tracker based on segment range and type filtering.protected SerializedMessageDefaultTrackingStrategy.ensureMessageSegment(SerializedMessage message) Method parameters in io.fluxzero.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 voidDefaultTrackingStrategy.onUpdate(List<SerializedMessage> messages) -
Uses of SerializedMessage in io.fluxzero.proxy
Classes in io.fluxzero.proxy that implement interfaces with type arguments of type SerializedMessageMethods in io.fluxzero.proxy with parameters of type SerializedMessageModifier and TypeMethodDescriptionprotected HttpRequestForwardProxyConsumer.asHttpRequest(SerializedMessage request, URI uri, WebRequestSettings settings) protected StringForwardProxyConsumer.formatType(SerializedMessage request) protected HttpRequest.BodyPublisherForwardProxyConsumer.getBodyPublisher(SerializedMessage request) protected WebRequestSettingsForwardProxyConsumer.getSettings(SerializedMessage request) protected voidForwardProxyConsumer.handle(SerializedMessage request, URI uri, WebRequestSettings settings) protected voidProxyRequestHandler.handleResponse(SerializedMessage responseMessage, WebRequest webRequest, io.undertow.server.HttpServerExchange se) protected io.undertow.server.HttpServerExchangeProxyRequestHandler.prepareForSending(SerializedMessage responseMessage, io.undertow.server.HttpServerExchange se, int statusCode) protected voidForwardProxyConsumer.publishHandleMessageMetrics(SerializedMessage request, boolean exceptionalResult, Instant start) protected voidForwardProxyConsumer.sendResponse(WebResponse response, SerializedMessage request) protected voidProxyRequestHandler.sendResponse(SerializedMessage responseMessage, io.undertow.server.HttpServerExchange se) Method parameters in io.fluxzero.proxy with type arguments of type SerializedMessageModifier and TypeMethodDescriptionvoidForwardProxyConsumer.accept(List<SerializedMessage> serializedMessages) protected voidWebsocketEndpoint.handleDisconnects(List<SerializedMessage> resultMessages) protected voidWebsocketEndpoint.handleResultMessages(List<SerializedMessage> resultMessages) -
Uses of SerializedMessage in io.fluxzero.sdk.common
Methods in io.fluxzero.sdk.common that return SerializedMessageModifier and TypeMethodDescriptionMessage.serialize(Serializer serializer) Serializes this message to aSerializedMessageusing the providedSerializer. -
Uses of SerializedMessage in io.fluxzero.sdk.common.serialization
Methods in io.fluxzero.sdk.common.serialization that return SerializedMessageMethods in io.fluxzero.sdk.common.serialization with parameters of type SerializedMessageModifier and TypeMethodDescriptiondefault DeserializingMessageSerializer.deserializeMessage(SerializedMessage message, MessageType messageType) Deserializes a singleSerializedMessageinto aDeserializingMessage.Method parameters in io.fluxzero.sdk.common.serialization with type arguments of type SerializedMessageModifier and TypeMethodDescriptiondefault Stream<DeserializingMessage> Serializer.deserializeMessages(Stream<SerializedMessage> dataStream, MessageType messageType) Deserializes a stream ofSerializedMessageintoDeserializingMessageinstances with the specifiedMessageType.default Stream<DeserializingMessage> Serializer.deserializeMessages(Stream<SerializedMessage> dataStream, MessageType messageType, UnknownTypeStrategy unknownTypeStrategy) Deserializes a stream ofSerializedMessageintoDeserializingMessageinstances with the specifiedMessageType.default Stream<DeserializingMessage> Serializer.deserializeMessages(Stream<SerializedMessage> dataStream, MessageType messageType, String topic) Deserializes a stream ofSerializedMessageintoDeserializingMessageinstances with the specifiedMessageType.default Stream<DeserializingMessage> Serializer.deserializeMessages(Stream<SerializedMessage> dataStream, MessageType messageType, String topic, UnknownTypeStrategy unknownTypeStrategy) Deserializes a stream ofSerializedMessageintoDeserializingMessageinstances with the specifiedMessageType.Constructors in io.fluxzero.sdk.common.serialization with parameters of type SerializedMessageModifierConstructorDescriptionDeserializingMessage(SerializedMessage message, Function<Type, Object> payload, MessageType messageType, String topic, Serializer serializer) Constructor parameters in io.fluxzero.sdk.common.serialization with type arguments of type SerializedMessageModifierConstructorDescriptionDeserializingMessage(DeserializingObject<byte[], SerializedMessage> delegate, MessageType messageType, String topic, Serializer serializer) -
Uses of SerializedMessage in io.fluxzero.sdk.configuration.client
Method parameters in io.fluxzero.sdk.configuration.client with type arguments of type SerializedMessageModifier and TypeMethodDescriptionvoidClientDispatchMonitor.accept(MessageType messageType, String topic, String namespace, List<SerializedMessage> messages) Called when a batch of messages is dispatched by the client. -
Uses of SerializedMessage in io.fluxzero.sdk.persisting.eventsourcing.client
Methods in io.fluxzero.sdk.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.fluxzero.sdk.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.fluxzero.sdk.persisting.repository
Method parameters in io.fluxzero.sdk.persisting.repository with type arguments of type SerializedMessageModifier and TypeMethodDescriptionprotected voidCachingAggregateRepository.handleEvents(List<SerializedMessage> messages) -
Uses of SerializedMessage in io.fluxzero.sdk.persisting.search.client
Methods in io.fluxzero.sdk.persisting.search.client that return SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessageInMemorySearchStore.asSerializedMessage(SerializedDocument document) Methods in io.fluxzero.sdk.persisting.search.client that return types with arguments of type SerializedMessageModifier and TypeMethodDescriptionInMemorySearchStore.openStream(String collection, Long lastIndex, int maxSize) Method parameters in io.fluxzero.sdk.persisting.search.client with type arguments of type SerializedMessageModifier and TypeMethodDescriptionCollectionMessageStore.append(List<SerializedMessage> messages) protected voidInMemorySearchStore.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.fluxzero.sdk.publishing
Methods in io.fluxzero.sdk.publishing that return SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessageDefaultResultGateway.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 SerializedMessageDispatchInterceptor.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.fluxzero.sdk.publishing that return types with arguments of type SerializedMessageModifier and TypeMethodDescriptionDefaultRequestHandler.ResponseCallback.finalCallback()Returns the value of thefinalCallbackrecord component.DefaultRequestHandler.ResponseCallback.intermediateCallback()Returns the value of theintermediateCallbackrecord 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.fluxzero.sdk.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 SerializedMessageDispatchInterceptor.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.fluxzero.sdk.publishing with type arguments of type SerializedMessageModifier and TypeMethodDescriptionprotected voidDefaultRequestHandler.handleResults(List<SerializedMessage> messages) protected CompletableFuture<SerializedMessage> DefaultRequestHandler.prepareRequest(SerializedMessage request, Duration timeout, Consumer<SerializedMessage> intermediateCallback) DefaultGenericGateway.sendAndForget(Guarantee guarantee, UnaryOperator<SerializedMessage> interceptor, Message... messages) GenericGateway.sendAndForget(Guarantee guarantee, UnaryOperator<SerializedMessage> interceptor, Message... messages) Sends multipleMessageobjects with a guarantee.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.fluxzero.sdk.publishing with type arguments of type SerializedMessageModifierConstructorDescriptionprotectedResponseCallback(Consumer<SerializedMessage> intermediateCallback, CompletableFuture<SerializedMessage> finalCallback) Creates an instance of aResponseCallbackrecord class.protectedResponseCallback(Consumer<SerializedMessage> intermediateCallback, CompletableFuture<SerializedMessage> finalCallback) Creates an instance of aResponseCallbackrecord class. -
Uses of SerializedMessage in io.fluxzero.sdk.publishing.client
Subinterfaces with type arguments of type SerializedMessage in io.fluxzero.sdk.publishing.clientModifier and TypeInterfaceDescriptioninterfaceLow-level interface for sendingSerializedMessages to a gateway (e.g. commands, events, queries).Methods in io.fluxzero.sdk.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.fluxzero.sdk.publishing.client with type arguments of type SerializedMessageModifier and TypeMethodDescriptionWebsocketGatewayClient.registerMonitor(Consumer<List<SerializedMessage>> monitor) -
Uses of SerializedMessage in io.fluxzero.sdk.publishing.correlation
Methods in io.fluxzero.sdk.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.fluxzero.sdk.publishing.routing
Methods in io.fluxzero.sdk.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.fluxzero.sdk.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.fluxzero.sdk.scheduling.client
Methods in io.fluxzero.sdk.scheduling.client that return types with arguments of type SerializedMessageModifier and TypeMethodDescriptionprotected Collection<SerializedMessage> InMemoryScheduleStore.filterMessages(Collection<SerializedMessage> messages) Methods in io.fluxzero.sdk.scheduling.client with parameters of type SerializedMessageMethod parameters in io.fluxzero.sdk.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.fluxzero.sdk.tracking
Methods in io.fluxzero.sdk.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.fluxzero.sdk.tracking.client
Methods in io.fluxzero.sdk.tracking.client that return SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessageInMemoryMessageStore.getMessage(long index) Methods in io.fluxzero.sdk.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.fluxzero.sdk.tracking.client with parameters of type SerializedMessageModifier and TypeMethodDescriptionLocalTrackingClient.append(Guarantee guarantee, SerializedMessage... messages) Method parameters in io.fluxzero.sdk.tracking.client with type arguments of type SerializedMessageModifier and TypeMethodDescriptionInMemoryMessageStore.append(List<SerializedMessage> messages) protected voidCachingTrackingClient.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 voidInMemoryMessageStore.notifyMonitors(List<SerializedMessage> messages) InMemoryMessageStore.registerMonitor(Consumer<List<SerializedMessage>> monitor) LocalTrackingClient.registerMonitor(Consumer<List<SerializedMessage>> monitor) static RegistrationDefaultTracker.start(Consumer<List<SerializedMessage>> consumer, MessageType messageType, ConsumerConfiguration config, Client client) Starts one or more trackers.static RegistrationDefaultTracker.start(Consumer<List<SerializedMessage>> consumer, MessageType messageType, ConsumerConfiguration config, Fluxzero fluxzero) Starts one or more trackers.static RegistrationDefaultTracker.start(Consumer<List<SerializedMessage>> consumer, MessageType messageType, String topic, ConsumerConfiguration config, Client client) Starts one or more trackers.static RegistrationDefaultTracker.start(Consumer<List<SerializedMessage>> consumer, MessageType messageType, String topic, ConsumerConfiguration config, Fluxzero fluxzero) Starts one or more trackers.static RegistrationDefaultTracker.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.fluxzero.sdk.web
Methods in io.fluxzero.sdk.web that return SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessageWebResponseCompressingInterceptor.compress(SerializedMessage response) Applies GZIP compression to the response payload and updates the metadata to indicate theContent-Encodingused.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 SerializedMessageprotected SerializedMessageForwardingWebConsumer.toMessage(HttpResponse<byte[]> response, Map<String, String> correlationData) Methods in io.fluxzero.sdk.web with parameters of type SerializedMessageModifier and TypeMethodDescriptionprotected SerializedMessageWebResponseCompressingInterceptor.compress(SerializedMessage response) Applies GZIP compression to the response payload and updates the metadata to indicate theContent-Encodingused.protected HttpRequestForwardingWebConsumer.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 booleanWebResponseCompressingInterceptor.shouldCompress(SerializedMessage serializedMessage, WebResponse response) Determines whether the given serialized message should be compressed based on specific criteria.Method parameters in io.fluxzero.sdk.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.fluxzero.testserver.scheduling
Methods in io.fluxzero.testserver.scheduling that return types with arguments of type SerializedMessageModifier and TypeMethodDescription