Interface ReactiveMessageSender<T>

Type Parameters:
T - the message payload type.

public interface ReactiveMessageSender<T>
Reactive message sender interface.
  • Method Summary

    Modifier and Type
    Method
    Description
    reactor.core.publisher.Flux<org.apache.pulsar.client.api.MessageId>
    sendMany(org.reactivestreams.Publisher<MessageSpec<T>> messageSpecs)
    Send multiple messages and get the associated message ids in the same order as the messages sent.
    reactor.core.publisher.Mono<org.apache.pulsar.client.api.MessageId>
    sendOne(MessageSpec<T> messageSpec)
    Send one message.
  • Method Details

    • sendOne

      reactor.core.publisher.Mono<org.apache.pulsar.client.api.MessageId> sendOne(MessageSpec<T> messageSpec)
      Send one message.
      Parameters:
      messageSpec - the spec of the message to send
      Returns:
      a publisher that will emit one message id and complete
    • sendMany

      reactor.core.publisher.Flux<org.apache.pulsar.client.api.MessageId> sendMany(org.reactivestreams.Publisher<MessageSpec<T>> messageSpecs)
      Send multiple messages and get the associated message ids in the same order as the messages sent.
      Parameters:
      messageSpecs - the specs of the messages to send
      Returns:
      a publisher that will emit a message id per message successfully sent in the order that they have been sent