Skip to content

Instantly share code, notes, and snippets.

@amuraru
Created May 19, 2021 09:06
Show Gist options
  • Save amuraru/9eeea053884cd697ac94a2863eeb13ca to your computer and use it in GitHub Desktop.
Save amuraru/9eeea053884cd697ac94a2863eeb13ca to your computer and use it in GitHub Desktop.
  • MINOR: Fix null exception in coordinator log (#10250)
  • KAFKA-12339: Add retry to admin client's listOffsets (#10152)
  • KAFKA-12321 the comparison function for uuid type should be 'equals' rather than '==' (#10098)
  • KAFKA-12193: Re-resolve IPs after a client disconnects (#9902) (#10061)
  • KAFKA-10793: move handling of FindCoordinatorFuture to fix race condition (#9671)
  • KAFKA-10798; Ensure response is delayed for failed SASL authentication with connection close delay (#9678)
  • MINOR: Do not print log4j for memberId required (#9667)
  • KAFKA-10134 Follow-up: Set the re-join flag in heartbeat failure (#9354)
  • MINOR: Fix now that kafka.apache.org resolves to 3 IP addresses (#9294)
  • KAFKA-10134: Enable heartbeat during PrepareRebalance and Depend On State For Poll Timeout (#8834)
  • Revert KAFKA-9309: Add the ability to translate Message to JSON (#9197)
  • MINOR: Fix deprecation version for NotLeaderForPartitionException (#9056)
  • KAFKA-10223; Use NOT_LEADER_OR_FOLLOWER instead of non-retriable REPLICA_NOT_AVAILABLE for consumers (#8979)
  • MINOR: Filter out quota configs for ConfigCommand using --bootstrap-server (#9030)
  • KAFKA-10134: Use long poll if we do not have fetchable partitions (#8934)
  • KAFKA-10239: Make GroupInstanceId ignorable in DescribeGroups (#8989)
  • KAFKA-10212: Describing a topic with the TopicCommand fails if unauthorised to use ListPartitionReassignments API
  • KAFKA-10173: Fix suppress changelog binary schema compatibility (#8905)
  • KAFKA-10113; Specify fetch offsets correctly in LogTruncationException (#8822)
  • KAFKA-10167: use the admin client to read end-offset (#8876)
  • KAFKA-10123; Fix incorrect value for AWAIT_RESET#hasPosition (#8841)
  • MINOR: reuse toConfigObject(Map) to generate Config (#8889)
  • KAFKA-10147 MockAdminClient#describeConfigs(Collection) is unable to handle broker resource (#8853)
  • KAFKA-10169: Error message when transit to Aborting / AbortableError / FatalError (#8880)
  • MINOR: Documentation for KIP-585 (#8839)
  • MINOR: reduce sizeInBytes for percentiles metrics (#8835)
  • KAFKA-9216: Enforce that Connect's internal topics use compact cleanup policy (#8828)
  • KAFKA-9848: Avoid triggering scheduled rebalance delay when task assignment fails but Connect workers remain in the group (#8805)
  • KAFKA-10012; Reduce overhead of strings in SelectorMetrics (#8684)
  • KAFKA-9840; Skip End Offset validation when the leader epoch is not reliable (#8486)
  • KAFKA-10110: Corrected potential NPE when null label value added to KafkaMetricsContext (#8811)
  • MINOR: fix backwards incompatibility in JmxReporter introduced by KIP-606
  • KAFKA-9313: Set use_all_dns_ips as the new default for client.dns.lookup (KIP-602) (#8644)
  • KAFKA-10089 The stale ssl engine factory is not closed after reconfigure (#8792)
  • KAFKA-10083: fix failed testReassignmentWithRandomSubscriptionsAndChanges tests (#8786)
  • KAFKA-9320: Enable TLSv1.3 by default (KIP-573) (#8695)
  • KAFKA-10082: Fix the failed testMultiConsumerStickyAssignment (#8777)
  • MINOR: Remove unused variable to fix spotBugs failure (#8779)
  • MINOR: ChangelogReader should poll for duration 0 for standby restore (#8773)
  • KAFKA-9987: optimize sticky assignment algorithm for same-subscription case (#8668)
  • KAFKA-9392; Clarify deleteAcls javadoc and add test for create/delete timing (#7956)
  • KAFKA-9494; Include additional metadata information in DescribeConfig response (KIP-569) (#8723)
  • KAFKA-10056; Ensure consumer metadata contains new topics on subscription change (#8739)
  • KAFKA-10029; Don't update completedReceives when channels are closed to avoid ConcurrentModificationException (#8705)
  • KAFKA-9130; KIP-518 Allow listing consumer groups per state (#8238)
  • MINOR: Relax Percentiles test (#8748)
  • KAFKA-9673: Filter and Conditional SMTs (#8699)
  • KAFKA-9146: Add option to force delete active members in StreamsResetter (#8589)
  • KAFKA-9960: implement KIP-606 to add metadata context to MetricsReporter (#8691)
  • KAFKA-9983: KIP-613: add INFO level e2e latency metrics (#8697)
  • KAFKA-9724 Newer clients not always sending fetch request to older brokers (#8376)
  • KAFKA-6145: KIP-441: Fix assignor config passthough (#8716)
  • KAFKA-9931: Implement KIP-605 to expand support for Connect worker internal topic configurations (#8654)
  • MINOR: Fix join group request timeout lower bound (#8702)
  • KAFKA-9855 - return cached Structs for Schemas with no fields (#8472)
  • MINOR: Fix redundant typos in comments and javadocs (#8693)
  • KAFKA-9955: Prevent SinkTask::close from shadowing other exceptions (#8618)
  • KAFKA-9984 Should fail the subscription when pattern is empty (#8665)
  • KAFKA-9650: include human readable units in ms and bytes configs (#8222)
  • KAFKA-6145: KIP-441: Improve assignment balance (#8588)
  • MINOR: Add a duplicate() method to Message classes (#8556)
  • KAFKA-9669; Loosen validation of inner offsets for older message formats (#8647)
  • MINOR: Use forEach and ifPresent to simplify Scala code (#8642)
  • MINOR: Log4j Improvements on Fetcher (#8629)
  • KAFKA-9419: Fix possible integer overflow in CircularIterator (#7950)
  • MINOR: MockAdminClient should return InvalidReplicationFactorException if brokers.size < replicationFactor
  • KAFKA-9731: Disable immediate fetch response for hw propagation if replica selector is not defined (#8607)
  • KAFKA-9918; SslEngineFactory is NOT closed when channel is closing (#8551)
  • MINOR: Annotate KafkaAdminClientTest.testAlterClientQuotas() with @Test
  • MINOR: Use min/max function when possible (#8577)
  • MINOR: Improve Sensor recording efficiency (#8593)
  • MINOR: Fix typo "transation" in AddPartitionsToTxnRequest.json (#8557)
  • KAFKA-9633: Ensure ConfigProviders are closed (#8204)
  • MINOR: Fix unused arguments used in formatted string and log messages (#8036)
  • KAFKA-9652: Fix throttle metric in RequestChannel and request log due to KIP-219 (#8567)
  • KAFKA-9823: Follow-up, check state for handling commit error response (#8548)
  • KAFKA-6145: KIP-441: Add TaskAssignor class config (#8541)
  • MINOR: Improve producer test BufferPoolTest#testCloseNotifyWaiters. (#7982)
  • KAKFA-9612: Add an option to kafka-configs.sh to add configs from a prop file (KIP-574)
  • KAFKA-9704: Fix the issue z/OS won't let us resize file when mmap. (#8224)
  • KAFKA-8639: Replace AddPartitionsToTxn with Automated Protocol (#8326)
  • MINOR: equals() should compare all fields for generated classes (#8539)
  • KAFKA-9823: Remember the sent generation for the coordinator request (#8445)
  • KAFKA-9852: Change the max duration that calls to the buffer pool can block from 2000ms to 10ms to reduce overall test runtime (#8464)
  • KAFKA-8955: Add an AbstractResponse#errorCounts(Stream) and tidy (#8417)
  • MINOR: Fix grammar in error message for InvalidRecordException (#8465)
  • KAFKA-6145: KIP-441: Add test scenarios to ensure rebalance convergence (#8475)
  • KAFKA-9854 Re-authenticating causes mismatched parse of response (#8471)
  • KAFKA-9703; Free up compression buffer after splitting a large batch
  • KAFKA-9864: Avoid expensive QuotaViolationException usage (#8477)
  • MINOR: avoid autoboxing in FetchRequest.PartitionData.equals
  • KAFKA-9539; Add leader epoch in StopReplicaRequest (KIP-570) (#8257)
  • KAFKA-9842; Add test case for OffsetsForLeaderEpoch grouping in Fetcher (#8457)
  • KAFKA-8436: use automated protocol for AddOffsetsToTxn (#7015)
  • KAFKA-3720: Change TimeoutException to BufferExhaustedException when no memory can be allocated for a record within max.block.ms (#8399)
  • MINOR: Allow a single struct to be a field in the protocol spec (#8413)
  • KAFKA-9309: Add the ability to translate Message classes to and from JSON (#7844)
  • KAFKA-9433: Use automated protocol for AlterConfigs request and response (#8315)
  • KAFKA-9583; Use topic-partitions grouped by node to send OffsetsForLeaderEpoch requests (#8077)
  • KAFKA-9835; Protect FileRecords.slice from concurrent write (#8451)
  • KAFKA-8890: Make SSL context/engine configuration extensible (KIP-519) (#8338)
  • KAFKA-9801: Still trigger rebalance when static member joins in CompletingRebalance phase (#8405)
  • KAFKA-9815; Ensure consumer always re-joins if JoinGroup fails (#8420)
  • MINOR: Remove redundant braces from log message in FetchSessionHandler (#8410)
  • KAFKA-9776: Downgrade TxnCommit API v3 when broker doesn't support (#8375)
  • KAFKA-9233: Fix IllegalStateException in Fetcher retrieval of beginning or end offsets for duplicate TopicPartition values (#7755)
  • MINOR: Fix Scala 2.13 compiler warnings (#8390)
  • MINOR: more logs for empty assignment (#8397)
  • MINOR: Fix MockAdminClient to not throw IndexOutOfBoundsException when brokerId is above the known one. (#8392)
  • MINOR: Add missing @Override annotation and simplify Thread declarations with lambdas (#8363)
  • MINOR: Don't process sasl.kerberos.principal.to.local.rules on client-side (#8362)
  • KAFKA-9373: Reduce shutdown time by avoiding unnecessary loading of indexes (#8346)
  • MINOR: Add synchronization to the protocol name check (#8349)
  • MINOR: Allow topics with null leader on MockAdminClient createTopic. (#8345)
  • KAFKA-9700: Fix negative estimatedCompressionRatio (#8285)
  • KAFKA-9711 The authentication failure caused by SSLEngine#beginHandshake is not properly caught and handled (#8287)
  • KAFKA-9651: Fix ArithmeticException (÷ by 0) in DefaultStreamPartitioner (#8226)
  • KAFKA-9634: Add note about thread safety in the ConfigProvider interface (#8205)
  • MINOR: fix linking errors in javadoc (#8198)
  • KAFKA-6145: Pt 2.5 Compute overall task lag per client (#8252)
  • KAFKA-9741: Update ConsumerGroupMetadata before calling onPartitionsRevoked() (#8325)
  • KAFKA-9701 (fix): Only check protocol name when generation is valid (#8324)
  • KAFKA-8820: kafka-reassign-partitions.sh should support the KIP-455 API (#8244)
  • KAFKA-9435: DescribeLogDirs automated protocol (#7972)
  • MINOR: return unmodifiableMap for PartitionStates.partitionStateMap. (#7637)
  • KAFKA-8618: Replace Txn marker with automated protocol (#7039)
  • KAFKA-9047; AdminClient group operations should respect retries and backoff (#8161)
  • KAFKA-9404: Use ArrayList instead of LinkedList in Sensor (#7936)
  • MINOR: Fix build and JavaDoc warnings (#8291)
  • KAFKA-9670; Reduce allocations in Metadata Response preparation (#8236)
  • MINOR: fix Scala 2.13 build error introduced in #8083 (#8301)
  • MINOR: Fix typo in CreateTopicsResponse.json (#8300)
  • KIP-546: Implement describeClientQuotas and alterClientQuotas. (#8083)
  • KAFKA-6647: Do note delete the lock file while holding the lock (#8267)
  • KAFKA-8768: DeleteRecords request/response automated protocol (#7957)
  • KAFKA-9657: Throw upon offset fetch unsupported stable flag protocol (#8265)
  • KAFKA-9644: Handle non-existent configs in incrementalAlterConfigs APPEND/SUBTRACT
  • KAFKA-9701: Add more debug log on client to reproduce the issue (#8272)
  • KAFKA-9605; Do not attempt to abort batches when txn manager is in fatal error (#8177)
  • KAFKA-9451: Update MockConsumer to support ConsumerGroupMetadata
  • KAFKA-9344: Override default values inside ConsumerConfigs (#7876)
  • KAFKA-9686: MockConsumer#endOffsets should be idempotent (#8255)
  • MINOR: Remove throttling logic from RecordAccumulator (#7195)
  • KAFKA-9645: Fallback to unsubscribe during Task Migrated (#8220)
  • KAFKA-9525: add enforceRebalance method to Consumer API (#8087)
  • KAFKA-9620: Do not throw in the middle of consumer user callbacks (#8187)
  • HOTFIX: testInitTransactionTimeout should use prepareResponse instead of respond (#8179)
  • MINOR: Consistent terminal period in Errors.defaultExceptionMessage (#3909)
  • KAFKA-9530; Fix flaky test testDescribeGroupWithShortInitializationTimeout (#8154)
  • KAFKA-9577; SaslClientAuthenticator incorrectly negotiates SASL_HANDSHAKE version (#8142)
  • KAFKA-9441: Add internal TransactionManager (#8105)
  • KAFKA-9206; Throw KafkaException on CORRUPT_MESSAGE error in Fetch response (#8111)
  • KAFKA-9481: Graceful handling TaskMigrated and TaskCorrupted (#8058)
  • MINOR: Fix a number of warnings in clients test (#8073)
  • MINOR: Add missing @Test annotation to MetadataTest#testMetadataMerge (#8141)
  • KAFKA-9544; Fix flaky test AdminClientTest.testDefaultApiTimeoutOverride (#8101)
  • KAFKA-9558; Fix retry logic in KafkaAdminClient listOffsets (#8119)
  • MINOR: Reduce log level to Trace for fetch offset downgrade (#8093)
  • KAFKA-9535; Update metadata before retrying partitions when fetching offsets (#8088)
  • KAFKA-8805; Bump producer epoch on recoverable errors (#7389)
  • KAFKA-9274: Gracefully handle timeout exception (#8060)
  • KAFKA-9106 make metrics exposed via jmx configurable (#7674)
  • MINOR: Do not override retries for idempotent producers (#8097)
  • KAFKA-9417: New Integration Test for KIP-447 (#8000)
  • KAFKA-6607: Commit correct offsets for transactional input data (#8091)
  • MINOR: Fix unnecessary metadata fetch before group assignment (#8095)
  • KAFKA-9505: Only loop over topics-to-validate in retries (#8039)
  • MINOR: Update schema field names in DescribeAcls Request/Response
  • KAFKA-9423: Refine layout of configuration options on website and make individual settings directly linkable (#7955)
  • KAFKA-8904: Improve producer's topic metadata fetching. (#7781)
  • KAFKA-8843: KIP-515: Zookeeper TLS support
  • MINOR: Simplify KafkaProducerTest (#8044)
  • KAFKA-9507; AdminClient should check for missing committed offsets (#8057)
  • DOCS - clarify transactionalID and idempotent behavior (#7821)
  • KAFKA-9447: Add new customized EOS model example (#8031)
  • KAFKA-9261; Client should handle unavailable leader metadata (#7770)
  • MINOR: Fix typos introduced in KIP-559 (#8042)
  • KAFKA-9113: Clean up task management and state management (#7997)
  • MINOR: fix checkstyle issue in ConsumerConfig.java (#8038)
  • KAFKA-9477 Document RoundRobinAssignor as an option for partition.assignment.strategy (#8007)
  • KAFKA-9492; Ignore record errors in ProduceResponse for older versions (#8030)
  • KAFKA-9027, KAFKA-9028: Convert create/delete acls requests/response to use generated protocol (#7725)
  • KAFKA-9437; Make the Kafka Protocol Friendlier with L7 Proxies [KIP-559] (#7994)
  • KAFKA-9375: Add names to all Connect threads (#7901)
  • KAFKA-8503; Add default api timeout to AdminClient (KIP-533) (#8011)
  • KAFKA-8162: IBM JDK Class not found error when handling SASL (#6524)
  • KAFKA-9474: Adds 'float64' to the RPC protocol types (#8012)
  • KAFKA-4203: Align broker default for max.message.bytes with Java producer default (#4154)
  • KAFKA-9426: Use switch instead of chained if/else in OffsetsForLeaderEpochClient (#7959)
  • KAFKA-9405: Use Map.computeIfAbsent where applicable (#7937)
  • KAFKA-9026: Use automatic RPC generation in DescribeAcls (#7560)
  • KAFKA-9460: Enable only TLSv1.2 by default and disable other TLS protocol versions (KIP-553) (#7998)
  • MINOR: MiniKdc JVM shutdown hook fix (#7946)
  • KAFKA-9181; Maintain clean separation between local and group subscriptions in consumer's SubscriptionState (#7941)
  • KAFKA-7737; Use single path in producer for initializing the producerId (#7920)
  • KAFKA-9418; Add new sendOffsetsToTransaction API to KafkaProducer (#7952)
  • KAFKA-7204: Avoid clearing records for paused partitions on poll of MockConsumer (#7505)
  • KAFKA-9457; Fix flaky test org.apache.kafka.common.network.SelectorTest.testGracefulClose (#7989)
  • KAFKA-9449; Adds support for closing the producer's BufferPool. (#7967)
  • KAFKA-9218: MirrorMaker 2 can fail to create topics (#7745)
  • KAFKA-8847; Deprecate and remove usage of supporting classes in kafka.security.auth (#7966)
  • [MINOR]: Fix typo in Fetcher comment (#7934)
  • MINOR: Remove unnecessary call to super in MetricConfig constructor (#7975)
  • KAFKA-9410; Make groupId Optional in KafkaConsumer (#7943)
  • KAFKA-9365: Add server side change to include consumer group information within transaction commit (#7897)
  • KAFKA-9420; Add flexible version support for converted protocols (#7931)
  • KAFKA-9346: Consumer back-off logic when fetching pending offsets (#7878)
  • KAFKA-9159: The caller of sendListOffsetRequest need to handle retriable InvalidMetadata (#7665)
  • KAFKA-7639: Read one request at a time from socket to avoid OOM (#5920)
  • KAFKA-8617: Use automated protocol for EndTxn API (#7029)
  • KAFKA-8421: Still return data during rebalance (#7312)
  • KAFKA-9144; Track timestamp from txn markers to prevent early producer expiration (#7687)
  • KAFKA-9287; Fix unneeded delay before failing pending transaction commit (#7799)
  • KAFKA-9383: Expose consumer group metadata (#7906)
  • MINOR: Link to related class in the Admin alterPartitionReassignments documentation (#7912)
  • MINOR: Update dependencies for Kafka 2.5 (#7909)
  • KAFKA-8988; Replace CreatePartitions Request/Response with automated protocol (#7493)
  • KAFKA-9330: Skip join when AdminClient.close is called in callback thread (#7866)
  • MINOR: Propagate LogContext to channel builders and SASL authenticator (#7867)
  • KAFKA-9324: Drop support for Scala 2.11 (KIP-531) (#7859)
  • KAFKA-9364: Fix misleading consumer logs on throttling (#7894)
  • KAFKA-8928: Logged producer config does not always match actual configured values (#7466)
  • KIP-543: Expand ConfigCommand's non-ZK functionality (#7780)
  • KAFKA-9306: The consumer must close KafkaConsumerMetrics (#7839)
  • KAFKA-7251; Add support for TLS 1.3 (#7804)
  • MINOR: trivial cleanups
  • MINOR; Refactor KafkaAdminClientTest to reduce the boilerplate code (#7842)
  • KAFKA-9297: CreateTopics API does not work with older version of the request/response (#7829)
  • KAFKA-8855; Collect and Expose Client's Name and Version in the Brokers (KIP-511 Part 2) (#7749)
  • KAFKA-7588: Pass custom configs to the ChannelBuilder implementations (#1037) (#7794)
  • KAFKA-7925 - Create credentials only once for sun.security.jgss.native (#6337)
  • KAFKA-9288: Do not allow the same object to be inserted multiple times into ImplicitLinkedHashCollection (#7809)
  • KAFKA-9241: Some SASL Clients not forced to re-authenticate (#7784)
  • KAFKA-9212; Ensure LeaderAndIsr state updated in controller context during reassignment (#7795)
  • KAFKA-9091: Add a metric tracking the number of open connections with a given SSL cipher type (#7588)
  • KAFKA-9131: Remove dead code for handling timeout exception (#7635)
  • KAFKA-9251; Describing a non consumer group with the Admin API hangs forever (#7763)
  • KAFKA-8933; Fix NPE in DefaultMetadataUpdater after authentication failure (#7682)
  • KAFKA-9190; Close connections with expired authentication sessions (#7723)
  • KAFKA-9203: Revert "MINOR: Remove workarounds for lz4-java bug affecting byte buffers (#6679)" (#7769)
  • MINOR: Proactively update producer topic access time. (#7672)
  • MINoR: Replace '>' in RoundRobinAssignor.java into '>' (#7073)
  • MINOR: Improve Admin interface Documentation
  • KAFKA-9229: Fix incompatible change in InitProducerIdRequest (#7746)
  • MINOR: Add ignorable field check to toStruct and fix usage (#7710)
  • MINOR: Add validation in MockAdminClient for replication factor (#7712)
  • KAFKA-8986: Allow null as a valid default for tagged fields. (#7585)
  • HOTFIX: safely clear all active state in onPartitionsLost (#7691)
  • MINOR: Remove explicit version checks in getErrorResponse methods (#7708)
  • MINOR: Small logging fixes in AbstractCoordinator (#7230)
  • KAFKA-9200: ListOffsetRequest missing error response for v5 (#7704)
  • MINOR. Replace Utils::readFileAsString method to read file as stream (#7208)
  • MINOR: Clarify max.request.size and max.messsage.bytes wrt compression (#7575)
  • MINOR: Add method hasMetrics() to class Sensor (#7692)
  • KAFKA-8710; Allow transactional producers to bump producer epoch [KIP-360] (#7115)
  • MINOR. Update Epoch field descrition in FetchRequest api doc (#7673)
  • KAFKA-8984: Improve tagged fields documentation
  • KAFKA-8677: Simplify the best-effort network client poll to never throw exception (#7613)
  • MINOR: Return null in key mapping of committed (#7659)
  • MINOR: Fix version range check in MessageTest (#7663)
  • KAFKA-9140: Also reset join future when generation was reset in order to re-join (#7647)
  • HOTFIX: remove reference to unused Assignment error code (#7645)
  • MINOR: Rework NewPartitionReassignment public API (#7638)
  • KAFKA-9110: Improve efficiency of disk reads when TLS is enabled (#7604)
  • HOTFIX: Try to complete Send even if no bytes were written (#7622)
  • KAFKA-8972 (2.4 blocker): TaskManager state should always be updated after rebalance (#7620)
  • MINOR: Replace some Java 7 style code with Java 8 style (#7623)
  • KAFKA-8868: Generate SubscriptionInfo protocol message (#7248)
  • KAFKA-9093: NullPointerException in KafkaConsumer with group.instance.id (#7590)
  • KAFKA-8972 (2.4 blocker): correctly release lost partitions during consumer.unsubscribe() (#7441)
  • KAFKA-9048 Pt1: Remove Unnecessary lookup in Fetch Building (#7576)
  • KAFKA-8992; Redefine RemoveMembersFromGroup interface on AdminClient (#7478)
  • MINOR: Re-implement NewPartitionReassignment#of() (#7592)
  • KAFKA-8700: Flaky Test QueryableStateIntegrationTest#queryOnRebalance (#7548)
  • KAFKA-8584: The RPC code generator should support ByteBuffer. (#7342)
  • KAFKA-9056; Inbound/outbound byte metrics should reflect incomplete sends/receives (#7551)
  • MINOR: Add toString to PartitionReassignment (#7579)
  • MINOR: Rename brokers to replicas in the reassignment API (#7570)
  • KAFKA-8943: Move SecurityProviderCreator to org.apache.kafka.common.security.auth package (#7564)
  • KAFKA-8482: Improve documentation on AdminClient#alterReplicaLogDirs, AlterReplicaLogDirsResult (#7083)
  • KAFKA-7689; Add AlterConsumerGroup/List Offsets to AdminClient [KIP-396] (#7296)
  • KAFKA-8455: Add VoidSerde to Serdes (#7485)
  • KAFKA-8962; Use least loaded node for AdminClient#describeTopics (#7421)
  • MINOR: AbstractRequestResponse should be an interface (#7513)
  • KAKFA-8950: Fix KafkaConsumer Fetcher breaking on concurrent disconnect (#7511)
  • KAFKA-8874: Add consumer metrics to observe user poll behavior (KIP-517)
  • KAFKA-8104: Consumer cannot rejoin to the group after rebalancing (#7460)
  • KAFKA-9039: Optimize ReplicaFetcher fetch path (#7443)
  • MINOR: Provide better messages when waiting for a condition in test (#7488)
  • KAFKA-9033; Use consumer/producer identity in generated clientId (#7514)
  • MINOR: move "Added/Removed sensor" log messages to TRACE (#7502)
  • KAFKA-9029: Flaky Test CooperativeStickyAssignorTest.testReassignmentWithRand: bump to 4 (#7503)
  • KAFKA-8729, pt 3: Add broker-side logic to handle the case when there are record_errors and error_message (#7167)
  • MINOR: fix compatibility-breaking bug in RequestHeader (#7479)
  • MINOR: Augment log4j to add generation number in performAssign (#7451)
  • KAFKA-8932; Add tag for CreateTopicsResponse.TopicConfigErrorCode (KIP-525) (#7464)
  • KAFKA-8983; AdminClient deleteRecords should not fail all partitions unnecessarily (#7449)
  • KAFKA-8179: Part 7, cooperative rebalancing in Streams (#7386)
  • KAFKA-8985; Add flexible version support to inter-broker APIs (#7453)
Sign up for free to join this conversation on GitHub. Already have an account? Sign in to comment