Object

zio.kafka.consumer

Consumer

Related Doc: package consumer

Permalink

object Consumer extends Serializable

Linear Supertypes
Serializable, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Consumer
  2. Serializable
  3. Serializable
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. sealed trait AutoOffsetStrategy extends AnyRef

    Permalink
  2. final case class Live(consumer: ConsumerAccess, settings: ConsumerSettings, runloop: Runloop) extends Service with Product with Serializable

    Permalink
  3. sealed trait OffsetRetrieval extends AnyRef

    Permalink
  4. trait Service extends AnyRef

    Permalink

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. object AutoOffsetStrategy

    Permalink
  5. object OffsetRetrieval

    Permalink
  6. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  7. def assignment: RIO[Blocking with Consumer, Set[TopicPartition]]

    Permalink

    Accessor method for Service.assignment

  8. def beginningOffsets(partitions: Set[TopicPartition], timeout: Duration = Duration.Infinity): RIO[Blocking with Consumer, Map[TopicPartition, Long]]

    Permalink

    Accessor method for Service.beginningOffsets

  9. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  10. def committed(partitions: Set[TopicPartition], timeout: Duration = Duration.Infinity): RIO[Blocking with Consumer, Map[TopicPartition, Option[OffsetAndMetadata]]]

    Permalink

    Accessor method for Service.committed

  11. def consumeWith[R, R1, K, V](settings: ConsumerSettings, subscription: Subscription, keyDeserializer: Deserializer[R1, K], valueDeserializer: Deserializer[R1, V], commitRetryPolicy: Schedule[Clock, Any, Any] = ...)(f: (K, V) ⇒ ZIO[R, Nothing, Unit])(implicit arg0: zio.Tag[R1], arg1: zio.Tag[K], arg2: zio.Tag[V]): ZIO[R with R1 with Blocking with Clock, Throwable, Unit]

    Permalink

    Execute an effect for each record and commit the offset after processing

    Execute an effect for each record and commit the offset after processing

    This method is the easiest way of processing messages on a Kafka topic.

    Messages on a single partition are processed sequentially, while the processing of multiple partitions happens in parallel.

    Offsets are committed after execution of the effect. They are batched when a commit action is in progress to avoid backpressuring the stream. When commits fail due to a org.apache.kafka.clients.consumer.RetriableCommitFailedException they are retried according to commitRetryPolicy

    The effect should absorb any failures. Failures should be handled by retries or ignoring the error, which will result in the Kafka message being skipped.

    Messages are processed with 'at least once' consistency: it is not guaranteed that every message that is processed by the effect has a corresponding offset commit before stream termination.

    Usage example:

    val settings: ConsumerSettings = ???
    val subscription = Subscription.Topics(Set("my-kafka-topic"))
    
    val consumerIO = Consumer.consumeWith(settings, subscription, Serdes.string, Serdes.string) { case (key, value) =>
      // Process the received record here
      putStrLn(s"Received record: ${key}: ${value}")
    }
    R

    Environment for the consuming effect

    R1

    Environment for the deserializers

    K

    Type of keys (an implicit Deserializer should be in scope)

    V

    Type of values (an implicit Deserializer should be in scope)

    settings

    Settings for creating a Consumer

    subscription

    Topic subscription parameters

    keyDeserializer

    Deserializer for the key of the messages

    valueDeserializer

    Deserializer for the value of the messages

    commitRetryPolicy

    Retry commits that failed due to a RetriableCommitFailedException according to this schedule

    f

    Function that returns the effect to execute for each message. It is passed the key and value

    returns

    Effect that completes with a unit value only when interrupted. May fail when the Consumer fails.

  12. def endOffsets(partitions: Set[TopicPartition], timeout: Duration = Duration.Infinity): RIO[Blocking with Consumer, Map[TopicPartition, Long]]

    Permalink

    Accessor method for Service.endOffsets

  13. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  14. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  15. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  16. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  17. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  18. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  19. def listTopics(timeout: Duration = Duration.Infinity): RIO[Blocking with Consumer, Map[String, List[PartitionInfo]]]

    Permalink

    Accessor method for Service.listTopics

  20. def live: ZLayer[Clock with Blocking with Has[ConsumerSettings] with Has[Diagnostics], Throwable, Consumer]

    Permalink
  21. def make(settings: ConsumerSettings, diagnostics: Diagnostics = Diagnostics.NoOp): ZManaged[Clock with Blocking, Throwable, Service]

    Permalink
  22. def metrics: RIO[Blocking with Consumer, Map[MetricName, Metric]]

    Permalink

    Accessor method for Service.metrics

  23. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  24. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  25. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  26. val offsetBatches: ZTransducer[Any, Nothing, Offset, OffsetBatch]

    Permalink
  27. def offsetsForTimes(timestamps: Map[TopicPartition, Long], timeout: Duration = Duration.Infinity): RIO[Blocking with Consumer, Map[TopicPartition, OffsetAndTimestamp]]

    Permalink

    Accessor method for Service.offsetsForTimes

  28. def partitionedStream[R, K, V](keyDeserializer: Deserializer[R, K], valueDeserializer: Deserializer[R, V])(implicit arg0: zio.Tag[R], arg1: zio.Tag[K], arg2: zio.Tag[V]): ZStream[Consumer with Clock with Blocking, Throwable, (TopicPartition, ZStream[R, Throwable, CommittableRecord[K, V]])]

    Permalink

    Accessor method for Service.partitionedStream

  29. def partitionsFor(topic: String, timeout: Duration = Duration.Infinity): RIO[Blocking with Consumer, List[PartitionInfo]]

    Permalink

    Accessor method for Service.partitionsFor

  30. def plainStream[R, K, V](keyDeserializer: Deserializer[R, K], valueDeserializer: Deserializer[R, V])(implicit arg0: zio.Tag[R], arg1: zio.Tag[K], arg2: zio.Tag[V]): ZStream[R with Consumer with Clock with Blocking, Throwable, CommittableRecord[K, V]]

    Permalink

    Accessor method for Service.plainStream

  31. def position(partition: TopicPartition, timeout: Duration = Duration.Infinity): RIO[Blocking with Consumer, Long]

    Permalink

    Accessor method for Service.position

  32. def stopConsumption: RIO[Consumer, Unit]

    Permalink

    Accessor method for Service.stopConsumption

  33. def subscribe(subscription: Subscription): RIO[Blocking with Consumer, Unit]

    Permalink

    Accessor method for Service.subscribe

  34. def subscribeAnd(subscription: Subscription): SubscribedConsumerFromEnvironment

    Permalink

    Accessor method for Service.subscribeAnd

  35. def subscription: RIO[Blocking with Consumer, Set[String]]

    Permalink

    Accessor method for Service.subscription

  36. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  37. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  38. def unsubscribe: RIO[Blocking with Consumer, Unit]

    Permalink

    Accessor method for Service.unsubscribe

  39. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  40. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  41. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  42. def withConsumerService[R, A](r: (Service) ⇒ RIO[R with Blocking, A]): RIO[R with Blocking with Consumer, A]

    Permalink

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped