Package | Description |
---|---|
org.apache.flink.streaming.connectors.kafka.internal | |
org.apache.flink.streaming.connectors.kafka.internals |
Modifier and Type | Method and Description |
---|---|
protected void |
KafkaFetcher.doCommitInternalOffsetsToKafka(Map<KafkaTopicPartition,Long> offsets,
KafkaCommitCallback commitCallback) |
protected void |
Kafka010Fetcher.doCommitInternalOffsetsToKafka(Map<KafkaTopicPartition,Long> offsets,
KafkaCommitCallback commitCallback) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractFetcher.commitInternalOffsetsToKafka(Map<KafkaTopicPartition,Long> offsets,
KafkaCommitCallback commitCallback)
Commits the given partition offsets to the Kafka brokers (or to ZooKeeper for older Kafka
versions).
|
protected abstract void |
AbstractFetcher.doCommitInternalOffsetsToKafka(Map<KafkaTopicPartition,Long> offsets,
KafkaCommitCallback commitCallback) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.