Interface ReactivePubSubCommands<V>

    • Method Detail

      • publish

        io.smallrye.mutiny.Uni<Void> publish​(String channel,
                                             V message)
        Publishes a message to a given channel
        Parameters:
        channel - the channel
        message - the message
        Returns:
        a Uni producing a null item once the message is sent, a failure otherwise.
      • subscribe

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribe​(String channel,
                                                                                         Consumer<V> onMessage)
        Subscribes to a given channel.
        Parameters:
        channel - the channel
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the given channel, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribeToPattern

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribeToPattern​(String pattern,
                                                                                                  Consumer<V> onMessage)
        Subscribes to a given pattern like chan*l.
        Parameters:
        pattern - the pattern
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the channels matching the pattern, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribeToPattern

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribeToPattern​(String pattern,
                                                                                                  BiConsumer<String,​V> onMessage)
        Same as subscribeToPattern(String, Consumer), but instead of receiving only the message payload, it also receives the name of the channel.
        Parameters:
        pattern - the pattern
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the channels matching the pattern, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed. The first parameter is the name of the channel. The second parameter is the payload.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribeToPatterns

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribeToPatterns​(List<String> patterns,
                                                                                                   Consumer<V> onMessage)
        Subscribes to the given patterns like chan*l.
        Parameters:
        patterns - the patterns
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the channels matching the pattern, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribeToPatterns

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribeToPatterns​(List<String> patterns,
                                                                                                   BiConsumer<String,​V> onMessage)
        Same as subscribeToPatterns(List, Consumer), but instead of only receiving the payload, it also receives the channel name.
        Parameters:
        patterns - the patterns
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the channels matching the pattern, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed. The first parameter is the channel name. The second one if the payload.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribe

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribe​(List<String> channels,
                                                                                         Consumer<V> onMessage)
        Subscribes to the given channels.
        Parameters:
        channels - the channels
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the given channels, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribe

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribe​(List<String> channels,
                                                                                         BiConsumer<String,​V> onMessage)
        Same as subscribe(List, Consumer), but instead of just receiving the payload, it also receives the channel name.
        Parameters:
        channels - the channels
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the given channels, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed. The first parameter is the channel name. The second one if the payload.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribe

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribe​(String channel,
                                                                                         Consumer<V> onMessage,
                                                                                         Runnable onEnd,
                                                                                         Consumer<Throwable> onException)
        Subscribes to a given channel.
        Parameters:
        channel - the channel
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the given channel, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onEnd - the end handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onException - the exception handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribeToPattern

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribeToPattern​(String pattern,
                                                                                                  Consumer<V> onMessage,
                                                                                                  Runnable onEnd,
                                                                                                  Consumer<Throwable> onException)
        Subscribes to a given pattern like chan*l.
        Parameters:
        pattern - the pattern
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the channels matching the pattern, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onEnd - the end handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onException - the exception handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribeToPattern

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribeToPattern​(String pattern,
                                                                                                  BiConsumer<String,​V> onMessage,
                                                                                                  Runnable onEnd,
                                                                                                  Consumer<Throwable> onException)
        Same as subscribeToPatterns(List, Consumer, Runnable, Consumer), but also receives the channel name.
        Parameters:
        pattern - the pattern
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the channels matching the pattern, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed. The first parameter is the name of the channel. The second parameter is the payload.
        onEnd - the end handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onException - the exception handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribeToPatterns

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribeToPatterns​(List<String> patterns,
                                                                                                   Consumer<V> onMessage,
                                                                                                   Runnable onEnd,
                                                                                                   Consumer<Throwable> onException)
        Subscribes to the given patterns like chan*l.
        Parameters:
        patterns - the patterns
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the channels matching the pattern, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onEnd - the end handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onException - the exception handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribeToPatterns

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribeToPatterns​(List<String> patterns,
                                                                                                   BiConsumer<String,​V> onMessage,
                                                                                                   Runnable onEnd,
                                                                                                   Consumer<Throwable> onException)
        Same as subscribeToPatterns(List, Consumer, Runnable, Consumer), but also receive the channel name.
        Parameters:
        patterns - the patterns
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the channels matching the pattern, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed. The first parameter is the name of the channel. The second parameter is the payload.
        onEnd - the end handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onException - the exception handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribe

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribe​(List<String> channels,
                                                                                         Consumer<V> onMessage,
                                                                                         Runnable onEnd,
                                                                                         Consumer<Throwable> onException)
        Subscribes to the given channels.
        Parameters:
        channels - the channels
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the given channels, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onEnd - the end handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onException - the exception handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribe

        io.smallrye.mutiny.Uni<ReactivePubSubCommands.ReactiveRedisSubscriber> subscribe​(List<String> channels,
                                                                                         BiConsumer<String,​V> onMessage,
                                                                                         Runnable onEnd,
                                                                                         Consumer<Throwable> onException)
        Same as subscribe(List, Consumer, Runnable, Consumer) but also receives the channel name.
        Parameters:
        channels - the channels
        onMessage - the message consumer. Be aware that this callback is invoked for each message sent to the given channels, and is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed. The first parameter is the name of the channel. The second parameter is the payload.
        onEnd - the end handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        onException - the exception handler. Be aware that this callback is invoked on the I/O thread. So, you must not block. Offload to a separate thread if needed.
        Returns:
        the subscriber object that lets you unsubscribe
      • subscribe

        io.smallrye.mutiny.Multi<V> subscribe​(String... channels)
        Subscribes to the given channels. This method returns a Multi emitting an item of type V for each received message. This emission happens on the I/O thread, so you must not block. Use emitOn to offload the processing to another thread.
        Parameters:
        channels - the channels
        Returns:
        the stream of message
      • subscribeAsMessages

        io.smallrye.mutiny.Multi<RedisPubSubMessage<V>> subscribeAsMessages​(String... channels)
        Same as subscribe(String...), but instead of receiving the message payload directly, it receives instances of RedisPubSubMessage wrapping the payload and the channel on which the message has been sent.
        Parameters:
        channels - the channels
        Returns:
        the stream of message
      • subscribeToPatterns

        io.smallrye.mutiny.Multi<V> subscribeToPatterns​(String... patterns)
        Subscribes to the given patterns. This method returns a Multi emitting an item of type V for each received message. This emission happens on the I/O thread, so you must not block. Use emitOn to offload the processing to another thread.
        Parameters:
        patterns - the patterns
        Returns:
        the stream of message
      • subscribeAsMessagesToPatterns

        io.smallrye.mutiny.Multi<RedisPubSubMessage<V>> subscribeAsMessagesToPatterns​(String... patterns)
        Same as subscribeToPatterns(String...), but instead of receiving only the message payload, it receives instances of RedisPubSubMessage containing both the payload and the name of the channel.
        Parameters:
        patterns - the patterns
        Returns:
        the stream of message