Package

com.sksamuel

pulsar4s

Permalink

package pulsar4s

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. pulsar4s
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. trait AsyncHandler[F[_]] extends AnyRef

    Permalink
  2. trait Consumer[T] extends Closeable

    Permalink
  3. case class ConsumerConfig(subscriptionName: Subscription, topics: Seq[Topic] = Nil, topicPattern: Option[Regex] = None, consumerEventListener: Option[ConsumerEventListener] = None, cryptoFailureAction: Option[ConsumerCryptoFailureAction] = None, consumerName: Option[String] = None, cryptoKeyReader: Option[CryptoKeyReader] = None, maxTotalReceiverQueueSizeAcrossPartitions: Option[Int] = None, negativeAckRedeliveryDelay: Option[FiniteDuration] = None, patternAutoDiscoveryPeriod: Option[Int] = None, priorityLevel: Option[Int] = None, receiverQueueSize: Option[Int] = None, subscriptionInitialPosition: Option[SubscriptionInitialPosition] = None, subscriptionType: Option[SubscriptionType] = None, readCompacted: Option[Boolean] = None) extends Product with Serializable

    Permalink
  4. trait ConsumerInterceptor[T] extends AutoCloseable

    Permalink
  5. class ConsumerInterceptorAdapter[T] extends org.apache.pulsar.client.api.ConsumerInterceptor[T]

    Permalink
  6. trait ConsumerMessage[T] extends AnyRef

    Permalink
  7. class DefaultConsumer[T] extends Consumer[T] with Logging

    Permalink
  8. case class DefaultConsumerMessage[T](key: Option[String], value: T, data: Array[Byte], props: Map[String, String], messageId: MessageId, sequenceId: SequenceId, producerName: ProducerName, publishTime: PublishTime, eventTime: EventTime, topic: Topic) extends ConsumerMessage[T] with Product with Serializable

    Permalink
  9. class DefaultProducer[T] extends Producer[T]

    Permalink
  10. case class DefaultProducerMessage[T](key: Option[String], value: T, props: Map[String, String] = Map.empty, sequenceId: Option[SequenceId] = None, eventTime: Option[EventTime] = None, disableReplication: Boolean = false, replicationClusters: List[String] = Nil) extends ProducerMessage[T] with Product with Serializable

    Permalink
  11. class DefaultPulsarClient extends PulsarClient with Logging

    Permalink
  12. class DefaultReader[T] extends Reader[T]

    Permalink
  13. case class EventTime(value: Long) extends Product with Serializable

    Permalink
  14. class FutureAsyncHandler extends AsyncHandler[Future]

    Permalink
  15. type JConsumer[T] = org.apache.pulsar.client.api.Consumer[T]

    Permalink
  16. type JMessage[T] = Message[T]

    Permalink
  17. type JMessageId = org.apache.pulsar.client.api.MessageId

    Permalink
  18. type JProducer[T] = org.apache.pulsar.client.api.Producer[T]

    Permalink
  19. sealed trait MessageId extends AnyRef

    Permalink

    A wrapper for the Java Pulsar client MessageId.

    A wrapper for the Java Pulsar client MessageId.

    Unfortunately we have to retain the underlying Java object, since some of the Java APIs assume TopicMessageIdImpl and perform a type cast from MessageId, and this type is not possible to create directly via the public Java API.

  20. trait Producer[T] extends Closeable with Logging

    Permalink
  21. case class ProducerConfig(topic: Topic, encryptionKey: Option[String] = None, batchingMaxMessages: Option[Int] = None, batchingMaxPublishDelay: Option[FiniteDuration] = None, blockIfQueueFull: Option[Boolean] = None, cryptoFailureAction: Option[ProducerCryptoFailureAction] = None, cryptoKeyReader: Option[CryptoKeyReader] = None, enableBatching: Option[Boolean] = None, hashingScheme: Option[HashingScheme] = None, initialSequenceId: Option[Long] = None, maxPendingMessages: Option[Int] = None, maxPendingMessagesAcrossPartitions: Option[Int] = None, messageRouter: Option[MessageRouter] = None, messageRoutingMode: Option[MessageRoutingMode] = None, producerName: Option[String] = None, sendTimeout: Option[FiniteDuration] = None, compressionType: Option[CompressionType] = None) extends Product with Serializable

    Permalink
  22. trait ProducerInterceptor[T] extends AutoCloseable

    Permalink
  23. class ProducerInterceptorAdapter[T] extends org.apache.pulsar.client.api.ProducerInterceptor[T]

    Permalink
  24. trait ProducerMessage[T] extends AnyRef

    Permalink
  25. class ProducerMessageBuilder[T] extends AnyRef

    Permalink
  26. case class ProducerName(name: String) extends Product with Serializable

    Permalink
  27. case class PublishTime(value: Long) extends Product with Serializable

    Permalink
  28. trait PulsarClient extends AnyRef

    Permalink
  29. case class PulsarClientConfig(serviceUrl: String, allowTlsInsecureConnection: Option[Boolean] = None, authentication: Option[Authentication] = None, connectionsPerBroker: Option[Int] = None, enableTcpNoDelay: Option[Boolean] = None, enableTls: Option[Boolean] = None, enableTlsHostnameVerification: Option[Boolean] = None, listenerThreads: Option[Int] = None, maxConcurrentLookupRequests: Option[Int] = None, maxNumberOfRejectedRequestPerConnection: Option[Int] = None, operationTimeout: Option[FiniteDuration] = None, keepAliveInterval: Option[FiniteDuration] = None, statsInterval: Option[FiniteDuration] = None, maxLookupRequests: Option[Int] = None, tlsTrustCertsFilePath: Option[String] = None, ioThreads: Option[Int] = None) extends Product with Serializable

    Permalink
  30. case class PulsarTopic(mode: String, tenant: String, namespace: String, topic: String) extends Product with Serializable

    Permalink
  31. trait Reader[T] extends Closeable

    Permalink
  32. case class ReaderConfig(topic: Topic, seek: MessageId, receiverQueueSize: Option[Int] = None, reader: Option[String] = None, readCompacted: Option[Boolean] = None) extends Product with Serializable

    Permalink
  33. case class SequenceId(value: Long) extends Product with Serializable

    Permalink
  34. case class Subscription(name: String) extends Product with Serializable

    Permalink
  35. case class Topic(name: String) extends Product with Serializable

    Permalink
  36. case class TopicPartition(name: String) extends Product with Serializable

    Permalink

Value Members

  1. object AsyncHandler

    Permalink
  2. object ConsumerMessage

    Permalink
  3. object MessageId

    Permalink
  4. object ProducerMessage

    Permalink
  5. object PulsarClient

    Permalink
  6. object PulsarTopic extends Serializable

    Permalink
  7. object Subscription extends Serializable

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped