You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@kafka.apache.org by cm...@apache.org on 2020/08/04 22:01:33 UTC

svn commit: r40857 [1/10] - in /release/kafka/2.6.0: ./ javadoc/ javadoc/org/

Author: cmccabe
Date: Tue Aug  4 22:01:33 2020
New Revision: 40857

Log:
Apache Kafka 2.6.0

Added:
    release/kafka/2.6.0/
    release/kafka/2.6.0/RELEASE_NOTES.html
    release/kafka/2.6.0/RELEASE_NOTES.html.asc
    release/kafka/2.6.0/RELEASE_NOTES.html.md5
    release/kafka/2.6.0/RELEASE_NOTES.html.sha1
    release/kafka/2.6.0/RELEASE_NOTES.html.sha512
    release/kafka/2.6.0/javadoc/
    release/kafka/2.6.0/javadoc/allclasses-frame.html
    release/kafka/2.6.0/javadoc/allclasses-noframe.html
    release/kafka/2.6.0/javadoc/constant-values.html
    release/kafka/2.6.0/javadoc/deprecated-list.html
    release/kafka/2.6.0/javadoc/help-doc.html
    release/kafka/2.6.0/javadoc/index-all.html
    release/kafka/2.6.0/javadoc/index.html
    release/kafka/2.6.0/javadoc/org/
    release/kafka/2.6.0/javadoc/org/index.html
    release/kafka/2.6.0/javadoc/overview-frame.html
    release/kafka/2.6.0/javadoc/overview-summary.html
    release/kafka/2.6.0/javadoc/overview-tree.html
    release/kafka/2.6.0/javadoc/package-list
    release/kafka/2.6.0/javadoc/script.js
    release/kafka/2.6.0/javadoc/serialized-form.html
    release/kafka/2.6.0/javadoc/stylesheet.css
    release/kafka/2.6.0/kafka-2.6.0-src.tgz   (with props)
    release/kafka/2.6.0/kafka-2.6.0-src.tgz.asc
    release/kafka/2.6.0/kafka-2.6.0-src.tgz.md5
    release/kafka/2.6.0/kafka-2.6.0-src.tgz.sha1
    release/kafka/2.6.0/kafka-2.6.0-src.tgz.sha512
    release/kafka/2.6.0/kafka_2.12-2.6.0-site-docs.tgz   (with props)
    release/kafka/2.6.0/kafka_2.12-2.6.0-site-docs.tgz.asc
    release/kafka/2.6.0/kafka_2.12-2.6.0-site-docs.tgz.md5
    release/kafka/2.6.0/kafka_2.12-2.6.0-site-docs.tgz.sha1
    release/kafka/2.6.0/kafka_2.12-2.6.0-site-docs.tgz.sha512
    release/kafka/2.6.0/kafka_2.12-2.6.0.tgz   (with props)
    release/kafka/2.6.0/kafka_2.12-2.6.0.tgz.asc
    release/kafka/2.6.0/kafka_2.12-2.6.0.tgz.md5
    release/kafka/2.6.0/kafka_2.12-2.6.0.tgz.sha1
    release/kafka/2.6.0/kafka_2.12-2.6.0.tgz.sha512
    release/kafka/2.6.0/kafka_2.13-2.6.0-site-docs.tgz   (with props)
    release/kafka/2.6.0/kafka_2.13-2.6.0-site-docs.tgz.asc
    release/kafka/2.6.0/kafka_2.13-2.6.0-site-docs.tgz.md5
    release/kafka/2.6.0/kafka_2.13-2.6.0-site-docs.tgz.sha1
    release/kafka/2.6.0/kafka_2.13-2.6.0-site-docs.tgz.sha512
    release/kafka/2.6.0/kafka_2.13-2.6.0.tgz   (with props)
    release/kafka/2.6.0/kafka_2.13-2.6.0.tgz.asc
    release/kafka/2.6.0/kafka_2.13-2.6.0.tgz.md5
    release/kafka/2.6.0/kafka_2.13-2.6.0.tgz.sha1
    release/kafka/2.6.0/kafka_2.13-2.6.0.tgz.sha512

Added: release/kafka/2.6.0/RELEASE_NOTES.html
==============================================================================
--- release/kafka/2.6.0/RELEASE_NOTES.html (added)
+++ release/kafka/2.6.0/RELEASE_NOTES.html Tue Aug  4 22:01:33 2020
@@ -0,0 +1,315 @@
+<h1>Release Notes - Kafka - Version 2.6.0</h1>
+<p>Below is a summary of the JIRA issues addressed in the 2.6.0 release of Kafka. For full documentation of the
+    release, a guide to get started, and information about the project, see the <a href="https://kafka.apache.org/">Kafka
+    project site</a>.</p>
+
+    <p><b>Note about upgrades:</b> Please carefully review the
+    <a href="https://kafka.apache.org/26/documentation.html#upgrade">upgrade documentation</a> for this release thoroughly
+    before upgrading your cluster. The upgrade notes discuss any critical information about incompatibilities and breaking
+    changes, performance changes, and any other changes that might impact your production deployment of Kafka.</p>
+
+    <p>The documentation for the most recent release can be found at
+    <a href="https://kafka.apache.org/documentation.html">https://kafka.apache.org/documentation.html</a>.</p>
+<h2>New Feature</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-6145">KAFKA-6145</a>] - Warm up new KS instances before migrating tasks - potentially a two phase rebalance</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8611">KAFKA-8611</a>] - Add KStream#repartition operation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8890">KAFKA-8890</a>] - KIP-519: Make SSL context/engine configuration extensible</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9320">KAFKA-9320</a>] - Enable TLSv1.3 by default and disable some of the older protocols</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9673">KAFKA-9673</a>] - Conditionally apply SMTs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9753">KAFKA-9753</a>] - Add task-level active-process-ratio to Streams metrics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9756">KAFKA-9756</a>] - Refactor the main loop to process more than one record of one task at a time</li>
+</ul>
+<h2>Improvement</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-4794">KAFKA-4794</a>] - Add access to OffsetStorageReader from SourceConnector</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-5295">KAFKA-5295</a>] - Allow Kafka Connect source connectors to specify topic-specific settings for new topics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-6037">KAFKA-6037</a>] - Make Sub-topology Parallelism Tunable</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-6453">KAFKA-6453</a>] - Document timestamp propagation semantics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-6508">KAFKA-6508</a>] - Look into optimizing StreamPartitionAssignor StandbyTask Assignment</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-6755">KAFKA-6755</a>] - MaskField SMT should optionally take a literal value to use instead of using null</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-7523">KAFKA-7523</a>] - TransformerSupplier/ProcessorSupplier enhancements</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-7740">KAFKA-7740</a>] - Kafka Admin Client should be able to manage user/client configurations for users and clients</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8147">KAFKA-8147</a>] - Add changelog topic configuration to KTable suppress</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8164">KAFKA-8164</a>] - Improve test passing rate by rerunning flaky tests</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8470">KAFKA-8470</a>] - State change logs should not be in TRACE level</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8938">KAFKA-8938</a>] - Connect - Improve Memory Allocations During Struct Validation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9112">KAFKA-9112</a>] - Combine streams `onAssignment` with `partitionsAssigned` task creation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9113">KAFKA-9113</a>] - Clean up task management</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9127">KAFKA-9127</a>] - Needless group coordination overhead for GlobalKTables</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9130">KAFKA-9130</a>] - Allow listing consumer groups per state</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9132">KAFKA-9132</a>] - Refactor StreamThread to take advantage of new ConsumerRebalanceListener exception handling</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9146">KAFKA-9146</a>] - Add option to force delete members in stream reset tool</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9177">KAFKA-9177</a>] - Pause completed partitions on restore consumer</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9216">KAFKA-9216</a>] - Enforce connect internal topic configuration at startup</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9290">KAFKA-9290</a>] - Update IQ related JavaDocs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9292">KAFKA-9292</a>] - KIP-551: Expose disk read and write metrics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9309">KAFKA-9309</a>] - Add the ability to translate Message classes to and from JSON</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9313">KAFKA-9313</a>] - Set default for client.dns.lookup to use_all_dns_ips</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9327">KAFKA-9327</a>] - GroupMetadata metrics are not documented</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9353">KAFKA-9353</a>] - Add groupInstanceId to DescribeGroup for better visibility</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9404">KAFKA-9404</a>] - Use ArrayList instead of LinkedList in Sensor Class</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9407">KAFKA-9407</a>] - Return Immutable List from SchemaSourceTask</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9409">KAFKA-9409</a>] - Increase Immutability of ClusterConfigState</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9419">KAFKA-9419</a>] - Integer Overflow Possible with CircularIterator</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9423">KAFKA-9423</a>] - Refine layout of configuration options on website and make individual settings directly linkable</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9468">KAFKA-9468</a>] - config.storage.topic partition count issue is hard to debug</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9481">KAFKA-9481</a>] - Improve TaskMigratedException handling on Stream thread</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9494">KAFKA-9494</a>] - Include data type of the config in ConfigEntry</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9525">KAFKA-9525</a>] - Allow explicit rebalance triggering on the Consumer</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9539">KAFKA-9539</a>] - Add leader epoch in StopReplicaRequest</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9561">KAFKA-9561</a>] - Update task input partitions when topic metadata changes</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9573">KAFKA-9573</a>] - TestUpgrade system test failed on Java11.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9594">KAFKA-9594</a>] - speed up the processing of LeaderAndIsrRequest</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9612">KAFKA-9612</a>] - CLI Dynamic Configuration with file input</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9626">KAFKA-9626</a>] - Benchmark and optimize AclAuthorizer.acls() </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9650">KAFKA-9650</a>] - Include human readable quantities for default config docs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9685">KAFKA-9685</a>] - Solve Set concatenation perf issue in AclAuthorizer</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9720">KAFKA-9720</a>] - Update gradle to 6.0+ </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9729">KAFKA-9729</a>] - Shrink inWriteLock time in SimpleAuthorizer</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9731">KAFKA-9731</a>] - Increased fetch request rate with leader selector due to HW propagation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9767">KAFKA-9767</a>] - Basic auth extension should have logging</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9779">KAFKA-9779</a>] - Add version 2.5 to streams system tests</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9780">KAFKA-9780</a>] - Deprecate commit records without record metadata</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9838">KAFKA-9838</a>] - Add additional log concurrency test cases</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9850">KAFKA-9850</a>] - Move KStream#repartition operator validation during Topology build process </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9853">KAFKA-9853</a>] - Improve performance of Log.fetchOffsetByTimestamp()</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9864">KAFKA-9864</a>] - Avoid expensive QuotaViolationException usage</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9865">KAFKA-9865</a>] - Expose output topic names from TopologyTestDriver</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9866">KAFKA-9866</a>] - Do not attempt to elect preferred leader replicas which are outside ISR</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9894">KAFKA-9894</a>] - Support Java 14</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9907">KAFKA-9907</a>] - Switch default build to Scala 2.13</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9919">KAFKA-9919</a>] - Add logging to KafkaBasedLog</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9931">KAFKA-9931</a>] - Kafka Connect should accept '-1' as a valid replication factor</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9932">KAFKA-9932</a>] - First LeaderAndIsrRequest can take long due to unnecessary ZK read</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9944">KAFKA-9944</a>] - Allow HTTP Response Headers to be Configured for Kafka Connect</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9949">KAFKA-9949</a>] - Flaky Test GlobalKTableIntegrationTest#shouldKStreamGlobalKTableLeftJoin</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9952">KAFKA-9952</a>] - Reconsider immediate propagation of hw when replica selector is used</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9960">KAFKA-9960</a>] - Metrics Reporter should support additional context tags</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9966">KAFKA-9966</a>] - Flaky Test EosBetaUpgradeIntegrationTest#shouldUpgradeFromEosAlphaToEosBeta</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9971">KAFKA-9971</a>] - Error Reporting in Sink Connectors</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9983">KAFKA-9983</a>] - Add INFO-level end-to-end latency metrics to Streams</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9987">KAFKA-9987</a>] - Improve sticky partition assignor algorithm</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10005">KAFKA-10005</a>] - Decouple RestoreListener from RestoreCallback and not enable bulk loading for RocksDB</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10012">KAFKA-10012</a>] - Reducing memory overhead associated with strings in MetricName</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10022">KAFKA-10022</a>] - console-producer supports the setting of client.id</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10074">KAFKA-10074</a>] - Improve performance of `matchingAcls`</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10115">KAFKA-10115</a>] - Incorporate errors.tolerance with the Errant Record Reporter</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10135">KAFKA-10135</a>] - Extract Task#executeAndMaybeSwallow to be a general utility function into TaskManager</li>
+</ul>
+<h2>Bug</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-3720">KAFKA-3720</a>] - Remove BufferExhaustedException from doSend() in KafkaProducer</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-6647">KAFKA-6647</a>] - KafkaStreams.cleanUp creates .lock file in directory its trying to clean (Windows OS)</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-7833">KAFKA-7833</a>] - StreamsBuilder should throw an exception if addGlobalStore and addStateStore is called for the same store builder</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-7885">KAFKA-7885</a>] - Streams: TopologyDescription violates equals-hashCode contract.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-7965">KAFKA-7965</a>] - Flaky Test ConsumerBounceTest#testRollingBrokerRestartsWithSmallerMaxGroupSizeConfigDisruptsBigGroup</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8011">KAFKA-8011</a>] - Flaky Test RegexSourceIntegrationTest#testRegexMatchesTopicsAWhenCreated</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8107">KAFKA-8107</a>] - Flaky Test kafka.api.ClientIdQuotaTest.testQuotaOverrideDelete</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8391">KAFKA-8391</a>] - Flaky Test RebalanceSourceConnectorsIntegrationTest#testDeleteConnector</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8574">KAFKA-8574</a>] - EOS race condition during task transition leads to LocalStateStore truncation in Kafka Streams 2.0.1</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8661">KAFKA-8661</a>] - Flaky Test RebalanceSourceConnectorsIntegrationTest#testStartTwoConnectors</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8672">KAFKA-8672</a>] - RebalanceSourceConnectorsIntegrationTest#testReconfigConnector</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8869">KAFKA-8869</a>] - Map taskConfigs in KafkaConfigBackingStore grows monotonically despite of task removals</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8910">KAFKA-8910</a>] - Incorrect javadoc at KafkaProducer.InterceptorCallback#onCompletion</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9034">KAFKA-9034</a>] - kafka-run-class.sh will fail if JAVA_HOME has space</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9047">KAFKA-9047</a>] - AdminClient group operations may not respect backoff</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9066">KAFKA-9066</a>] - Kafka Connect JMX : source & sink task metrics missing for tasks in failed state</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9074">KAFKA-9074</a>] - Connect's Values class does not parse time or timestamp values from string literals</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9161">KAFKA-9161</a>] - Close gaps in Streams configs documentation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9173">KAFKA-9173</a>] - StreamsPartitionAssignor assigns partitions to only one worker</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9176">KAFKA-9176</a>] - Flaky test failure:  OptimizedKTableIntegrationTest.shouldApplyUpdatesToStandbyStore</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9206">KAFKA-9206</a>] - Consumer should handle `CORRUPT_MESSAGE` error code in fetch response</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9225">KAFKA-9225</a>] - kafka fail to run on linux-aarch64</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9298">KAFKA-9298</a>] - Reuse of a mapped stream causes an Invalid Topology</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9308">KAFKA-9308</a>] - Misses SAN after certificate creation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9373">KAFKA-9373</a>] - Improve shutdown performance via lazy accessing the offset and time indices.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9374">KAFKA-9374</a>] - Worker can be disabled by blocked connectors</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9388">KAFKA-9388</a>] - Flaky Test StandbyTaskCreationIntegrationTest.shouldCreateStandByTasksForMaterializedAndOptimizedSourceTables</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9472">KAFKA-9472</a>] - Reducing number of tasks for connector causes deleted tasks to show as UNASSIGNED</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9490">KAFKA-9490</a>] - Some factory methods in Grouped are missing generic parameters</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9498">KAFKA-9498</a>] - Topic validation during the creation trigger unnecessary TopicChange events </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9501">KAFKA-9501</a>] - Promote Standby tasks to active tasks without closing them</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9533">KAFKA-9533</a>] - JavaDocs of KStream#ValueTransform incorrect</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9537">KAFKA-9537</a>] - Abstract transformations in configurations cause unfriendly error message.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9540">KAFKA-9540</a>] - Application getting "Could not find the standby task 0_4 while closing it" error</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9553">KAFKA-9553</a>] - Transaction state loading metric does not count total loading time</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9557">KAFKA-9557</a>] - Thread-level "process" metrics are computed incorrectly</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9568">KAFKA-9568</a>] - Kstreams APPLICATION_SERVER_CONFIG is not updated with static membership</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9570">KAFKA-9570</a>] - SSL cannot be configured for Connect in standalone mode</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9572">KAFKA-9572</a>] - Sum Computation with Exactly-Once Enabled and Injected Failures Misses Some Records</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9583">KAFKA-9583</a>] - OffsetsForLeaderEpoch requests are sometimes not sent to the leader of partition</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9600">KAFKA-9600</a>] - EndTxn handler should check strict epoch equality</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9603">KAFKA-9603</a>] - Number of open files keeps increasing in Streams application</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9605">KAFKA-9605</a>] - EOS Producer could throw illegal state if trying to complete a failed batch after fatal error</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9607">KAFKA-9607</a>] - Should not clear partition queue during task close</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9610">KAFKA-9610</a>] - Should not throw illegal state exception during task revocation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9614">KAFKA-9614</a>] - Avoid initializing the topology twice when resuming stream tasks from suspended state</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9617">KAFKA-9617</a>] - Replica Fetcher can mark partition as failed when max.message.bytes is changed</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9620">KAFKA-9620</a>] - Task revocation failure could introduce remaining unclean tasks</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9623">KAFKA-9623</a>] - Streams will attempt to commit during shutdown if rebalance is in progress</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9625">KAFKA-9625</a>] - Unable to Describe broker configurations that have been set via IncrementalAlterConfigs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9632">KAFKA-9632</a>] - Transient test failure: PartitionLockTest.testAppendReplicaFetchWithUpdateIsr</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9633">KAFKA-9633</a>] - ConfigProvider.close() not called</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9642">KAFKA-9642</a>] - "BigDecimal(double)" should not be used</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9644">KAFKA-9644</a>] - incrementalAlterConfigs OpType.APPEND on unset property fails with NullPointerException</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9645">KAFKA-9645</a>] - Records could not find corresponding partition/task</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9652">KAFKA-9652</a>] - Throttle time metric needs to be updated for KIP-219</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9656">KAFKA-9656</a>] - TxnOffsetCommit should not return COORDINATOR_LOADING error for old request versions</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9663">KAFKA-9663</a>] - KafkaStreams.metadataForKey, queryMetadataForKey docs don't mention null</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9667">KAFKA-9667</a>] - Connect JSON serde strip trailing zeros</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9675">KAFKA-9675</a>] - RocksDB metrics reported always at zero</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9677">KAFKA-9677</a>] - Low consume bandwidth quota may cause consumer not being able to fetch data</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9691">KAFKA-9691</a>] - Flaky test kafka.admin.TopicCommandWithAdminClientTest#testDescribeUnderReplicatedPartitionsWhenReassignmentIsInProgress</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9695">KAFKA-9695</a>] - AdminClient allows null topic configs, but broker throws NPE</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9700">KAFKA-9700</a>] - Negative estimatedCompressionRatio leads to misjudgment about if there is no room</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9703">KAFKA-9703</a>] - ProducerBatch.split takes up too many resources if the bigBatch is huge</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9704">KAFKA-9704</a>] - z/OS won't let us resize file when mmap</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9711">KAFKA-9711</a>] - The authentication failure caused by SSLEngine#beginHandshake is not properly caught and handled</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9712">KAFKA-9712</a>] - Reflections library 0.9.12 introduced in 2.5 causes regression scanning for plugins on plugin_path</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9716">KAFKA-9716</a>] - Values of compression-rate and compression-rate-avg are misleading</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9718">KAFKA-9718</a>] - Don't log passwords for AlterConfigs requests in request logs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9724">KAFKA-9724</a>] - Consumer wrongly ignores fetched records "since it no longer has valid position"</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9739">KAFKA-9739</a>] - StreamsBuilder.build fails with StreamsException "Found a null keyChangingChild node for OptimizableRepartitionNode"</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9743">KAFKA-9743</a>] - StreamTask could fail to close during HandleNewAssignment</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9768">KAFKA-9768</a>] - rest.advertised.listener configuration is not handled properly by the worker</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9775">KAFKA-9775</a>] - IllegalFormatConversionException from kafka-consumer-perf-test.sh</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9777">KAFKA-9777</a>] - Purgatory locking bug can lead to hanging transaction</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9783">KAFKA-9783</a>] - Flaky Test QueryableStateIntegrationTest#concurrentAccesses</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9788">KAFKA-9788</a>] - Sensor name collision for group and transaction coordinator load metrics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9796">KAFKA-9796</a>] - Broker shutdown could be stuck forever under certain conditions</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9797">KAFKA-9797</a>] - Fix flaky system test TestSecurityRollingUpgrade.test_enable_separate_interbroker_listener</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9812">KAFKA-9812</a>] - Integration tests hang and timeout the entire PR build on jenkins </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9818">KAFKA-9818</a>] - Flaky Test RecordCollectorTest.shouldNotThrowStreamsExceptionOnSubsequentCallIfASendFailsWithContinueExceptionHandler</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9819">KAFKA-9819</a>] - Flaky Test StoreChangelogReaderTest#shouldNotThrowOnUnknownRevokedPartition[0]</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9820">KAFKA-9820</a>] - validateMessagesAndAssignOffsetsCompressed allocates batch iterator which is not used</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9821">KAFKA-9821</a>] - Stream task may skip assignment with static members and incremental rebalances</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9823">KAFKA-9823</a>] - Consumer should check equality of the generation for coordinator requests</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9826">KAFKA-9826</a>] - Log cleaning repeatedly picks same segment with no effect when first dirty offset is past start of active segment</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9830">KAFKA-9830</a>] - DeadLetterQueueReporter leaks KafkaProducer instance</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9840">KAFKA-9840</a>] - Consumer should not use OffsetForLeaderEpoch without current epoch validation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9841">KAFKA-9841</a>] - Connector and Task duplicated when a worker join with old generation assignment</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9844">KAFKA-9844</a>] - Maximum number of members within a group is not always enforced due to a race condition in join group</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9845">KAFKA-9845</a>] - plugin.path property does not work with config provider</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9848">KAFKA-9848</a>] - Avoid triggering scheduled rebalance delay when task assignment fails but Connect workers remain in the group</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9849">KAFKA-9849</a>] - Fix issue with worker.unsync.backoff.ms creating zombie workers when incremental cooperative rebalancing is used</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9851">KAFKA-9851</a>] - Revoking Connect tasks due to connectivity issues should also clear running assignment</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9854">KAFKA-9854</a>] - Re-authenticating causes mismatched parse of response</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9859">KAFKA-9859</a>] - kafka-streams-application-reset tool doesn't take into account topics generated by KTable foreign key join operation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9868">KAFKA-9868</a>] - Flaky Test EOSUncleanShutdownIntegrationTest.shouldWorkWithUncleanShutdownWipeOutStateStore</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9875">KAFKA-9875</a>] - Flaky Test SuppressionDurabilityIntegrationTest.shouldRecoverBufferAfterShutdown[exactly_once]</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9883">KAFKA-9883</a>] - Connect request to restart task can result in IllegalArgumentError: "uriTemplate" parameter is null</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9885">KAFKA-9885</a>] - Evict last members of a group when the maximum allowed is reached</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9888">KAFKA-9888</a>] - REST extensions can mutate connector configs in worker config state snapshot</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9891">KAFKA-9891</a>] - Invalid state store content after task migration with exactly_once and standby replicas</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9896">KAFKA-9896</a>] - Flaky Test StandbyTaskEOSIntegrationTest#surviveWithOneTaskAsStandby[exactly_once_beta]</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9898">KAFKA-9898</a>] - Flaky Test StoreQueryIntegrationTest.shouldQueryAllStalePartitionStores</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9918">KAFKA-9918</a>] - SslEngineFactory is NOT closed when channel is closing</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9921">KAFKA-9921</a>] - Caching is not working properly with WindowStateStore when retaining duplicates</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9922">KAFKA-9922</a>] - Update examples README</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9925">KAFKA-9925</a>] - Non-key KTable Joining may result in duplicate schema name in confluence schema registry</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9928">KAFKA-9928</a>] - Flaky GlobalKTableEOSIntegrationTest#shouldKStreamGlobalKTableLeftJoin[exactly_once_beta]</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9939">KAFKA-9939</a>] - Fetch request metrics are updated twice for delayed fetches</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9942">KAFKA-9942</a>] - ConfigCommand fails to set client quotas for default users with --bootstrap-server.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9945">KAFKA-9945</a>] - TopicCommand should support --if-exists and --if-not-exists when --bootstrap-server is used</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9950">KAFKA-9950</a>] - MirrorMaker2 sharing of ConfigDef can lead to ConcurrentModificationException</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9955">KAFKA-9955</a>] - Exceptions thrown from SinkTask::close shadow other exceptions</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9969">KAFKA-9969</a>] - ConnectorClientConfigRequest is loaded in isolation and throws LinkageError</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9972">KAFKA-9972</a>] - Corrupted standby task could be committed</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9980">KAFKA-9980</a>] - Fix bug where alterClientQuotas could not set default client quotas</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9984">KAFKA-9984</a>] - Should fail the subscription when pattern is empty</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9985">KAFKA-9985</a>] - Sink connector consuming DLQ topic may exhaust broker</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9991">KAFKA-9991</a>] - Flaky Test KTableSourceTopicRestartIntegrationTest.shouldRestoreAndProgressWhenTopicWrittenToDuringRestorationWithEosAlphaEnabled</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9992">KAFKA-9992</a>] - EmbeddedKafkaCluster.deleteTopicAndWait not working with kafka_2.13</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9996">KAFKA-9996</a>] - upgrade zookeeper to 3.5.8 to address security vulnerabilities</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10001">KAFKA-10001</a>] - Store's own restore listener should be triggered in store changelog reader</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10004">KAFKA-10004</a>] - ConfigCommand fails to find default broker configs without ZK</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10017">KAFKA-10017</a>] - Flaky Test EosBetaUpgradeIntegrationTest.shouldUpgradeFromEosAlphaToEosBeta</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10018">KAFKA-10018</a>] -  Change command line tools from /bin/sh to /bin/bash</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10029">KAFKA-10029</a>] - Selector.completedReceives should not be modified when channel is closed</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10030">KAFKA-10030</a>] - Throw exception while fetching a key from a single partition</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10043">KAFKA-10043</a>] -  Some parameters will be overwritten which was configured in consumer.config where running "ConsumerPerformance.scala"</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10049">KAFKA-10049</a>] - KTable-KTable Foreign Key join throwing Serialization Exception </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10052">KAFKA-10052</a>] - Flaky Test InternalTopicsIntegrationTest.testCreateInternalTopicsWithFewerReplicasThanBrokers</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10056">KAFKA-10056</a>] - Consumer metadata may use outdated groupSubscription that doesn't contain newly subscribed topics</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10061">KAFKA-10061</a>] - Flaky Test `ReassignPartitionsIntegrationTest .testCancellation`</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10063">KAFKA-10063</a>] - UnsupportedOperation when querying cleaner metrics after shutdown</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10066">KAFKA-10066</a>] - TopologyTestDriver isn't taking record headers into account during de/serialization</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10069">KAFKA-10069</a>] - The user-defined "predicate" and "negate" are not removed from Transformation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10079">KAFKA-10079</a>] - Improve thread-level stickiness of stateful tasks</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10080">KAFKA-10080</a>] - IllegalStateException after duplicate CompleteCommit append to transaction log</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10085">KAFKA-10085</a>] - Compute lag correctly for optimized source changelogs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10089">KAFKA-10089</a>] - The stale ssl engine factory is not closed after reconfigure</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10102">KAFKA-10102</a>] - Source node references not updated after rebuilding topology</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10110">KAFKA-10110</a>] - ConnectDistributed fails with NPE when Kafka cluster has no ID</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10111">KAFKA-10111</a>] - SinkTaskContext.errantRecordReporter() added in KIP-610 should be a default method</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10113">KAFKA-10113</a>] - LogTruncationException sets fetch offsets incorrectly</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10123">KAFKA-10123</a>] - Regression resetting offsets in consumer when fetching from old broker</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10134">KAFKA-10134</a>] - High CPU issue during rebalance in Kafka consumer after upgrading to 2.5</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10144">KAFKA-10144</a>] - Corrupted standby tasks are not always cleaned up</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10147">KAFKA-10147</a>] - MockAdminClient#describeConfigs(Collection<ConfigResource>) is unable to handle broker resource</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10148">KAFKA-10148</a>] - Kafka Streams Restores too few Records with eos-beta Enabled </li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10150">KAFKA-10150</a>] - IllegalStateException when revoking task in CREATED state</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10151">KAFKA-10151</a>] - Flaky Test StoreUpgradeIntegrationTest.shouldMigratePersistentKeyValueStoreToTimestampedKeyValueStoreUsingPapi</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10152">KAFKA-10152</a>] - Attempt to write checkpoint without first committing during recycle</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10165">KAFKA-10165</a>] - Percentiles metric leaking memory</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10166">KAFKA-10166</a>] - Excessive TaskCorruptedException seen in testing</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10167">KAFKA-10167</a>] - Streams EOS-Beta should not try to get end-offsets as read-committed</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10169">KAFKA-10169</a>] - KafkaException: Failing batch since transaction was aborted</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10173">KAFKA-10173</a>] - BufferUnderflowException during Kafka Streams Upgrade</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10192">KAFKA-10192</a>] - Flaky test BlockingConnectorTest#testBlockInConnectorStop</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10198">KAFKA-10198</a>] - Dirty tasks may be recycled instead of closed</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10209">KAFKA-10209</a>] - Fix connect_rest_test.py after the introduction of new connector configs</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10212">KAFKA-10212</a>] - Describing a topic with the TopicCommand fails if unauthorised to use ListPartitionReassignments API</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10214">KAFKA-10214</a>] - fix flaky zookeeper_tls_test.py</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10223">KAFKA-10223</a>] - ReplicaNotAvailableException must be retriable to handle reassignments</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10224">KAFKA-10224</a>] - The license term about jersey is not correct</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10235">KAFKA-10235</a>] - Fix flaky transactions_test.py</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10239">KAFKA-10239</a>] - The groupInstanceId field in DescribeGroup response should be ignorable</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10247">KAFKA-10247</a>] - Streams may attempt to process after closing a task</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10249">KAFKA-10249</a>] - In-memory stores are skipped when checkpointing but not skipped when reading the checkpoint</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10257">KAFKA-10257</a>] - system test kafkatest.tests.core.security_rolling_upgrade_test fails</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10262">KAFKA-10262</a>] - StateDirectory is not thread-safe</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10268">KAFKA-10268</a>] - dynamic config like "--delete-config log.retention.ms" doesn't work</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10274">KAFKA-10274</a>] - Transaction system test uses inconsistent timeouts</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10287">KAFKA-10287</a>] - fix flaky streams/streams_standby_replica_test.py</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10306">KAFKA-10306</a>] - GlobalThread might loop forever</li>
+</ul>
+<h2>Task</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-6342">KAFKA-6342</a>] - Remove workaround for JSON parsing of non-escaped strings</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8835">KAFKA-8835</a>] - Update documentation for URP changes in KIP-352</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9343">KAFKA-9343</a>] - Add ps command for Kafka and zookeeper process on z/OS.</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9392">KAFKA-9392</a>] - Document and add test for deleteAcls that match single/multiple resources</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9670">KAFKA-9670</a>] - Benchmark and optimize MetadataResponse preparation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10003">KAFKA-10003</a>] - Deprecate KStream#through in favor of KStream#repartition</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10064">KAFKA-10064</a>] - Add documentation for KIP-571</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10084">KAFKA-10084</a>] - System test failure: StreamsEosTest.test_failure_and_recovery_complex</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10086">KAFKA-10086</a>] - Standby state isn't always re-used when transitioning to active</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10153">KAFKA-10153</a>] - Error Reporting in Connect Documentation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10185">KAFKA-10185</a>] - Streams should log summarized restoration information at info level</li>
+</ul>
+<h2>Test</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9182">KAFKA-9182</a>] - Flaky Test org.apache.kafka.streams.integration.KTableSourceTopicRestartIntegrationTest.shouldRestoreAndProgressWhenTopicWrittenToDuringRestorationWithEosEnabled</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10286">KAFKA-10286</a>] - Connect system tests should wait for workers to join group</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10295">KAFKA-10295</a>] - ConnectDistributedTest.test_bounce should wait for graceful stop</li>
+</ul>
+<h2>Sub-task</h2>
+<ul>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-4696">KAFKA-4696</a>] - Streams standby task assignment should be state-store aware</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-4969">KAFKA-4969</a>] - State-store workload-aware StreamsPartitionAssignor</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8436">KAFKA-8436</a>] - Replace AddOffsetsToTxn request/response with automated protocol</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8618">KAFKA-8618</a>] - Replace WriteTxnMarkers request/response with automated protocol</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-8768">KAFKA-8768</a>] - Replace DeleteRecords request/response with automated protocol</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9433">KAFKA-9433</a>] - Replace AlterConfigs request/response with automated protocol</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9435">KAFKA-9435</a>] - Replace DescribeLogDirs request/response with automated protocol</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9441">KAFKA-9441</a>] - Refactor commit logic</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9451">KAFKA-9451</a>] - Pass consumer group metadata to producer on commit</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9466">KAFKA-9466</a>] - Add documentation for new stream EOS change</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9719">KAFKA-9719</a>] - Add System Test For ensuring the EOS-beta app would crash with broker downgrade</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9748">KAFKA-9748</a>] - Extend EOS integration test for EOS-beta</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9760">KAFKA-9760</a>] - Add EOS protocol changes to documentation</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-9832">KAFKA-9832</a>] - Extend EOS system tests for EOS-beta</li>
+<li>[<a href="https://issues.apache.org/jira/browse/KAFKA-10248">KAFKA-10248</a>] - Drop idempotent KTable source updates</li>
+</ul>

Added: release/kafka/2.6.0/RELEASE_NOTES.html.asc
==============================================================================
--- release/kafka/2.6.0/RELEASE_NOTES.html.asc (added)
+++ release/kafka/2.6.0/RELEASE_NOTES.html.asc Tue Aug  4 22:01:33 2020
@@ -0,0 +1,17 @@
+-----BEGIN PGP SIGNATURE-----
+
+iQJGBAABCgAwFiEEfkF+XvPxSMDrGnYrpbmZvwxBS+sFAl8gbVMSHHJoYXVjaEBh
+cGFjaGUub3JnAAoJEKW5mb8MQUvrPrAP/i9WV1GsGB3EIdj0eRUz6woGn97qH5He
+JLxCfR7jCUV/SBW7q+M/Vo+Lu5g5v9WVRIXbNI8kDspPjAnorWxYAItzDeXBaelg
+J2Xg1M1FTSosdcfVk0CgXtHlZbfnBob+0iqaXK7fXHjFv1w9MsJkNGhcapaJuuSA
+I/M6qmOJbexlAVvZu2all4vpePS8AgEmspblMysdkhu42qJPTDVxcCLpNuAR5hkD
+8oKNsv63ZSJ9JYj2mqiWNB+10d0EgUd7Z38zgfORPLiEB2MIk59QNVq0jB4EKqMb
+4w2waLY3R1ZT60e50M/m1S4e1wfCLG6VpoTkgGku19TDJZP9lWrlSi8T+fninxF6
+rKlDh8ntHj/ryDyDH5SV4dbfELFlWoKC6sHJNsJNaRinkkwY+O+AV7GIUINpKRfG
+1SvmJv79Nvt2xj9I9SpOCo+a6Z7YTry82Subm//Dk9Ayqhd76BJdU6eJ0aunrytY
+WUFop9n609+3tJb7m6Gf1vDfkMvrlzh0Pvu9b0NpCx9JdLY7wP/KLnfxsb4n750l
+ZiSUoO4WOIcNb2CwSzLULp6zMD0yJru1AV4hKphwD0CJPrVAYblhaom3sFdi1r0X
+Jcdz4oIfmPbcjA+coXwVn/UmJLXvy29dyb94imhoQcYmNBiAF2cGSzv18MDLbAkQ
+T/+4SYRdmLgO
+=8pdH
+-----END PGP SIGNATURE-----

Added: release/kafka/2.6.0/RELEASE_NOTES.html.md5
==============================================================================
--- release/kafka/2.6.0/RELEASE_NOTES.html.md5 (added)
+++ release/kafka/2.6.0/RELEASE_NOTES.html.md5 Tue Aug  4 22:01:33 2020
@@ -0,0 +1 @@
+RELEASE_NOTES.html: 5F 35 E5 BE 24 39 51 FE  66 E1 4B D8 A4 CA 40 C3

Added: release/kafka/2.6.0/RELEASE_NOTES.html.sha1
==============================================================================
--- release/kafka/2.6.0/RELEASE_NOTES.html.sha1 (added)
+++ release/kafka/2.6.0/RELEASE_NOTES.html.sha1 Tue Aug  4 22:01:33 2020
@@ -0,0 +1 @@
+RELEASE_NOTES.html: 7EDA B96E 43CF B48A 795A  68B3 2AF0 6F7A 5A79 EF6A

Added: release/kafka/2.6.0/RELEASE_NOTES.html.sha512
==============================================================================
--- release/kafka/2.6.0/RELEASE_NOTES.html.sha512 (added)
+++ release/kafka/2.6.0/RELEASE_NOTES.html.sha512 Tue Aug  4 22:01:33 2020
@@ -0,0 +1,3 @@
+RELEASE_NOTES.html: 2DFFEA22 4548AB51 26C3CCC3 7DFD8567 529A2F4E 4BAEE9F8
+                    20642B47 A2FFED33 F4030430 F090A01B A6E330E7 53AB9F9B
+                    42AA01AD 7006E215 EA0B10AB 3CCF4EAF