Create a DBaaS Kafka service

POST /dbaas-kafka/{name}

Create a DBaaS Kafka service

Path parameters

  • name dbaas-service-name Required

    Service name

    Minimum length is 0, maximum length is 63.

application/json

Body Required

  • Kafka authentication methods

    Hide authentication-methods attributes Show authentication-methods attributes
    • Enable certificate/SSL authentication

    • sasl boolean

      Enable SASL authentication

  • Enable Kafka-REST service

  • Allow clients to connect to kafka_connect from the public internet for service nodes that are in a project VPC or another type of private network

  • ip-filter array[string]

    Allow incoming connections from CIDR address block, e.g. '10.20.0.0/16'

  • schema-registry-settings json-schema-schema-registry

    Schema Registry configuration

    Hide schema-registry-settings attributes Show schema-registry-settings attributes
    • topic_name topic_name

      The durable single partition topic that acts as the durable log for the data. This topic must be compacted to avoid losing data due to retention policy. Please note that changing this configuration in an existing Schema Registry / Karapace setup leads to previous schemas being inaccessible, data encoded with them potentially unreadable and schema ID sequence put out of order. It's only possible to do the switch while Schema Registry / Karapace is disabled. Defaults to _schemas.

      Minimum length is 1, maximum length is 249. Format should match the following pattern: ^(?!\.$|\.\.$)[-_.A-Za-z0-9]+$.

    • leader_eligibility leader_eligibility

      If true, Karapace / Schema Registry on the service nodes can participate in leader election. It might be needed to disable this when the schemas topic is replicated to a secondary cluster and Karapace / Schema Registry there must not participate in leader election. Defaults to true.

  • kafka-rest-settings json-schema-kafka-rest

    Kafka REST configuration

    Hide kafka-rest-settings attributes Show kafka-rest-settings attributes
    • producer_acks producer.acks

      The number of acknowledgments the producer requires the leader to have received before considering a request complete. If set to 'all' or '-1', the leader will wait for the full set of in-sync replicas to acknowledge the record.

      Values are all, -1, 0, or 1. Default value is 1.

    • producer_compression_type producer.compression.type

      Specify the default compression type for producers. This configuration accepts the standard compression codecs ('gzip', 'snappy', 'lz4', 'zstd'). It additionally accepts 'none' which is the default and equivalent to no compression.

      Values are gzip, snappy, lz4, zstd, or none.

    • producer_linger_ms producer.linger.ms

      Wait for up to the given delay to allow batching records together

      Minimum value is 0, maximum value is 5000. Default value is 0.

    • producer_max_request_size producer.max.request.size

      The maximum size of a request in bytes. Note that Kafka broker can also cap the record batch size.

      Minimum value is 0, maximum value is 2147483647. Default value is 1048576.

    • consumer_enable_auto_commit consumer.enable.auto.commit

      If true the consumer's offset will be periodically committed to Kafka in the background

      Default value is true.

    • consumer_request_max_bytes consumer.request.max.bytes

      Maximum number of bytes in unencoded message keys and values by a single request

      Minimum value is 0, maximum value is 671088640. Default value is 67108864.

    • consumer_request_timeout_ms consumer.request.timeout.ms

      The maximum total time to wait for messages for a request if the maximum number of messages has not yet been reached

      Minimum value is 1000, maximum value is 30000. Values are 1000, 15000, or 30000. Default value is 1000.

    • simpleconsumer_pool_size_max simpleconsumer.pool.size.max

      Maximum number of SimpleConsumers that can be instantiated per broker

      Minimum value is 10, maximum value is 250. Default value is 25.

  • Service is protected against termination and powering off

  • kafka-connect-settings json-schema-kafka-connect

    Kafka Connect configuration values

    Hide kafka-connect-settings attributes Show kafka-connect-settings attributes
    • producer_buffer_memory The total bytes of memory the producer can use to buffer records waiting to be sent to the broker

      The total bytes of memory the producer can use to buffer records waiting to be sent to the broker (defaults to 33554432).

      Minimum value is 5242880, maximum value is 134217728.

    • consumer_max_poll_interval_ms The maximum delay between polls when using consumer group management

      The maximum delay in milliseconds between invocations of poll() when using consumer group management (defaults to 300000).

      Minimum value is 1, maximum value is 2147483647.

    • producer_compression_type The default compression type for producers

      Specify the default compression type for producers. This configuration accepts the standard compression codecs ('gzip', 'snappy', 'lz4', 'zstd'). It additionally accepts 'none' which is the default and equivalent to no compression.

      Values are gzip, snappy, lz4, zstd, or none.

    • connector_client_config_override_policy Client config override policy

      Defines what client configurations can be overridden by the connector. Default is None

      Values are None or All.

    • offset_flush_interval_ms The interval at which to try committing offsets for tasks

      The interval at which to try committing offsets for tasks (defaults to 60000).

      Minimum value is 1, maximum value is 100000000.

    • scheduled_rebalance_max_delay_ms The maximum delay of rebalancing connector workers

      The maximum delay that is scheduled in order to wait for the return of one or more departed workers before rebalancing and reassigning their connectors and tasks to the group. During this period the connectors and tasks of the departed workers remain unassigned. Defaults to 5 minutes.

      Minimum value is 0, maximum value is 600000.

    • consumer_fetch_max_bytes The maximum amount of data the server should return for a fetch request

      Records are fetched in batches by the consumer, and if the first record batch in the first non-empty partition of the fetch is larger than this value, the record batch will still be returned to ensure that the consumer can make progress. As such, this is not a absolute maximum.

      Minimum value is 1048576, maximum value is 104857600.

    • consumer_max_partition_fetch_bytes The maximum amount of data per-partition the server will return.

      Records are fetched in batches by the consumer.If the first record batch in the first non-empty partition of the fetch is larger than this limit, the batch will still be returned to ensure that the consumer can make progress.

      Minimum value is 1048576, maximum value is 104857600.

    • offset_flush_timeout_ms Offset flush timeout

      Maximum number of milliseconds to wait for records to flush and partition offset data to be committed to offset storage before cancelling the process and restoring the offset data to be committed in a future attempt (defaults to 5000).

      Minimum value is 1, maximum value is 2147483647.

    • consumer_auto_offset_reset Consumer auto offset reset

      What to do when there is no initial offset in Kafka or if the current offset does not exist any more on the server. Default is earliest

      Values are earliest or latest.

    • producer_max_request_size The maximum size of a request in bytes

      This setting will limit the number of record batches the producer will send in a single request to avoid sending huge requests.

      Minimum value is 131072, maximum value is 67108864.

    • producer_batch_size The batch size in bytes the producer will attempt to collect for the same partition before publishing to broker

      This setting gives the upper bound of the batch size to be sent. If there are fewer than this many bytes accumulated for this partition, the producer will 'linger' for the linger.ms time waiting for more records to show up. A batch size of zero will disable batching entirely (defaults to 16384).

      Minimum value is 0, maximum value is 5242880.

    • session_timeout_ms The timeout used to detect failures when using Kafka’s group management facilities

      The timeout in milliseconds used to detect failures when using Kafka’s group management facilities (defaults to 10000).

      Minimum value is 1, maximum value is 2147483647.

    • producer_linger_ms Wait for up to the given delay to allow batching records together

      This setting gives the upper bound on the delay for batching: once there is batch.size worth of records for a partition it will be sent immediately regardless of this setting, however if there are fewer than this many bytes accumulated for this partition the producer will 'linger' for the specified time waiting for more records to show up. Defaults to 0.

      Minimum value is 0, maximum value is 5000.

    • consumer_isolation_level Consumer isolation level

      Transaction read isolation level. read_uncommitted is the default, but read_committed can be used if consume-exactly-once behavior is desired.

      Values are read_uncommitted or read_committed.

    • consumer_max_poll_records The maximum number of records returned by a single poll

      The maximum number of records returned in a single call to poll() (defaults to 500).

      Minimum value is 1, maximum value is 10000.

  • Automatic maintenance settings

    Hide maintenance attributes Show maintenance attributes
    • dow string Required

      Day of week for installing updates

      Values are saturday, tuesday, never, wednesday, sunday, friday, monday, or thursday.

    • time string Required

      Time for installing updates, UTC

      Minimum length is 8, maximum length is 8.

  • kafka-settings json-schema-kafka

    Kafka-specific settings

    Default value is {} (empty).

    Hide kafka-settings attributes Show kafka-settings attributes
    • sasl_oauthbearer_expected_audience sasl.oauthbearer.expected.audience

      The (optional) comma-delimited setting for the broker to use to verify that the JWT was issued for one of the expected audiences.

      Maximum length is 128.

    • group_max_session_timeout_ms group.max.session.timeout.ms

      The maximum allowed session timeout for registered consumers. Longer timeouts give consumers more time to process messages in between heartbeats at the cost of a longer time to detect failures.

      Minimum value is 0, maximum value is 1800000.

    • log_flush_interval_messages log.flush.interval.messages

      The number of messages accumulated on a log partition before messages are flushed to disk

      Minimum value is 1, maximum value is 9223372036854775807.

    • sasl_oauthbearer_jwks_endpoint_url sasl.oauthbearer.jwks.endpoint.url

      OIDC JWKS endpoint URL. By setting this the SASL SSL OAuth2/OIDC authentication is enabled. See also other options for SASL OAuth2/OIDC.

      Maximum length is 2048.

    • max_connections_per_ip max.connections.per.ip

      The maximum number of connections allowed from each ip address (defaults to 2147483647).

      Minimum value is 256, maximum value is 2147483647.

    • sasl_oauthbearer_expected_issuer sasl.oauthbearer.expected.issuer

      Optional setting for the broker to use to verify that the JWT was created by the expected issuer.

      Maximum length is 128.

    • log_index_size_max_bytes log.index.size.max.bytes

      The maximum size in bytes of the offset index

      Minimum value is 1048576, maximum value is 104857600.

    • auto_create_topics_enable auto.create.topics.enable

      Enable auto creation of topics

    • log_index_interval_bytes log.index.interval.bytes

      The interval with which Kafka adds an entry to the offset index

      Minimum value is 0, maximum value is 104857600.

    • replica_fetch_max_bytes replica.fetch.max.bytes

      The number of bytes of messages to attempt to fetch for each partition (defaults to 1048576). This is not an absolute maximum, if the first record batch in the first non-empty partition of the fetch is larger than this value, the record batch will still be returned to ensure that progress can be made.

      Minimum value is 1048576, maximum value is 104857600.

    • num_partitions num.partitions

      Number of partitions for autocreated topics

      Minimum value is 1, maximum value is 1000.

    • transaction_state_log_segment_bytes transaction.state.log.segment.bytes

      The transaction topic segment bytes should be kept relatively small in order to facilitate faster log compaction and cache loads (defaults to 104857600 (100 mebibytes)).

      Minimum value is 1048576, maximum value is 2147483647.

    • replica_fetch_response_max_bytes replica.fetch.response.max.bytes

      Maximum bytes expected for the entire fetch response (defaults to 10485760). Records are fetched in batches, and if the first record batch in the first non-empty partition of the fetch is larger than this value, the record batch will still be returned to ensure that progress can be made. As such, this is not an absolute maximum.

      Minimum value is 10485760, maximum value is 1048576000.

    • log_message_timestamp_type log.message.timestamp.type

      Define whether the timestamp in the message is message create time or log append time.

      Values are CreateTime or LogAppendTime.

    • connections_max_idle_ms connections.max.idle.ms

      Idle connections timeout: the server socket processor threads close the connections that idle for longer than this.

      Minimum value is 1000, maximum value is 3600000.

    • log_flush_interval_ms log.flush.interval.ms

      The maximum time in ms that a message in any topic is kept in memory before flushed to disk. If not set, the value in log.flush.scheduler.interval.ms is used

      Minimum value is 0, maximum value is 9223372036854775807.

    • log_preallocate log.preallocate

      Should pre allocate file when create new segment?

    • log_segment_delete_delay_ms log.segment.delete.delay.ms

      The amount of time to wait before deleting a file from the filesystem

      Minimum value is 0, maximum value is 3600000.

    • message_max_bytes message.max.bytes

      The maximum size of message that the server can receive.

      Minimum value is 0, maximum value is 100001200.

    • group_initial_rebalance_delay_ms group.initial.rebalance.delay.ms

      The amount of time, in milliseconds, the group coordinator will wait for more consumers to join a new group before performing the first rebalance. A longer delay means potentially fewer rebalances, but increases the time until processing begins. The default value for this is 3 seconds. During development and testing it might be desirable to set this to 0 in order to not delay test execution time.

      Minimum value is 0, maximum value is 300000.

    • log_local_retention_bytes log.local.retention.bytes

      The maximum size of local log segments that can grow for a partition before it gets eligible for deletion. If set to -2, the value of log.retention.bytes is used. The effective value should always be less than or equal to log.retention.bytes value.

      Minimum value is -2, maximum value is 9223372036854775807.

    • log_roll_jitter_ms log.roll.jitter.ms

      The maximum jitter to subtract from logRollTimeMillis (in milliseconds). If not set, the value in log.roll.jitter.hours is used

      Minimum value is 0, maximum value is 9223372036854775807.

    • transaction_remove_expired_transaction_cleanup_interval_ms transaction.remove.expired.transaction.cleanup.interval.ms

      The interval at which to remove transactions that have expired due to transactional.id.expiration.ms passing (defaults to 3600000 (1 hour)).

      Minimum value is 600000, maximum value is 3600000.

    • default_replication_factor default.replication.factor

      Replication factor for autocreated topics

      Minimum value is 1, maximum value is 10.

    • log_roll_ms log.roll.ms

      The maximum time before a new log segment is rolled out (in milliseconds).

      Minimum value is 1, maximum value is 9223372036854775807.

    • producer_purgatory_purge_interval_requests producer.purgatory.purge.interval.requests

      The purge interval (in number of requests) of the producer request purgatory(defaults to 1000).

      Minimum value is 10, maximum value is 10000.

    • log_retention_bytes log.retention.bytes

      The maximum size of the log before deleting messages

      Minimum value is -1, maximum value is 9223372036854775807.

    • min_insync_replicas min.insync.replicas

      When a producer sets acks to 'all' (or '-1'), min.insync.replicas specifies the minimum number of replicas that must acknowledge a write for the write to be considered successful.

      Minimum value is 1, maximum value is 7.

    • compression_type compression.type

      Specify the final compression type for a given topic. This configuration accepts the standard compression codecs ('gzip', 'snappy', 'lz4', 'zstd'). It additionally accepts 'uncompressed' which is equivalent to no compression; and 'producer' which means retain the original compression codec set by the producer.

      Values are gzip, snappy, lz4, zstd, uncompressed, or producer.

    • log_message_timestamp_difference_max_ms log.message.timestamp.difference.max.ms

      The maximum difference allowed between the timestamp when a broker receives a message and the timestamp specified in the message

      Minimum value is 0, maximum value is 9223372036854775807.

    • log_local_retention_ms log.local.retention.ms

      The number of milliseconds to keep the local log segments before it gets eligible for deletion. If set to -2, the value of log.retention.ms is used. The effective value should always be less than or equal to log.retention.ms value.

      Minimum value is -2, maximum value is 9223372036854775807.

    • log_message_downconversion_enable log.message.downconversion.enable

      This configuration controls whether down-conversion of message formats is enabled to satisfy consume requests.

    • sasl_oauthbearer_sub_claim_name sasl.oauthbearer.sub.claim.name

      Name of the scope from which to extract the subject claim from the JWT. Defaults to sub.

      Maximum length is 128.

    • max_incremental_fetch_session_cache_slots max.incremental.fetch.session.cache.slots

      The maximum number of incremental fetch sessions that the broker will maintain.

      Minimum value is 1000, maximum value is 10000.

    • log_retention_hours log.retention.hours

      The number of hours to keep a log file before deleting it

      Minimum value is -1, maximum value is 2147483647.

    • group_min_session_timeout_ms group.min.session.timeout.ms

      The minimum allowed session timeout for registered consumers. Longer timeouts give consumers more time to process messages in between heartbeats at the cost of a longer time to detect failures.

      Minimum value is 0, maximum value is 60000.

    • socket_request_max_bytes socket.request.max.bytes

      The maximum number of bytes in a socket request (defaults to 104857600).

      Minimum value is 10485760, maximum value is 209715200.

    • log_segment_bytes log.segment.bytes

      The maximum size of a single log file

      Minimum value is 10485760, maximum value is 1073741824.

    • log-cleanup-and-compaction Configure log cleaner for topic compaction
      Hide log-cleanup-and-compaction attributes Show log-cleanup-and-compaction attributes
      • log_cleaner_delete_retention_ms log.cleaner.delete.retention.ms

        How long are delete records retained?

        Minimum value is 0, maximum value is 315569260000.

      • log_cleaner_max_compaction_lag_ms log.cleaner.max.compaction.lag.ms

        The maximum amount of time message will remain uncompacted. Only applicable for logs that are being compacted

        Minimum value is 30000, maximum value is 9223372036854775807.

      • log_cleaner_min_cleanable_ratio log.cleaner.min.cleanable.ratio

        Controls log compactor frequency. Larger value means more frequent compactions but also more space wasted for logs. Consider setting log.cleaner.max.compaction.lag.ms to enforce compactions sooner, instead of setting a very high value for this option.

        Minimum value is 0.2, maximum value is 0.9.

      • log_cleaner_min_compaction_lag_ms log.cleaner.min.compaction.lag.ms

        The minimum time a message will remain uncompacted in the log. Only applicable for logs that are being compacted.

        Minimum value is 0, maximum value is 9223372036854775807.

      • log_cleanup_policy log.cleanup.policy

        The default cleanup policy for segments beyond the retention window

        Values are delete, compact, or compact,delete.

    • offsets_retention_minutes offsets.retention.minutes

      Log retention window in minutes for offsets topic

      Minimum value is 1, maximum value is 2147483647.

    • log_retention_ms log.retention.ms

      The number of milliseconds to keep a log file before deleting it (in milliseconds), If not set, the value in log.retention.minutes is used. If set to -1, no time limit is applied.

      Minimum value is -1, maximum value is 9223372036854775807.

  • Enable Schema-Registry service

  • version string

    Kafka major version

    Minimum length is 1.

  • plan string Required

    Subscription plan

    Minimum length is 1, maximum length is 128.

Responses

  • 200 application/json

    200

    Hide response attributes Show response attributes operation
    • id string(uuid)

      Operation ID

    • reason string

      Operation failure reason

      Values are incorrect, unknown, unavailable, forbidden, busy, fault, partial, not-found, interrupted, unsupported, or conflict.

    • Related resource reference

      Hide reference attributes Show reference attributes
      • id string(uuid)

        Reference ID

      • command string

        Command name

    • message string

      Operation message

    • state string

      Operation status

      Values are failure, pending, success, or timeout.

POST /dbaas-kafka/{name}
curl \
 -X POST https://api-ch-gva-2.exoscale.com/v2/dbaas-kafka/{name} \
 -H "Content-Type: application/json" \
 -d '{"authentication-methods":{"certificate":true,"sasl":true},"kafka-rest-enabled":true,"kafka-connect-enabled":true,"ip-filter":["string"],"schema-registry-settings":{"topic_name":"_schemas","leader_eligibility":true},"kafka-rest-settings":{"producer_acks":"1","producer_compression_type":"gzip","producer_linger_ms":0,"producer_max_request_size":1048576,"consumer_enable_auto_commit":true,"consumer_request_max_bytes":67108864,"consumer_request_timeout_ms":1000,"simpleconsumer_pool_size_max":25},"termination-protection":true,"kafka-connect-settings":{"producer_buffer_memory":8388608,"consumer_max_poll_interval_ms":300000,"producer_compression_type":"gzip","connector_client_config_override_policy":"None","offset_flush_interval_ms":60000,"scheduled_rebalance_max_delay_ms":300000,"consumer_fetch_max_bytes":52428800,"consumer_max_partition_fetch_bytes":1048576,"offset_flush_timeout_ms":5000,"consumer_auto_offset_reset":"earliest","producer_max_request_size":1048576,"producer_batch_size":1024,"session_timeout_ms":10000,"producer_linger_ms":100,"consumer_isolation_level":"read_uncommitted","consumer_max_poll_records":500},"maintenance":{"dow":"saturday","time":"string"},"kafka-settings":{"sasl_oauthbearer_expected_audience":"string","group_max_session_timeout_ms":1800000,"log_flush_interval_messages":9223372036854775807,"sasl_oauthbearer_jwks_endpoint_url":"string","max_connections_per_ip":42,"sasl_oauthbearer_expected_issuer":"string","log_index_size_max_bytes":10485760,"auto_create_topics_enable":true,"log_index_interval_bytes":4096,"replica_fetch_max_bytes":42,"num_partitions":42,"transaction_state_log_segment_bytes":104857600,"replica_fetch_response_max_bytes":42,"log_message_timestamp_type":"CreateTime","connections_max_idle_ms":540000,"log_flush_interval_ms":42,"log_preallocate":false,"log_segment_delete_delay_ms":60000,"message_max_bytes":1048588,"group_initial_rebalance_delay_ms":3000,"log_local_retention_bytes":42,"log_roll_jitter_ms":42,"transaction_remove_expired_transaction_cleanup_interval_ms":3600000,"default_replication_factor":42,"log_roll_ms":42,"producer_purgatory_purge_interval_requests":42,"log_retention_bytes":42,"min_insync_replicas":1,"compression_type":"gzip","log_message_timestamp_difference_max_ms":42,"log_local_retention_ms":42,"log_message_downconversion_enable":true,"sasl_oauthbearer_sub_claim_name":"string","max_incremental_fetch_session_cache_slots":1000,"log_retention_hours":42,"group_min_session_timeout_ms":6000,"socket_request_max_bytes":42,"log_segment_bytes":42,"log-cleanup-and-compaction":{"log_cleaner_delete_retention_ms":86400000,"log_cleaner_max_compaction_lag_ms":42,"log_cleaner_min_cleanable_ratio":0.5,"log_cleaner_min_compaction_lag_ms":42,"log_cleanup_policy":"delete"},"offsets_retention_minutes":10080,"log_retention_ms":42},"schema-registry-enabled":true,"version":"string","plan":"string"}'
Request example
{
  "authentication-methods": {
    "certificate": true,
    "sasl": true
  },
  "kafka-rest-enabled": true,
  "kafka-connect-enabled": true,
  "ip-filter": [
    "string"
  ],
  "schema-registry-settings": {
    "topic_name": "_schemas",
    "leader_eligibility": true
  },
  "kafka-rest-settings": {
    "producer_acks": "1",
    "producer_compression_type": "gzip",
    "producer_linger_ms": 0,
    "producer_max_request_size": 1048576,
    "consumer_enable_auto_commit": true,
    "consumer_request_max_bytes": 67108864,
    "consumer_request_timeout_ms": 1000,
    "simpleconsumer_pool_size_max": 25
  },
  "termination-protection": true,
  "kafka-connect-settings": {
    "producer_buffer_memory": 8388608,
    "consumer_max_poll_interval_ms": 300000,
    "producer_compression_type": "gzip",
    "connector_client_config_override_policy": "None",
    "offset_flush_interval_ms": 60000,
    "scheduled_rebalance_max_delay_ms": 300000,
    "consumer_fetch_max_bytes": 52428800,
    "consumer_max_partition_fetch_bytes": 1048576,
    "offset_flush_timeout_ms": 5000,
    "consumer_auto_offset_reset": "earliest",
    "producer_max_request_size": 1048576,
    "producer_batch_size": 1024,
    "session_timeout_ms": 10000,
    "producer_linger_ms": 100,
    "consumer_isolation_level": "read_uncommitted",
    "consumer_max_poll_records": 500
  },
  "maintenance": {
    "dow": "saturday",
    "time": "string"
  },
  "kafka-settings": {
    "sasl_oauthbearer_expected_audience": "string",
    "group_max_session_timeout_ms": 1800000,
    "log_flush_interval_messages": 9223372036854775807,
    "sasl_oauthbearer_jwks_endpoint_url": "string",
    "max_connections_per_ip": 42,
    "sasl_oauthbearer_expected_issuer": "string",
    "log_index_size_max_bytes": 10485760,
    "auto_create_topics_enable": true,
    "log_index_interval_bytes": 4096,
    "replica_fetch_max_bytes": 42,
    "num_partitions": 42,
    "transaction_state_log_segment_bytes": 104857600,
    "replica_fetch_response_max_bytes": 42,
    "log_message_timestamp_type": "CreateTime",
    "connections_max_idle_ms": 540000,
    "log_flush_interval_ms": 42,
    "log_preallocate": false,
    "log_segment_delete_delay_ms": 60000,
    "message_max_bytes": 1048588,
    "group_initial_rebalance_delay_ms": 3000,
    "log_local_retention_bytes": 42,
    "log_roll_jitter_ms": 42,
    "transaction_remove_expired_transaction_cleanup_interval_ms": 3600000,
    "default_replication_factor": 42,
    "log_roll_ms": 42,
    "producer_purgatory_purge_interval_requests": 42,
    "log_retention_bytes": 42,
    "min_insync_replicas": 1,
    "compression_type": "gzip",
    "log_message_timestamp_difference_max_ms": 42,
    "log_local_retention_ms": 42,
    "log_message_downconversion_enable": true,
    "sasl_oauthbearer_sub_claim_name": "string",
    "max_incremental_fetch_session_cache_slots": 1000,
    "log_retention_hours": 42,
    "group_min_session_timeout_ms": 6000,
    "socket_request_max_bytes": 42,
    "log_segment_bytes": 42,
    "log-cleanup-and-compaction": {
      "log_cleaner_delete_retention_ms": 86400000,
      "log_cleaner_max_compaction_lag_ms": 42,
      "log_cleaner_min_cleanable_ratio": 0.5,
      "log_cleaner_min_compaction_lag_ms": 42,
      "log_cleanup_policy": "delete"
    },
    "offsets_retention_minutes": 10080,
    "log_retention_ms": 42
  },
  "schema-registry-enabled": true,
  "version": "string",
  "plan": "string"
}
Response examples (200)
{
  "id": "string",
  "reason": "incorrect",
  "reference": {
    "id": "string",
    "link": "string",
    "command": "string"
  },
  "message": "string",
  "state": "failure"
}