Class and Description |
---|
AbstractFetcher
Base class for all fetchers, which implement the connections to Kafka brokers and pull records
from Kafka partitions.
|
AbstractPartitionDiscoverer
Base class for all partition discoverers.
|
KafkaTopicPartition
Flink's description of a partition in a Kafka topic.
|
KafkaTopicsDescriptor
A Kafka Topics Descriptor describes how the consumer subscribes to Kafka topics - either a fixed
list of topics, or a topic pattern.
|
Class and Description |
---|
AbstractFetcher
Base class for all fetchers, which implement the connections to Kafka brokers and pull records
from Kafka partitions.
|
AbstractPartitionDiscoverer
Base class for all partition discoverers.
|
AbstractPartitionDiscoverer.WakeupException
Signaling exception to indicate that an actual Kafka call was interrupted.
|
ClosableBlockingQueue
A special form of blocking queue with two additions:
The queue can be closed atomically when empty.
|
KafkaCommitCallback
A callback interface that the source operator can implement to trigger custom actions when a
commit request completes, which should normally be triggered from checkpoint complete event.
|
KafkaTopicPartition
Flink's description of a partition in a Kafka topic.
|
KafkaTopicPartitionState
The state that the Flink Kafka Consumer holds for each Kafka partition.
|
KafkaTopicsDescriptor
A Kafka Topics Descriptor describes how the consumer subscribes to Kafka topics - either a fixed
list of topics, or a topic pattern.
|
Class and Description |
---|
AbstractPartitionDiscoverer.ClosedException
Thrown if this discoverer was used to discover partitions after it was closed.
|
AbstractPartitionDiscoverer.WakeupException
Signaling exception to indicate that an actual Kafka call was interrupted.
|
ClosableBlockingQueue
A special form of blocking queue with two additions:
The queue can be closed atomically when empty.
|
KafkaCommitCallback
A callback interface that the source operator can implement to trigger custom actions when a
commit request completes, which should normally be triggered from checkpoint complete event.
|
KafkaTopicPartition
Flink's description of a partition in a Kafka topic.
|
KafkaTopicPartitionLeader
Serializable Topic Partition info with leader Node information.
|
KafkaTopicPartitionState
The state that the Flink Kafka Consumer holds for each Kafka partition.
|
KafkaTopicsDescriptor
A Kafka Topics Descriptor describes how the consumer subscribes to Kafka topics - either a fixed
list of topics, or a topic pattern.
|
Class and Description |
---|
AbstractFetcher
Base class for all fetchers, which implement the connections to Kafka brokers and pull records
from Kafka partitions.
|
KafkaTopicPartition
Flink's description of a partition in a Kafka topic.
|
Class and Description |
---|
KafkaTopicPartition
Flink's description of a partition in a Kafka topic.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.