kafka

consumer

package consumer

Visibility
  1. Public
  2. All

Type Members

  1. class AssignmentContext extends AnyRef

  2. trait BaseConsumer extends AnyRef

    A base consumer used to abstract both old and new consumer this class should be removed (along with BaseProducer) be removed once we deprecate old consumer

  3. case class BaseConsumerRecord(topic: String, partition: Int, offset: Long, key: Array[Byte], value: Array[Byte]) extends Product with Serializable

  4. case class Blacklist(rawRegex: String) extends TopicFilter with Product with Serializable

  5. class ConsumerConfig extends ZKConfig

  6. trait ConsumerConnector extends AnyRef

    Main interface for consumer

  7. class ConsumerFetcherManager extends AbstractFetcherManager

    Usage: Once ConsumerFetcherManager is created, startConnections() and stopAllConnections() can be called repeatedly until shutdown() is called.

  8. class ConsumerFetcherThread extends AbstractFetcherThread

  9. class ConsumerIterator[K, V] extends IteratorTemplate[MessageAndMetadata[K, V]] with Logging

    An iterator that blocks until a value can be read from the supplied queue.

  10. case class ConsumerThreadId(consumer: String, threadId: Int) extends Ordered[ConsumerThreadId] with Product with Serializable

  11. class ConsumerTimeoutException extends RuntimeException

  12. class ConsumerTopicMetrics extends KafkaMetricsGroup

    Annotations
    @threadsafe()
  13. class ConsumerTopicStats extends Logging

    Tracks metrics for each topic the given consumer client has consumed data from.

  14. class FetchRequestAndResponseMetrics extends KafkaMetricsGroup

  15. class FetchRequestAndResponseStats extends AnyRef

    Tracks metrics of the requests made by a given consumer client to all brokers, and the responses obtained from the brokers.

  16. case class FetchedDataChunk(messages: ByteBufferMessageSet, topicInfo: PartitionTopicInfo, fetchOffset: Long) extends Product with Serializable

  17. class KafkaStream[K, V] extends Iterable[MessageAndMetadata[K, V]] with Iterable[MessageAndMetadata[K, V]]

  18. class NewShinyConsumer extends BaseConsumer

  19. class OldConsumer extends BaseConsumer

  20. trait PartitionAssignor extends AnyRef

  21. class PartitionTopicInfo extends Logging

  22. class RangeAssignor extends PartitionAssignor with Logging

    Range partitioning works on a per-topic basis.

  23. class RoundRobinAssignor extends PartitionAssignor with Logging

    The round-robin partition assignor lays out all the available partitions and all the available consumer threads.

  24. class SimpleConsumer extends Logging

    A consumer of kafka messages

  25. trait TopicEventHandler[T] extends AnyRef

  26. sealed abstract class TopicFilter extends Logging

  27. case class Whitelist(rawRegex: String) extends TopicFilter with Product with Serializable

  28. class ZookeeperTopicEventWatcher extends Logging

Value Members

  1. object Consumer extends Logging

  2. object ConsumerConfig extends Config

  3. object ConsumerFetcherThread

  4. object ConsumerTopicStatsRegistry

    Stores the topic stats information of each consumer client in a (clientId -> ConsumerTopicStats) map.

  5. object FetchRequestAndResponseStatsRegistry

    Stores the fetch request and response stats information of each consumer client in a (clientId -> FetchRequestAndResponseStats) map.

  6. object PartitionAssignor

  7. object PartitionTopicInfo

Ungrouped