KafkaConsumer

fs2.kafka.KafkaConsumer
See theKafkaConsumer companion object
sealed abstract class KafkaConsumer[F[_], K, V] extends KafkaConsume[F, K, V], KafkaConsumeChunk[F, K, V], KafkaAssignment[F], KafkaOffsetsV2[F], KafkaSubscription[F], KafkaTopicsV2[F], KafkaCommit[F], KafkaMetrics[F], KafkaConsumerLifecycle[F]

KafkaConsumer represents a consumer of Kafka records, with the ability to subscribe to topics, start a single top-level stream, and optionally control it via the provided fiber instance.

The following top-level streams are provided.

  • stream provides a single stream of records, where the order of records is guaranteed per topic-partition.

  • partitionedStream provides a stream with elements as streams that continually request records for a single partition. Order is guaranteed per topic-partition, but all assigned partitions will have to be processed in parallel.

  • partitionsMapStream provides a stream where each element contains a current assignment. The current assignment is the Map, where keys is a TopicPartition, and values are streams with records for a particular TopicPartition.
    For the streams, records are wrapped in CommittableConsumerRecords which provide CommittableOffsets with the ability to commit record offsets to Kafka. For performance reasons, offsets are usually committed in batches using CommittableOffsetBatch. Provided Pipes, like commitBatchWithin are available for batch committing offsets. If you are not committing offsets to Kafka, you can simply discard the CommittableOffset, and only make use of the record.

While it's technically possible to start more than one stream from a single KafkaConsumer, it is generally not recommended as there is no guarantee which stream will receive which records, and there might be an overlap, in terms of duplicate records, between the two streams. If a first stream completes, possibly with error, there's no guarantee the stream has processed all of the records it received, and a second stream from the same KafkaConsumer might not be able to pick up where the first one left off. Therefore, only create a single top-level stream per KafkaConsumer, and if you want to start a new stream if the first one finishes, let the KafkaConsumer shutdown and create a new one.

Attributes

Companion
object
Source
KafkaConsumer.scala
Graph
Supertypes
trait KafkaMetrics[F]
trait KafkaCommit[F]
trait KafkaTopicsV2[F]
trait KafkaTopics[F]
trait KafkaOffsetsV2[F]
trait KafkaOffsets[F]
trait KafkaAssignment[F]
trait KafkaConsumeChunk[F, K, V]
trait KafkaConsume[F, K, V]
class Object
trait Matchable
class Any
Show all

Members list

Value members

Inherited methods

def assign(topic: String): F[Unit]

Manually assigns all partitions for the specified topic to the consumer.

Manually assigns all partitions for the specified topic to the consumer.

Attributes

Inherited from:
KafkaAssignment
Source
KafkaAssignment.scala
def assign(topic: String, partitions: Type[Int]): F[Unit]

Manually assigns the specified list of partitions for the specified topic to the consumer.

Manually assigns the specified list of partitions for the specified topic to the consumer. This function does not allow for incremental assignment and will replace the previous assignment (if there is one).

Manual topic assignment through this method does not use the consumer's group management functionality. As such, there will be no rebalance operation triggered when group membership or cluster and topic metadata change. Note that it is not possible to use both manual partition assignment with assign and group assignment with subscribe.

If auto-commit is enabled, an async commit (based on the old assignment) will be triggered before the new assignment replaces the old one.

To unassign all partitions, use KafkaConsumer#unsubscribe.

Attributes

See also

org.apache.kafka.clients.consumer.KafkaConsumer#assign

Inherited from:
KafkaAssignment
Source
KafkaAssignment.scala
def assign(partitions: Type[TopicPartition]): F[Unit]

Manually assigns the specified list of topic partitions to the consumer.

Manually assigns the specified list of topic partitions to the consumer. This function does not allow for incremental assignment and will replace the previous assignment (if there is one).

Manual topic assignment through this method does not use the consumer's group management functionality. As such, there will be no rebalance operation triggered when group membership or cluster and topic metadata change. Note that it is not possible to use both manual partition assignment with assign and group assignment with subscribe.

If auto-commit is enabled, an async commit (based on the old assignment) will be triggered before the new assignment replaces the old one.

To unassign all partitions, use KafkaConsumer#unsubscribe.

Attributes

See also

org.apache.kafka.clients.consumer.KafkaConsumer#assign

Inherited from:
KafkaAssignment
Source
KafkaAssignment.scala
def assignment: F[SortedSet[TopicPartition]]

Returns the set of partitions currently assigned to this consumer.

Returns the set of partitions currently assigned to this consumer.

Attributes

Inherited from:
KafkaAssignment
Source
KafkaAssignment.scala
def assignmentStream: Stream[F, SortedSet[TopicPartition]]

Stream where the elements are the set of TopicPartitions currently assigned to this consumer.

Stream where the elements are the set of TopicPartitions currently assigned to this consumer. The stream emits whenever a rebalance changes partition assignments.

Attributes

Inherited from:
KafkaAssignment
Source
KafkaAssignment.scala

Wait for consumer to shut down.

Wait for consumer to shut down. Note that awaitTermination is guaranteed to complete after consumer shutdown, even when the consumer is cancelled with terminate.

This method will not initiate shutdown. To initiate shutdown and wait for it to complete, you can use terminate >> awaitTermination.

Attributes

Inherited from:
KafkaConsumerLifecycle
Source
KafkaConsumerLifecycle.scala
def beginningOffsets(partitions: Set[TopicPartition], timeout: FiniteDuration): F[Map[TopicPartition, Long]]

Returns the first offset for the specified partitions.

Returns the first offset for the specified partitions.

Attributes

Inherited from:
KafkaTopics
Source
KafkaTopics.scala
def beginningOffsets(partitions: Set[TopicPartition]): F[Map[TopicPartition, Long]]

Returns the first offset for the specified partitions.

Returns the first offset for the specified partitions.

Timeout is determined by default.api.timeout.ms, which is set using ConsumerSettings#withDefaultApiTimeout.

Attributes

Inherited from:
KafkaTopics
Source
KafkaTopics.scala
def commitAsync(offsets: Map[TopicPartition, OffsetAndMetadata]): F[Unit]

Commit the specified offsets for the specified list of topics and partitions to Kafka.

Commit the specified offsets for the specified list of topics and partitions to Kafka.

This commits offsets to Kafka. The offsets committed using this API will be used on the first fetch after every rebalance and also on startup. As such, if you need to store offsets in anything other than Kafka, this API should not be used. The committed offset should be the next message your application will consume, i.e. lastProcessedMessageOffset + 1. If automatic group management with subscribe is used, then the committed offsets must belong to the currently auto-assigned partitions.

Offsets committed through multiple calls to this API are guaranteed to be sent in the same order as the invocations. Additionally note that offsets committed through this API are guaranteed to complete before a subsequent call to commitSync (and variants) returns.

Note, that the recommended way for committing offsets in fs2-kafka is to use commit on CommittableConsumerRecord, CommittableOffset or CommittableOffsetBatch. commitAsync and commitSync usually needs only for some custom scenarios.

Value parameters

offsets

A map of offsets by partition with associate metadata.

Attributes

See also

org.apache.kafka.clients.consumer.KafkaConsumer#commitAsync

Inherited from:
KafkaCommit
Source
KafkaCommit.scala
def commitSync(offsets: Map[TopicPartition, OffsetAndMetadata]): F[Unit]

Commit the specified offsets for the specified list of topics and partitions.

Commit the specified offsets for the specified list of topics and partitions.

This commits offsets to Kafka. The offsets committed using this API will be used on the first fetch after every rebalance and also on startup. As such, if you need to store offsets in anything other than Kafka, this API should not be used. The committed offset should be the next message your application will consume, i.e. lastProcessedMessageOffset + 1. If automatic group management with subscribe is used, then the committed offsets must belong to the currently auto-assigned partitions.

Despite of it's name, this method is not blocking. But it's based on a blocking org.apache.kafka.clients.consumer.KafkaConsumer#commitSync method.

Note, that the recommended way for committing offsets in fs2-kafka is to use commit on CommittableConsumerRecord, CommittableOffset or CommittableOffsetBatch. commitAsync and commitSync usually needs only for some custom scenarios.

Value parameters

offsets

A map of offsets by partition with associated metadata

Attributes

See also

org.apache.kafka.clients.consumer.KafkaConsumer#commitSync

Inherited from:
KafkaCommit
Source
KafkaCommit.scala
def committed(partitions: Set[TopicPartition], timeout: FiniteDuration): F[Map[TopicPartition, OffsetAndMetadata]]

Returns the last committed offsets for the given partitions.

Returns the last committed offsets for the given partitions.

Timeout is determined by default.api.timeout.ms, which is set using ConsumerSettings#withDefaultApiTimeout.

Attributes

Inherited from:
KafkaOffsetsV2
Source
KafkaOffsetsV2.scala
def committed(partitions: Set[TopicPartition]): F[Map[TopicPartition, OffsetAndMetadata]]

Returns the last committed offsets for the given partitions.

Returns the last committed offsets for the given partitions.

Attributes

Inherited from:
KafkaOffsetsV2
Source
KafkaOffsetsV2.scala
final def consumeChunk(processor: Chunk[ConsumerRecord[K, V]] => F[CommitNow])(implicit F: Concurrent[F]): F[Nothing]

Consume from all assigned partitions concurrently, processing the records in Chunks.

Consume from all assigned partitions concurrently, processing the records in Chunks. For each Chunk, the provided processor is called, after that has finished the offsets for all messages in the chunk are committed.

This method is intended to be used in cases that require at-least-once-delivery, where messages have to be processed before offsets are committed. By relying on the methods like partitionedStream, records, and similar, you have to correctly implement not only your processing logic but also the correct mechanism for committing offsets. This can be tricky to do in a correct and efficient way.

Working with Chunks of records has several benefits:

  • As a user, you don't have to care about committing offsets correctly. You can focus on implementing your business logic

  • It's very straightforward to batch several messages from a Chunk together, e.g. for efficient writes to a persistent storage

  • You can liberally use logic that involves concurrency, filtering, and re-ordering of messages without having to worry about incorrect offset commits


The processor is a function that takes a Chunk[ConsumerRecord[K, V]] and returns a F[CommitNow]. CommitNow is isomorphic to Unit, but helps in transporting the intention that processing of a Chunk is done, offsets should be committed, and no important processing should be done afterwards.

The returned value has the type F[Nothing], because it's a never-ending process that doesn't terminate, and therefore doesn't return a result.

Attributes

See also

CommitNow

Note

This method does not make any use of Kafka's auto-commit feature, it implements "manual" commits in a way that suits most of the common use cases.

you have to first use subscribe or assign the consumer before using this Stream. If you forgot to subscribe, there will be a NotSubscribedException raised in the Stream.

Inherited from:
KafkaConsumeChunk
Source
KafkaConsumeChunk.scala
def endOffsets(partitions: Set[TopicPartition], timeout: FiniteDuration): F[Map[TopicPartition, Long]]

Returns the last offset for the specified partitions.

Returns the last offset for the specified partitions.

Attributes

Inherited from:
KafkaTopics
Source
KafkaTopics.scala
def endOffsets(partitions: Set[TopicPartition]): F[Map[TopicPartition, Long]]

Returns the last offset for the specified partitions.

Returns the last offset for the specified partitions.

Timeout is determined by request.timeout.ms, which is set using ConsumerSettings#withRequestTimeout.

Attributes

Inherited from:
KafkaTopics
Source
KafkaTopics.scala
def listTopics(timeout: FiniteDuration): F[Map[String, List[PartitionInfo]]]

Get metadata about partitions for all topics that the user is authorized to view.

Get metadata about partitions for all topics that the user is authorized to view. This method will issue a remote call to the server.

Attributes

Inherited from:
KafkaTopicsV2
Source
KafkaTopicsV2.scala
def listTopics: F[Map[String, List[PartitionInfo]]]

Get metadata about partitions for all topics that the user is authorized to view.

Get metadata about partitions for all topics that the user is authorized to view. This method will issue a remote call to the server.

Timeout is determined by default.api.timeout.ms, which is set using ConsumerSettings#withDefaultApiTimeout.

Attributes

Inherited from:
KafkaTopicsV2
Source
KafkaTopicsV2.scala
def metrics: F[Map[MetricName, Metric]]

Returns consumer metrics.

Returns consumer metrics.

Attributes

See also

org.apache.kafka.clients.consumer.KafkaConsumer#metrics

Inherited from:
KafkaMetrics
Source
KafkaMetrics.scala
def offsetsForTimes(timestampsToSearch: Map[TopicPartition, Long], timeout: FiniteDuration): F[Map[TopicPartition, Option[OffsetAndTimestamp]]]

Look up the offsets for the given partitions by timestamp.

Look up the offsets for the given partitions by timestamp. The returned offset for each partition is the earliest offset whose timestamp is greater than or equal to the given timestamp in the corresponding partition.

The consumer does not have to be assigned the partitions. If no messages exist yet for a partition, it will not exist in the returned map.

Attributes

Inherited from:
KafkaTopicsV2
Source
KafkaTopicsV2.scala
def offsetsForTimes(timestampsToSearch: Map[TopicPartition, Long]): F[Map[TopicPartition, Option[OffsetAndTimestamp]]]

Look up the offsets for the given partitions by timestamp.

Look up the offsets for the given partitions by timestamp. The returned offset for each partition is the earliest offset whose timestamp is greater than or equal to the given timestamp in the corresponding partition.

The consumer does not have to be assigned the partitions. If no messages exist yet for a partition, it will not exist in the returned map.

Timeout is determined by default.api.timeout.ms, which is set using ConsumerSettings#withDefaultApiTimeout.

Attributes

Inherited from:
KafkaTopicsV2
Source
KafkaTopicsV2.scala

Alias for partitionedStream

Alias for partitionedStream

Attributes

Inherited from:
KafkaConsume
Source
KafkaConsume.scala

Stream where the elements themselves are Streams which continually request records for a single partition.

Stream where the elements themselves are Streams which continually request records for a single partition. These Streams will have to be processed in parallel, using parJoin or parJoinUnbounded. Note that when using parJoin(n) and n is smaller than the number of currently assigned partitions, then there will be assigned partitions which won't be processed. For that reason, prefer parJoinUnbounded and the actual limit will be the number of assigned partitions.

If you do not want to process all partitions in parallel, then you can use records instead, where records for all partitions are in a single Stream.

Attributes

Note

you have to first use subscribe or assign the consumer before using this Stream. If you forgot to subscribe, there will be a NotSubscribedException raised in the Stream.

Inherited from:
KafkaConsume
Source
KafkaConsume.scala
def partitionsFor(topic: String, timeout: FiniteDuration): F[List[PartitionInfo]]

Returns the partitions for the specified topic.

Returns the partitions for the specified topic.

Attributes

Inherited from:
KafkaTopics
Source
KafkaTopics.scala
def partitionsFor(topic: String): F[List[PartitionInfo]]

Returns the partitions for the specified topic.

Returns the partitions for the specified topic.

Timeout is determined by default.api.timeout.ms, which is set using ConsumerSettings#withDefaultApiTimeout.

Attributes

Inherited from:
KafkaTopics
Source
KafkaTopics.scala
def partitionsMapStream: Stream[F, Map[TopicPartition, Stream[F, CommittableConsumerRecord[F, K, V]]]]

Stream where each element contains a Map with all newly assigned partitions.

Stream where each element contains a Map with all newly assigned partitions. Keys of this Map are TopicPartitions, and values are record streams for the particular TopicPartition. These streams will be closed only when a partition is revoked.

With the default assignor, all previous partitions are revoked at once, and a new set of partitions is assigned to a consumer on each rebalance. In this case, each returned Map contains the full partition assignment for the consumer. And all streams from the previous assignment are closed. It means, that partitionsMapStream reflects the default assignment process in a streaming manner.

This may not be the case when a custom assignor is configured in the consumer. When using the CooperativeStickyAssignor, for instance, partitions may be revoked individually. In this case, each element in the stream (eachMap) will contain only streams for newly assigned partitions. Previously returned streams for partitions that are retained will remain active. Only streams for revoked partitions will be closed.

This is the most generic Stream method. If you don't need such control, consider using partitionedStream or stream methods. They are both based on a partitionsMapStream.

Attributes

See also
Note

you have to first use subscribe or assign to subscribe the consumer before using this Stream. If you forgot to subscribe, there will be a NotSubscribedException raised in the Stream.

Inherited from:
KafkaConsume
Source
KafkaConsume.scala
def position(partition: TopicPartition, timeout: FiniteDuration): F[Long]

Returns the offset of the next record that will be fetched.

Returns the offset of the next record that will be fetched.

Attributes

Inherited from:
KafkaOffsets
Source
KafkaOffsets.scala
def position(partition: TopicPartition): F[Long]

Returns the offset of the next record that will be fetched.

Returns the offset of the next record that will be fetched.

Timeout is determined by default.api.timeout.ms, which is set using ConsumerSettings#withDefaultApiTimeout.

Attributes

Inherited from:
KafkaOffsets
Source
KafkaOffsets.scala
final def records: Stream[F, CommittableConsumerRecord[F, K, V]]

Consume from all assigned partitions, producing a stream of CommittableConsumerRecords.

Consume from all assigned partitions, producing a stream of CommittableConsumerRecords. Alias for stream.

Attributes

Inherited from:
KafkaConsume
Source
KafkaConsume.scala
def seek(partition: TopicPartition, offset: Long): F[Unit]

Overrides the fetch offsets that the consumer will use when reading the next record.

Overrides the fetch offsets that the consumer will use when reading the next record. If this API is invoked for the same partition more than once, the latest offset will be used. Note that you may lose data if this API is arbitrarily used in the middle of consumption to reset the fetch offsets.

Attributes

Inherited from:
KafkaOffsets
Source
KafkaOffsets.scala
def seekToBeginning[G[_] : Foldable](partitions: G[TopicPartition]): F[Unit]

Seeks to the first offset for each of the specified partitions.

Seeks to the first offset for each of the specified partitions. If no partitions are provided, seeks to the first offset for all currently assigned partitions.

Note that this seek evaluates lazily, and only on the next call to poll or position.

Attributes

Inherited from:
KafkaOffsets
Source
KafkaOffsets.scala

Seeks to the first offset for each currently assigned partition.

Seeks to the first offset for each currently assigned partition. This is equivalent to using seekToBeginning with an empty set of partitions.

Note that this seek evaluates lazily, and only on the next call to poll or position.

Attributes

Inherited from:
KafkaOffsets
Source
KafkaOffsets.scala
def seekToEnd[G[_] : Foldable](partitions: G[TopicPartition]): F[Unit]

Seeks to the last offset for each of the specified partitions.

Seeks to the last offset for each of the specified partitions. If no partitions are provided, seeks to the last offset for all currently assigned partitions.

Note that this seek evaluates lazily, and only on the next call to poll or position.

Attributes

Inherited from:
KafkaOffsets
Source
KafkaOffsets.scala
def seekToEnd: F[Unit]

Seeks to the last offset for each currently assigned partition.

Seeks to the last offset for each currently assigned partition. This is equivalent to using seekToEnd with an empty set of partitions.

Note that this seek evaluates lazily, and only on the next call to poll or position.

Attributes

Inherited from:
KafkaOffsets
Source
KafkaOffsets.scala

Stops consuming new messages from Kafka.

Stops consuming new messages from Kafka. This method could be used to implement a graceful shutdown.

This method has a few effects:

  • After this call no more data will be fetched from Kafka through the poll method.

  • All currently running streams will continue to run until all in-flight messages will be processed. It means that streams will be completed when all fetched messages will be processed.

If some of the records methods will be called after stopConsuming call, these methods will return empty streams.

More than one call of stopConsuming will have no effect.

Attributes

Inherited from:
KafkaConsume
Source
KafkaConsume.scala

Alias for partitionedStream.parJoinUnbounded.

Alias for partitionedStream.parJoinUnbounded.

Attributes

See also

partitionedRecords for more information

Note

you have to first use subscribe or assign the consumer before using this Stream. If you forgot to subscribe, there will be a NotSubscribedException raised in the Stream.

Inherited from:
KafkaConsume
Source
KafkaConsume.scala
def subscribe(regex: Regex): F[Unit]

Subscribes the consumer to the topics matching the specified Regex.

Subscribes the consumer to the topics matching the specified Regex. Note that you have to use one of the subscribe functions before you can use any of the provided Streams, or a NotSubscribedException will be raised in the Streams.

Value parameters

regex

the regex to which matching topics should be subscribed

Attributes

Inherited from:
KafkaSubscription
Source
KafkaSubscription.scala
def subscribe[G[_] : Reducible](topics: G[String]): F[Unit]

Subscribes the consumer to the specified topics.

Subscribes the consumer to the specified topics. Note that you have to use one of the subscribe functions to subscribe to one or more topics before using any of the provided Streams, or a NotSubscribedException will be raised in the Streams.

Value parameters

topics

the topics to which the consumer should subscribe

Attributes

Inherited from:
KafkaSubscription
Source
KafkaSubscription.scala
def subscribeTo(firstTopic: String, remainingTopics: String*): F[Unit]

Subscribes the consumer to the specified topics.

Subscribes the consumer to the specified topics. Note that you have to use one of the subscribe functions to subscribe to one or more topics before using any of the provided Streams, or a NotSubscribedException will be raised in the Streams.

Attributes

Inherited from:
KafkaSubscription
Source
KafkaSubscription.scala
def terminate: F[Unit]

Whenever terminate is invoked, an attempt will be made to stop the underlying consumer.

Whenever terminate is invoked, an attempt will be made to stop the underlying consumer. The terminate operation will not wait for the consumer to shutdown. If you also want to wait for the shutdown to complete, you can use terminate >> awaitTermination.

Attributes

Inherited from:
KafkaConsumerLifecycle
Source
KafkaConsumerLifecycle.scala
def unsubscribe: F[Unit]

Unsubscribes the consumer from all topics and partitions assigned by subscribe or assign.

Unsubscribes the consumer from all topics and partitions assigned by subscribe or assign.

Attributes

Inherited from:
KafkaSubscription
Source
KafkaSubscription.scala