Versions Compared

Key

  • This line was added.
  • This line was removed.
  • Formatting was changed.
Comment: Added KIP-476 to adopted list

...

To create your own KIP, click on

Create from template
templateName54329345
templateId54329345
titleKIP-NEXT: Insert Title Here
buttonLabelCreate KIP
. If you don't have permission, please send an email with your Wiki ID to dev@kafka.apache.org and request permission (http://kafka.apache.org/contact). Also add an entry to the table KIPs under discussion (for Streams API KIPs, please also add it to Kafka Streams sub page).

Table of Contents
476

Purpose

We want to make Kafka a core architectural component for users. We also support a large number of integrations with other tools, systems, and clients. Keeping this kind of usage health requires a high level of compatibility between releases — core architectural elements can't break compatibility or shift functionality from release to release. As a result each new major feature or public api has to be done in a way that we can stick with it going forward.

...


KIP (please keep this sorted by KIP number)

Release

12KIP-455: Create an Administrative API for Replica Reassignment2.4.0 (WIP)KIP-488: Clean up Sum,Count,Total Metrics2.4.0
32KIP-484: Expose metrics for group and transaction metadata loading duration2.4.0 (WIP)
3KIP-476: Add Java AdminClient Interface2.4.0
4KIP-465: Add Consolidated Connector Endpoint to Connect REST API2.3.0
5KIP-464: Defaults for AdminClient#createTopic2.4.0
6KIP-462: Use local thread id for KStreams2.3.0
7KIP-461: Improve Replica Fetcher behavior at handling partition failure2.3.0
8KIP-460: Admin Leader Election RPC2.4.0
9KIP-458: Connector Client Config Override Policy2.3.0
10KIP-455: Create an Administrative API for Replica Reassignment2.4.0 (WIP)
11KIP-454: Expansion of the ConnectClusterState interface2.3.0
1112KIP-453: Add close() method to RocksDBConfigSetter2.3.0
1213KIP-449: Add connector contexts to log messages in Connect workers 2.3.0
1314KIP-446: Add changelog topic configuration to KTable suppress2.4.0 (WIP)
1415KIP-445: In-memory Session Store2.3.0
1516

KIP-443: Return to default segment.ms and segment.index.bytes in Streams repartition topics

2.3.0
1617KIP-442: Return to default max poll interval in Streams2.3.0
1718KIP-436: Add a metric indicating start time2.3.0
1819KIP-430 - Return Authorized Operations in Describe Responses2.3.0
1920KIP-429: Kafka Consumer Incremental Rebalance Protocol2.4.0 (WIP)
2021KIP-428: Add in-memory window store2.3.0
2122KIP-427: Add AtMinIsr topic partition category (new metric & TopicCommand option)2.3.0
2223KIP-425: Add some Log4J Kafka Appender Properties for Producing to Secured Brokers2.3.0
2324KIP-421: Support resolving externalized secrets in AbstractConfig2.3.0
2425KIP-420: Add Single Value Fetch in Session Stores2.2.0
2526KIP-417: Allow JmxTool to connect to a secured RMI port2.3.0
2627KIP-415: Incremental Cooperative Rebalancing in Kafka Connect2.3.0
2728KIP-414: Expose Embedded ClientIds in Kafka Streams2.2.0
2829KIP-412: Extend Admin API to support dynamic application log levels2.4.0 (WIP)
2930

KIP-411: Make default Kafka Connect worker task client IDs distinct

2.3.0
3031KIP-402: Improve fairness in SocketServer processors2.2.0 (partially implemented) / 2.3.0
3132KIP-394: Require member.id for initial join group request2.2.0
3233KIP-393: Time windowed serde to properly deserialize changelog input topic2.2.0
3334KIP-386: Standardize on Min/Avg/Max metrics' default value2.2.0
3435KIP-382: MirrorMaker 2.02.4.0 (WIP)
3536KIP-380: Detect outdated control requests and bounced brokers using broker generation2.2.0
3637KIP-377: TopicCommand to use AdminClient2.2.0
3738KIP-376: Implement AutoClosable on appropriate classes that want to be used in a try-with-resource statement2.2.0
3839KIP-374: Add '--help' option to all available Kafka CLI commands2.2.0
3940KIP-372: Naming Repartition Topics for Joins and Grouping2.1.0
4041KIP-371: Add a configuration to build custom SSL principal name2.2.0
4142KIP 368: Allow SASL Connections to Periodically Re-Authenticate2.2.0
4243KIP-367 Introduce close(Duration) to Producer and AdminClient instead of close(long, TimeUnit)2.2.0
4344KIP-366: Make FunctionConversions deprecated2.1.0
4445KIP-365: Materialized, Serialized, Joined, Consumed and Produced with implicit Serde2.1.0
4546KIP-361: Add Consumer Configuration to Disable Auto Topic Creation2.3.0
4647KIP-359: Verify leader epoch in produce requests2.4.0 (WIP)
4748KIP-358: Migrate Streams API to Duration instead of long ms times2.1.0
4849KIP-357: Add support to list ACLs per principal2.1.0
4950KIP-356: Add withCachingDisabled() to StoreBuilder2.1.0
5051KIP-354: Add a Maximum Log Compaction Lag2.3.0
5152KIP-353: Improve Kafka Streams Timestamp Synchronization2.1.0
5253KIP-351: Add --under-min-isr option to describe topics command2.3.0
5354KIP-346: Improve LogCleaner behavior on error2.1
5455KIP-345: Introduce static membership protocol to reduce consumer rebalances2.4.0 (WIP), partially available in 2.3.0
5556KIP-342 Add support for custom SASL extensions in OAuthBearer authentication2.1.0
5657KIP-341: Update Sticky Assignor's User Data Protocol2.3.0
5758KIP-340: Allow kafka-reassign-partitions.sh and kafka-log-dirs.sh to take admin client property file2.1.0
5859KIP-339: Create a new IncrementalAlterConfigs API2.3.0 
5960KIP-338 Support to exclude the internal topics in kafka-topics.sh command2.1.0
6061KIP-336: Consolidate ExtendedSerializer/Serializer and ExtendedDeserializer/Deserializer2.1.0
6162KIP-332: Update AclCommand to use AdminClient API2.1.0
6263KIP-331 Add default implementation to close() and configure() for Serializer, Deserializer and Serde2.3.0
6364KIP-330: Add retentionPeriod in SessionBytesStoreSupplier2.1.0
6465KIP-328: Ability to suppress updates for KTables2.1.0 (partially implemented) / 2.3.0 (WIP)
6566KIP-324: Add method to get metrics() in AdminClient2.1.0
6667KIP-322: Return new error code for DeleteTopics API when topic deletion disabled.2.1.0
6768KIP-321: Update TopologyDescription to better represent Source and Sink Nodes2.1.0
6869KIP-320: Allow fetchers to detect and handle log truncation2.1.0 (partially implemented) / 2.2.0
6970KIP-319: Replace segments with segmentInterval in WindowBytesStoreSupplier2.1.0
7071KIP-313: Add KStream.flatTransform and KStream.flatTransformValues 

2.2.0 (partially implemented)

/ 2.3.0

7172KIP-312 Add Overloaded StreamsBuilder Build Method to Accept java.util.Properties2.1.0
7273KIP-308: Support dynamic update of max.connections.per.ip/max.connections.per.ip.overrides2.1.0
7374KIP-307: Allow to define custom processor names with KStreams DSL2.3.0 (partial)
7475KIP-306: Configuration for Delaying Response to Failed Authentication2.1.0
7576KIP-305: Add Connect primitive number converters2.0.0
7677KIP-303: Add Dynamic Routing in Streams Sink2.0.0
7778KIP-302 - Enable Kafka clients to use all DNS resolved IP addresses2.1.0
7879KIP-300: Add Windowed KTable API in StreamsBuilder2.4.0
7980KIP-298: Error Handling in Connect2.0.0
8081KIP-297: Externalizing Secrets for Connect Configurations2.0.0
8182KIP-295 Add Streams Configuration Allowing for Optional Topology Optimization2.0.0
8283KIP-294 - Enable TLS hostname verification by default2.0.0
8384KIP-292: Add transformValues() method to KTable2.0.0
8485KIP-290: Support for Prefixed ACLs2.0.0
8586KIP-289: Improve the default group id behavior in KafkaConsumer2.2.0
8687KIP-285: Connect Rest Extension Plugin2.0.0
8788KIP-284: Set default retention ms for Streams repartition topics to Long.MAX_VALUE2.0.0
8889KIP-283: Efficient Memory Usage for Down-Conversion2.0.0
8990KIP-282: Add the listener name to the authentication context2.0.0
9091KIP-281: ConsumerPerformance: Increase Polling Loop Timeout and Make It Reachable by the End User2.0.0
9192KIP-279: Fix log divergence between leader and follower after fast leader fail over2.0.0
9293KIP-278 - Add version option to Kafka's commands2.0.0
9394KIP-277 - Fine Grained ACL for CreateTopics API2.0.0
9495KIP-276 - Add StreamsConfig prefix for different consumers2.0.0
9596KIP-274: Kafka Streams Skipped Records Metrics2.0.0
9697KIP-272: Add API version tag to broker's RequestsPerSec metric2.0.0
9798KIP-270 - A Scala Wrapper Library for Kafka Streams2.0.0
9899KIP-268: Simplify Kafka Streams Rebalance Metadata Upgrade2.0.0
99100KIP-267: Add Processor Unit Test Support to Kafka Streams Test Utils2.0.0
100101KIP-266: Fix consumer indefinite blocking behavior2.0.0
101102KIP-265: Make Windowed Serde to public APIs2.0.0
102103KIP-261: Add Single Value Fetch in Window Stores2.0.0
103104KIP-258: Allow to Store Record Timestamps in RocksDB2.3.0 (partially implemented)
104105KIP-257 - Configurable Quota Management2.0.0
105106KIP-255: OAuth Authentication via SASL/OAUTHBEARER2.0.0
106107KIP-251: Allow timestamp manipulation in Processor API2.0.0
107108KIP-249: Add Delegation Token Operations to KafkaAdminClient2.0.0
108109KIP-247: Add public test utils for Kafka Streams1.1.0
109110KIP-245: Use Properties instead of StreamsConfig in KafkaStreams constructor2.0.0
110111KIP-244: Add Record Header support to Kafka Streams Processor API2.0.0
111112KIP-243: Make ProducerConfig and ConsumerConfig constructors public1.1.0
112113KIP-239 Add queryableStoreName() to GlobalKTable1.1.0
113114KIP-238: Expose Kafka cluster ID in Connect REST API1.1.0
114115KIP-237: More Controller Health Metrics2.0.0
115116KIP-235: Add DNS alias support for secured connection2.1.0
116117KIP-233: Simplify StreamsBuilder#addGlobalStore1.1.0
117118KIP-231: Improve the Required ACL of ListGroups API2.1.0
118119KIP-229: DeleteGroups API1.1.0
119120KIP-227 - Introduce Incremental FetchRequests to Increase Partition Scalability1.1.0
120121KIP-226 - Dynamic Broker Configuration1.1.0
121122KIP-225 - Use tags for consumer “records.lag” metrics1.1.0
122123KIP-224: Add configuration parameter `retries` to Streams API1.1.0
123124KIP-223 - Add per-topic min lead and per-partition lead metrics to KafkaConsumer2.0.0
124125KIP-222 - Add Consumer Group operations to Admin API2.0.0
125126KIP-220: Add AdminClient into Kafka Streams' ClientSupplier1.1.0
126127KIP-219 - Improve quota communication2.0.0
127128KIP-218: Make KafkaFuture.Function java 8 lambda compatible1.1.0
128129KIP-215: Add topic regex support for Connect sinks1.1.0
129130KIP-214: Add zookeeper.max.in.flight.requests config to the broker1.1.0
130131KIP-213 Support non-key joining in KTable2.4.0 (WIP)
131132KIP-212: Enforce set of legal characters for connector names1.1.0
132133KIP-211: Revise Expiration Semantics of Consumer Group Offsets2.1.0
133134KIP-210 - Provide for custom error handling when Kafka Streams fails to produce1.1.0
134135KIP-208: Add SSL support to Kafka Connect REST interface1.1.0
135136KIP-207: Offsets returned by ListOffsetsResponse should be monotonically increasing even during a partition leader change2.2.0
136137KIP-206: Add support for UUID serialization and deserialization2.1.0
137138KIP-205: Add all() and range() API to ReadOnlyWindowStore1.1.0
138139KIP-204 : Adding records deletion operation to the new Admin Client API1.1.0
139140KIP-203: Add toLowerCase support to sasl.kerberos.principal.to.local rule 1.1.0
140141KIP-202: Move merge() from StreamsBuilder to KStream1.0.0
141142KIP-198: Remove ZK dependency from Streams Reset Tool1.0.0
142143KIP-197 Connect REST API should include the connector type when describing a connector1.0.0
143144KIP-196: Add metrics to Kafka Connect framework1.0.0
144145KIP-195: AdminClient.createPartitions1.0.0
145146KIP-192 : Provide cleaner semantics when idempotence is enabled1.0.0
146147KIP-191: KafkaConsumer.subscribe() overload that takes just Pattern1.0.0
147148KIP-190: Handle client-ids consistently between clients and brokers1.0.0
148149KIP-189: Improve principal builder interface and add support for SASL1.0.0
149150KIP-188 - Add new metrics to support health checks1.0.0
150151KIP-187 - Add cumulative count metric for all Kafka rate metrics1.0.0
151152KIP-186: Increase offsets retention default to 7 days2.0.0
152153KIP-183 - Change PreferredReplicaLeaderElectionCommand to use AdminClient2.2.0
153154KIP-182: Reduce Streams DSL overloads and allow easier use of custom storage engines1.0.0
154155KIP-180: Add a broker metric specifying the number of consumer group rebalances in progress1.1.0
155156KIP-177: Consumer perf tool should count rebalance time1.0.0
156157KIP-176: Remove deprecated new-consumer option for tools2.0.0
157158KIP-175: Additional '--describe' views for ConsumerGroupCommand1.1.0
158159KIP-174 - Deprecate and remove internal converter configs in WorkerConfig2.0.0
159160KIP-173: Add prefix to StreamsConfig to enable setting default internal topic configs1.0.0
160161KIP-171 - Extend Consumer Group Reset Offset for Stream Application1.1.0
161162KIP-168: Add GlobalTopicCount and GlobalPartitionCount metric per cluster1.0.0
162163KIP-167: Add interface for the state store restoration process1.0.0
163164

KIP-164 - Add UnderMinIsrPartitionCount and per-partition UnderMinIsr metrics

1.0.0
164165

KIP-163: Lower the Minimum Required ACL Permission of OffsetFetch

1.0.0
165166KIP-162: Enable topic deletion by default1.0.0
166167KIP-161: streams deserialization exception handlers1.0.0
167168KIP-160: Augment KStream.print(), KStream.writeAsText() to allow users pass in extra parameters in the printed string1.0.0
168169KIP-157 - Add consumer config options to streams reset tool1.0.0
169170KIP-156 Add option "dry run" to Streams application reset tool0.11.0.0
170171KIP-155 - Add range scan for windowed state stores0.11.0.0
171172KIP-154 Add Kafka Connect configuration properties for creating internal topics0.11.0.0
172173KIP-153: Include only client traffic in BytesOutPerSec metric0.11.0.0
173174KIP-152 - Improve diagnostics for SASL authentication failures1.0.0
174175KIP-151 Expose Connector type in REST API0.11.0.0
175176KIP-150 - Kafka-Streams Cogroup2.4.0 (WIP)
176177KIP-149: Enabling key access in ValueTransformer, ValueMapper, and ValueJoiner1.1.0 (partially implemented)
(WIP for 2.4.0)
177178KIP-146 - Classloading Isolation in Connect

0.11.0.0

178179KIP-145 - Expose Record Headers in Kafka Connect1.1.0
179180KIP-144: Exponential backoff for broker reconnect attempts0.11.0.0
180181KIP-143: Controller Health Metrics0.11.0.0
181182KIP-140: Add administrative RPCs for adding, deleting, and listing ACLs0.11.0.0
182183KIP-138: Change punctuate semantics1.0.0
183184KIP-137: Enhance TopicCommand --describe to show topics marked for deletion0.11.0.0
184185KIP-136: Add Listener name to SelectorMetrics tags0.11.0.0
185186KIP-134: Delay initial consumer group rebalance0.11.0.0
186187KIP-133: Describe and Alter Configs Admin APIs0.11.0.0
187188KIP-130: Expose states of active tasks to KafkaStreams public API1.0.0
188189KIP-129: Streams Exactly-Once Semantics0.11.0.0
189190KIP-128: Add ByteArrayConverter for Kafka Connect0.11.0.0
190191KIP-126 - Allow KafkaProducer to split and resend oversized batches.0.11.0.0
191192KIP-124 - Request rate quotas0.11.0.0
192193KIP-123: Allow per stream/table timestamp extractor0.11.0.0
193194KIP-122: Add Reset Consumer Group Offsets tooling0.11.0.0
194195KIP-121: Add KStream peek method

0.11.0.0

195196KIP-120: Cleanup Kafka Streams builder API1.0.0
196197KIP-119: Drop Support for Scala 2.10 in Kafka 0.110.11.0.0
197198KIP-118: Drop Support for Java 72.0.0
198199KIP-117: Add a public AdminClient API for Kafka admin operations0.11.0.0
199200KIP-115: Enforce offsets.topic.replication.factor upon __consumer_offsets auto topic creation0.11.0.0
200201KIP-114: KTable state stores and improved semantics0.11.0.0
201202KIP-113: Support replicas movement between log directories1.1.0
202203KIP-112: Handle disk failure for JBOD1.0.0
203204KIP-110: Add Codec for ZStandard Compression2.1.0
204205KIP-109: Old Consumer Deprecation0.11.0.0
205206KIP-108: Create Topic Policy0.10.2.0
206207KIP-107: Add deleteRecordsBefore() API in AdminClient0.11.0.0
207208

KIP-106 - Change Default unclean.leader.election.enabled from True to False

0.11.0.0
208209KIP-105: Addition of Record Level for Sensors0.10.2.0
209210KIP-104: Granular Sensors for Streams 0.10.2.0
210211KIP-103: Separation of Internal and External traffic0.10.2.0
211212KIP-102 - Add close with timeout for consumers0.10.2.0
212213KIP-101 - Alter Replication Protocol to use Leader Epoch rather than High Watermark for Truncation0.11.0.0
213214KIP-100 - Relax Type constraints in Kafka Streams API0.10.2.0
214215KIP-99: Add Global Tables to Kafka Streams0.10.2.0
215216KIP-98 - Exactly Once Delivery and Transactional Messaging0.11.0.0
216217KIP-97: Improved Kafka Client RPC Compatibility Policy0.10.2.0
217218KIP-96 - Add per partition metrics for in-sync and assigned replica count0.10.2.0
218219KIP-94 Session Windows0.10.2.0
219220KIP-93: Improve invalid timestamp handling in Kafka Streams0.10.2.0
220221KIP-92 - Add per partition lag metrics to KafkaConsumer0.10.2.0
221222KIP-91 Provide Intuitive User Timeouts in The Producer2.1.0
222223KIP-90 - Remove zkClient dependency from Streams0.10.2.0
223224KIP-89: Allow sink connectors to decouple flush and offset commit0.10.2.0
224225KIP-88: OffsetFetch Protocol Update0.10.2.0
225226KIP-86: Configurable SASL callback handlers2.0.0
226227KIP-85: Dynamic JAAS configuration for Kafka clients0.10.2.0
227228KIP-84: Support SASL SCRAM mechanisms0.10.2.0
228229KIP-82 - Add Record Headers0.11.0.0
229230KIP-81: Bound Fetch memory usage in the consumer2.4.0 (WIP)
230231KIP-79 - ListOffsetRequest/ListOffsetResponse v1 and add timestamp search methods to the new consumer0.10.1.0
231232KIP-78: Cluster Id0.10.1.0
232233KIP-77: Improve Kafka Streams Join Semantics0.10.2.0
233234KIP-75 - Add per-connector Converters0.10.1.0
234235KIP-74: Add Fetch Response Size Limit in Bytes0.10.1.0
235236KIP-73: Replication Quotas0.10.1.0
236237KIP-72: Allow putting a bound on memory consumed by Incoming request 1.0.0
237238KIP-71: Enable log compaction and deletion to co-exist0.10.1.0
238239KIP-70: Revise Partition Assignment Semantics on New Consumer's Subscription Change0.10.1.0
239240KIP-67: Queryable state for Kafka Streams0.10.1.0
240241KIP-66: Single Message Transforms for Kafka Connect0.10.2.0 / 0.11.0.0
241242KIP-65: Expose timestamps to Connect0.10.1.0
242243KIP-63: Unify store and downstream caching in streams0.10.1.0
243244KIP-62: Allow consumer to send heartbeats from a background thread0.10.1.0
244245KIP-60 - Make Java client classloading more flexible0.10.1.0
245246KIP-58 - Make Log Compaction Point Configurable0.10.1.0
246247KIP-57 - Interoperable LZ4 Framing0.10.0.0
247248KIP-56: Allow cross origin HTTP requests on all HTTP methods0.10.0.0
248249KIP-55: Secure Quotas for Authenticated Users0.10.1.0
249250KIP-54: Sticky Partition Assignment Strategy0.11.0.0
250251KIP-52: Connector Control APIs0.10.0.0
251252KIP-51 - List Connectors REST API0.10.0.0
252253KIP-50 - Move Authorizer to o.a.k.common package0.10.1.0
253254KIP-48 Delegation token support for Kafka1.1.0
254255KIP-45 - Standardize all client sequence interaction on j.u.Collection.0.10.0.0
255256KIP-43: Kafka SASL enhancements0.10.0.0
256257KIP-42: Add Producer and Consumer Interceptors0.10.0.0
257258KIP-41: Consumer Max Records0.10.0.0
258259KIP-40: ListGroups and DescribeGroup0.9.0.0
259260KIP-38: ZooKeeper Authentication0.9.0.0
260261KIP-36 - Rack aware replica assignment0.10.0.0
261262KIP-35 - Retrieving protocol version0.10.0.0
262263KIP-33 - Add a time based log index0.10.1.0
263264KIP-32 - Add timestamps to Kafka message0.10.0.0
264265KIP-31 - Move to relative offsets in compressed message sets0.10.0.0
265266KIP-28 - Add a processor client0.10.0.0
266267KIP-26 - Add Kafka Connect framework for data import/export0.9.0.0
267268KIP-25 - System test improvements0.9.0.0
268269KIP-22 - Expose a Partitioner interface in the new producer0.9.0.0
269270KIP-21 - Dynamic Configuration0.9.0.0 (WIP)
270271KIP-20 Enable log preallocate to improve consume performance under windows and some old Linux file system0.9.0.0
271272KIP-19 - Add a request timeout to NetworkClient0.9.0.0
272273KIP-16 - Automated Replica Lag Tuning0.9.0.0
273274KIP-15 - Add a close method with a timeout in the producer0.9.0.0
274275KIP-13 - Quota Design0.9.0.0
275276KIP-12 - Kafka Sasl/Kerberos and SSL implementation0.9.0.0
276277KIP-11 - Kafka Authorizer design0.9.0.0
277278KIP-8 - Add a flush method to the producer API0.9.0.0
278279KIP-4 - Metadata Protocol Changes0.10.0.0
279280KIP-4 - Command line and centralized administrative operations0.9.0.0, 0.10.0.0, 0.10.1.0
280281KIP-3 - Mirror Maker Enhancement0.9.0.0
281282KIP-2 - Refactor brokers to allow listening on multiple ports and IPs0.9.0.0
282283KIP-1 - Remove support of request.required.acks0.9.0.0

...

KIPComment
KIP-59: Proposal for a kafka broker commandSent emails to Dev discussion group. Work tracked under KAFKA-3663.
KIP-125: ZookeeperConsumerConnector to KafkaConsumer Migration and Rollback
KIP-131 - Add access to OffsetStorageReader from SourceConnector
KIP-135 : Send of null key to a compacted topic should throw non-retriable error back to user
KIP 141 - ProducerRecord & SourceRecord: Add timestamp constructors
KIP-142: Add ListTopicsRequest to efficiently list all the topics in a cluster
KIP-148: Add a connect timeout for client
KIP-158: Kafka Connect should allow source connectors to set topic-specific settings for new topics
KIP-159: Introducing Rich functions to Streams
KIP-166 - Add a tool to make amounts of replicas and leaders on brokers balanced
KIP-169 - Lag-Aware Partition Assignment Strategy
KIP-178: Size-based log directory selection strategy


KIP-185: Make exactly once in order delivery the default producer setting


KIP-193: Add SchemaBuilder.from(Schema)
KIP-199: Add Kafka Connect offset tool
KIP-201: Rationalising Policy interfaces
KIP-209: Connection String Support
KIP-216: IQ should throw different exceptions for different errors
KIP-217: Expose a timeout to allow an expired ZK session to be re-created
KIP-221: Enhance KStream with Connecting Topic Creation and Repartition HintDiscussion
KIP-228 Negative record timestamp supportVoting in progress
KIP-234: add support for getting topic defaults from AdminClient
KIP-236: Interruptible Partition Reassignment Discussion
KIP-240: AdminClient.listReassignments() AdminClient.describeReassignments()
KIP-242: Mask password in Kafka Connect Rest API response
KIP-250 Add Support for Quorum-based Producer Acknowledgment
KIP-252 - Extend ACLs to allow filtering based on ip ranges and subnets
KIP-253: Support in-order message delivery with partition expansion Discussion
KIP-254: JsonConverter Exception Handeling
KIP-259: Improve Streams DSL Timestamp Propagation Semantics
KIP-260: add primary join operation for Stream-Stream join (WIP)Draft
KIP-264: Add a consumer metric to record raw fetch sizeVoting in progress
KIP-271: Add NetworkClient redirectorDiscussion
KIP-273: Kafka to support using ETCD beside ZookeeperDiscussion
KIP-275 - Indicate "isClosing" in the SinkTaskContextVoting in progress
KIP-280: Enhanced log compactionDiscussion

KIP-291: Separating controller connections and requests from the data plane

Accepted
KIP-293 Add new metrics for consumer/replication fetch requestsVoting in progress
KIP-296: Add connector level configurability for producer/consumer client configs Discussion
KIP-301: Schema Inferencing for JsonConverterDiscussion
KIP-304: Connect runtime mode improvements for container platformsDiscussion
KIP-314: KTable to GlobalKTable Bi-directional JoinDiscussion
KIP-315: Stream Join Sticky AssignorDiscussion
KIP-316: Command-line overrides for ConnectDistributed worker propertiesDiscussion
KIP-317: Add end-to-end data encryption functionality to Apache KafkaDiscussion
KIP-325: Extend Consumer Group Command to Show Beginning OffsetsVoting in Progress345
KIP-326: Schedulable KTable as Graph sourceDiscussion
KIP-333: Add faster mode of rebalancingDiscussion
KIP-334 - Include partitions in exceptions raised during consumer record deserialization/validation
KIP-335: Consider configurations for KafkaStreams

Discussion

KIP-347: Enable batching in FindCoordinatorRequestDiscussion
KIP-348 Eliminate null from SourceTask#poll()
KIP-350: Allow kafka-topics.sh to take brokerid as parameter to show partitions associated with it
KIP-356: Add KafkaConsumer fetch-error-rate and fetch-error-total metricsDiscussion
KIP-360: Improve handling of unknown producerDiscussion
KIP-362: Support Dynamic Session WindowDiscussion
KIP-363: Allow performance tools to print final results to output fileDiscussion
KIP-369: Alternative Partitioner to Support "Always Round-Robin" SelectionAccepted
KIP-370: Remove Orphan PartitionsDiscussion
KIP-373: Allow users to create delegation tokens for other usersDiscussion
KIP-375: Kafka Clients - make Metadata#TOPIC_EXPIRY_MS configurableDiscussion
KIP-378: Enable Dependency Injection for Kafka Streams handlersDiscussion

KIP-379: Multiple Consumer Group Management

Accepted
KIP-381: Connect: Tell about records that had their offsets flushed in callback

Voting in progress (restarted 18th January 2019, due to no votes in first attempt)

KIP-383:  Pluggable interface for SSL FactoryVoting in progress
KIP-384: Add config for incompatible changes to persistent metadataDiscussion
KIP-385: Avoid throwing away prefetched dataDiscussion
KIP-387: Fair Message Consumption Across Partitions in KafkaConsumer

Discussion

KIP-388: Add observer interface to record request and responseDiscussion
KIP-389: Introduce a configurable consumer group size limitAccepted
KIP-390: Allow fine-grained configuration for compressionDiscussion, JIRA exists with pull-request
KIP-391: Allow Producing with Offsets for Cluster ReplicationDiscussion, JIRA exists with pull-request
KIP-392: Allow consumers to fetch from closest replicaDiscussion
KIP-395: Encypt-then-MAC Delegation token metadata

KIP-396: Add Commit/List Offsets Operations to AdminClient

Discussion
KIP-397: Add methods to override fetch offsets based on timestampDiscussion
KIP-398: Support reading trust store from classpathDiscussion
KIP-399: Extend ProductionExceptionHandler to cover serialization exceptionsDiscussion
KIP-400: Improve exit status in case of errors in ConsoleProducerDiscussion
KIP-401: TransformerSupplier/ProcessorSupplier StateStore connectingVoting in progress
KIP-403: Increase ProducerPerformance precision by using nanoTimeDraft
KIP-405: Kafka Tiered Storage

Discussion

KIP-406: GlobalStreamThread should honor custom offset policy.Discussion
KIP-407: Kafka Connect support override worker kafka api configuration with connector configuration that post by rest api
KIP-408: Add asynchronous processing to Kafka StreamsDiscussion

KIP-409: Allow creating under-replicated topics and partitions


KIP-410: Add metric for request handler thread pool utilization by request type

Discussion
KIP-416: Notify SourceTask of ACK'd offsets, metadataDiscussion
KIP-418: A method-chaining way to branch KStreamDiscussion, JIRA exists with pull-request
KIP-419: Safely notify Kafka Connect SourceTask is stoppedVoting in progress, JIRA exists with pull request
KIP-421: Support resolving externalized secrets in AbstractConfigAccepted
KIP-422: Add support for client quota configuration in the Kafka Admin ClientDiscussion, JIRA exists with pull-request
KIP-423: Add JoinReason to Consumer Join Group Protocol

Discussion

KIP-424: Allow suppression of intermediate events based on wall clock timeDiscussion
KIP-426: Persist Broker Id to ZookeeperDiscussion
KIP-431: Support of printing additional ConsumerRecord fields in DefaultMessageFormatterVoting in progress, JIRA exists with pull-request
KIP-434: Add Replica Fetcher and Log Cleaner Count MetricsDiscussion
KIP-435: Internal Partition Reassignment BatchingDiscussion
KIP-437: Custom replacement for MaskField SMTVoting in progress, JIRA exists with pull-request
KIP-438: Expose task, connector IDs in Connect APIDiscussion
KIP-439: Cleanup built-in Store interfacesDiscussion
KIP-440: Extend Connect Converter to support headersVoting in progress
KIP-444: Augment metrics for Kafka StreamsDiscussion
KIP-448: Add State Stores Unit Test Support to Kafka Streams Test UtilsDiscussion
KIP-450: Sliding Window Aggregations in the DSLDiscussion
KIP-452: Tool to view cluster statusDiscussion, JIRA exists
KIP-457: Add DISCONNECTED status to Kafka StreamsDiscussion 
KIP-459: Improve KafkaStreams#closeDiscussion
KIP-463: Auto-configure non-default Serdes passed alongside the TopologyBuilderUnder discussion
KIP-466: Add support for List<T> serialization and deserializationVoting in progress
KIP-468: Avoid decompression of record when validate record at server in the scene of inPlaceAssignment .Under discussion
KIP-470: TopologyTestDriver test input and output usability improvementsUnder discussion
KIP-471: Expose RocksDB Metrics in Kafka Streams

Accepted

KIP-473: Enable KafkaLog4JAppender to use SASL Authentication Callback HandlersUnder Discussion 
KIP-474: To deprecate WindowStore#put(key, value)Accepted
KIP-475: New Metrics to Measure Number of Tasks on a ConnectorAcceptedKIP-476: Add Java AdminClient InterfaceUnder Discussion
KIP-477: Add PATCH method for connector config in Connect REST APIUnder Discussion
KIP-478 - Strongly typed Processor APIUnder Discussion
KIP-479: Add Materialized to JoinUnder Discussion
KIP-480: Sticky PartitionerAccepted
KIP-481: SerDe Improvements for Connect Decimal type in JSONUnder Discussion
KIP-482: Optional fields in the Kafka Protocol
KIP-487: Automatic Topic Creation on ProducerUnder Discussion
KIP-489: Kafka Consumer Record Latency MetricUnder Discussion
KIP-490: log when consumer groups lose a message because offset has been deletedUnder discussion
KIP-491: Preferred Leader Deprioritized List (Temporary Blacklist)Under discussion

...