From 82584e1fde2886e902ede02ada3185df15286bac Mon Sep 17 00:00:00 2001 From: Christo Date: Thu, 11 Sep 2025 10:58:08 +0100 Subject: [PATCH 1/2] Add 4.0.1 docs --- 40/documentation.html | 2 +- 40/generated/connect_rest.yaml | 2 +- 40/generated/protocol_messages.html | 3372 ++++++++++++++++- 40/generated/topic_config.html | 2 +- 40/js/templateData.js | 2 +- .../developer-guide/config-streams.html | 34 +- 40/streams/developer-guide/datatypes.html | 2 +- 40/streams/developer-guide/dsl-api.html | 4 +- 40/streams/upgrade-guide.html | 2 +- 40/toc.html | 1 + 40/upgrade.html | 29 +- 11 files changed, 3313 insertions(+), 139 deletions(-) diff --git a/40/documentation.html b/40/documentation.html index 16b5b2190..b142263ac 100644 --- a/40/documentation.html +++ b/40/documentation.html @@ -30,7 +30,7 @@
- +

Documentation

Kafka 4.0 Documentation

diff --git a/40/generated/connect_rest.yaml b/40/generated/connect_rest.yaml index 69639ddb3..1f2607cc0 100644 --- a/40/generated/connect_rest.yaml +++ b/40/generated/connect_rest.yaml @@ -8,7 +8,7 @@ info: name: Apache 2.0 url: https://www.apache.org/licenses/LICENSE-2.0.html title: Kafka Connect REST API - version: 4.0.0 + version: 4.0.1 paths: /: get: diff --git a/40/generated/protocol_messages.html b/40/generated/protocol_messages.html index 6cb593709..2f86f4a08 100644 --- a/40/generated/protocol_messages.html +++ b/40/generated/protocol_messages.html @@ -843,6 +843,98 @@
Produce API (Key: 0):
+
Produce Response (Version: 12) => [responses] throttle_time_ms _tagged_fields 
+  responses => name [partition_responses] _tagged_fields 
+    name => COMPACT_STRING
+    partition_responses => index error_code base_offset log_append_time_ms log_start_offset [record_errors] error_message _tagged_fields 
+      index => INT32
+      error_code => INT16
+      base_offset => INT64
+      log_append_time_ms => INT64
+      log_start_offset => INT64
+      record_errors => batch_index batch_index_error_message _tagged_fields 
+        batch_index => INT32
+        batch_index_error_message => COMPACT_NULLABLE_STRING
+      error_message => COMPACT_NULLABLE_STRING
+  throttle_time_ms => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
responsesEach produce response.
nameThe topic name.
partition_responsesEach partition that we produced to within the topic.
indexThe partition index.
error_codeThe error code, or 0 if there was no error.
base_offsetThe base offset.
log_append_time_msThe timestamp returned by broker after appending the messages. If CreateTime is used for the topic, the timestamp will be -1. If LogAppendTime is used for the topic, the timestamp will be the broker local time when the messages are appended.
log_start_offsetThe log start offset.
record_errorsThe batch indices of records that caused the batch to be dropped.
batch_indexThe batch index of the record that caused the batch to be dropped.
batch_index_error_messageThe error message of the record that caused the batch to be dropped.
_tagged_fieldsThe tagged fields
error_messageThe global error message summarizing the common root cause of the records that caused the batch to be dropped.
_tagged_fields + + + + + +
TagTagged fieldDescription
0current_leaderThe leader broker that the producer should use for future requests. + + + + + + + + +
FieldDescription
leader_idThe ID of the current leader or -1 if the leader is unknown.
leader_epochThe latest known leader epoch.
_tagged_fieldsThe tagged fields
+
+
_tagged_fieldsThe tagged fields
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
_tagged_fields + + + + + +
TagTagged fieldDescription
0node_endpointsEndpoints for all current-leaders enumerated in PartitionProduceResponses, with errors NOT_LEADER_OR_FOLLOWER. + + + + + + + + + + + + +
FieldDescription
node_idThe ID of the associated node.
hostThe node's hostname.
portThe node's port.
rackThe rack of the node, or null if it has not been assigned to a rack.
_tagged_fieldsThe tagged fields
+
+
+
Fetch API (Key: 1):
Requests:
@@ -2740,6 +2832,131 @@
Fetch API (Key: 1):
+
Fetch Response (Version: 17) => throttle_time_ms error_code session_id [responses] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  session_id => INT32
+  responses => topic_id [partitions] _tagged_fields 
+    topic_id => UUID
+    partitions => partition_index error_code high_watermark last_stable_offset log_start_offset [aborted_transactions] preferred_read_replica records _tagged_fields 
+      partition_index => INT32
+      error_code => INT16
+      high_watermark => INT64
+      last_stable_offset => INT64
+      log_start_offset => INT64
+      aborted_transactions => producer_id first_offset _tagged_fields 
+        producer_id => INT64
+        first_offset => INT64
+      preferred_read_replica => INT32
+      records => COMPACT_RECORDS
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe top level response error code.
session_idThe fetch session ID, or 0 if this is not part of a fetch session.
responsesThe response topics.
topic_idThe unique topic ID.
partitionsThe topic partitions.
partition_indexThe partition index.
error_codeThe error code, or 0 if there was no fetch error.
high_watermarkThe current high water mark.
last_stable_offsetThe last stable offset (or LSO) of the partition. This is the last offset such that the state of all transactional records prior to this offset have been decided (ABORTED or COMMITTED).
log_start_offsetThe current log start offset.
aborted_transactionsThe aborted transactions.
producer_idThe producer id associated with the aborted transaction.
first_offsetThe first offset in the aborted transaction.
_tagged_fieldsThe tagged fields
preferred_read_replicaThe preferred read replica for the consumer to use on its next fetch request.
recordsThe record data.
_tagged_fields + + + + + + + + + +
TagTagged fieldDescription
0diverging_epochIn case divergence is detected based on the `LastFetchedEpoch` and `FetchOffset` in the request, this field indicates the largest epoch and its end offset such that subsequent records are known to diverge. + + + + + + + + +
FieldDescription
epochThe largest epoch.
end_offsetThe end offset of the epoch.
_tagged_fieldsThe tagged fields
+
1current_leaderThe current leader of the partition. + + + + + + + + +
FieldDescription
leader_idThe ID of the current leader or -1 if the leader is unknown.
leader_epochThe latest known leader epoch.
_tagged_fieldsThe tagged fields
+
2snapshot_idIn the case of fetching an offset less than the LogStartOffset, this is the end offset and epoch that should be used in the FetchSnapshot request. + + + + + + + + +
FieldDescription
end_offsetThe end offset of the epoch.
epochThe largest epoch.
_tagged_fieldsThe tagged fields
+
+
_tagged_fieldsThe tagged fields
_tagged_fields + + + + + +
TagTagged fieldDescription
0node_endpointsEndpoints for all current-leaders enumerated in PartitionData, with errors NOT_LEADER_OR_FOLLOWER & FENCED_LEADER_EPOCH. + + + + + + + + + + + + +
FieldDescription
node_idThe ID of the associated node.
hostThe node's hostname.
portThe node's port.
rackThe rack of the node, or null if it has not been assigned to a rack.
_tagged_fieldsThe tagged fields
+
+
+
ListOffsets API (Key: 2):
Requests:
@@ -3393,6 +3610,46 @@
ListOffsets API (Key: 2):
_tagged_fieldsThe tagged fields +
ListOffsets Response (Version: 10) => throttle_time_ms [topics] _tagged_fields 
+  throttle_time_ms => INT32
+  topics => name [partitions] _tagged_fields 
+    name => COMPACT_STRING
+    partitions => partition_index error_code timestamp offset leader_epoch _tagged_fields 
+      partition_index => INT32
+      error_code => INT16
+      timestamp => INT64
+      offset => INT64
+      leader_epoch => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
topicsEach topic in the response.
nameThe topic name.
partitionsEach partition in the response.
partition_indexThe partition index.
error_codeThe partition error code, or 0 if there was no error.
timestampThe timestamp associated with the returned offset.
offsetThe returned offset.
leader_epochThe leader epoch associated with the returned offset.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
Metadata API (Key: 3):
Requests:
@@ -4544,8 +4801,92 @@
Metadata API (Key: 3):
_tagged_fieldsThe tagged fields -
OffsetCommit API (Key: 8):
- +
Metadata Response (Version: 13) => throttle_time_ms [brokers] cluster_id controller_id [topics] error_code _tagged_fields 
+  throttle_time_ms => INT32
+  brokers => node_id host port rack _tagged_fields 
+    node_id => INT32
+    host => COMPACT_STRING
+    port => INT32
+    rack => COMPACT_NULLABLE_STRING
+  cluster_id => COMPACT_NULLABLE_STRING
+  controller_id => INT32
+  topics => error_code name topic_id is_internal [partitions] topic_authorized_operations _tagged_fields 
+    error_code => INT16
+    name => COMPACT_NULLABLE_STRING
+    topic_id => UUID
+    is_internal => BOOLEAN
+    partitions => error_code partition_index leader_id leader_epoch [replica_nodes] [isr_nodes] [offline_replicas] _tagged_fields 
+      error_code => INT16
+      partition_index => INT32
+      leader_id => INT32
+      leader_epoch => INT32
+      replica_nodes => INT32
+      isr_nodes => INT32
+      offline_replicas => INT32
+    topic_authorized_operations => INT32
+  error_code => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
brokersA list of brokers present in the cluster.
node_idThe broker ID.
hostThe broker hostname.
portThe broker port.
rackThe rack of the broker, or null if it has not been assigned to a rack.
_tagged_fieldsThe tagged fields
cluster_idThe cluster ID that responding broker belongs to.
controller_idThe ID of the controller broker.
topicsEach topic in the response.
error_codeThe topic error, or 0 if there was no error.
nameThe topic name. Null for non-existing topics queried by ID. This is never null when ErrorCode is zero. One of Name and TopicId is always populated.
topic_idThe topic id. Zero for non-existing topics queried by name. This is never zero when ErrorCode is zero. One of Name and TopicId is always populated.
is_internalTrue if the topic is internal.
partitionsEach partition in the topic.
error_codeThe partition error, or 0 if there was no error.
partition_indexThe partition index.
leader_idThe ID of the leader broker.
leader_epochThe leader epoch of this partition.
replica_nodesThe set of all nodes that host this partition.
isr_nodesThe set of nodes that are in sync with the leader for this partition.
offline_replicasThe set of offline replicas of this partition.
_tagged_fieldsThe tagged fields
topic_authorized_operations32-bit bitfield to represent authorized operations for this topic.
_tagged_fieldsThe tagged fields
error_codeThe top-level error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
+
+
OffsetCommit API (Key: 8):
+ Requests:
OffsetCommit Request (Version: 2) => group_id generation_id_or_member_epoch member_id retention_time_ms [topics] 
   group_id => STRING
@@ -5040,6 +5381,37 @@ 
OffsetCommit API (Key: 8):
_tagged_fieldsThe tagged fields
+
OffsetCommit Response (Version: 9) => throttle_time_ms [topics] _tagged_fields 
+  throttle_time_ms => INT32
+  topics => name [partitions] _tagged_fields 
+    name => COMPACT_STRING
+    partitions => partition_index error_code _tagged_fields 
+      partition_index => INT32
+      error_code => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
topicsThe responses for each topic.
nameThe topic name.
partitionsThe responses for each partition in the topic.
partition_indexThe partition index.
error_codeThe error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
OffsetFetch API (Key: 9):
Requests:
@@ -5557,6 +5929,57 @@
OffsetFetch API (Key: 9):
_tagged_fieldsThe tagged fields +
OffsetFetch Response (Version: 9) => throttle_time_ms [groups] _tagged_fields 
+  throttle_time_ms => INT32
+  groups => group_id [topics] error_code _tagged_fields 
+    group_id => COMPACT_STRING
+    topics => name [partitions] _tagged_fields 
+      name => COMPACT_STRING
+      partitions => partition_index committed_offset committed_leader_epoch metadata error_code _tagged_fields 
+        partition_index => INT32
+        committed_offset => INT64
+        committed_leader_epoch => INT32
+        metadata => COMPACT_NULLABLE_STRING
+        error_code => INT16
+    error_code => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
groupsThe responses per group id.
group_idThe group ID.
topicsThe responses per topic.
nameThe topic name.
partitionsThe responses per partition.
partition_indexThe partition index.
committed_offsetThe committed message offset.
committed_leader_epochThe leader epoch.
metadataThe partition metadata.
error_codeThe partition-level error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
error_codeThe group-level error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
FindCoordinator API (Key: 10):
Requests:
@@ -5823,9 +6246,103 @@
FindCoordinator API (Key: 10):_tagged_fieldsThe tagged fields +
FindCoordinator Response (Version: 6) => throttle_time_ms [coordinators] _tagged_fields 
+  throttle_time_ms => INT32
+  coordinators => key node_id host port error_code error_message _tagged_fields 
+    key => COMPACT_STRING
+    node_id => INT32
+    host => COMPACT_STRING
+    port => INT32
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
coordinatorsEach coordinator result in the response.
keyThe coordinator key.
node_idThe node id.
hostThe host name.
portThe port.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
JoinGroup API (Key: 11):
Requests:
+
JoinGroup Request (Version: 0) => group_id session_timeout_ms member_id protocol_type [protocols] 
+  group_id => STRING
+  session_timeout_ms => INT32
+  member_id => STRING
+  protocol_type => STRING
+  protocols => name metadata 
+    name => STRING
+    metadata => BYTES
+

Request header version: 1

+ + + + + + + + + + + + + + + + + +
FieldDescription
group_idThe group identifier.
session_timeout_msThe coordinator considers the consumer dead if it receives no heartbeat after this timeout in milliseconds.
member_idThe member id assigned by the group coordinator.
protocol_typeThe unique name the for class of protocols implemented by the group we want to join.
protocolsThe list of protocols that the member supports.
nameThe protocol name.
metadataThe protocol metadata.
+
+
JoinGroup Request (Version: 1) => group_id session_timeout_ms rebalance_timeout_ms member_id protocol_type [protocols] 
+  group_id => STRING
+  session_timeout_ms => INT32
+  rebalance_timeout_ms => INT32
+  member_id => STRING
+  protocol_type => STRING
+  protocols => name metadata 
+    name => STRING
+    metadata => BYTES
+

Request header version: 1

+ + + + + + + + + + + + + + + + + + + +
FieldDescription
group_idThe group identifier.
session_timeout_msThe coordinator considers the consumer dead if it receives no heartbeat after this timeout in milliseconds.
rebalance_timeout_msThe maximum time in milliseconds that the coordinator will wait for each member to rejoin when rebalancing the group.
member_idThe member id assigned by the group coordinator.
protocol_typeThe unique name the for class of protocols implemented by the group we want to join.
protocolsThe list of protocols that the member supports.
nameThe protocol name.
metadataThe protocol metadata.
+
JoinGroup Request (Version: 2) => group_id session_timeout_ms rebalance_timeout_ms member_id protocol_type [protocols] 
   group_id => STRING
   session_timeout_ms => INT32
@@ -6112,6 +6629,68 @@ 
JoinGroup API (Key: 11):
Responses:
+
JoinGroup Response (Version: 0) => error_code generation_id protocol_name leader member_id [members] 
+  error_code => INT16
+  generation_id => INT32
+  protocol_name => STRING
+  leader => STRING
+  member_id => STRING
+  members => member_id metadata 
+    member_id => STRING
+    metadata => BYTES
+

Response header version: 0

+ + + + + + + + + + + + + + + + + + + +
FieldDescription
error_codeThe error code, or 0 if there was no error.
generation_idThe generation ID of the group.
protocol_nameThe group protocol selected by the coordinator.
leaderThe leader of the group.
member_idThe member ID assigned by the group coordinator.
membersThe group members.
member_idThe group member ID.
metadataThe group member metadata.
+
+
JoinGroup Response (Version: 1) => error_code generation_id protocol_name leader member_id [members] 
+  error_code => INT16
+  generation_id => INT32
+  protocol_name => STRING
+  leader => STRING
+  member_id => STRING
+  members => member_id metadata 
+    member_id => STRING
+    metadata => BYTES
+

Response header version: 0

+ + + + + + + + + + + + + + + + + + + +
FieldDescription
error_codeThe error code, or 0 if there was no error.
generation_idThe generation ID of the group.
protocol_nameThe group protocol selected by the coordinator.
leaderThe leader of the group.
member_idThe member ID assigned by the group coordinator.
membersThe group members.
member_idThe group member ID.
metadataThe group member metadata.
+
JoinGroup Response (Version: 2) => throttle_time_ms error_code generation_id protocol_name leader member_id [members] 
   throttle_time_ms => INT32
   error_code => INT16
@@ -6380,6 +6959,53 @@ 
JoinGroup API (Key: 11):
_tagged_fieldsThe tagged fields
+
JoinGroup Response (Version: 9) => throttle_time_ms error_code generation_id protocol_type protocol_name leader skip_assignment member_id [members] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  generation_id => INT32
+  protocol_type => COMPACT_NULLABLE_STRING
+  protocol_name => COMPACT_NULLABLE_STRING
+  leader => COMPACT_STRING
+  skip_assignment => BOOLEAN
+  member_id => COMPACT_STRING
+  members => member_id group_instance_id metadata _tagged_fields 
+    member_id => COMPACT_STRING
+    group_instance_id => COMPACT_NULLABLE_STRING
+    metadata => COMPACT_BYTES
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
generation_idThe generation ID of the group.
protocol_typeThe group protocol name.
protocol_nameThe group protocol selected by the coordinator.
leaderThe leader of the group.
skip_assignmentTrue if the leader must skip running the assignment.
member_idThe member ID assigned by the group coordinator.
membersThe group members.
member_idThe group member ID.
group_instance_idThe unique identifier of the consumer instance provided by end user.
metadataThe group member metadata.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
Heartbeat API (Key: 12):
Requests:
@@ -6521,6 +7147,21 @@
Heartbeat API (Key: 12):
error_codeThe error code, or 0 if there was no error. +
Heartbeat Response (Version: 4) => throttle_time_ms error_code _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+

Response header version: 1

+ + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
+
LeaveGroup API (Key: 13):
Requests:
@@ -6722,6 +7363,35 @@
LeaveGroup API (Key: 13):
_tagged_fieldsThe tagged fields +
LeaveGroup Response (Version: 5) => throttle_time_ms error_code [members] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  members => member_id group_instance_id error_code _tagged_fields 
+    member_id => COMPACT_STRING
+    group_instance_id => COMPACT_NULLABLE_STRING
+    error_code => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
membersList of leaving member responses.
member_idThe member ID to remove from the group.
group_instance_idThe group instance ID to remove from the group.
error_codeThe error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
SyncGroup API (Key: 14):
Requests:
@@ -6978,6 +7648,30 @@
SyncGroup API (Key: 14):
_tagged_fieldsThe tagged fields +
SyncGroup Response (Version: 5) => throttle_time_ms error_code protocol_type protocol_name assignment _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  protocol_type => COMPACT_NULLABLE_STRING
+  protocol_name => COMPACT_NULLABLE_STRING
+  assignment => COMPACT_BYTES
+

Response header version: 1

+ + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
protocol_typeThe group protocol type.
protocol_nameThe group protocol name.
assignmentThe member assignment.
_tagged_fieldsThe tagged fields
+
DescribeGroups API (Key: 15):
Requests:
@@ -7362,6 +8056,67 @@
DescribeGroups API (Key: 15):
_tagged_fieldsThe tagged fields +
DescribeGroups Response (Version: 6) => throttle_time_ms [groups] _tagged_fields 
+  throttle_time_ms => INT32
+  groups => error_code error_message group_id group_state protocol_type protocol_data [members] authorized_operations _tagged_fields 
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+    group_id => COMPACT_STRING
+    group_state => COMPACT_STRING
+    protocol_type => COMPACT_STRING
+    protocol_data => COMPACT_STRING
+    members => member_id group_instance_id client_id client_host member_metadata member_assignment _tagged_fields 
+      member_id => COMPACT_STRING
+      group_instance_id => COMPACT_NULLABLE_STRING
+      client_id => COMPACT_STRING
+      client_host => COMPACT_STRING
+      member_metadata => COMPACT_BYTES
+      member_assignment => COMPACT_BYTES
+    authorized_operations => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
groupsEach described group.
error_codeThe describe error, or 0 if there was no error.
error_messageThe describe error message, or null if there was no error.
group_idThe group ID string.
group_stateThe group state string, or the empty string.
protocol_typeThe group protocol type, or the empty string.
protocol_dataThe group protocol data, or the empty string.
membersThe group members.
member_idThe member id.
group_instance_idThe unique identifier of the consumer instance provided by end user.
client_idThe client ID used in the member's latest join group request.
client_hostThe client host.
member_metadataThe metadata corresponding to the current group protocol in use.
member_assignmentThe current assignment provided by the group leader.
_tagged_fieldsThe tagged fields
authorized_operations32-bit bitfield to represent authorized operations for this group.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
ListGroups API (Key: 16):
Requests:
@@ -7541,6 +8296,38 @@
ListGroups API (Key: 16):
_tagged_fieldsThe tagged fields +
ListGroups Response (Version: 5) => throttle_time_ms error_code [groups] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  groups => group_id protocol_type group_state group_type _tagged_fields 
+    group_id => COMPACT_STRING
+    protocol_type => COMPACT_STRING
+    group_state => COMPACT_STRING
+    group_type => COMPACT_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
groupsEach group in the response.
group_idThe group ID.
protocol_typeThe group protocol type.
group_stateThe group state name.
group_typeThe group type name.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
SaslHandshake API (Key: 17):
Requests:
@@ -7578,7 +8365,20 @@
SaslHandshake API (Key: 17):
mechanismsThe mechanisms enabled in the server. -
ApiVersions API (Key: 18):
+
SaslHandshake Response (Version: 1) => error_code [mechanisms] 
+  error_code => INT16
+  mechanisms => STRING
+

Response header version: 0

+ + + + + + + +
FieldDescription
error_codeThe error code, or 0 if there was no error.
mechanismsThe mechanisms enabled in the server.
+
+
ApiVersions API (Key: 18):
Requests:
ApiVersions Request (Version: 0) => 
@@ -7771,6 +8571,72 @@ 
ApiVersions API (Key: 18):
+
ApiVersions Response (Version: 4) => error_code [api_keys] throttle_time_ms _tagged_fields 
+  error_code => INT16
+  api_keys => api_key min_version max_version _tagged_fields 
+    api_key => INT16
+    min_version => INT16
+    max_version => INT16
+  throttle_time_ms => INT32
+

Response header version: 0

+ + + + + + + + + + + + + + + + + + + +
FieldDescription
error_codeThe top-level error code.
api_keysThe APIs supported by the broker.
api_keyThe API index.
min_versionThe minimum supported version, inclusive.
max_versionThe maximum supported version, inclusive.
_tagged_fieldsThe tagged fields
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
_tagged_fields + + + + + + + + + + + +
TagTagged fieldDescription
0supported_featuresFeatures supported by the broker. Note: in v0-v3, features with MinSupportedVersion = 0 are omitted. + + + + + + + + + + +
FieldDescription
nameThe name of the feature.
min_versionThe minimum supported version for the feature.
max_versionThe maximum supported version for the feature.
_tagged_fieldsThe tagged fields
+
1finalized_features_epochThe monotonically increasing epoch for the finalized features information. Valid values are >= 0. A value of -1 is special and represents unknown epoch.
2finalized_featuresList of cluster-wide finalized features. The information is valid only if FinalizedFeaturesEpoch >= 0. + + + + + + + + + + +
FieldDescription
nameThe name of the feature.
max_version_levelThe cluster-wide finalized max version level for the feature.
min_version_levelThe cluster-wide finalized min version level for the feature.
_tagged_fieldsThe tagged fields
+
3zk_migration_readySet by a KRaft controller if the required configurations for ZK migration are present.
+
+
CreateTopics API (Key: 19):
Requests:
@@ -8241,6 +9107,68 @@
CreateTopics API (Key: 19):
_tagged_fieldsThe tagged fields +
CreateTopics Response (Version: 7) => throttle_time_ms [topics] _tagged_fields 
+  throttle_time_ms => INT32
+  topics => name topic_id error_code error_message num_partitions replication_factor [configs] _tagged_fields 
+    name => COMPACT_STRING
+    topic_id => UUID
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+    num_partitions => INT32
+    replication_factor => INT16
+    configs => name value read_only config_source is_sensitive _tagged_fields 
+      name => COMPACT_STRING
+      value => COMPACT_NULLABLE_STRING
+      read_only => BOOLEAN
+      config_source => INT8
+      is_sensitive => BOOLEAN
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
topicsResults for each topic we tried to create.
nameThe topic name.
topic_idThe unique topic ID.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
num_partitionsNumber of partitions of the topic.
replication_factorReplication factor of the topic.
configsConfiguration of the topic.
nameThe configuration name.
valueThe configuration value.
read_onlyTrue if the configuration is read-only.
config_sourceThe configuration source.
is_sensitiveTrue if this configuration is sensitive.
_tagged_fieldsThe tagged fields
_tagged_fields + + + + + +
TagTagged fieldDescription
0topic_config_error_codeOptional topic config error returned if configs are not returned in the response.
+
_tagged_fieldsThe tagged fields
+
DeleteTopics API (Key: 20):
Requests:
@@ -8443,6 +9371,35 @@
DeleteTopics API (Key: 20):
_tagged_fieldsThe tagged fields +
DeleteTopics Response (Version: 6) => throttle_time_ms [responses] _tagged_fields 
+  throttle_time_ms => INT32
+  responses => name topic_id error_code error_message _tagged_fields 
+    name => COMPACT_NULLABLE_STRING
+    topic_id => UUID
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
responsesThe results for each topic we tried to delete.
nameThe topic name.
topic_idThe unique topic ID.
error_codeThe deletion error, or 0 if the deletion succeeded.
error_messageThe error message, or null if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
DeleteRecords API (Key: 21):
Requests:
@@ -8584,6 +9541,40 @@
DeleteRecords API (Key: 21):
error_codeThe deletion error code, or 0 if the deletion succeeded. +
DeleteRecords Response (Version: 2) => throttle_time_ms [topics] _tagged_fields 
+  throttle_time_ms => INT32
+  topics => name [partitions] _tagged_fields 
+    name => COMPACT_STRING
+    partitions => partition_index low_watermark error_code _tagged_fields 
+      partition_index => INT32
+      low_watermark => INT64
+      error_code => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
topicsEach topic that we wanted to delete records from.
nameThe topic name.
partitionsEach partition that we wanted to delete records from.
partition_indexThe partition index.
low_watermarkThe partition low water mark.
error_codeThe deletion error code, or 0 if the deletion succeeded.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
InitProducerId API (Key: 22):
Requests:
@@ -8793,6 +9784,27 @@
InitProducerId API (Key: 22):
_tagged_fieldsThe tagged fields +
InitProducerId Response (Version: 5) => throttle_time_ms error_code producer_id producer_epoch _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  producer_id => INT64
+  producer_epoch => INT16
+

Response header version: 1

+ + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
producer_idThe current producer id.
producer_epochThe current epoch associated with the producer id.
_tagged_fieldsThe tagged fields
+
OffsetForLeaderEpoch API (Key: 23):
Requests:
@@ -8946,6 +9958,43 @@
OffsetForLeaderEpoch API (Key: 2 end_offsetThe end offset of the epoch. +
OffsetForLeaderEpoch Response (Version: 4) => throttle_time_ms [topics] _tagged_fields 
+  throttle_time_ms => INT32
+  topics => topic [partitions] _tagged_fields 
+    topic => COMPACT_STRING
+    partitions => error_code partition leader_epoch end_offset _tagged_fields 
+      error_code => INT16
+      partition => INT32
+      leader_epoch => INT32
+      end_offset => INT64
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
topicsEach topic we fetched offsets for.
topicThe topic name.
partitionsEach partition in the topic we fetched offsets for.
error_codeThe error code 0, or if there was no error.
partitionThe partition index.
leader_epochThe leader epoch of the partition.
end_offsetThe end offset of the epoch.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
AddPartitionsToTxn API (Key: 24):
Requests:
@@ -9276,10 +10325,52 @@
AddPartitionsToTxn API (Key: 24):< _tagged_fieldsThe tagged fields -
AddOffsetsToTxn API (Key: 25):
- -Requests:
-
AddOffsetsToTxn Request (Version: 0) => transactional_id producer_id producer_epoch group_id 
+
AddPartitionsToTxn Response (Version: 5) => throttle_time_ms error_code [results_by_transaction] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  results_by_transaction => transactional_id [topic_results] _tagged_fields 
+    transactional_id => COMPACT_STRING
+    topic_results => name [results_by_partition] _tagged_fields 
+      name => COMPACT_STRING
+      results_by_partition => partition_index partition_error_code _tagged_fields 
+        partition_index => INT32
+        partition_error_code => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msDuration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe response top level error code.
results_by_transactionResults categorized by transactional ID.
transactional_idThe transactional id corresponding to the transaction.
topic_resultsThe results for each topic.
nameThe topic name.
results_by_partitionThe results for each partition.
partition_indexThe partition indexes.
partition_error_codeThe response error code.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
+
AddOffsetsToTxn API (Key: 25):
+ +Requests:
+
AddOffsetsToTxn Request (Version: 0) => transactional_id producer_id producer_epoch group_id 
   transactional_id => STRING
   producer_id => INT64
   producer_epoch => INT16
@@ -9433,6 +10524,21 @@ 
AddOffsetsToTxn API (Key: 25):_tagged_fieldsThe tagged fields
+
AddOffsetsToTxn Response (Version: 4) => throttle_time_ms error_code _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+

Response header version: 1

+ + + + + + + + + +
FieldDescription
throttle_time_msDuration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe response error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
+
EndTxn API (Key: 26):
Requests:
@@ -9626,6 +10732,27 @@
EndTxn API (Key: 26):
_tagged_fieldsThe tagged fields
+
EndTxn Response (Version: 5) => throttle_time_ms error_code producer_id producer_epoch _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  producer_id => INT64
+  producer_epoch => INT16
+

Response header version: 1

+ + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
producer_idThe producer ID.
producer_epochThe current epoch associated with the producer.
_tagged_fieldsThe tagged fields
+
WriteTxnMarkers API (Key: 27):
Requests:
@@ -9667,6 +10794,42 @@
WriteTxnMarkers API (Key: 27): Responses:
+
WriteTxnMarkers Response (Version: 1) => [markers] _tagged_fields 
+  markers => producer_id [topics] _tagged_fields 
+    producer_id => INT64
+    topics => name [partitions] _tagged_fields 
+      name => COMPACT_STRING
+      partitions => partition_index error_code _tagged_fields 
+        partition_index => INT32
+        error_code => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
markersThe results for writing makers.
producer_idThe current producer ID in use by the transactional ID.
topicsThe results by topic.
nameThe topic name.
partitionsThe results by partition.
partition_indexThe partition index.
error_codeThe error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
TxnOffsetCommit API (Key: 28):
Requests:
@@ -10087,6 +11250,37 @@
TxnOffsetCommit API (Key: 28):_tagged_fieldsThe tagged fields +
TxnOffsetCommit Response (Version: 5) => throttle_time_ms [topics] _tagged_fields 
+  throttle_time_ms => INT32
+  topics => name [partitions] _tagged_fields 
+    name => COMPACT_STRING
+    partitions => partition_index error_code _tagged_fields 
+      partition_index => INT32
+      error_code => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
topicsThe responses for each topic.
nameThe topic name.
partitionsThe responses for each partition in the topic.
partition_indexThe partition index.
error_codeThe error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
DescribeAcls API (Key: 29):
Requests:
@@ -10271,6 +11465,55 @@
DescribeAcls API (Key: 29):
_tagged_fieldsThe tagged fields +
DescribeAcls Response (Version: 3) => throttle_time_ms error_code error_message [resources] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  resources => resource_type resource_name pattern_type [acls] _tagged_fields 
+    resource_type => INT8
+    resource_name => COMPACT_STRING
+    pattern_type => INT8
+    acls => principal host operation permission_type _tagged_fields 
+      principal => COMPACT_STRING
+      host => COMPACT_STRING
+      operation => INT8
+      permission_type => INT8
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
resourcesEach Resource that is referenced in an ACL.
resource_typeThe resource type.
resource_nameThe resource name.
pattern_typeThe resource pattern type.
aclsThe ACLs.
principalThe ACL principal.
hostThe ACL host.
operationThe ACL operation.
permission_typeThe ACL permission type.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
CreateAcls API (Key: 30):
Requests:
@@ -10418,6 +11661,29 @@
CreateAcls API (Key: 30):
_tagged_fieldsThe tagged fields +
CreateAcls Response (Version: 3) => throttle_time_ms [results] _tagged_fields 
+  throttle_time_ms => INT32
+  results => error_code error_message _tagged_fields 
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
resultsThe results for each ACL creation.
error_codeThe result error, or zero if there was no error.
error_messageThe result message, or null if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
DeleteAcls API (Key: 31):
Requests:
@@ -10627,42 +11893,97 @@
DeleteAcls API (Key: 31):
_tagged_fieldsThe tagged fields -
DescribeConfigs API (Key: 32):
- -Requests:
-
DescribeConfigs Request (Version: 1) => [resources] include_synonyms 
-  resources => resource_type resource_name [configuration_keys] 
-    resource_type => INT8
-    resource_name => STRING
-    configuration_keys => STRING
-  include_synonyms => BOOLEAN
-

Request header version: 1

+
DeleteAcls Response (Version: 3) => throttle_time_ms [filter_results] _tagged_fields 
+  throttle_time_ms => INT32
+  filter_results => error_code error_message [matching_acls] _tagged_fields 
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+    matching_acls => error_code error_message resource_type resource_name pattern_type principal host operation permission_type _tagged_fields 
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+      resource_type => INT8
+      resource_name => COMPACT_STRING
+      pattern_type => INT8
+      principal => COMPACT_STRING
+      host => COMPACT_STRING
+      operation => INT8
+      permission_type => INT8
+

Response header version: 1

- + - + - + - + - -
Field Description
resourcesThe resources whose configurations we want to describe.
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
resource_typeThe resource type.
filter_resultsThe results for each filter.
resource_nameThe resource name.
error_codeThe error code, or 0 if the filter succeeded.
configuration_keysThe configuration keys to list, or null to list all configuration keys.
error_messageThe error message, or null if the filter succeeded.
include_synonymsTrue if we should include all synonyms.
-
-
DescribeConfigs Request (Version: 2) => [resources] include_synonyms 
-  resources => resource_type resource_name [configuration_keys] 
-    resource_type => INT8
-    resource_name => STRING
-    configuration_keys => STRING
-  include_synonyms => BOOLEAN
-

Request header version: 1

- - - - + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
matching_aclsThe ACLs which matched this filter.
error_codeThe deletion error code, or 0 if the deletion succeeded.
error_messageThe deletion error message, or null if the deletion succeeded.
resource_typeThe ACL resource type.
resource_nameThe ACL resource name.
pattern_typeThe ACL resource pattern type.
principalThe ACL principal.
hostThe ACL host.
operationThe ACL operation.
permission_typeThe ACL permission type.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
+
DescribeConfigs API (Key: 32):
+ +Requests:
+
DescribeConfigs Request (Version: 1) => [resources] include_synonyms 
+  resources => resource_type resource_name [configuration_keys] 
+    resource_type => INT8
+    resource_name => STRING
+    configuration_keys => STRING
+  include_synonyms => BOOLEAN
+

Request header version: 1

+ + + + + + + + + + + + + +
FieldDescription
resourcesThe resources whose configurations we want to describe.
resource_typeThe resource type.
resource_nameThe resource name.
configuration_keysThe configuration keys to list, or null to list all configuration keys.
include_synonymsTrue if we should include all synonyms.
+
+
DescribeConfigs Request (Version: 2) => [resources] include_synonyms 
+  resources => resource_type resource_name [configuration_keys] 
+    resource_type => INT8
+    resource_name => STRING
+    configuration_keys => STRING
+  include_synonyms => BOOLEAN
+

Request header version: 1

+ + + + @@ -10900,6 +12221,75 @@
DescribeConfigs API (Key: 32):documentation
FieldDescription
resourcesThe resources whose configurations we want to describe.
resource_typeThe resource type.
The configuration documentation.
+
DescribeConfigs Response (Version: 4) => throttle_time_ms [results] _tagged_fields 
+  throttle_time_ms => INT32
+  results => error_code error_message resource_type resource_name [configs] _tagged_fields 
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+    resource_type => INT8
+    resource_name => COMPACT_STRING
+    configs => name value read_only config_source is_sensitive [synonyms] config_type documentation _tagged_fields 
+      name => COMPACT_STRING
+      value => COMPACT_NULLABLE_STRING
+      read_only => BOOLEAN
+      config_source => INT8
+      is_sensitive => BOOLEAN
+      synonyms => name value source _tagged_fields 
+        name => COMPACT_STRING
+        value => COMPACT_NULLABLE_STRING
+        source => INT8
+      config_type => INT8
+      documentation => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
resultsThe results for each resource.
error_codeThe error code, or 0 if we were able to successfully describe the configurations.
error_messageThe error message, or null if we were able to successfully describe the configurations.
resource_typeThe resource type.
resource_nameThe resource name.
configsEach listed configuration.
nameThe configuration name.
valueThe configuration value.
read_onlyTrue if the configuration is read-only.
config_sourceThe configuration source.
is_sensitiveTrue if this configuration is sensitive.
synonymsThe synonyms for this configuration key.
nameThe synonym name.
valueThe synonym value.
sourceThe synonym source.
_tagged_fieldsThe tagged fields
config_typeThe configuration data type. Type can be one of the following values - BOOLEAN, STRING, INT, SHORT, LONG, DOUBLE, LIST, CLASS, PASSWORD.
documentationThe configuration documentation.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
AlterConfigs API (Key: 33):
Requests:
@@ -11044,6 +12434,35 @@
AlterConfigs API (Key: 33):
resource_nameThe resource name.
+
AlterConfigs Response (Version: 2) => throttle_time_ms [responses] _tagged_fields 
+  throttle_time_ms => INT32
+  responses => error_code error_message resource_type resource_name _tagged_fields 
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+    resource_type => INT8
+    resource_name => COMPACT_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msDuration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
responsesThe responses for each resource.
error_codeThe resource error code.
error_messageThe resource error message, or null if there was no error.
resource_typeThe resource type.
resource_nameThe resource name.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
AlterReplicaLogDirs API (Key: 34):
Requests:
@@ -11123,6 +12542,37 @@
AlterReplicaLogDirs API (Key: 34) error_codeThe error code, or 0 if there was no error. +
AlterReplicaLogDirs Response (Version: 2) => throttle_time_ms [results] _tagged_fields 
+  throttle_time_ms => INT32
+  results => topic_name [partitions] _tagged_fields 
+    topic_name => COMPACT_STRING
+    partitions => partition_index error_code _tagged_fields 
+      partition_index => INT32
+      error_code => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msDuration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
resultsThe results for each topic.
topic_nameThe name of the topic.
partitionsThe results for each partition.
partition_indexThe partition index.
error_codeThe error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
DescribeLogDirs API (Key: 35):
Requests:
@@ -11342,6 +12792,63 @@
DescribeLogDirs API (Key: 35):_tagged_fieldsThe tagged fields +
DescribeLogDirs Response (Version: 4) => throttle_time_ms error_code [results] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  results => error_code log_dir [topics] total_bytes usable_bytes _tagged_fields 
+    error_code => INT16
+    log_dir => COMPACT_STRING
+    topics => name [partitions] _tagged_fields 
+      name => COMPACT_STRING
+      partitions => partition_index partition_size offset_lag is_future_key _tagged_fields 
+        partition_index => INT32
+        partition_size => INT64
+        offset_lag => INT64
+        is_future_key => BOOLEAN
+    total_bytes => INT64
+    usable_bytes => INT64
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
resultsThe log directories.
error_codeThe error code, or 0 if there was no error.
log_dirThe absolute log directory path.
topicsThe topics.
nameThe topic name.
partitionsThe partitions.
partition_indexThe partition index.
partition_sizeThe size of the log segments in this partition in bytes.
offset_lagThe lag of the log's LEO w.r.t. partition's HW (if it is the current log for the partition) or current replica's LEO (if it is the future log for the partition).
is_future_keyTrue if this log is created by AlterReplicaLogDirsRequest and will replace the current log of the replica in the future.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
total_bytesThe total size in bytes of the volume the log directory is in.
usable_bytesThe usable size in bytes of the volume the log directory is in.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
SaslAuthenticate API (Key: 36):
Requests:
@@ -11413,6 +12920,27 @@
SaslAuthenticate API (Key: 36):< session_lifetime_msNumber of milliseconds after which only re-authentication over the existing connection to create a new session can occur. +
SaslAuthenticate Response (Version: 2) => error_code error_message auth_bytes session_lifetime_ms _tagged_fields 
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  auth_bytes => COMPACT_BYTES
+  session_lifetime_ms => INT64
+

Response header version: 1

+ + + + + + + + + + + + + +
FieldDescription
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
auth_bytesThe SASL authentication bytes from the server, as defined by the SASL mechanism.
session_lifetime_msNumber of milliseconds after which only re-authentication over the existing connection to create a new session can occur.
_tagged_fieldsThe tagged fields
+
CreatePartitions API (Key: 37):
Requests:
@@ -11611,10 +13139,36 @@
CreatePartitions API (Key: 37):< _tagged_fieldsThe tagged fields -
CreateDelegationToken API (Key: 38):
- -Requests:
-
CreateDelegationToken Request (Version: 1) => [renewers] max_lifetime_ms 
+
CreatePartitions Response (Version: 3) => throttle_time_ms [results] _tagged_fields 
+  throttle_time_ms => INT32
+  results => name error_code error_message _tagged_fields 
+    name => COMPACT_STRING
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
resultsThe partition creation results for each topic.
nameThe topic name.
error_codeThe result error, or zero if there was no error.
error_messageThe result message, or null if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
+
CreateDelegationToken API (Key: 38):
+ +Requests:
+
CreateDelegationToken Request (Version: 1) => [renewers] max_lifetime_ms 
   renewers => principal_type principal_name 
     principal_type => STRING
     principal_name => STRING
@@ -11756,6 +13310,48 @@ 
CreateDelegationToken API (Key: _tagged_fieldsThe tagged fields
+
CreateDelegationToken Response (Version: 3) => error_code principal_type principal_name token_requester_principal_type token_requester_principal_name issue_timestamp_ms expiry_timestamp_ms max_timestamp_ms token_id hmac throttle_time_ms _tagged_fields 
+  error_code => INT16
+  principal_type => COMPACT_STRING
+  principal_name => COMPACT_STRING
+  token_requester_principal_type => COMPACT_STRING
+  token_requester_principal_name => COMPACT_STRING
+  issue_timestamp_ms => INT64
+  expiry_timestamp_ms => INT64
+  max_timestamp_ms => INT64
+  token_id => COMPACT_STRING
+  hmac => COMPACT_BYTES
+  throttle_time_ms => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
error_codeThe top-level error, or zero if there was no error.
principal_typeThe principal type of the token owner.
principal_nameThe name of the token owner.
token_requester_principal_typeThe principal type of the requester of the token.
token_requester_principal_nameThe principal type of the requester of the token.
issue_timestamp_msWhen this token was generated.
expiry_timestamp_msWhen this token expires.
max_timestamp_msThe maximum lifetime of this token.
token_idThe token UUID.
hmacHMAC of the delegation token.
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
_tagged_fieldsThe tagged fields
+
RenewDelegationToken API (Key: 39):
Requests:
@@ -11804,6 +13400,24 @@
RenewDelegationToken API (Key: 3 throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
+
RenewDelegationToken Response (Version: 2) => error_code expiry_timestamp_ms throttle_time_ms _tagged_fields 
+  error_code => INT16
+  expiry_timestamp_ms => INT64
+  throttle_time_ms => INT32
+

Response header version: 1

+ + + + + + + + + + + +
FieldDescription
error_codeThe error code, or 0 if there was no error.
expiry_timestamp_msThe timestamp in milliseconds at which this token expires.
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
_tagged_fieldsThe tagged fields
+
ExpireDelegationToken API (Key: 40):
Requests:
@@ -11852,6 +13466,24 @@
ExpireDelegationToken API (Key: throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota. +
ExpireDelegationToken Response (Version: 2) => error_code expiry_timestamp_ms throttle_time_ms _tagged_fields 
+  error_code => INT16
+  expiry_timestamp_ms => INT64
+  throttle_time_ms => INT32
+

Response header version: 1

+ + + + + + + + + + + +
FieldDescription
error_codeThe error code, or 0 if there was no error.
expiry_timestamp_msThe timestamp in milliseconds at which this token expires.
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
_tagged_fieldsThe tagged fields
+
DescribeDelegationToken API (Key: 41):
Requests:
@@ -12010,6 +13642,64 @@
DescribeDelegationToken API ( _tagged_fieldsThe tagged fields +
DescribeDelegationToken Response (Version: 3) => error_code [tokens] throttle_time_ms _tagged_fields 
+  error_code => INT16
+  tokens => principal_type principal_name token_requester_principal_type token_requester_principal_name issue_timestamp expiry_timestamp max_timestamp token_id hmac [renewers] _tagged_fields 
+    principal_type => COMPACT_STRING
+    principal_name => COMPACT_STRING
+    token_requester_principal_type => COMPACT_STRING
+    token_requester_principal_name => COMPACT_STRING
+    issue_timestamp => INT64
+    expiry_timestamp => INT64
+    max_timestamp => INT64
+    token_id => COMPACT_STRING
+    hmac => COMPACT_BYTES
+    renewers => principal_type principal_name _tagged_fields 
+      principal_type => COMPACT_STRING
+      principal_name => COMPACT_STRING
+  throttle_time_ms => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
error_codeThe error code, or 0 if there was no error.
tokensThe tokens.
principal_typeThe token principal type.
principal_nameThe token principal name.
token_requester_principal_typeThe principal type of the requester of the token.
token_requester_principal_nameThe principal type of the requester of the token.
issue_timestampThe token issue timestamp in milliseconds.
expiry_timestampThe token expiry timestamp in milliseconds.
max_timestampThe token maximum timestamp length in milliseconds.
token_idThe token ID.
hmacThe token HMAC.
renewersThose who are able to renew this token before it expires.
principal_typeThe renewer principal type.
principal_nameThe renewer principal name.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
_tagged_fieldsThe tagged fields
+
DeleteGroups API (Key: 42):
Requests:
@@ -12084,6 +13774,29 @@
DeleteGroups API (Key: 42):
error_codeThe deletion error, or 0 if the deletion succeeded. +
DeleteGroups Response (Version: 2) => throttle_time_ms [results] _tagged_fields 
+  throttle_time_ms => INT32
+  results => group_id error_code _tagged_fields 
+    group_id => COMPACT_STRING
+    error_code => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
resultsThe deletion results.
group_idThe group id.
error_codeThe deletion error, or 0 if the deletion succeeded.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
ElectLeaders API (Key: 43):
Requests:
@@ -12214,6 +13927,43 @@
ElectLeaders API (Key: 43):
error_messageThe result message, or null if there was no error. +
ElectLeaders Response (Version: 2) => throttle_time_ms error_code [replica_election_results] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  replica_election_results => topic [partition_result] _tagged_fields 
+    topic => COMPACT_STRING
+    partition_result => partition_id error_code error_message _tagged_fields 
+      partition_id => INT32
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe top level response error code.
replica_election_resultsThe election results, or an empty array if the requester did not have permission and the request asks for all partitions.
topicThe topic name.
partition_resultThe results for each partition.
partition_idThe partition id.
error_codeThe result error, or zero if there was no error.
error_messageThe result message, or null if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
IncrementalAlterConfigs API (Key: 44):
Requests:
@@ -12311,6 +14061,35 @@
IncrementalAlterConfigs API ( resource_nameThe resource name. +
IncrementalAlterConfigs Response (Version: 1) => throttle_time_ms [responses] _tagged_fields 
+  throttle_time_ms => INT32
+  responses => error_code error_message resource_type resource_name _tagged_fields 
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+    resource_type => INT8
+    resource_name => COMPACT_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msDuration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
responsesThe responses for each resource.
error_codeThe resource error code.
error_messageThe resource error message, or null if there was no error.
resource_typeThe resource type.
resource_nameThe resource name.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
AlterPartitionReassignments API (Key: 45):
Requests:
@@ -12346,26 +14125,66 @@
AlterPartitionReassignmen Responses:
-
ListPartitionReassignments API (Key: 46):
- -Requests:
-
ListPartitionReassignments Request (Version: 0) => timeout_ms [topics] _tagged_fields 
-  timeout_ms => INT32
-  topics => name [partition_indexes] _tagged_fields 
+
AlterPartitionReassignments Response (Version: 0) => throttle_time_ms error_code error_message [responses] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  responses => name [partitions] _tagged_fields 
     name => COMPACT_STRING
-    partition_indexes => INT32
-

Request header version: 2

+ partitions => partition_index error_code error_message _tagged_fields + partition_index => INT32 + error_code => INT16 + error_message => COMPACT_NULLABLE_STRING +

Response header version: 1

- + - + - + - + + + + + + + + + + + + + + + + + +
Field Description
timeout_msThe time in ms to wait for the request to complete.
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
topicsThe topics to list partition reassignments for, or null to list everything.
error_codeThe top-level error code, or 0 if there was no error.
nameThe topic name.
error_messageThe top-level error message, or null if there was no error.
partition_indexesThe partitions to list partition reassignments for.
responsesThe responses to topics to reassign.
nameThe topic name.
partitionsThe responses to partitions to reassign.
partition_indexThe partition index.
error_codeThe error code for this partition, or 0 if there was no error.
error_messageThe error message for this partition, or null if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
+
ListPartitionReassignments API (Key: 46):
+ +Requests:
+
ListPartitionReassignments Request (Version: 0) => timeout_ms [topics] _tagged_fields 
+  timeout_ms => INT32
+  topics => name [partition_indexes] _tagged_fields 
+    name => COMPACT_STRING
+    partition_indexes => INT32
+

Request header version: 2

+ + + + + + + + + + + @@ -12373,6 +14192,49 @@
ListPartitionReassignments
FieldDescription
timeout_msThe time in ms to wait for the request to complete.
topicsThe topics to list partition reassignments for, or null to list everything.
nameThe topic name.
partition_indexesThe partitions to list partition reassignments for.
_tagged_fieldsThe tagged fields
Responses:
+
ListPartitionReassignments Response (Version: 0) => throttle_time_ms error_code error_message [topics] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  topics => name [partitions] _tagged_fields 
+    name => COMPACT_STRING
+    partitions => partition_index [replicas] [adding_replicas] [removing_replicas] _tagged_fields 
+      partition_index => INT32
+      replicas => INT32
+      adding_replicas => INT32
+      removing_replicas => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe top-level error code, or 0 if there was no error.
error_messageThe top-level error message, or null if there was no error.
topicsThe ongoing reassignments for each topic.
nameThe topic name.
partitionsThe ongoing reassignments for each partition.
partition_indexThe index of the partition.
replicasThe current replica set.
adding_replicasThe set of replicas we are currently adding.
removing_replicasThe set of replicas we are currently removing.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
OffsetDelete API (Key: 47):
Requests:
@@ -12399,6 +14261,34 @@
OffsetDelete API (Key: 47):
Responses:
+
OffsetDelete Response (Version: 0) => error_code throttle_time_ms [topics] 
+  error_code => INT16
+  throttle_time_ms => INT32
+  topics => name [partitions] 
+    name => STRING
+    partitions => partition_index error_code 
+      partition_index => INT32
+      error_code => INT16
+

Response header version: 0

+ + + + + + + + + + + + + + + + + +
FieldDescription
error_codeThe top-level error code, or 0 if there was no error.
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
topicsThe responses for each topic.
nameThe topic name.
partitionsThe responses for each partition in the topic.
partition_indexThe partition index.
error_codeThe error code, or 0 if there was no error.
+
DescribeClientQuotas API (Key: 48):
Requests:
@@ -12488,6 +14378,51 @@
DescribeClientQuotas API (Key: 4 valueThe quota configuration value. +
DescribeClientQuotas Response (Version: 1) => throttle_time_ms error_code error_message [entries] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  entries => [entity] [values] _tagged_fields 
+    entity => entity_type entity_name _tagged_fields 
+      entity_type => COMPACT_STRING
+      entity_name => COMPACT_NULLABLE_STRING
+    values => key value _tagged_fields 
+      key => COMPACT_STRING
+      value => FLOAT64
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or `0` if the quota description succeeded.
error_messageThe error message, or `null` if the quota description succeeded.
entriesA result entry.
entityThe quota entity description.
entity_typeThe entity type.
entity_nameThe entity name, or null if the default.
_tagged_fieldsThe tagged fields
valuesThe quota values for the entity.
keyThe quota configuration key.
valueThe quota configuration value.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
AlterClientQuotas API (Key: 49):
Requests:
@@ -12596,6 +14531,40 @@
AlterClientQuotas API (Key: 49):entity_nameThe name of the entity, or null if the default. +
AlterClientQuotas Response (Version: 1) => throttle_time_ms [entries] _tagged_fields 
+  throttle_time_ms => INT32
+  entries => error_code error_message [entity] _tagged_fields 
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+    entity => entity_type entity_name _tagged_fields 
+      entity_type => COMPACT_STRING
+      entity_name => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
entriesThe quota configuration entries to alter.
error_codeThe error code, or `0` if the quota alteration succeeded.
error_messageThe error message, or `null` if the quota alteration succeeded.
entityThe quota entity to alter.
entity_typeThe entity type.
entity_nameThe name of the entity, or null if the default.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
DescribeUserScramCredentials API (Key: 50):
Requests:
@@ -12617,6 +14586,49 @@
DescribeUserScramCredent Responses:
+
DescribeUserScramCredentials Response (Version: 0) => throttle_time_ms error_code error_message [results] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  results => user error_code error_message [credential_infos] _tagged_fields 
+    user => COMPACT_STRING
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+    credential_infos => mechanism iterations _tagged_fields 
+      mechanism => INT8
+      iterations => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe message-level error code, 0 except for user authorization or infrastructure issues.
error_messageThe message-level error message, if any.
resultsThe results for descriptions, one per user.
userThe user name.
error_codeThe user-level error code.
error_messageThe user-level error message, if any.
credential_infosThe mechanism and related information associated with the user's SCRAM credentials.
mechanismThe SCRAM mechanism.
iterationsThe number of iterations used in the SCRAM credential.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
AlterUserScramCredentials API (Key: 51):
Requests:
@@ -12661,6 +14673,32 @@
AlterUserScramCredentials A Responses:
+
AlterUserScramCredentials Response (Version: 0) => throttle_time_ms [results] _tagged_fields 
+  throttle_time_ms => INT32
+  results => user error_code error_message _tagged_fields 
+    user => COMPACT_STRING
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
resultsThe results for deletions and alterations, one per affected user.
userThe user name.
error_codeThe error code.
error_messageThe error message, if any.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
DescribeQuorum API (Key: 55):
Requests:
@@ -12860,27 +14898,123 @@
DescribeQuorum API (Key: 55):
_tagged_fieldsThe tagged fields -
UpdateFeatures API (Key: 57):
- -Requests:
-
UpdateFeatures Request (Version: 0) => timeout_ms [feature_updates] _tagged_fields 
-  timeout_ms => INT32
-  feature_updates => feature max_version_level allow_downgrade _tagged_fields 
-    feature => COMPACT_STRING
-    max_version_level => INT16
-    allow_downgrade => BOOLEAN
-

Request header version: 2

+
DescribeQuorum Response (Version: 2) => error_code error_message [topics] [nodes] _tagged_fields 
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  topics => topic_name [partitions] _tagged_fields 
+    topic_name => COMPACT_STRING
+    partitions => partition_index error_code error_message leader_id leader_epoch high_watermark [current_voters] [observers] _tagged_fields 
+      partition_index => INT32
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+      leader_id => INT32
+      leader_epoch => INT32
+      high_watermark => INT64
+      current_voters => replica_id replica_directory_id log_end_offset last_fetch_timestamp last_caught_up_timestamp _tagged_fields 
+        replica_id => INT32
+        replica_directory_id => UUID
+        log_end_offset => INT64
+        last_fetch_timestamp => INT64
+        last_caught_up_timestamp => INT64
+      observers => replica_id replica_directory_id log_end_offset last_fetch_timestamp last_caught_up_timestamp _tagged_fields 
+        replica_id => INT32
+        replica_directory_id => UUID
+        log_end_offset => INT64
+        last_fetch_timestamp => INT64
+        last_caught_up_timestamp => INT64
+  nodes => node_id [listeners] _tagged_fields 
+    node_id => INT32
+    listeners => name host port _tagged_fields 
+      name => COMPACT_STRING
+      host => COMPACT_STRING
+      port => UINT16
+

Response header version: 1

- + - + - + - + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
Field Description
timeout_msHow long to wait in milliseconds before timing out the request.
error_codeThe top level error code.
feature_updatesThe list of updates to finalized features.
error_messageThe error message, or null if there was no error.
featureThe name of the finalized feature to be updated.
topicsThe response from the describe quorum API.
max_version_levelThe new maximum version level for the finalized feature. A value >= 1 is valid. A value < 1, is special, and can be used to request the deletion of the finalized feature.
topic_nameThe topic name.
partitionsThe partition data.
partition_indexThe partition index.
error_codeThe partition error code.
error_messageThe error message, or null if there was no error.
leader_idThe ID of the current leader or -1 if the leader is unknown.
leader_epochThe latest known leader epoch.
high_watermarkThe high water mark.
current_votersThe current voters of the partition.
replica_idThe ID of the replica.
replica_directory_idThe replica directory ID of the replica.
log_end_offsetThe last known log end offset of the follower or -1 if it is unknown.
last_fetch_timestampThe last known leader wall clock time time when a follower fetched from the leader. This is reported as -1 both for the current leader or if it is unknown for a voter.
last_caught_up_timestampThe leader wall clock append time of the offset for which the follower made the most recent fetch request. This is reported as the current time for the leader and -1 if unknown for a voter.
_tagged_fieldsThe tagged fields
observersThe observers of the partition.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
nodesThe nodes in the quorum.
node_idThe ID of the associated node.
listenersThe listeners of this controller.
nameThe name of the endpoint.
hostThe hostname.
portThe port.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
+
UpdateFeatures API (Key: 57):
+ +Requests:
+
UpdateFeatures Request (Version: 0) => timeout_ms [feature_updates] _tagged_fields 
+  timeout_ms => INT32
+  feature_updates => feature max_version_level allow_downgrade _tagged_fields 
+    feature => COMPACT_STRING
+    max_version_level => INT16
+    allow_downgrade => BOOLEAN
+

Request header version: 2

+ + + + + + + + + + + @@ -13012,6 +15146,24 @@
UpdateFeatures API (Key: 57):
FieldDescription
timeout_msHow long to wait in milliseconds before timing out the request.
feature_updatesThe list of updates to finalized features.
featureThe name of the finalized feature to be updated.
max_version_levelThe new maximum version level for the finalized feature. A value >= 1 is valid. A value < 1, is special, and can be used to request the deletion of the finalized feature.
allow_downgradeDEPRECATED in version 1 (see DowngradeType). When set to true, the finalized feature version level is allowed to be downgraded/deleted. The downgrade request will fail if the new maximum version level is a value that's not lower than the existing maximum finalized version level.
_tagged_fieldsThe tagged fields
+
UpdateFeatures Response (Version: 2) => throttle_time_ms error_code error_message _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe top-level error code, or `0` if there was no top-level error.
error_messageThe top-level error message, or `null` if there was no top-level error.
_tagged_fieldsThe tagged fields
+
DescribeCluster API (Key: 60):
Requests:
@@ -13152,6 +15304,56 @@
DescribeCluster API (Key: 60):_tagged_fieldsThe tagged fields
+
DescribeCluster Response (Version: 2) => throttle_time_ms error_code error_message endpoint_type cluster_id controller_id [brokers] cluster_authorized_operations _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  endpoint_type => INT8
+  cluster_id => COMPACT_STRING
+  controller_id => INT32
+  brokers => broker_id host port rack is_fenced _tagged_fields 
+    broker_id => INT32
+    host => COMPACT_STRING
+    port => INT32
+    rack => COMPACT_NULLABLE_STRING
+    is_fenced => BOOLEAN
+  cluster_authorized_operations => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe top-level error code, or 0 if there was no error.
error_messageThe top-level error message, or null if there was no error.
endpoint_typeThe endpoint type that was described. 1=brokers, 2=controllers.
cluster_idThe cluster ID that responding broker belongs to.
controller_idThe ID of the controller broker.
brokersEach broker in the response.
broker_idThe broker ID.
hostThe broker hostname.
portThe broker port.
rackThe rack of the broker, or null if it has not been assigned to a rack.
is_fencedWhether the broker is fenced
_tagged_fieldsThe tagged fields
cluster_authorized_operations32-bit bitfield to represent authorized operations for this cluster.
_tagged_fieldsThe tagged fields
+
DescribeProducers API (Key: 61):
Requests:
@@ -13176,6 +15378,63 @@
DescribeProducers API (Key: 61): Responses:
+
DescribeProducers Response (Version: 0) => throttle_time_ms [topics] _tagged_fields 
+  throttle_time_ms => INT32
+  topics => name [partitions] _tagged_fields 
+    name => COMPACT_STRING
+    partitions => partition_index error_code error_message [active_producers] _tagged_fields 
+      partition_index => INT32
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+      active_producers => producer_id producer_epoch last_sequence last_timestamp coordinator_epoch current_txn_start_offset _tagged_fields 
+        producer_id => INT64
+        producer_epoch => INT32
+        last_sequence => INT32
+        last_timestamp => INT64
+        coordinator_epoch => INT32
+        current_txn_start_offset => INT64
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
topicsEach topic in the response.
nameThe topic name.
partitionsEach partition in the response.
partition_indexThe partition index.
error_codeThe partition error code, or 0 if there was no error.
error_messageThe partition error message, which may be null if no additional details are available.
active_producersThe active producers for the partition.
producer_idThe producer id.
producer_epochThe producer epoch.
last_sequenceThe last sequence number sent by the producer.
last_timestampThe last timestamp sent by the producer.
coordinator_epochThe current epoch of the producer group.
current_txn_start_offsetThe current transaction start offset of the producer.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
UnregisterBroker API (Key: 64):
Requests:
@@ -13192,6 +15451,24 @@
UnregisterBroker API (Key: 64):< Responses:
+
UnregisterBroker Response (Version: 0) => throttle_time_ms error_code error_message _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + +
FieldDescription
throttle_time_msDuration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
error_messageThe top-level error message, or `null` if there was no top-level error.
_tagged_fieldsThe tagged fields
+
DescribeTransactions API (Key: 65):
Requests:
@@ -13208,6 +15485,55 @@
DescribeTransactions API (Key: 6 Responses:
+
DescribeTransactions Response (Version: 0) => throttle_time_ms [transaction_states] _tagged_fields 
+  throttle_time_ms => INT32
+  transaction_states => error_code transactional_id transaction_state transaction_timeout_ms transaction_start_time_ms producer_id producer_epoch [topics] _tagged_fields 
+    error_code => INT16
+    transactional_id => COMPACT_STRING
+    transaction_state => COMPACT_STRING
+    transaction_timeout_ms => INT32
+    transaction_start_time_ms => INT64
+    producer_id => INT64
+    producer_epoch => INT16
+    topics => topic [partitions] _tagged_fields 
+      topic => COMPACT_STRING
+      partitions => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
transaction_statesThe current state of the transaction.
error_codeThe error code.
transactional_idThe transactional id.
transaction_stateThe current transaction state of the producer.
transaction_timeout_msThe timeout in milliseconds for the transaction.
transaction_start_time_msThe start time of the transaction in milliseconds.
producer_idThe current producer id associated with the transaction.
producer_epochThe current epoch associated with the producer id.
topicsThe set of partitions included in the current transaction (if active). When a transaction is preparing to commit or abort, this will include only partitions which do not have markers.
topicThe topic name.
partitionsThe partition ids included in the current transaction.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
ListTransactions API (Key: 66):
Requests:
@@ -13277,27 +15603,59 @@
ListTransactions API (Key: 66):< _tagged_fieldsThe tagged fields -
ConsumerGroupHeartbeat API (Key: 68):
- -Requests:
-
ConsumerGroupHeartbeat Request (Version: 0) => group_id member_id member_epoch instance_id rack_id rebalance_timeout_ms [subscribed_topic_names] server_assignor [topic_partitions] _tagged_fields 
-  group_id => COMPACT_STRING
-  member_id => COMPACT_STRING
-  member_epoch => INT32
-  instance_id => COMPACT_NULLABLE_STRING
-  rack_id => COMPACT_NULLABLE_STRING
-  rebalance_timeout_ms => INT32
-  subscribed_topic_names => COMPACT_STRING
-  server_assignor => COMPACT_NULLABLE_STRING
-  topic_partitions => topic_id [partitions] _tagged_fields 
-    topic_id => UUID
-    partitions => INT32
-

Request header version: 2

+
ListTransactions Response (Version: 1) => throttle_time_ms error_code [unknown_state_filters] [transaction_states] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  unknown_state_filters => COMPACT_STRING
+  transaction_states => transactional_id producer_id transaction_state _tagged_fields 
+    transactional_id => COMPACT_STRING
+    producer_id => INT64
+    transaction_state => COMPACT_STRING
+

Response header version: 1

- + + + + + + + + + + + + + + + + + +
Field Description
group_idThe group identifier.
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
unknown_state_filtersSet of state filters provided in the request which were unknown to the transaction coordinator.
transaction_statesThe current state of the transaction for the transactional id.
transactional_idThe transactional id.
producer_idThe producer id.
transaction_stateThe current transaction state of the producer.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
+
ConsumerGroupHeartbeat API (Key: 68):
+ +Requests:
+
ConsumerGroupHeartbeat Request (Version: 0) => group_id member_id member_epoch instance_id rack_id rebalance_timeout_ms [subscribed_topic_names] server_assignor [topic_partitions] _tagged_fields 
+  group_id => COMPACT_STRING
+  member_id => COMPACT_STRING
+  member_epoch => INT32
+  instance_id => COMPACT_NULLABLE_STRING
+  rack_id => COMPACT_NULLABLE_STRING
+  rebalance_timeout_ms => INT32
+  subscribed_topic_names => COMPACT_STRING
+  server_assignor => COMPACT_NULLABLE_STRING
+  topic_partitions => topic_id [partitions] _tagged_fields 
+    topic_id => UUID
+    partitions => INT32
+

Request header version: 2

+ + + + + @@ -13415,6 +15773,49 @@
ConsumerGroupHeartbeat API (Ke
FieldDescription
group_idThe group identifier.
member_idThe member id generated by the consumer. The member id must be kept during the entire lifetime of the consumer process.
_tagged_fieldsThe tagged fields
+
ConsumerGroupHeartbeat Response (Version: 1) => throttle_time_ms error_code error_message member_id member_epoch heartbeat_interval_ms assignment _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  member_id => COMPACT_NULLABLE_STRING
+  member_epoch => INT32
+  heartbeat_interval_ms => INT32
+  assignment => [topic_partitions] _tagged_fields 
+    topic_partitions => topic_id [partitions] _tagged_fields 
+      topic_id => UUID
+      partitions => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe top-level error code, or 0 if there was no error.
error_messageThe top-level error message, or null if there was no error.
member_idThe member id is generated by the consumer starting from version 1, while in version 0, it can be provided by users or generated by the group coordinator.
member_epochThe member epoch.
heartbeat_interval_msThe heartbeat interval in milliseconds.
assignmentnull if not provided; the assignment otherwise.
topic_partitionsThe partitions assigned to the member that can be used immediately.
topic_idThe topic ID.
partitionsThe partitions.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
ConsumerGroupDescribe API (Key: 69):
Requests:
@@ -13545,6 +15946,105 @@
ConsumerGroupDescribe API (Key: _tagged_fieldsThe tagged fields
+
ConsumerGroupDescribe Response (Version: 1) => throttle_time_ms [groups] _tagged_fields 
+  throttle_time_ms => INT32
+  groups => error_code error_message group_id group_state group_epoch assignment_epoch assignor_name [members] authorized_operations _tagged_fields 
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+    group_id => COMPACT_STRING
+    group_state => COMPACT_STRING
+    group_epoch => INT32
+    assignment_epoch => INT32
+    assignor_name => COMPACT_STRING
+    members => member_id instance_id rack_id member_epoch client_id client_host [subscribed_topic_names] subscribed_topic_regex assignment target_assignment member_type _tagged_fields 
+      member_id => COMPACT_STRING
+      instance_id => COMPACT_NULLABLE_STRING
+      rack_id => COMPACT_NULLABLE_STRING
+      member_epoch => INT32
+      client_id => COMPACT_STRING
+      client_host => COMPACT_STRING
+      subscribed_topic_names => COMPACT_STRING
+      subscribed_topic_regex => COMPACT_NULLABLE_STRING
+      assignment => [topic_partitions] _tagged_fields 
+        topic_partitions => topic_id topic_name [partitions] _tagged_fields 
+          topic_id => UUID
+          topic_name => COMPACT_STRING
+          partitions => INT32
+      target_assignment => [topic_partitions] _tagged_fields 
+        topic_partitions => topic_id topic_name [partitions] _tagged_fields 
+          topic_id => UUID
+          topic_name => COMPACT_STRING
+          partitions => INT32
+      member_type => INT8
+    authorized_operations => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
groupsEach described group.
error_codeThe describe error, or 0 if there was no error.
error_messageThe top-level error message, or null if there was no error.
group_idThe group ID string.
group_stateThe group state string, or the empty string.
group_epochThe group epoch.
assignment_epochThe assignment epoch.
assignor_nameThe selected assignor.
membersThe members.
member_idThe member ID.
instance_idThe member instance ID.
rack_idThe member rack ID.
member_epochThe current member epoch.
client_idThe client ID.
client_hostThe client host.
subscribed_topic_namesThe subscribed topic names.
subscribed_topic_regexthe subscribed topic regex otherwise or null of not provided.
assignmentThe current assignment.
topic_partitionsThe assigned topic-partitions to the member.
topic_idThe topic ID.
topic_nameThe topic name.
partitionsThe partitions.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
target_assignmentThe target assignment.
member_type-1 for unknown. 0 for classic member. +1 for consumer member.
_tagged_fieldsThe tagged fields
authorized_operations32-bit bitfield to represent authorized operations for this group.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
GetTelemetrySubscriptions API (Key: 71):
Requests:
@@ -13561,6 +16061,42 @@
GetTelemetrySubscriptions A Responses:
+
GetTelemetrySubscriptions Response (Version: 0) => throttle_time_ms error_code client_instance_id subscription_id [accepted_compression_types] push_interval_ms telemetry_max_bytes delta_temporality [requested_metrics] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  client_instance_id => UUID
+  subscription_id => INT32
+  accepted_compression_types => INT8
+  push_interval_ms => INT32
+  telemetry_max_bytes => INT32
+  delta_temporality => BOOLEAN
+  requested_metrics => COMPACT_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
client_instance_idAssigned client instance id if ClientInstanceId was 0 in the request, else 0.
subscription_idUnique identifier for the current subscription set for this client instance.
accepted_compression_typesCompression types that broker accepts for the PushTelemetryRequest.
push_interval_msConfigured push interval, which is the lowest configured interval in the current subscription set.
telemetry_max_bytesThe maximum bytes of binary data the broker accepts in PushTelemetryRequest.
delta_temporalityFlag to indicate monotonic/counter metrics are to be emitted as deltas or cumulative values.
requested_metricsRequested metrics prefix string match. Empty array: No metrics subscribed, Array[0] empty string: All metrics subscribed.
_tagged_fieldsThe tagged fields
+
PushTelemetry API (Key: 72):
Requests:
@@ -13589,6 +16125,21 @@
PushTelemetry API (Key: 72):
Responses:
+
PushTelemetry Response (Version: 0) => throttle_time_ms error_code _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+

Response header version: 1

+ + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
_tagged_fieldsThe tagged fields
+
ListClientMetricsResources API (Key: 74):
Requests:
@@ -13602,6 +16153,29 @@
ListClientMetricsResources Responses:
+
ListClientMetricsResources Response (Version: 0) => throttle_time_ms error_code [client_metrics_resources] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  client_metrics_resources => name _tagged_fields 
+    name => COMPACT_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
client_metrics_resourcesEach client metrics resource in the response.
nameThe resource name.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
DescribeTopicPartitions API (Key: 75):
Requests:
@@ -13637,34 +16211,152 @@
DescribeTopicPartitions API ( Responses:
-
ShareGroupHeartbeat API (Key: 76):
- -Requests:
-
ShareGroupHeartbeat Request (Version: 0) => group_id member_id member_epoch rack_id [subscribed_topic_names] _tagged_fields 
-  group_id => COMPACT_STRING
-  member_id => COMPACT_STRING
-  member_epoch => INT32
-  rack_id => COMPACT_NULLABLE_STRING
-  subscribed_topic_names => COMPACT_STRING
-

This version of the request is unstable.

Request header version: 2

- - - - - - - - - - - - - +
DescribeTopicPartitions Response (Version: 0) => throttle_time_ms [topics] next_cursor _tagged_fields 
+  throttle_time_ms => INT32
+  topics => error_code name topic_id is_internal [partitions] topic_authorized_operations _tagged_fields 
+    error_code => INT16
+    name => COMPACT_NULLABLE_STRING
+    topic_id => UUID
+    is_internal => BOOLEAN
+    partitions => error_code partition_index leader_id leader_epoch [replica_nodes] [isr_nodes] [eligible_leader_replicas] [last_known_elr] [offline_replicas] _tagged_fields 
+      error_code => INT16
+      partition_index => INT32
+      leader_id => INT32
+      leader_epoch => INT32
+      replica_nodes => INT32
+      isr_nodes => INT32
+      eligible_leader_replicas => INT32
+      last_known_elr => INT32
+      offline_replicas => INT32
+    topic_authorized_operations => INT32
+  next_cursor => topic_name partition_index _tagged_fields 
+    topic_name => COMPACT_STRING
+    partition_index => INT32
+

Response header version: 1

+
FieldDescription
group_idThe group identifier.
member_idThe member id.
member_epochThe current member epoch; 0 to join the group; -1 to leave the group.
rack_idnull if not provided or if it didn't change since the last heartbeat; the rack ID of consumer otherwise.
subscribed_topic_namesnull if it didn't change since the last heartbeat; the subscribed topic names otherwise.
+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
topicsEach topic in the response.
error_codeThe topic error, or 0 if there was no error.
nameThe topic name.
topic_idThe topic id.
is_internalTrue if the topic is internal.
partitionsEach partition in the topic.
error_codeThe partition error, or 0 if there was no error.
partition_indexThe partition index.
leader_idThe ID of the leader broker.
leader_epochThe leader epoch of this partition.
replica_nodesThe set of all nodes that host this partition.
isr_nodesThe set of nodes that are in sync with the leader for this partition.
eligible_leader_replicasThe new eligible leader replicas otherwise.
last_known_elrThe last known ELR.
offline_replicasThe set of offline replicas of this partition.
_tagged_fieldsThe tagged fields
topic_authorized_operations32-bit bitfield to represent authorized operations for this topic.
_tagged_fieldsThe tagged fields
next_cursorThe next topic and partition index to fetch details for.
topic_nameThe name for the first topic to process.
partition_indexThe partition index to start with.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
+
ShareGroupHeartbeat API (Key: 76):
+ +Requests:
+
ShareGroupHeartbeat Request (Version: 0) => group_id member_id member_epoch rack_id [subscribed_topic_names] _tagged_fields 
+  group_id => COMPACT_STRING
+  member_id => COMPACT_STRING
+  member_epoch => INT32
+  rack_id => COMPACT_NULLABLE_STRING
+  subscribed_topic_names => COMPACT_STRING
+

This version of the request is unstable.

Request header version: 2

+ + + + + + + + + + + + +
FieldDescription
group_idThe group identifier.
member_idThe member id.
member_epochThe current member epoch; 0 to join the group; -1 to leave the group.
rack_idnull if not provided or if it didn't change since the last heartbeat; the rack ID of consumer otherwise.
subscribed_topic_namesnull if it didn't change since the last heartbeat; the subscribed topic names otherwise.
_tagged_fieldsThe tagged fields
Responses:
+
ShareGroupHeartbeat Response (Version: 0) => throttle_time_ms error_code error_message member_id member_epoch heartbeat_interval_ms assignment _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  member_id => COMPACT_NULLABLE_STRING
+  member_epoch => INT32
+  heartbeat_interval_ms => INT32
+  assignment => [topic_partitions] _tagged_fields 
+    topic_partitions => topic_id [partitions] _tagged_fields 
+      topic_id => UUID
+      partitions => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe top-level error code, or 0 if there was no error.
error_messageThe top-level error message, or null if there was no error.
member_idThe member ID is generated by the consumer and provided by the consumer for all requests.
member_epochThe member epoch.
heartbeat_interval_msThe heartbeat interval in milliseconds.
assignmentnull if not provided; the assignment otherwise.
topic_partitionsThe partitions assigned to the member.
topic_idThe topic ID.
partitionsThe partitions.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
ShareGroupDescribe API (Key: 77):
Requests:
@@ -13684,6 +16376,89 @@
ShareGroupDescribe API (Key: 77):< Responses:
+
ShareGroupDescribe Response (Version: 0) => throttle_time_ms [groups] _tagged_fields 
+  throttle_time_ms => INT32
+  groups => error_code error_message group_id group_state group_epoch assignment_epoch assignor_name [members] authorized_operations _tagged_fields 
+    error_code => INT16
+    error_message => COMPACT_NULLABLE_STRING
+    group_id => COMPACT_STRING
+    group_state => COMPACT_STRING
+    group_epoch => INT32
+    assignment_epoch => INT32
+    assignor_name => COMPACT_STRING
+    members => member_id rack_id member_epoch client_id client_host [subscribed_topic_names] assignment _tagged_fields 
+      member_id => COMPACT_STRING
+      rack_id => COMPACT_NULLABLE_STRING
+      member_epoch => INT32
+      client_id => COMPACT_STRING
+      client_host => COMPACT_STRING
+      subscribed_topic_names => COMPACT_STRING
+      assignment => [topic_partitions] _tagged_fields 
+        topic_partitions => topic_id topic_name [partitions] _tagged_fields 
+          topic_id => UUID
+          topic_name => COMPACT_STRING
+          partitions => INT32
+    authorized_operations => INT32
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
groupsEach described group.
error_codeThe describe error, or 0 if there was no error.
error_messageThe top-level error message, or null if there was no error.
group_idThe group ID string.
group_stateThe group state string, or the empty string.
group_epochThe group epoch.
assignment_epochThe assignment epoch.
assignor_nameThe selected assignor.
membersThe members.
member_idThe member ID.
rack_idThe member rack ID.
member_epochThe current member epoch.
client_idThe client ID.
client_hostThe client host.
subscribed_topic_namesThe subscribed topic names.
assignmentThe current assignment.
topic_partitionsThe assigned topic-partitions to the member.
topic_idThe topic ID.
topic_nameThe topic name.
partitionsThe partitions.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
authorized_operations32-bit bitfield to represent authorized operations for this group.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
ShareFetch API (Key: 78):
Requests:
@@ -13747,18 +16522,109 @@
ShareFetch API (Key: 78):
_tagged_fieldsThe tagged fields -forgotten_topics_dataThe partitions to remove from this share session. +forgotten_topics_dataThe partitions to remove from this share session. + +topic_idThe unique topic ID. + +partitionsThe partitions indexes to forget. + +_tagged_fieldsThe tagged fields + +_tagged_fieldsThe tagged fields + + +Responses:
+
ShareFetch Response (Version: 0) => throttle_time_ms error_code error_message [responses] [node_endpoints] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  responses => topic_id [partitions] _tagged_fields 
+    topic_id => UUID
+    partitions => partition_index error_code error_message acknowledge_error_code acknowledge_error_message current_leader records [acquired_records] _tagged_fields 
+      partition_index => INT32
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+      acknowledge_error_code => INT16
+      acknowledge_error_message => COMPACT_NULLABLE_STRING
+      current_leader => leader_id leader_epoch _tagged_fields 
+        leader_id => INT32
+        leader_epoch => INT32
+      records => COMPACT_RECORDS
+      acquired_records => first_offset last_offset delivery_count _tagged_fields 
+        first_offset => INT64
+        last_offset => INT64
+        delivery_count => INT16
+  node_endpoints => node_id host port rack _tagged_fields 
+    node_id => INT32
+    host => COMPACT_STRING
+    port => INT32
+    rack => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + - + - +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe top-level response error code.
error_messageThe top-level error message, or null if there was no error.
responsesThe response topics.
topic_idThe unique topic ID.
partitionsThe topic partitions.
partition_indexThe partition index.
error_codeThe fetch error code, or 0 if there was no fetch error.
error_messageThe fetch error message, or null if there was no fetch error.
acknowledge_error_codeThe acknowledge error code, or 0 if there was no acknowledge error.
acknowledge_error_messageThe acknowledge error message, or null if there was no acknowledge error.
current_leaderThe current leader of the partition.
leader_idThe ID of the current leader or -1 if the leader is unknown.
leader_epochThe latest known leader epoch.
_tagged_fieldsThe tagged fields
recordsThe record data.
acquired_recordsThe acquired records.
first_offsetThe earliest offset in this batch of acquired records.
last_offsetThe last offset of this batch of acquired records.
delivery_countThe delivery count of this batch of acquired records.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
node_endpointsEndpoints for all current leaders enumerated in PartitionData with error NOT_LEADER_OR_FOLLOWER.
node_idThe ID of the associated node.
hostThe node's hostname.
topic_idThe unique topic ID.
portThe node's port.
partitionsThe partitions indexes to forget.
rackThe rack of the node, or null if it has not been assigned to a rack.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
-Responses:
ShareAcknowledge API (Key: 79):
Requests:
@@ -13811,6 +16677,74 @@
ShareAcknowledge API (Key: 79):< Responses:
+
ShareAcknowledge Response (Version: 0) => throttle_time_ms error_code error_message [responses] [node_endpoints] _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+  responses => topic_id [partitions] _tagged_fields 
+    topic_id => UUID
+    partitions => partition_index error_code error_message current_leader _tagged_fields 
+      partition_index => INT32
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+      current_leader => leader_id leader_epoch _tagged_fields 
+        leader_id => INT32
+        leader_epoch => INT32
+  node_endpoints => node_id host port rack _tagged_fields 
+    node_id => INT32
+    host => COMPACT_STRING
+    port => INT32
+    rack => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe top level response error code.
error_messageThe top-level error message, or null if there was no error.
responsesThe response topics.
topic_idThe unique topic ID.
partitionsThe topic partitions.
partition_indexThe partition index.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
current_leaderThe current leader of the partition.
leader_idThe ID of the current leader or -1 if the leader is unknown.
leader_epochThe latest known leader epoch.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
node_endpointsEndpoints for all current leaders enumerated in PartitionData with error NOT_LEADER_OR_FOLLOWER.
node_idThe ID of the associated node.
hostThe node's hostname.
portThe node's port.
rackThe rack of the node, or null if it has not been assigned to a rack.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
AddRaftVoter API (Key: 80):
Requests:
@@ -13850,6 +16784,24 @@
AddRaftVoter API (Key: 80):
Responses:
+
AddRaftVoter Response (Version: 0) => throttle_time_ms error_code error_message _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
_tagged_fieldsThe tagged fields
+
RemoveRaftVoter API (Key: 81):
Requests:
@@ -13872,6 +16824,24 @@
RemoveRaftVoter API (Key: 81): Responses:
+
RemoveRaftVoter Response (Version: 0) => throttle_time_ms error_code error_message _tagged_fields 
+  throttle_time_ms => INT32
+  error_code => INT16
+  error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + +
FieldDescription
throttle_time_msThe duration in milliseconds for which the request was throttled due to a quota violation, or zero if the request did not violate any quota.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
_tagged_fieldsThe tagged fields
+
InitializeShareGroupState API (Key: 83):
Requests:
@@ -13910,6 +16880,37 @@
InitializeShareGroupState A Responses:
+
InitializeShareGroupState Response (Version: 0) => [results] _tagged_fields 
+  results => topic_id [partitions] _tagged_fields 
+    topic_id => UUID
+    partitions => partition error_code error_message _tagged_fields 
+      partition => INT32
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + +
FieldDescription
resultsThe initialization results.
topic_idThe topic identifier.
partitionsThe results for the partitions.
partitionThe partition index.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
ReadShareGroupState API (Key: 84):
Requests:
@@ -13945,6 +16946,60 @@
ReadShareGroupState API (Key: 84) Responses:
+
ReadShareGroupState Response (Version: 0) => [results] _tagged_fields 
+  results => topic_id [partitions] _tagged_fields 
+    topic_id => UUID
+    partitions => partition error_code error_message state_epoch start_offset [state_batches] _tagged_fields 
+      partition => INT32
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+      state_epoch => INT32
+      start_offset => INT64
+      state_batches => first_offset last_offset delivery_state delivery_count _tagged_fields 
+        first_offset => INT64
+        last_offset => INT64
+        delivery_state => INT8
+        delivery_count => INT16
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
resultsThe read results.
topic_idThe topic identifier.
partitionsThe results for the partitions.
partitionThe partition index.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
state_epochThe state epoch for this share-partition.
start_offsetThe share-partition start offset, which can be -1 if it is not yet initialized.
state_batchesThe state batches for this share-partition.
first_offsetThe base offset of this state batch.
last_offsetThe last offset of this state batch.
delivery_stateThe state - 0:Available,2:Acked,4:Archived.
delivery_countThe delivery count.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
WriteShareGroupState API (Key: 85):
Requests:
@@ -14003,6 +17058,37 @@
WriteShareGroupState API (Key: 8 Responses:
+
WriteShareGroupState Response (Version: 0) => [results] _tagged_fields 
+  results => topic_id [partitions] _tagged_fields 
+    topic_id => UUID
+    partitions => partition error_code error_message _tagged_fields 
+      partition => INT32
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + +
FieldDescription
resultsThe write results.
topic_idThe topic identifier.
partitionsThe results for the partitions.
partitionThe partition index.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
DeleteShareGroupState API (Key: 86):
Requests:
@@ -14035,6 +17121,37 @@
DeleteShareGroupState API (Key: Responses:
+
DeleteShareGroupState Response (Version: 0) => [results] _tagged_fields 
+  results => topic_id [partitions] _tagged_fields 
+    topic_id => UUID
+    partitions => partition error_code error_message _tagged_fields 
+      partition => INT32
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + +
FieldDescription
resultsThe delete results.
topic_idThe topic identifier.
partitionsThe results for the partitions.
partitionThe partition index.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
ReadShareGroupStateSummary API (Key: 87):
Requests:
@@ -14070,4 +17187,41 @@
ReadShareGroupStateSummary Responses:
+
ReadShareGroupStateSummary Response (Version: 0) => [results] _tagged_fields 
+  results => topic_id [partitions] _tagged_fields 
+    topic_id => UUID
+    partitions => partition error_code error_message state_epoch start_offset _tagged_fields 
+      partition => INT32
+      error_code => INT16
+      error_message => COMPACT_NULLABLE_STRING
+      state_epoch => INT32
+      start_offset => INT64
+

Response header version: 1

+ + + + + + + + + + + + + + + + + + + + + + + + + +
FieldDescription
resultsThe read results.
topic_idThe topic identifier.
partitionsThe results for the partitions.
partitionThe partition index.
error_codeThe error code, or 0 if there was no error.
error_messageThe error message, or null if there was no error.
state_epochThe state epoch of the share-partition.
start_offsetThe share-partition start offset.
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
_tagged_fieldsThe tagged fields
+
diff --git a/40/generated/topic_config.html b/40/generated/topic_config.html index 6de2732c4..d67be4eee 100644 --- a/40/generated/topic_config.html +++ b/40/generated/topic_config.html @@ -276,7 +276,7 @@

remote.storage.enable

-

To enable tiered storage for a topic, set this configuration as true. You can not disable this config once it is enabled. It will be provided in future versions.

+

To enable tiered storage for a topic, set this configuration to true. To disable tiered storage for a topic that has it enabled, set this configuration to false. When disabling, you must also set remote.log.delete.on.disable to true.

diff --git a/40/js/templateData.js b/40/js/templateData.js index 34c8a96b7..fedf50f2a 100644 --- a/40/js/templateData.js +++ b/40/js/templateData.js @@ -19,6 +19,6 @@ limitations under the License. var context={ "version": "40", "dotVersion": "4.0", - "fullDotVersion": "4.0.0", + "fullDotVersion": "4.0.1", "scalaVersion": "2.13" }; diff --git a/40/streams/developer-guide/config-streams.html b/40/streams/developer-guide/config-streams.html index a7d82b97c..b14bd0427 100644 --- a/40/streams/developer-guide/config-streams.html +++ b/40/streams/developer-guide/config-streams.html @@ -296,12 +296,12 @@

num.standby.replicas

- + - + @@ -326,11 +326,10 @@

num.standby.replicasnull

- + @@ -481,54 +480,59 @@

num.standby.replicas-1 -

+ + + + + + - + - + (10 minutes) - + - + - + (5 minutes) - + - + - + (1 day) - + diff --git a/40/streams/developer-guide/datatypes.html b/40/streams/developer-guide/datatypes.html index a35272568..f2968591c 100644 --- a/40/streams/developer-guide/datatypes.html +++ b/40/streams/developer-guide/datatypes.html @@ -103,7 +103,7 @@

Primitive and basic types<dependency> <groupId>org.apache.kafka</groupId> <artifactId>kafka-clients</artifactId> - <version>{{fullDotVersion}}</version> + <version>2.8.0</version> </dependency>

This artifact provides the following serde implementations under the package org.apache.kafka.common.serialization, which you can leverage when e.g., defining default serializers in your Streams configuration.

Type:boolean
Default:false
commit.interval.ms Low The frequency in milliseconds with which to save the position (offsets in source topics) of tasks.30000 (30 seconds)30000 (30 seconds) (at-least-once) / 100 (exactly-once)
default.deserialization.exception.handler (Deprecated. Use deserialization.exception.handler instead.) Medium Exception handling class that implements the DeserializationExceptionHandler interface.LogAndContinueExceptionHandlerLogAndFailExceptionHandler
default.key.serde Medium
default.dsl.store
default.dsl.store (Deprecated. Use dsl.store.suppliers.class instead.) Low - [DEPRECATED] The default state store type used by DSL operators. Deprecated in - favor of dsl.store.suppliers.class + The default state store type used by DSL operators. "ROCKS_DB"
retry.backoff.ms
repartition.purge.interval.msLowThe frequency in milliseconds with which to delete fully consumed records from repartition topics. Purging will occur after at least this value since the last purge, but may be delayed until later.30000 (30 seconds)
retry.backoff.ms Low The amount of time in milliseconds, before a request is retried. 100
rocksdb.config.setter
rocksdb.config.setter Medium The RocksDB configuration. null
state.cleanup.delay.ms
state.cleanup.delay.ms Low The amount of time in milliseconds to wait before deleting state when a partition has migrated. 600000
state.dir
state.dir High Directory location for state stores. /${java.io.tmpdir}/kafka-streams
task.assignor.class
task.assignor.class Medium A task assignor class or class name implementing the TaskAssignor interface. The high-availability task assignor.
task.timeout.ms
task.timeout.ms Medium The maximum amount of time in milliseconds a task might stall due to internal errors and retries until an error is raised. For a timeout of 0 ms, a task would raise an error for the first internal error. For any timeout larger than 0 ms, a task will retry at least once before an error is raised. 300000
topology.optimization
topology.optimization Medium A configuration telling Kafka Streams if it should optimize the topology and what optimizations to apply. Acceptable values are: StreamsConfig.NO_OPTIMIZATION (none), StreamsConfig.OPTIMIZE (all) or a comma separated list of specific optimizations: StreamsConfig.REUSE_KTABLE_SOURCE_TOPICS (reuse.ktable.source.topics), StreamsConfig.MERGE_REPARTITION_TOPICS (merge.repartition.topics), StreamsConfig.SINGLE_STORE_SELF_JOIN (single.store.self.join). "NO_OPTIMIZATION"
upgrade.from
upgrade.from Medium The version you are upgrading from during a rolling upgrade. See Upgrade From null
windowstore.changelog.additional.retention.ms
windowstore.changelog.additional.retention.ms Low Added to a windows maintainMs to ensure data is not deleted from the log prematurely. Allows for clock drift. 86400000
window.size.ms
window.size.ms Low Sets window size for the deserializer in order to calculate window end times. null
diff --git a/40/streams/developer-guide/dsl-api.html b/40/streams/developer-guide/dsl-api.html index 4e4133dab..4de5389ac 100644 --- a/40/streams/developer-guide/dsl-api.html +++ b/40/streams/developer-guide/dsl-api.html @@ -764,10 +764,10 @@

Manually trigger repartitioning of the stream with desired number of partitions. (details)

- repartition() is similar to through() however Kafka Streams will manage the topic for you. + Kafka Streams will manage the topic for repartition(). Generated topic is treated as internal topic, as a result data will be purged automatically as any other internal repartition topic. In addition, you can specify the desired number of partitions, which allows to easily scale in/out downstream sub-topologies. - repartition() operation always triggers repartitioning of the stream, as a result it can be used with embedded Processor API methods (like transform() et al.) that do not trigger auto repartitioning when key changing operation is performed beforehand. + repartition() operation always triggers repartitioning of the stream, as a result it can be used with embedded Processor API methods (like process() et al.) that do not trigger auto repartitioning when key changing operation is performed beforehand.
KStream<byte[], String> stream = ... ;
 KStream<byte[], String> repartitionedStream = stream.repartition(Repartitioned.numberOfPartitions(10));
diff --git a/40/streams/upgrade-guide.html b/40/streams/upgrade-guide.html index 404211c74..f3d9713d9 100644 --- a/40/streams/upgrade-guide.html +++ b/40/streams/upgrade-guide.html @@ -224,7 +224,7 @@

Streams API

In order to reduce storage overhead and improve API usability, a new method in the Java and Scala APIs that accepts a BiFunction for foreign key extraction is introduced by - KIP-1104. + KIP-1104. KIP-1104 allows foreign key extraction from both the key and value in KTable joins in Apache Kafka. Previously, foreign key joins in KTables only allowed extraction from the value, which led to data duplication and potential inconsistencies. This enhancement introduces a new method in the Java and Scala APIs that accepts a BiFunction for foreign key extraction, enabling more intuitive and efficient joins. diff --git a/40/toc.html b/40/toc.html index c42961cf7..f0bd3e84e 100644 --- a/40/toc.html +++ b/40/toc.html @@ -148,6 +148,7 @@

  • 6.7 Monitoring
    • Security Considerations for Remote Monitoring using JMX +
    • Group Coordinator Monitoring
    • Tiered Storage Monitoring
    • KRaft Monitoring
    • Selector Monitoring diff --git a/40/upgrade.html b/40/upgrade.html index 01b0c51ea..86507f66e 100644 --- a/40/upgrade.html +++ b/40/upgrade.html @@ -19,9 +19,9 @@