You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@flink.apache.org by "Wei-Che Wei (Jira)" <ji...@apache.org> on 2019/10/01 08:05:00 UTC

[jira] [Created] (FLINK-14302) FlinkKafkaInternalProducer should not send `ADD_PARTITIONS_TO_TXN` request if `newPartitionsInTransaction` is empty when enable EoS

Wei-Che Wei created FLINK-14302:
-----------------------------------

             Summary: FlinkKafkaInternalProducer should not send `ADD_PARTITIONS_TO_TXN` request if `newPartitionsInTransaction` is empty when enable EoS
                 Key: FLINK-14302
                 URL: https://issues.apache.org/jira/browse/FLINK-14302
             Project: Flink
          Issue Type: Bug
          Components: Connectors / Kafka
            Reporter: Wei-Che Wei


As the survey in this mailing list thread [1], kafka server will bind the error with topic-partition list when it handles `AddPartitionToTxnRequest`. So when the request body contains no topic-partition, the error won't be sent back to kafka producer client. Moreover, it producer internal api, it always check if `newPartitionsInTransaction` is empty before sending ADD_PARTITIONS_TO_TXN request to kafka cluster. We should apply it as well if you need to explicitly call it in the first commit phase of two-phase commit sink.

[1] [http://apache-flink-user-mailing-list-archive.2336050.n4.nabble.com/Kafka-producer-failed-with-InvalidTxnStateException-when-performing-commit-transaction-td29384.html]



--
This message was sent by Atlassian Jira
(v8.3.4#803005)