[jira] [Assigned] (KAFKA-12430) emit.heartbeats.enabled = false should disable heartbeats topic creation

2021-05-24 Thread Ivan Yurchenko (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12430?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Ivan Yurchenko reassigned KAFKA-12430: -- Assignee: (was: Ivan Yurchenko) > emit.heartbeats.enabled = false should disable

[jira] [Updated] (KAFKA-12430) emit.heartbeats.enabled = false should disable heartbeats topic creation

2021-05-24 Thread Ivan Yurchenko (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12430?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Ivan Yurchenko updated KAFKA-12430: --- Description: Currently, whether MirrorMaker 2's {{MirrorHeartbeatConnector}} emits

[GitHub] [kafka] vahidhashemian commented on a change in pull request #10552: KAFKA-12675: improve the sticky general assignor scalability and performance

2021-05-24 Thread GitBox
vahidhashemian commented on a change in pull request #10552: URL: https://github.com/apache/kafka/pull/10552#discussion_r638437845 ## File path: clients/src/main/java/org/apache/kafka/clients/consumer/internals/AbstractStickyAssignor.java ## @@ -637,19 +709,27 @@ private void

[GitHub] [kafka] KahnCheny commented on pull request #10746: MINOR: remove unneccessary public keyword from ProducerInterceptor/ConsumerInterceptor interface

2021-05-24 Thread GitBox
KahnCheny commented on pull request #10746: URL: https://github.com/apache/kafka/pull/10746#issuecomment-847490202 > @KahnCheny , thanks for the PR. LGTM! Could you also remove the `public` keyword in `ConsumerInterceptor` ? Thank you. Of course. -- This is an automated message

[GitHub] [kafka] showuon commented on a change in pull request #10755: MINOR: deprecate TaskMetadata constructor, replace TaskId#parse and add tests

2021-05-24 Thread GitBox
showuon commented on a change in pull request #10755: URL: https://github.com/apache/kafka/pull/10755#discussion_r638426531 ## File path: streams/src/main/java/org/apache/kafka/streams/processor/TaskMetadata.java ## @@ -40,6 +40,18 @@ private final Optional

[GitHub] [kafka] showuon commented on a change in pull request #10749: KAFKA-12773: Use UncheckedIOException when wrapping IOException

2021-05-24 Thread GitBox
showuon commented on a change in pull request #10749: URL: https://github.com/apache/kafka/pull/10749#discussion_r638422416 ## File path: raft/src/main/java/org/apache/kafka/raft/FileBasedStateStore.java ## @@ -91,14 +92,22 @@ private QuorumStateData readStateFromFile(File

[GitHub] [kafka] ableegoldman commented on pull request #10755: MINOR: deprecate TaskMetadata constructor, replace TaskId#parse and add tests

2021-05-24 Thread GitBox
ableegoldman commented on pull request #10755: URL: https://github.com/apache/kafka/pull/10755#issuecomment-847495713 All tests passed except for unrelated flaky `kafka.connect.integration.RebalanceSourceConnectorsIntegrationTest.testRemovingWorker()` -- This is an automated message

[jira] [Created] (KAFKA-12845) Rollback change which requires join key to be non null on KStream->GlobalKTable

2021-05-24 Thread Pedro Gontijo (Jira)
Pedro Gontijo created KAFKA-12845: - Summary: Rollback change which requires join key to be non null on KStream->GlobalKTable Key: KAFKA-12845 URL: https://issues.apache.org/jira/browse/KAFKA-12845

[GitHub] [kafka] ableegoldman commented on a change in pull request #10609: KAFKA-12648: Pt. 1 - Add NamedTopology to protocol and state directory structure

2021-05-24 Thread GitBox
ableegoldman commented on a change in pull request #10609: URL: https://github.com/apache/kafka/pull/10609#discussion_r638396898 ## File path: streams/src/main/java/org/apache/kafka/streams/processor/internals/StateDirectory.java ## @@ -387,18 +422,18 @@ public synchronized

[GitHub] [kafka] ableegoldman edited a comment on pull request #10609: KAFKA-12648: Pt. 1 - Add NamedTopology to protocol and state directory structure

2021-05-24 Thread GitBox
ableegoldman edited a comment on pull request #10609: URL: https://github.com/apache/kafka/pull/10609#issuecomment-845638871 Rebased after the TaskId changes in KIP-470, and responded to all comments. Not much has changed since the last review, just cleaning up here and there. ~It's

[GitHub] [kafka] sasukerui closed pull request #10751: MINOR: update java doc for ConsumerCoordinator

2021-05-24 Thread GitBox
sasukerui closed pull request #10751: URL: https://github.com/apache/kafka/pull/10751 -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific comment. For queries about this service,

[GitHub] [kafka] ableegoldman commented on pull request #10755: MINOR: deprecate TaskMetadata constructor, replace TaskId#parse and add tests

2021-05-24 Thread GitBox
ableegoldman commented on pull request #10755: URL: https://github.com/apache/kafka/pull/10755#issuecomment-847442114 cc @mjsax -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific

[GitHub] [kafka] ableegoldman merged pull request #10690: MINOR: clarify message ordering with max in-flight requests and idempotent producer

2021-05-24 Thread GitBox
ableegoldman merged pull request #10690: URL: https://github.com/apache/kafka/pull/10690 -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific comment. For queries about this service,

[jira] [Commented] (KAFKA-12835) Topic IDs can mismatch on brokers (after interbroker protocol version update)

2021-05-24 Thread Justine Olshan (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12835?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350684#comment-17350684 ] Justine Olshan commented on KAFKA-12835: Hi [~ivanyu]. Previously we could lose topic IDs in the

[GitHub] [kafka] ableegoldman edited a comment on pull request #10690: MINOR: clarify message ordering with max in-flight requests and idempotent producer

2021-05-24 Thread GitBox
ableegoldman edited a comment on pull request #10690: URL: https://github.com/apache/kafka/pull/10690#issuecomment-847413919 Some unrelated test failures in `RaftClusterTest`, `connect.integration.RebalanceSourceConnectorsIntegrationTest.testDeleteConnector()`, and

[GitHub] [kafka] ableegoldman commented on pull request #10690: MINOR: clarify message ordering with max in-flight requests and idempotent producer

2021-05-24 Thread GitBox
ableegoldman commented on pull request #10690: URL: https://github.com/apache/kafka/pull/10690#issuecomment-847413919 Some unrelated test failures in `RaftClusterTest`, `connect.integration.RebalanceSourceConnectorsIntegrationTest.testDeleteConnector()`, and

[GitHub] [kafka] ijuma closed pull request #10497: KAFKA-12342; Merge RaftClient and MetaLogManager interfaces and remove shim

2021-05-24 Thread GitBox
ijuma closed pull request #10497: URL: https://github.com/apache/kafka/pull/10497 -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific comment. For queries about this service, please

[GitHub] [kafka] ableegoldman commented on a change in pull request #10755: MINOR: deprecate TaskMetadata constructor, replace TaskId#parse and add tests

2021-05-24 Thread GitBox
ableegoldman commented on a change in pull request #10755: URL: https://github.com/apache/kafka/pull/10755#discussion_r638336725 ## File path: streams/src/main/java/org/apache/kafka/streams/processor/TaskId.java ## @@ -80,6 +83,35 @@ public String toString() { return

[GitHub] [kafka] ableegoldman opened a new pull request #10755: MINOR: deprecate TaskMetadata constructor, replace TaskId#parse and add tests

2021-05-24 Thread GitBox
ableegoldman opened a new pull request #10755: URL: https://github.com/apache/kafka/pull/10755 Quick followup to KIP-740. I also noticed the TaskId#parse method had been modified previously, and should be re-added to the public TaskId class. It also had no tests, so now it does --

[jira] [Created] (KAFKA-12844) KIP-740 follow up: clean up TaskId

2021-05-24 Thread A. Sophie Blee-Goldman (Jira)
A. Sophie Blee-Goldman created KAFKA-12844: -- Summary: KIP-740 follow up: clean up TaskId Key: KAFKA-12844 URL: https://issues.apache.org/jira/browse/KAFKA-12844 Project: Kafka Issue

[jira] [Created] (KAFKA-12843) KIP-740 follow up: clean up TaskMetadata

2021-05-24 Thread A. Sophie Blee-Goldman (Jira)
A. Sophie Blee-Goldman created KAFKA-12843: -- Summary: KIP-740 follow up: clean up TaskMetadata Key: KAFKA-12843 URL: https://issues.apache.org/jira/browse/KAFKA-12843 Project: Kafka

[jira] [Commented] (KAFKA-12838) Kafka Broker - Request threads inefficiently blocking during produce

2021-05-24 Thread Ryan Cabral (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12838?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350654#comment-17350654 ] Ryan Cabral commented on KAFKA-12838: - Yes, increasing the number of partitions can help reduce

[GitHub] [kafka] jolshan commented on pull request #10754: KAFKA-12835: Topic IDs can mismatch on brokers (after interbroker protocol version update)

2021-05-24 Thread GitBox
jolshan commented on pull request #10754: URL: https://github.com/apache/kafka/pull/10754#issuecomment-847389546 Hmm looks like `KafkaMetadataLogTest.testTopicId` is failing because we set `keepPartitionMetadataFile` to be false. When I ensure that we only assign topicId when

[jira] [Commented] (KAFKA-9168) Integrate JNI direct buffer support to RocksDBStore

2021-05-24 Thread A. Sophie Blee-Goldman (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-9168?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350650#comment-17350650 ] A. Sophie Blee-Goldman commented on KAFKA-9168: --- Yep, all the rocksdb work waiting on more

[GitHub] [kafka] junrao commented on a change in pull request #10684: MINOR: Improve Log layer segment iteration logic and few other areas

2021-05-24 Thread GitBox
junrao commented on a change in pull request #10684: URL: https://github.com/apache/kafka/pull/10684#discussion_r638164890 ## File path: core/src/main/scala/kafka/log/LogSegments.scala ## @@ -210,11 +209,23 @@ class LogSegments(topicPartition: TopicPartition) { * @return

[GitHub] [kafka] jolshan opened a new pull request #10754: KAFKA-12835: Topic IDs can mismatch on brokers (after interbroker protocol version update)

2021-05-24 Thread GitBox
jolshan opened a new pull request #10754: URL: https://github.com/apache/kafka/pull/10754 Upon upgrading to IBP 2.8, topic ID can end up getting reassigned which can cause errors in LeaderAndIsr handling when the partition metadata files from the previous ID are still on the broker.

[jira] [Commented] (KAFKA-12838) Kafka Broker - Request threads inefficiently blocking during produce

2021-05-24 Thread Ryanne Dolan (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12838?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350606#comment-17350606 ] Ryanne Dolan commented on KAFKA-12838: -- Would it help to significantly increase the number of

[GitHub] [kafka] fqaiser94 commented on a change in pull request #10747: KAFKA-12446: Define KGroupedTable#aggregate subtractor + adder order of execution

2021-05-24 Thread GitBox
fqaiser94 commented on a change in pull request #10747: URL: https://github.com/apache/kafka/pull/10747#discussion_r637657442 ## File path: streams/src/main/java/org/apache/kafka/streams/kstream/internals/ChangedSerializer.java ## @@ -45,34 +45,30 @@ public void

[GitHub] [kafka] fqaiser94 commented on a change in pull request #10747: KAFKA-12446: Define KGroupedTable#aggregate subtractor + adder order of execution

2021-05-24 Thread GitBox
fqaiser94 commented on a change in pull request #10747: URL: https://github.com/apache/kafka/pull/10747#discussion_r637657442 ## File path: streams/src/main/java/org/apache/kafka/streams/kstream/internals/ChangedSerializer.java ## @@ -45,34 +45,30 @@ public void

[GitHub] [kafka] cmccabe opened a new pull request #10753: KAFKA-12803: Support reassigning partitions when in KRaft mode

2021-05-24 Thread GitBox
cmccabe opened a new pull request #10753: URL: https://github.com/apache/kafka/pull/10753 Support the KIP-455 reassignment API when in KRaft mode. Reassignments which merely rearrange partitions complete immediately. Those that only remove a partition complete immediately if the ISR

[GitHub] [kafka] mumrah opened a new pull request #10752: KAFKA-12620 Allocate Producer IDs in KRaft controller

2021-05-24 Thread GitBox
mumrah opened a new pull request #10752: URL: https://github.com/apache/kafka/pull/10752 This is part 2 of [KIP-730](https://cwiki.apache.org/confluence/display/KAFKA/KIP-730%3A+Producer+ID+generation+in+KRaft+mode), part 1 was in #10504. This PR adds support on the KRaft

[GitHub] [kafka] junrao merged pull request #10742: MINOR: Add log identifier/prefix printing in Log layer static functions

2021-05-24 Thread GitBox
junrao merged pull request #10742: URL: https://github.com/apache/kafka/pull/10742 -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific comment. For queries about this service, please

[jira] [Commented] (KAFKA-8522) Tombstones can survive forever

2021-05-24 Thread Jun Rao (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-8522?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350551#comment-17350551 ] Jun Rao commented on KAFKA-8522: latest PR link > Tombstones can survive forever >

[GitHub] [kafka] dejan2609 commented on pull request #10698: KAFKA-12770: introduce `checkstyleVersion` build option (for overriding CheckStyle project-defined dependency version)

2021-05-24 Thread GitBox
dejan2609 commented on pull request #10698: URL: https://github.com/apache/kafka/pull/10698#issuecomment-847201180 CheckStyle team (@romani) needs this in order to add Kafka project into their regression suit here:

[GitHub] [kafka] dejan2609 edited a comment on pull request #10698: KAFKA-12770: introduce `checkstyleVersion` build option (for overriding CheckStyle project-defined dependency version)

2021-05-24 Thread GitBox
dejan2609 edited a comment on pull request #10698: URL: https://github.com/apache/kafka/pull/10698#issuecomment-847174293 If I may ask you @showuon: do we need to ping someone else for another review (or for merge into trunk) ? _Edit (just to answer to my self): there are two types

[GitHub] [kafka] dejan2609 commented on pull request #10698: KAFKA-12770: introduce `checkstyleVersion` build option (for overriding CheckStyle project-defined dependency version)

2021-05-24 Thread GitBox
dejan2609 commented on pull request #10698: URL: https://github.com/apache/kafka/pull/10698#issuecomment-847174293 If I may ask you @showuon: do we need to ping someone else for another review (or for merge into trunk) ? -- This is an automated message from the Apache Git Service. To

[GitHub] [kafka] dengziming commented on pull request #10751: MINOR: update java doc for ConsumerCoordinator

2021-05-24 Thread GitBox
dengziming commented on pull request #10751: URL: https://github.com/apache/kafka/pull/10751#issuecomment-847135527 iif means if and only if -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to

[GitHub] [kafka] vvcephei commented on pull request #10744: KAFKA-8410: KTableProcessor migration groundwork

2021-05-24 Thread GitBox
vvcephei commented on pull request #10744: URL: https://github.com/apache/kafka/pull/10744#issuecomment-847118811 Filed ticket for Connect test: https://issues.apache.org/jira/browse/KAFKA-12842 Commented on ticket for Raft test: https://issues.apache.org/jira/browse/KAFKA-12629 --

[jira] [Updated] (KAFKA-12629) Failing Test: RaftClusterTest

2021-05-24 Thread John Roesler (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12629?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] John Roesler updated KAFKA-12629: - Summary: Failing Test: RaftClusterTest (was: Flaky Test RaftClusterTest) > Failing Test:

[jira] [Comment Edited] (KAFKA-12629) Flaky Test RaftClusterTest

2021-05-24 Thread John Roesler (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12629?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350483#comment-17350483 ] John Roesler edited comment on KAFKA-12629 at 5/24/21, 3:22 PM: Failed

[jira] [Updated] (KAFKA-12677) The raftCluster always send to the wrong active controller and never update

2021-05-24 Thread John Roesler (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12677?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] John Roesler updated KAFKA-12677: - Fix Version/s: 3.0.0 > The raftCluster always send to the wrong active controller and never

[jira] [Updated] (KAFKA-12677) The raftCluster always send to the wrong active controller and never update

2021-05-24 Thread John Roesler (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12677?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] John Roesler updated KAFKA-12677: - Priority: Blocker (was: Major) > The raftCluster always send to the wrong active controller

[jira] [Updated] (KAFKA-12629) Flaky Test RaftClusterTest

2021-05-24 Thread John Roesler (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12629?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] John Roesler updated KAFKA-12629: - Priority: Blocker (was: Critical) > Flaky Test RaftClusterTest > -- >

[jira] [Updated] (KAFKA-12629) Flaky Test RaftClusterTest

2021-05-24 Thread John Roesler (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12629?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] John Roesler updated KAFKA-12629: - Fix Version/s: 3.0.0 > Flaky Test RaftClusterTest > -- > >

[jira] [Commented] (KAFKA-12629) Flaky Test RaftClusterTest

2021-05-24 Thread John Roesler (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12629?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350483#comment-17350483 ] John Roesler commented on KAFKA-12629: -- Failed also on:

[jira] [Created] (KAFKA-12842) Failing test: org.apache.kafka.connect.integration.ConnectWorkerIntegrationTest.testSourceTaskNotBlockedOnShutdownWithNonExistentTopic

2021-05-24 Thread John Roesler (Jira)
John Roesler created KAFKA-12842: Summary: Failing test: org.apache.kafka.connect.integration.ConnectWorkerIntegrationTest.testSourceTaskNotBlockedOnShutdownWithNonExistentTopic Key: KAFKA-12842 URL:

[GitHub] [kafka] sasukerui opened a new pull request #10751: MINOR: update java doc for ConsumerCoordinator

2021-05-24 Thread GitBox
sasukerui opened a new pull request #10751: URL: https://github.com/apache/kafka/pull/10751 fix typo -- This is an automated message from the Apache Git Service. To respond to the message, please log on to GitHub and use the URL above to go to the specific comment. For queries about

[GitHub] [kafka] showuon commented on pull request #10552: KAFKA-12675: improve the sticky general assignor scalability and performance

2021-05-24 Thread GitBox
showuon commented on pull request #10552: URL: https://github.com/apache/kafka/pull/10552#issuecomment-847042383 @vahidhashemian , thanks for your comments. I've updated. Please take a look again. Thank you. -- This is an automated message from the Apache Git Service. To respond to the

[GitHub] [kafka] showuon commented on a change in pull request #10552: KAFKA-12675: improve the sticky general assignor scalability and performance

2021-05-24 Thread GitBox
showuon commented on a change in pull request #10552: URL: https://github.com/apache/kafka/pull/10552#discussion_r637943535 ## File path: clients/src/main/java/org/apache/kafka/clients/consumer/internals/AbstractStickyAssignor.java ## @@ -80,9 +80,7 @@ public MemberData(List

[GitHub] [kafka] showuon commented on a change in pull request #10552: KAFKA-12675: improve the sticky general assignor scalability and performance

2021-05-24 Thread GitBox
showuon commented on a change in pull request #10552: URL: https://github.com/apache/kafka/pull/10552#discussion_r637941574 ## File path: clients/src/test/java/org/apache/kafka/clients/consumer/internals/AbstractStickyAssignorTest.java ## @@ -598,6 +555,43 @@ public void

[GitHub] [kafka] showuon commented on a change in pull request #10552: KAFKA-12675: improve the sticky general assignor scalability and performance

2021-05-24 Thread GitBox
showuon commented on a change in pull request #10552: URL: https://github.com/apache/kafka/pull/10552#discussion_r637939950 ## File path: clients/src/main/java/org/apache/kafka/clients/consumer/internals/AbstractStickyAssignor.java ## @@ -384,37 +326,39 @@ private boolean

[GitHub] [kafka] showuon commented on a change in pull request #10552: KAFKA-12675: improve the sticky general assignor scalability and performance

2021-05-24 Thread GitBox
showuon commented on a change in pull request #10552: URL: https://github.com/apache/kafka/pull/10552#discussion_r637936879 ## File path: clients/src/main/java/org/apache/kafka/clients/consumer/internals/AbstractStickyAssignor.java ## @@ -444,23 +392,32 @@ private boolean

[jira] [Commented] (KAFKA-12333) KafkaMetadataLog and MockLock should validate that appended epochs are monotonically

2021-05-24 Thread loboxu (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12333?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350413#comment-17350413 ] loboxu commented on KAFKA-12333: [~jsancio] The problem seems to have been fixed, right? >

[GitHub] [kafka] fqaiser94 commented on a change in pull request #10747: KAFKA-12446: Define KGroupedTable#aggregate subtractor + adder order of execution

2021-05-24 Thread GitBox
fqaiser94 commented on a change in pull request #10747: URL: https://github.com/apache/kafka/pull/10747#discussion_r637657442 ## File path: streams/src/main/java/org/apache/kafka/streams/kstream/internals/ChangedSerializer.java ## @@ -45,34 +45,30 @@ public void

[GitHub] [kafka] fqaiser94 commented on a change in pull request #10747: KAFKA-12446: Define KGroupedTable#aggregate subtractor + adder order of execution

2021-05-24 Thread GitBox
fqaiser94 commented on a change in pull request #10747: URL: https://github.com/apache/kafka/pull/10747#discussion_r637657442 ## File path: streams/src/main/java/org/apache/kafka/streams/kstream/internals/ChangedSerializer.java ## @@ -45,34 +45,30 @@ public void

[GitHub] [kafka] fqaiser94 commented on a change in pull request #10747: KAFKA-12446: Define KGroupedTable#aggregate subtractor + adder order of execution

2021-05-24 Thread GitBox
fqaiser94 commented on a change in pull request #10747: URL: https://github.com/apache/kafka/pull/10747#discussion_r637657657 ## File path: streams/src/main/java/org/apache/kafka/streams/kstream/internals/KTableRepartitionMap.java ## @@ -90,14 +90,19 @@ public void

[GitHub] [kafka] ayoukhananov commented on pull request #10728: NPE from the provided metadata in client callback in case of ApiException.

2021-05-24 Thread GitBox
ayoukhananov commented on pull request #10728: URL: https://github.com/apache/kafka/pull/10728#issuecomment-846970648 @showuon Thanks for your feedback. 1. NPE happened in our Prod env . I miss the part of Jira ticket and added now this

[jira] [Created] (KAFKA-12841) NPE from the provided metadata in client callback in case of ApiException

2021-05-24 Thread Avi Youkhananov (Jira)
Avi Youkhananov created KAFKA-12841: --- Summary: NPE from the provided metadata in client callback in case of ApiException Key: KAFKA-12841 URL: https://issues.apache.org/jira/browse/KAFKA-12841

[GitHub] [kafka] fqaiser94 commented on a change in pull request #10747: KAFKA-12446: Define KGroupedTable#aggregate subtractor + adder order of execution

2021-05-24 Thread GitBox
fqaiser94 commented on a change in pull request #10747: URL: https://github.com/apache/kafka/pull/10747#discussion_r637657442 ## File path: streams/src/main/java/org/apache/kafka/streams/kstream/internals/ChangedSerializer.java ## @@ -45,34 +45,30 @@ public void

[GitHub] [kafka] DuongPTIT opened a new pull request #10750: KAFKA-8120 Getting NegativeArraySizeException when using Kafka Connect to send data to Kafka

2021-05-24 Thread GitBox
DuongPTIT opened a new pull request #10750: URL: https://github.com/apache/kafka/pull/10750 Getting NegativeArraySizeException when using Kafka Connect to send data to Kafka on Kafka version 2.5 PTAL @huxihx @kkonstantine . Many thanks. ### Committer Checklist (excluded from

[jira] [Created] (KAFKA-12840) Removing `compact` cleaning on a topic should abort on-going compactions

2021-05-24 Thread David Jacot (Jira)
David Jacot created KAFKA-12840: --- Summary: Removing `compact` cleaning on a topic should abort on-going compactions Key: KAFKA-12840 URL: https://issues.apache.org/jira/browse/KAFKA-12840 Project:

[jira] [Commented] (KAFKA-12835) Topic IDs can mismatch on brokers (after interbroker protocol version update)

2021-05-24 Thread Ivan Yurchenko (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12835?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350330#comment-17350330 ] Ivan Yurchenko commented on KAFKA-12835: bq. I was curious about your upgrade process. Is there

[jira] [Issue Comment Deleted] (KAFKA-8120) Getting NegativeArraySizeException when using Kafka Connect to send data to Kafka

2021-05-24 Thread Pham Huy Hoang (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-8120?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] Pham Huy Hoang updated KAFKA-8120: -- Comment: was deleted (was: Hi [~wj1918], I tried to test as your above steps. However, I got

[jira] [Assigned] (KAFKA-12461) Extend LogManager to cover the metadata topic

2021-05-24 Thread loboxu (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12461?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ] loboxu reassigned KAFKA-12461: -- Assignee: loboxu > Extend LogManager to cover the metadata topic >

[jira] [Commented] (KAFKA-8120) Getting NegativeArraySizeException when using Kafka Connect to send data to Kafka

2021-05-24 Thread Pham Huy Hoang (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-8120?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350289#comment-17350289 ] Pham Huy Hoang commented on KAFKA-8120: --- Hi [~wj1918], I tried to test as your above steps.

[jira] [Commented] (KAFKA-12805) Aborted send could have a different exception than DisconnectException

2021-05-24 Thread Luke Chen (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12805?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350279#comment-17350279 ] Luke Chen commented on KAFKA-12805: --- [~nicolas.guyomar], I tried to set the  

[jira] [Commented] (KAFKA-12773) Use UncheckedIOException when wrapping IOException

2021-05-24 Thread loboxu (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12773?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350274#comment-17350274 ] loboxu commented on KAFKA-12773: [~jagsancio]  Could you please tell me the name of your GitHub

[GitHub] [kafka] socutes opened a new pull request #10749: KAFKA-12773: Use UncheckedIOException when wrapping IOException

2021-05-24 Thread GitBox
socutes opened a new pull request #10749: URL: https://github.com/apache/kafka/pull/10749 The raft module may not be fully consistent on this but in general in that module we have decided to not throw the checked IOException. We have been avoiding checked IOException exceptions by

[jira] [Commented] (KAFKA-12534) kafka-configs does not work with ssl enabled kafka broker.

2021-05-24 Thread kaushik srinivas (Jira)
[ https://issues.apache.org/jira/browse/KAFKA-12534?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel=17350264#comment-17350264 ] kaushik srinivas commented on KAFKA-12534: -- Hi [~cricket007] To update more on this, the test