kafka

producer

package producer

Visibility
  1. Public
  2. All

Type Members

  1. trait BaseProducer extends AnyRef

  2. class BrokerPartitionInfo extends Logging

  3. class ByteArrayPartitioner extends Partitioner

  4. class DefaultPartitioner extends Partitioner

  5. case class KeyedMessage[K, V](topic: String, key: K, partKey: Any, message: V) extends Product with Serializable

    A topic, key, and value.

  6. class NewShinyProducer extends BaseProducer

  7. class OldProducer extends BaseProducer

  8. case class PartitionAndLeader(topic: String, partitionId: Int, leaderBrokerIdOpt: Option[Int]) extends Product with Serializable

  9. trait Partitioner extends AnyRef

    A partitioner controls the mapping between user-provided keys and kafka partitions.

  10. class Producer[K, V] extends Logging

  11. class ProducerClosedException extends RuntimeException

  12. class ProducerConfig extends AsyncProducerConfig with SyncProducerConfigShared

  13. class ProducerPool extends Logging

  14. class ProducerRequestMetrics extends KafkaMetricsGroup

  15. class ProducerRequestStats extends AnyRef

    Tracks metrics of requests made by a given producer client to all brokers.

  16. class ProducerStats extends KafkaMetricsGroup

  17. class ProducerTopicMetrics extends KafkaMetricsGroup

    Annotations
    @threadsafe()
  18. class ProducerTopicStats extends AnyRef

    Tracks metrics for each topic the given producer client has produced data to.

  19. class SyncProducer extends Logging

    Annotations
    @threadsafe()
  20. class SyncProducerConfig extends SyncProducerConfigShared

  21. trait SyncProducerConfigShared extends AnyRef

Value Members

  1. object ProducerConfig extends Config

  2. object ProducerPool

  3. object ProducerRequestStatsRegistry

    Stores the request stats information of each producer client in a (clientId -> ProducerRequestStats) map.

  4. object ProducerStatsRegistry

    Stores metrics of serialization and message sending activity of each producer client in a (clientId -> ProducerStats) map.

  5. object ProducerTopicStatsRegistry

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

  6. object SyncProducer

  7. object SyncProducerConfig

  8. package async

Ungrouped