package kafka
- Alphabetic
- Public
- Protected
Package Members
Type Members
- sealed trait AutoSubscription extends Subscription
Kafka-speak for these is "Subscriptions".
- sealed trait CommitDelivery extends AnyRef
- Annotations
- @ApiMayChange()
- class CommitTimeoutException extends TimeoutException
Commits will be failed with this exception if Kafka doesn't respond within
commit-timeout
- sealed trait CommitWhen extends AnyRef
- Annotations
- @ApiMayChange()
- class CommitterSettings extends AnyRef
Settings for committer.
Settings for committer. See
akka.kafka.committer
section in reference.conf. Note that the companion object providesapply
andcreate
functions for convenient construction of the settings, together with thewith
methods. - class ConnectionCheckerSettings extends AnyRef
- class ConsumerFailed extends RuntimeException
Kafka consumer stages fail with this exception.
- sealed trait ConsumerRebalanceEvent extends AnyRef
- Annotations
- @ApiMayChange()
- class ConsumerSettings[K, V] extends AnyRef
Settings for consumers.
Settings for consumers. See
akka.kafka.consumer
section inreference.conf
. Note that the companion object providesapply
andcreate
functions for convenient construction of the settings, together with thewith
methods.The constructor is Internal API.
- class InitialPollFailed extends ConsumerFailed
- final case class KafkaConnectionFailed(te: TimeoutException, attempts: Int) extends Exception with Product with Serializable
- sealed trait ManualSubscription extends Subscription
Kafka-speak for these is "Assignments".
- class OffsetResetProtectionSettings extends AnyRef
- class ProducerSettings[K, V] extends AnyRef
Settings for producers.
Settings for producers. See
akka.kafka.producer
section in reference.conf. Note that the companion object providesapply
andcreate
functions for convenient construction of the settings, together with thewith
methods.The constructor is Internal API.
- final class RestrictedConsumer extends AnyRef
Offers parts of the org.apache.kafka.clients.consumer.Consumer API which becomes available to the akka.kafka.scaladsl.PartitionAssignmentHandler callbacks.
Offers parts of the org.apache.kafka.clients.consumer.Consumer API which becomes available to the akka.kafka.scaladsl.PartitionAssignmentHandler callbacks.
- Annotations
- @ApiMayChange()
- sealed trait Subscription extends AnyRef
- final case class TopicPartitionsAssigned(sub: Subscription, topicPartitions: Set[TopicPartition]) extends ConsumerRebalanceEvent with Product with Serializable
- Annotations
- @ApiMayChange()
- final case class TopicPartitionsRevoked(sub: Subscription, topicPartitions: Set[TopicPartition]) extends ConsumerRebalanceEvent with Product with Serializable
- Annotations
- @ApiMayChange()
- class WakeupsExceeded extends ConsumerFailed
Value Members
- object CommitDelivery
Selects how the stream delivers commits to the internal actor.
Selects how the stream delivers commits to the internal actor.
- Annotations
- @ApiMayChange()
- object CommitWhen
Selects when the stream will commit an offset.
Selects when the stream will commit an offset.
- Annotations
- @ApiMayChange()
- object CommitterSettings
- object ConnectionCheckerSettings
- object ConsumerMessage
Classes that are used in both javadsl.Consumer and scaladsl.Consumer.
- object ConsumerSettings
- object KafkaConsumerActor
- object Metadata
Messages for Kafka metadata fetching via KafkaConsumerActor.
Messages for Kafka metadata fetching via KafkaConsumerActor.
NOTE: Processing of these requests blocks the actor loop. The KafkaConsumerActor is configured to run on its own dispatcher, so just as the other remote calls to Kafka, the blocking happens within a designated thread pool. However, calling these during consuming might affect performance and even cause timeouts in extreme cases.
- object OffsetResetProtectionSettings
The thresholds after which reset protection is enabled.
The thresholds after which reset protection is enabled. Offsets, time, or both can be provided.
- object ProducerMessage
Classes that are used in both javadsl.Producer and scaladsl.Producer.
- object ProducerSettings
- object Subscriptions
- object Version