Class PulsarConnector

java.lang.Object
io.smallrye.reactive.messaging.pulsar.PulsarConnector
All Implemented Interfaces:
InboundConnector, OutboundConnector, io.smallrye.reactive.messaging.health.HealthReporter, org.eclipse.microprofile.reactive.messaging.spi.ConnectorFactory

@ApplicationScoped public class PulsarConnector extends Object implements InboundConnector, OutboundConnector, io.smallrye.reactive.messaging.health.HealthReporter
  • Field Details

  • Constructor Details

    • PulsarConnector

      public PulsarConnector()
  • Method Details

    • getPublisher

      public Flow.Publisher<? extends org.eclipse.microprofile.reactive.messaging.Message<?>> getPublisher(org.eclipse.microprofile.config.Config config)
      Specified by:
      getPublisher in interface InboundConnector
    • getSubscriber

      public Flow.Subscriber<? extends org.eclipse.microprofile.reactive.messaging.Message<?>> getSubscriber(org.eclipse.microprofile.config.Config config)
      Specified by:
      getSubscriber in interface OutboundConnector
    • terminate

      public void terminate(@Observes(notifyObserver=IF_EXISTS) @Priority(50) @BeforeDestroyed(jakarta.enterprise.context.ApplicationScoped.class) Object event)
    • getClient

      public org.apache.pulsar.client.api.PulsarClient getClient(String channel)
    • getConsumer

      public <T> org.apache.pulsar.client.api.Consumer<T> getConsumer(String channel)
    • getProducer

      public <T> org.apache.pulsar.client.api.Producer<T> getProducer(String channel)
    • getConsumerChannels

      public Set<String> getConsumerChannels()
    • getProducerChannels

      public Set<String> getProducerChannels()
    • getStartup

      public io.smallrye.reactive.messaging.health.HealthReport getStartup()
      Specified by:
      getStartup in interface io.smallrye.reactive.messaging.health.HealthReporter
    • getReadiness

      public io.smallrye.reactive.messaging.health.HealthReport getReadiness()
      Specified by:
      getReadiness in interface io.smallrye.reactive.messaging.health.HealthReporter
    • getLiveness

      public io.smallrye.reactive.messaging.health.HealthReport getLiveness()
      Specified by:
      getLiveness in interface io.smallrye.reactive.messaging.health.HealthReporter