Uses of Interface
com.rabbitmq.stream.Message
-
Packages that use Message Package Description com.rabbitmq.stream Main API for RabbitMQ Stream Java Client.com.rabbitmq.stream.codec Implementations of AMQP 1.0Codec.com.rabbitmq.stream.impl 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 Message Modifier and Type Method Description default MessageMessage. annotate(String key, Object value)Add a message annotation to the message.MessageMessageBuilder. build()Create the message.default MessageMessage. copy()Create a copy of the message.MessageCodec. decode(byte[] data)MessageConfirmationStatus. getMessage()Methods in com.rabbitmq.stream with parameters of type Message Modifier and Type Method Description Codec.EncodedMessageCodec. encode(Message message)voidMessageHandler. handle(MessageHandler.Context context, Message message)Callback for an inbound message.TObservationCollector. prePublish(String stream, Message message)Start observation.voidObservationCollector. published(T context, Message message)Callback when the message is about to be published.List<String>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 Message Modifier and Type Method Description ProducerBuilderProducerBuilder. filterValue(Function<Message,String> filterValueExtractor)Logic to extract a filter value from a message.ConsumerBuilder.FilterConfigurationConsumerBuilder.FilterConfiguration. postFilter(Predicate<Message> filter)Client-side filtering logic, occurring after the server-side filtering.ProducerBuilder.RoutingConfigurationProducerBuilder. routing(Function<Message,String> routingKeyExtractor)Configure the routing for super streams (partitioned streams).Constructors in com.rabbitmq.stream with parameters of type Message Constructor Description ConfirmationStatus(Message message, boolean confirmed, short code) -
Uses of Message in com.rabbitmq.stream.codec
Methods in com.rabbitmq.stream.codec that return Message Modifier and Type Method Description MessageWrapperMessageBuilder. build()protected MessageSwiftMqCodec. createMessage(byte[] data)MessageQpidProtonCodec. decode(byte[] data)MessageSimpleCodec. decode(byte[] data)MessageSwiftMqCodec. decode(byte[] data)Methods in com.rabbitmq.stream.codec with parameters of type Message Modifier and Type Method Description Codec.EncodedMessageQpidProtonCodec. encode(Message message)Codec.EncodedMessageSimpleCodec. encode(Message message)Codec.EncodedMessageSwiftMqCodec. encode(Message message) -
Uses of Message in com.rabbitmq.stream.impl
Methods in com.rabbitmq.stream.impl with parameters of type Message Modifier and Type Method Description MessageBatchMessageBatch. add(Message message)voidClient.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 Message Modifier and Type Method Description List<Long>Client. publish(byte publisherId, List<Message> messages)List<Long>Client. publish(byte publisherId, List<Message> messages, Client.OutboundEntityMappingCallback mappingCallback)List<Long>Client. publish(byte publisherId, List<Message> messages, Client.OutboundEntityMappingCallback mappingCallback, ToLongFunction<Object> publishSequenceFunction)List<Long>Client. publish(byte publisherId, List<Message> messages, ToLongFunction<Object> publishSequenceFunction)Constructor parameters in com.rabbitmq.stream.impl with type arguments of type Message Constructor Description MessageBatch(Compression compression, List<Message> messages)
-