Uses of Interface
com.rabbitmq.stream.Message
Packages that use Message
Package
Description
Main API for RabbitMQ Stream Java Client.
Implementations of AMQP 1.0
Codec.Implementation-specific, non-public interfaces and classes of the RabbitMQ Stream Java Client.
-
Uses of Message in com.rabbitmq.stream
Methods in com.rabbitmq.stream that return MessageModifier and TypeMethodDescriptiondefault MessageAdd a message annotation to the message.MessageBuilder.build()Create the message.default MessageMessage.copy()Create a copy of the message.Codec.decode(byte[] data) ConfirmationStatus.getMessage()Methods in com.rabbitmq.stream with parameters of type MessageModifier and TypeMethodDescriptionvoidMessageHandler.handle(MessageHandler.Context context, Message message) Callback for an inbound message.ObservationCollector.prePublish(String stream, Message message) Start observation.voidCallback when the message is about to be published.RoutingStrategy.route(Message message, RoutingStrategy.Metadata metadata) Where to route a message.voidProducer.send(Message message, ConfirmationHandler confirmationHandler) Publish a message.Method parameters in com.rabbitmq.stream with type arguments of type MessageModifier and TypeMethodDescriptionProducerBuilder.filterValue(Function<Message, String> filterValueExtractor) Logic to extract a filter value from a message.ConsumerBuilder.FilterConfiguration.postFilter(Predicate<Message> filter) Client-side filtering logic, occurring after the server-side filtering.Configure the routing for super streams (partitioned streams).Constructors in com.rabbitmq.stream with parameters of type Message -
Uses of Message in com.rabbitmq.stream.codec
Methods in com.rabbitmq.stream.codec that return MessageModifier and TypeMethodDescriptionWrapperMessageBuilder.build()protected MessageSwiftMqCodec.createMessage(byte[] data) QpidProtonCodec.decode(byte[] data) SimpleCodec.decode(byte[] data) SwiftMqCodec.decode(byte[] data) Methods in com.rabbitmq.stream.codec with parameters of type MessageModifier and TypeMethodDescription -
Uses of Message in com.rabbitmq.stream.impl
Methods in com.rabbitmq.stream.impl with parameters of type MessageModifier and TypeMethodDescriptionvoidClient.MessageListener.handle(byte subscriptionId, long offset, long chunkTimestamp, long committedChunkId, Object chunkContext, Message message) Method parameters in com.rabbitmq.stream.impl with type arguments of type MessageModifier and TypeMethodDescriptionClient.publish(byte publisherId, List<Message> messages, Client.OutboundEntityMappingCallback mappingCallback) Client.publish(byte publisherId, List<Message> messages, Client.OutboundEntityMappingCallback mappingCallback, ToLongFunction<Object> publishSequenceFunction) Client.publish(byte publisherId, List<Message> messages, ToLongFunction<Object> publishSequenceFunction) Constructor parameters in com.rabbitmq.stream.impl with type arguments of type Message -
Uses of Message in com.rabbitmq.stream.observation.micrometer
Subclasses with type arguments of type Message in com.rabbitmq.stream.observation.micrometerModifier and TypeClassDescriptionclassObservation.Contextfor RabbitMQ Stream consuming.classObservation.Contextfor RabbitMQ Stream publishing.