github.com/confluentinc/confluent-kafka-go@v1.9.2/kafka/api.html (about)

     1  <!DOCTYPE html>
     2  <html>
     3   <head>
     4    <meta content="text/html; charset=utf-8" http-equiv="Content-Type"/>
     5    <meta content="width=device-width, initial-scale=1" name="viewport"/>
     6    <meta content="#375EAB" name="theme-color"/>
     7    <title>
     8     kafka - Go Documentation Server
     9    </title>
    10    <link href="https://go.dev/css/styles.css" rel="stylesheet" type="text/css"/>
    11    <script>
    12     window.initFuncs = [];
    13    </script>
    14    <script defer="" src="https://go.dev/js/jquery.js">
    15    </script>
    16    <script>
    17     var goVersion = "go1.14";
    18    </script>
    19    <script defer="" src="https://go.dev/js/godocs.js">
    20    </script>
    21   </head>
    22   <body>
    23    <div id="lowframe" style="position: fixed; bottom: 0; left: 0; height: 0; width: 100%; border-top: thin solid grey; background-color: white; overflow: auto;">
    24     ...
    25    </div>
    26    <!-- #lowframe -->
    27    <div class="wide" id="page">
    28     <div class="container">
    29      <h1>
    30       Package kafka
    31       <span class="text-muted">
    32       </span>
    33      </h1>
    34      <div id="nav">
    35      </div>
    36      <!--
    37  	Copyright 2009 The Go Authors. All rights reserved.
    38  	Use of this source code is governed by a BSD-style
    39  	license that can be found in the LICENSE file.
    40  -->
    41      <!--
    42  	Note: Static (i.e., not template-generated) href and id
    43  	attributes start with "pkg-" to make it impossible for
    44  	them to conflict with generated attributes (some of which
    45  	correspond to Go identifiers).
    46  -->
    47      <script>
    48       document.ANALYSIS_DATA = null;
    49  	document.CALLGRAPH = null;
    50      </script>
    51      <div id="short-nav">
    52       <dl>
    53        <dd>
    54         <code>
    55          import "github.com/confluentinc/confluent-kafka-go/kafka"
    56         </code>
    57        </dd>
    58       </dl>
    59       <dl>
    60        <dd>
    61         <a class="overviewLink" href="#pkg-overview">
    62          Overview
    63         </a>
    64        </dd>
    65        <dd>
    66         <a class="indexLink" href="#pkg-index">
    67          Index
    68         </a>
    69        </dd>
    70        <dd>
    71        </dd>
    72       </dl>
    73      </div>
    74      <!-- The package's Name is printed as title by the top-level template -->
    75      <div class="toggleVisible" id="pkg-overview">
    76       <div class="collapsed">
    77        <h2 class="toggleButton" title="Click to show Overview section">
    78         Overview ▹
    79        </h2>
    80       </div>
    81       <div class="expanded">
    82        <h2 class="toggleButton" title="Click to hide Overview section">
    83         Overview ▾
    84        </h2>
    85        <p>
    86         Package kafka provides high-level Apache Kafka producer and consumers
    87  using bindings on-top of the librdkafka C library.
    88        </p>
    89        <h3 id="hdr-High_level_Consumer">
    90         High-level Consumer
    91        </h3>
    92        <p>
    93         * Decide if you want to read messages and events by calling `.Poll()` or
    94  the deprecated option of using the `.Events()` channel. (If you want to use
    95  `.Events()` channel then set `"go.events.channel.enable": true`).
    96        </p>
    97        <p>
    98         * Create a Consumer with `kafka.NewConsumer()` providing at
    99  least the `bootstrap.servers` and `group.id` configuration properties.
   100        </p>
   101        <p>
   102         * Call `.Subscribe()` or (`.SubscribeTopics()` to subscribe to multiple topics)
   103  to join the group with the specified subscription set.
   104  Subscriptions are atomic, calling `.Subscribe*()` again will leave
   105  the group and rejoin with the new set of topics.
   106        </p>
   107        <p>
   108         * Start reading events and messages from either the `.Events` channel
   109  or by calling `.Poll()`.
   110        </p>
   111        <p>
   112         * When the group has rebalanced each client member is assigned a
   113  (sub-)set of topic+partitions.
   114  By default the consumer will start fetching messages for its assigned
   115  partitions at this point, but your application may enable rebalance
   116  events to get an insight into what the assigned partitions where
   117  as well as set the initial offsets. To do this you need to pass
   118  `"go.application.rebalance.enable": true` to the `NewConsumer()` call
   119  mentioned above. You will (eventually) see a `kafka.AssignedPartitions` event
   120  with the assigned partition set. You can optionally modify the initial
   121  offsets (they'll default to stored offsets and if there are no previously stored
   122  offsets it will fall back to `"auto.offset.reset"`
   123  which defaults to the `latest` message) and then call `.Assign(partitions)`
   124  to start consuming. If you don't need to modify the initial offsets you will
   125  not need to call `.Assign()`, the client will do so automatically for you if
   126  you dont, unless you are using the channel-based consumer in which case
   127  you MUST call `.Assign()` when receiving the `AssignedPartitions` and
   128  `RevokedPartitions` events.
   129        </p>
   130        <p>
   131         * As messages are fetched they will be made available on either the
   132  `.Events` channel or by calling `.Poll()`, look for event type `*kafka.Message`.
   133        </p>
   134        <p>
   135         * Handle messages, events and errors to your liking.
   136        </p>
   137        <p>
   138         * When you are done consuming call `.Close()` to commit final offsets
   139  and leave the consumer group.
   140        </p>
   141        <h3 id="hdr-Producer">
   142         Producer
   143        </h3>
   144        <p>
   145         * Create a Producer with `kafka.NewProducer()` providing at least
   146  the `bootstrap.servers` configuration properties.
   147        </p>
   148        <p>
   149         * Messages may now be produced either by sending a `*kafka.Message`
   150  on the `.ProduceChannel` or by calling `.Produce()`.
   151        </p>
   152        <p>
   153         * Producing is an asynchronous operation so the client notifies the application
   154  of per-message produce success or failure through something called delivery reports.
   155  Delivery reports are by default emitted on the `.Events()` channel as `*kafka.Message`
   156  and you should check `msg.TopicPartition.Error` for `nil` to find out if the message
   157  was succesfully delivered or not.
   158  It is also possible to direct delivery reports to alternate channels
   159  by providing a non-nil `chan Event` channel to `.Produce()`.
   160  If no delivery reports are wanted they can be completely disabled by
   161  setting configuration property `"go.delivery.reports": false`.
   162        </p>
   163        <p>
   164         * When you are done producing messages you will need to make sure all messages
   165  are indeed delivered to the broker (or failed), remember that this is
   166  an asynchronous client so some of your messages may be lingering in internal
   167  channels or tranmission queues.
   168  To do this you can either keep track of the messages you've produced
   169  and wait for their corresponding delivery reports, or call the convenience
   170  function `.Flush()` that will block until all message deliveries are done
   171  or the provided timeout elapses.
   172        </p>
   173        <p>
   174         * Finally call `.Close()` to decommission the producer.
   175        </p>
   176        <h3 id="hdr-Transactional_producer_API">
   177         Transactional producer API
   178        </h3>
   179        <p>
   180         The transactional producer operates on top of the idempotent producer,
   181  and provides full exactly-once semantics (EOS) for Apache Kafka when used
   182  with the transaction aware consumer (`isolation.level=read_committed`).
   183        </p>
   184        <p>
   185         A producer instance is configured for transactions by setting the
   186  `transactional.id` to an identifier unique for the application. This
   187  id will be used to fence stale transactions from previous instances of
   188  the application, typically following an outage or crash.
   189        </p>
   190        <p>
   191         After creating the transactional producer instance using `NewProducer()`
   192  the transactional state must be initialized by calling
   193  `InitTransactions()`. This is a blocking call that will
   194  acquire a runtime producer id from the transaction coordinator broker
   195  as well as abort any stale transactions and fence any still running producer
   196  instances with the same `transactional.id`.
   197        </p>
   198        <p>
   199         Once transactions are initialized the application may begin a new
   200  transaction by calling `BeginTransaction()`.
   201  A producer instance may only have one single on-going transaction.
   202        </p>
   203        <p>
   204         Any messages produced after the transaction has been started will
   205  belong to the ongoing transaction and will be committed or aborted
   206  atomically.
   207  It is not permitted to produce messages outside a transaction
   208  boundary, e.g., before `BeginTransaction()` or after `CommitTransaction()`,
   209  `AbortTransaction()` or if the current transaction has failed.
   210        </p>
   211        <p>
   212         If consumed messages are used as input to the transaction, the consumer
   213  instance must be configured with `enable.auto.commit` set to `false`.
   214  To commit the consumed offsets along with the transaction pass the
   215  list of consumed partitions and the last offset processed + 1 to
   216  `SendOffsetsToTransaction()` prior to committing the transaction.
   217  This allows an aborted transaction to be restarted using the previously
   218  committed offsets.
   219        </p>
   220        <p>
   221         To commit the produced messages, and any consumed offsets, to the
   222  current transaction, call `CommitTransaction()`.
   223  This call will block until the transaction has been fully committed or
   224  failed (typically due to fencing by a newer producer instance).
   225        </p>
   226        <p>
   227         Alternatively, if processing fails, or an abortable transaction error is
   228  raised, the transaction needs to be aborted by calling
   229  `AbortTransaction()` which marks any produced messages and
   230  offset commits as aborted.
   231        </p>
   232        <p>
   233         After the current transaction has been committed or aborted a new
   234  transaction may be started by calling `BeginTransaction()` again.
   235        </p>
   236        <p>
   237         Retriable errors:
   238  Some error cases allow the attempted operation to be retried, this is
   239  indicated by the error object having the retriable flag set which can
   240  be detected by calling `err.(kafka.Error).IsRetriable()`.
   241  When this flag is set the application may retry the operation immediately
   242  or preferably after a shorter grace period (to avoid busy-looping).
   243  Retriable errors include timeouts, broker transport failures, etc.
   244        </p>
   245        <p>
   246         Abortable errors:
   247  An ongoing transaction may fail permanently due to various errors,
   248  such as transaction coordinator becoming unavailable, write failures to the
   249  Apache Kafka log, under-replicated partitions, etc.
   250  At this point the producer application must abort the current transaction
   251  using `AbortTransaction()` and optionally start a new transaction
   252  by calling `BeginTransaction()`.
   253  Whether an error is abortable or not is detected by calling
   254  `err.(kafka.Error).TxnRequiresAbort()` on the returned error object.
   255        </p>
   256        <p>
   257         Fatal errors:
   258  While the underlying idempotent producer will typically only raise
   259  fatal errors for unrecoverable cluster errors where the idempotency
   260  guarantees can't be maintained, most of these are treated as abortable by
   261  the transactional producer since transactions may be aborted and retried
   262  in their entirety;
   263  The transactional producer on the other hand introduces a set of additional
   264  fatal errors which the application needs to handle by shutting down the
   265  producer and terminate. There is no way for a producer instance to recover
   266  from fatal errors.
   267  Whether an error is fatal or not is detected by calling
   268  `err.(kafka.Error).IsFatal()` on the returned error object or by checking
   269  the global `GetFatalError()`.
   270        </p>
   271        <p>
   272         Handling of other errors:
   273  For errors that have neither retriable, abortable or the fatal flag set
   274  it is not always obvious how to handle them. While some of these errors
   275  may be indicative of bugs in the application code, such as when
   276  an invalid parameter is passed to a method, other errors might originate
   277  from the broker and be passed thru as-is to the application.
   278  The general recommendation is to treat these errors, that have
   279  neither the retriable or abortable flags set, as fatal.
   280        </p>
   281        <p>
   282         Error handling example:
   283        </p>
   284        <pre>retry:
   285  
   286     err := producer.CommitTransaction(...)
   287     if err == nil {
   288         return nil
   289     } else if err.(kafka.Error).TxnRequiresAbort() {
   290         do_abort_transaction_and_reset_inputs()
   291     } else if err.(kafka.Error).IsRetriable() {
   292         goto retry
   293     } else { // treat all other errors as fatal errors
   294         panic(err)
   295     }
   296  </pre>
   297        <h3 id="hdr-Events">
   298         Events
   299        </h3>
   300        <p>
   301         Apart from emitting messages and delivery reports the client also communicates
   302  with the application through a number of different event types.
   303  An application may choose to handle or ignore these events.
   304        </p>
   305        <h3 id="hdr-Consumer_events">
   306         Consumer events
   307        </h3>
   308        <p>
   309         * `*kafka.Message` - a fetched message.
   310        </p>
   311        <p>
   312         * `AssignedPartitions` - The assigned partition set for this client following a rebalance.
   313  Requires `go.application.rebalance.enable`
   314        </p>
   315        <p>
   316         * `RevokedPartitions` - The counter part to `AssignedPartitions` following a rebalance.
   317  `AssignedPartitions` and `RevokedPartitions` are symmetrical.
   318  Requires `go.application.rebalance.enable`
   319        </p>
   320        <p>
   321         * `PartitionEOF` - Consumer has reached the end of a partition.
   322  NOTE: The consumer will keep trying to fetch new messages for the partition.
   323        </p>
   324        <p>
   325         * `OffsetsCommitted` - Offset commit results (when `enable.auto.commit` is enabled).
   326        </p>
   327        <h3 id="hdr-Producer_events">
   328         Producer events
   329        </h3>
   330        <p>
   331         * `*kafka.Message` - delivery report for produced message.
   332  Check `.TopicPartition.Error` for delivery result.
   333        </p>
   334        <h3 id="hdr-Generic_events_for_both_Consumer_and_Producer">
   335         Generic events for both Consumer and Producer
   336        </h3>
   337        <p>
   338         * `KafkaError` - client (error codes are prefixed with _) or broker error.
   339  These errors are normally just informational since the
   340  client will try its best to automatically recover (eventually).
   341        </p>
   342        <p>
   343         * `OAuthBearerTokenRefresh` - retrieval of a new SASL/OAUTHBEARER token is required.
   344  This event only occurs with sasl.mechanism=OAUTHBEARER.
   345  Be sure to invoke SetOAuthBearerToken() on the Producer/Consumer/AdminClient
   346  instance when a successful token retrieval is completed, otherwise be sure to
   347  invoke SetOAuthBearerTokenFailure() to indicate that retrieval failed (or
   348  if setting the token failed, which could happen if an extension doesn't meet
   349  the required regular expression); invoking SetOAuthBearerTokenFailure() will
   350  schedule a new event for 10 seconds later so another retrieval can be attempted.
   351        </p>
   352        <p>
   353         Hint: If your application registers a signal notification
   354  (signal.Notify) makes sure the signals channel is buffered to avoid
   355  possible complications with blocking Poll() calls.
   356        </p>
   357        <p>
   358         Note: The Confluent Kafka Go client is safe for concurrent use.
   359        </p>
   360       </div>
   361      </div>
   362      <div class="toggleVisible" id="pkg-index">
   363       <div class="collapsed">
   364        <h2 class="toggleButton" title="Click to show Index section">
   365         Index ▹
   366        </h2>
   367       </div>
   368       <div class="expanded">
   369        <h2 class="toggleButton" title="Click to hide Index section">
   370         Index ▾
   371        </h2>
   372        <!-- Table of contents for API; must be named manual-nav to turn off auto nav. -->
   373        <div id="manual-nav">
   374         <dl>
   375          <dd>
   376           <a href="#pkg-constants">
   377            Constants
   378           </a>
   379          </dd>
   380          <dd>
   381           <a href="#LibraryVersion">
   382            func LibraryVersion() (int, string)
   383           </a>
   384          </dd>
   385          <dd>
   386           <a href="#WriteErrorCodes">
   387            func WriteErrorCodes(f *os.File)
   388           </a>
   389          </dd>
   390          <dd>
   391           <a href="#ACLBinding">
   392            type ACLBinding
   393           </a>
   394          </dd>
   395          <dd>
   396           <a href="#ACLBindingFilter">
   397            type ACLBindingFilter
   398           </a>
   399          </dd>
   400          <dd>
   401           <a href="#ACLBindingFilters">
   402            type ACLBindingFilters
   403           </a>
   404          </dd>
   405          <dd>
   406           <a href="#ACLBindings">
   407            type ACLBindings
   408           </a>
   409          </dd>
   410          <dd>
   411           <a href="#ACLBindings.Len">
   412            func (a ACLBindings) Len() int
   413           </a>
   414          </dd>
   415          <dd>
   416           <a href="#ACLBindings.Less">
   417            func (a ACLBindings) Less(i, j int) bool
   418           </a>
   419          </dd>
   420          <dd>
   421           <a href="#ACLBindings.Swap">
   422            func (a ACLBindings) Swap(i, j int)
   423           </a>
   424          </dd>
   425          <dd>
   426           <a href="#ACLOperation">
   427            type ACLOperation
   428           </a>
   429          </dd>
   430          <dd>
   431           <a href="#ACLOperationFromString">
   432            func ACLOperationFromString(aclOperationString string) (ACLOperation, error)
   433           </a>
   434          </dd>
   435          <dd>
   436           <a href="#ACLOperation.String">
   437            func (o ACLOperation) String() string
   438           </a>
   439          </dd>
   440          <dd>
   441           <a href="#ACLPermissionType">
   442            type ACLPermissionType
   443           </a>
   444          </dd>
   445          <dd>
   446           <a href="#ACLPermissionTypeFromString">
   447            func ACLPermissionTypeFromString(aclPermissionTypeString string) (ACLPermissionType, error)
   448           </a>
   449          </dd>
   450          <dd>
   451           <a href="#ACLPermissionType.String">
   452            func (o ACLPermissionType) String() string
   453           </a>
   454          </dd>
   455          <dd>
   456           <a href="#AdminClient">
   457            type AdminClient
   458           </a>
   459          </dd>
   460          <dd>
   461           <a href="#NewAdminClient">
   462            func NewAdminClient(conf *ConfigMap) (*AdminClient, error)
   463           </a>
   464          </dd>
   465          <dd>
   466           <a href="#NewAdminClientFromConsumer">
   467            func NewAdminClientFromConsumer(c *Consumer) (a *AdminClient, err error)
   468           </a>
   469          </dd>
   470          <dd>
   471           <a href="#NewAdminClientFromProducer">
   472            func NewAdminClientFromProducer(p *Producer) (a *AdminClient, err error)
   473           </a>
   474          </dd>
   475          <dd>
   476           <a href="#AdminClient.AlterConfigs">
   477            func (a *AdminClient) AlterConfigs(ctx context.Context, resources []ConfigResource, options ...AlterConfigsAdminOption) (result []ConfigResourceResult, err error)
   478           </a>
   479          </dd>
   480          <dd>
   481           <a href="#AdminClient.Close">
   482            func (a *AdminClient) Close()
   483           </a>
   484          </dd>
   485          <dd>
   486           <a href="#AdminClient.ClusterID">
   487            func (a *AdminClient) ClusterID(ctx context.Context) (clusterID string, err error)
   488           </a>
   489          </dd>
   490          <dd>
   491           <a href="#AdminClient.ControllerID">
   492            func (a *AdminClient) ControllerID(ctx context.Context) (controllerID int32, err error)
   493           </a>
   494          </dd>
   495          <dd>
   496           <a href="#AdminClient.CreateACLs">
   497            func (a *AdminClient) CreateACLs(ctx context.Context, aclBindings ACLBindings, options ...CreateACLsAdminOption) (result []CreateACLResult, err error)
   498           </a>
   499          </dd>
   500          <dd>
   501           <a href="#AdminClient.CreatePartitions">
   502            func (a *AdminClient) CreatePartitions(ctx context.Context, partitions []PartitionsSpecification, options ...CreatePartitionsAdminOption) (result []TopicResult, err error)
   503           </a>
   504          </dd>
   505          <dd>
   506           <a href="#AdminClient.CreateTopics">
   507            func (a *AdminClient) CreateTopics(ctx context.Context, topics []TopicSpecification, options ...CreateTopicsAdminOption) (result []TopicResult, err error)
   508           </a>
   509          </dd>
   510          <dd>
   511           <a href="#AdminClient.DeleteACLs">
   512            func (a *AdminClient) DeleteACLs(ctx context.Context, aclBindingFilters ACLBindingFilters, options ...DeleteACLsAdminOption) (result []DeleteACLsResult, err error)
   513           </a>
   514          </dd>
   515          <dd>
   516           <a href="#AdminClient.DeleteTopics">
   517            func (a *AdminClient) DeleteTopics(ctx context.Context, topics []string, options ...DeleteTopicsAdminOption) (result []TopicResult, err error)
   518           </a>
   519          </dd>
   520          <dd>
   521           <a href="#AdminClient.DescribeACLs">
   522            func (a *AdminClient) DescribeACLs(ctx context.Context, aclBindingFilter ACLBindingFilter, options ...DescribeACLsAdminOption) (result *DescribeACLsResult, err error)
   523           </a>
   524          </dd>
   525          <dd>
   526           <a href="#AdminClient.DescribeConfigs">
   527            func (a *AdminClient) DescribeConfigs(ctx context.Context, resources []ConfigResource, options ...DescribeConfigsAdminOption) (result []ConfigResourceResult, err error)
   528           </a>
   529          </dd>
   530          <dd>
   531           <a href="#AdminClient.GetMetadata">
   532            func (a *AdminClient) GetMetadata(topic *string, allTopics bool, timeoutMs int) (*Metadata, error)
   533           </a>
   534          </dd>
   535          <dd>
   536           <a href="#AdminClient.SetOAuthBearerToken">
   537            func (a *AdminClient) SetOAuthBearerToken(oauthBearerToken OAuthBearerToken) error
   538           </a>
   539          </dd>
   540          <dd>
   541           <a href="#AdminClient.SetOAuthBearerTokenFailure">
   542            func (a *AdminClient) SetOAuthBearerTokenFailure(errstr string) error
   543           </a>
   544          </dd>
   545          <dd>
   546           <a href="#AdminClient.String">
   547            func (a *AdminClient) String() string
   548           </a>
   549          </dd>
   550          <dd>
   551           <a href="#AdminOption">
   552            type AdminOption
   553           </a>
   554          </dd>
   555          <dd>
   556           <a href="#AdminOptionOperationTimeout">
   557            type AdminOptionOperationTimeout
   558           </a>
   559          </dd>
   560          <dd>
   561           <a href="#SetAdminOperationTimeout">
   562            func SetAdminOperationTimeout(t time.Duration) (ao AdminOptionOperationTimeout)
   563           </a>
   564          </dd>
   565          <dd>
   566           <a href="#AdminOptionRequestTimeout">
   567            type AdminOptionRequestTimeout
   568           </a>
   569          </dd>
   570          <dd>
   571           <a href="#SetAdminRequestTimeout">
   572            func SetAdminRequestTimeout(t time.Duration) (ao AdminOptionRequestTimeout)
   573           </a>
   574          </dd>
   575          <dd>
   576           <a href="#AdminOptionValidateOnly">
   577            type AdminOptionValidateOnly
   578           </a>
   579          </dd>
   580          <dd>
   581           <a href="#SetAdminValidateOnly">
   582            func SetAdminValidateOnly(validateOnly bool) (ao AdminOptionValidateOnly)
   583           </a>
   584          </dd>
   585          <dd>
   586           <a href="#AlterConfigsAdminOption">
   587            type AlterConfigsAdminOption
   588           </a>
   589          </dd>
   590          <dd>
   591           <a href="#AlterOperation">
   592            type AlterOperation
   593           </a>
   594          </dd>
   595          <dd>
   596           <a href="#AlterOperation.String">
   597            func (o AlterOperation) String() string
   598           </a>
   599          </dd>
   600          <dd>
   601           <a href="#AssignedPartitions">
   602            type AssignedPartitions
   603           </a>
   604          </dd>
   605          <dd>
   606           <a href="#AssignedPartitions.String">
   607            func (e AssignedPartitions) String() string
   608           </a>
   609          </dd>
   610          <dd>
   611           <a href="#BrokerMetadata">
   612            type BrokerMetadata
   613           </a>
   614          </dd>
   615          <dd>
   616           <a href="#ConfigEntry">
   617            type ConfigEntry
   618           </a>
   619          </dd>
   620          <dd>
   621           <a href="#StringMapToConfigEntries">
   622            func StringMapToConfigEntries(stringMap map[string]string, operation AlterOperation) []ConfigEntry
   623           </a>
   624          </dd>
   625          <dd>
   626           <a href="#ConfigEntry.String">
   627            func (c ConfigEntry) String() string
   628           </a>
   629          </dd>
   630          <dd>
   631           <a href="#ConfigEntryResult">
   632            type ConfigEntryResult
   633           </a>
   634          </dd>
   635          <dd>
   636           <a href="#ConfigEntryResult.String">
   637            func (c ConfigEntryResult) String() string
   638           </a>
   639          </dd>
   640          <dd>
   641           <a href="#ConfigMap">
   642            type ConfigMap
   643           </a>
   644          </dd>
   645          <dd>
   646           <a href="#ConfigMap.Get">
   647            func (m ConfigMap) Get(key string, defval ConfigValue) (ConfigValue, error)
   648           </a>
   649          </dd>
   650          <dd>
   651           <a href="#ConfigMap.Set">
   652            func (m ConfigMap) Set(kv string) error
   653           </a>
   654          </dd>
   655          <dd>
   656           <a href="#ConfigMap.SetKey">
   657            func (m ConfigMap) SetKey(key string, value ConfigValue) error
   658           </a>
   659          </dd>
   660          <dd>
   661           <a href="#ConfigResource">
   662            type ConfigResource
   663           </a>
   664          </dd>
   665          <dd>
   666           <a href="#ConfigResource.String">
   667            func (c ConfigResource) String() string
   668           </a>
   669          </dd>
   670          <dd>
   671           <a href="#ConfigResourceResult">
   672            type ConfigResourceResult
   673           </a>
   674          </dd>
   675          <dd>
   676           <a href="#ConfigResourceResult.String">
   677            func (c ConfigResourceResult) String() string
   678           </a>
   679          </dd>
   680          <dd>
   681           <a href="#ConfigSource">
   682            type ConfigSource
   683           </a>
   684          </dd>
   685          <dd>
   686           <a href="#ConfigSource.String">
   687            func (t ConfigSource) String() string
   688           </a>
   689          </dd>
   690          <dd>
   691           <a href="#ConfigValue">
   692            type ConfigValue
   693           </a>
   694          </dd>
   695          <dd>
   696           <a href="#Consumer">
   697            type Consumer
   698           </a>
   699          </dd>
   700          <dd>
   701           <a href="#NewConsumer">
   702            func NewConsumer(conf *ConfigMap) (*Consumer, error)
   703           </a>
   704          </dd>
   705          <dd>
   706           <a href="#Consumer.Assign">
   707            func (c *Consumer) Assign(partitions []TopicPartition) (err error)
   708           </a>
   709          </dd>
   710          <dd>
   711           <a href="#Consumer.Assignment">
   712            func (c *Consumer) Assignment() (partitions []TopicPartition, err error)
   713           </a>
   714          </dd>
   715          <dd>
   716           <a href="#Consumer.AssignmentLost">
   717            func (c *Consumer) AssignmentLost() bool
   718           </a>
   719          </dd>
   720          <dd>
   721           <a href="#Consumer.Close">
   722            func (c *Consumer) Close() (err error)
   723           </a>
   724          </dd>
   725          <dd>
   726           <a href="#Consumer.Commit">
   727            func (c *Consumer) Commit() ([]TopicPartition, error)
   728           </a>
   729          </dd>
   730          <dd>
   731           <a href="#Consumer.CommitMessage">
   732            func (c *Consumer) CommitMessage(m *Message) ([]TopicPartition, error)
   733           </a>
   734          </dd>
   735          <dd>
   736           <a href="#Consumer.CommitOffsets">
   737            func (c *Consumer) CommitOffsets(offsets []TopicPartition) ([]TopicPartition, error)
   738           </a>
   739          </dd>
   740          <dd>
   741           <a href="#Consumer.Committed">
   742            func (c *Consumer) Committed(partitions []TopicPartition, timeoutMs int) (offsets []TopicPartition, err error)
   743           </a>
   744          </dd>
   745          <dd>
   746           <a href="#Consumer.Events">
   747            func (c *Consumer) Events() chan Event
   748           </a>
   749          </dd>
   750          <dd>
   751           <a href="#Consumer.GetConsumerGroupMetadata">
   752            func (c *Consumer) GetConsumerGroupMetadata() (*ConsumerGroupMetadata, error)
   753           </a>
   754          </dd>
   755          <dd>
   756           <a href="#Consumer.GetMetadata">
   757            func (c *Consumer) GetMetadata(topic *string, allTopics bool, timeoutMs int) (*Metadata, error)
   758           </a>
   759          </dd>
   760          <dd>
   761           <a href="#Consumer.GetRebalanceProtocol">
   762            func (c *Consumer) GetRebalanceProtocol() string
   763           </a>
   764          </dd>
   765          <dd>
   766           <a href="#Consumer.GetWatermarkOffsets">
   767            func (c *Consumer) GetWatermarkOffsets(topic string, partition int32) (low, high int64, err error)
   768           </a>
   769          </dd>
   770          <dd>
   771           <a href="#Consumer.IncrementalAssign">
   772            func (c *Consumer) IncrementalAssign(partitions []TopicPartition) (err error)
   773           </a>
   774          </dd>
   775          <dd>
   776           <a href="#Consumer.IncrementalUnassign">
   777            func (c *Consumer) IncrementalUnassign(partitions []TopicPartition) (err error)
   778           </a>
   779          </dd>
   780          <dd>
   781           <a href="#Consumer.Logs">
   782            func (c *Consumer) Logs() chan LogEvent
   783           </a>
   784          </dd>
   785          <dd>
   786           <a href="#Consumer.OffsetsForTimes">
   787            func (c *Consumer) OffsetsForTimes(times []TopicPartition, timeoutMs int) (offsets []TopicPartition, err error)
   788           </a>
   789          </dd>
   790          <dd>
   791           <a href="#Consumer.Pause">
   792            func (c *Consumer) Pause(partitions []TopicPartition) (err error)
   793           </a>
   794          </dd>
   795          <dd>
   796           <a href="#Consumer.Poll">
   797            func (c *Consumer) Poll(timeoutMs int) (event Event)
   798           </a>
   799          </dd>
   800          <dd>
   801           <a href="#Consumer.Position">
   802            func (c *Consumer) Position(partitions []TopicPartition) (offsets []TopicPartition, err error)
   803           </a>
   804          </dd>
   805          <dd>
   806           <a href="#Consumer.QueryWatermarkOffsets">
   807            func (c *Consumer) QueryWatermarkOffsets(topic string, partition int32, timeoutMs int) (low, high int64, err error)
   808           </a>
   809          </dd>
   810          <dd>
   811           <a href="#Consumer.ReadMessage">
   812            func (c *Consumer) ReadMessage(timeout time.Duration) (*Message, error)
   813           </a>
   814          </dd>
   815          <dd>
   816           <a href="#Consumer.Resume">
   817            func (c *Consumer) Resume(partitions []TopicPartition) (err error)
   818           </a>
   819          </dd>
   820          <dd>
   821           <a href="#Consumer.Seek">
   822            func (c *Consumer) Seek(partition TopicPartition, timeoutMs int) error
   823           </a>
   824          </dd>
   825          <dd>
   826           <a href="#Consumer.SetOAuthBearerToken">
   827            func (c *Consumer) SetOAuthBearerToken(oauthBearerToken OAuthBearerToken) error
   828           </a>
   829          </dd>
   830          <dd>
   831           <a href="#Consumer.SetOAuthBearerTokenFailure">
   832            func (c *Consumer) SetOAuthBearerTokenFailure(errstr string) error
   833           </a>
   834          </dd>
   835          <dd>
   836           <a href="#Consumer.StoreMessage">
   837            func (c *Consumer) StoreMessage(m *Message) (storedOffsets []TopicPartition, err error)
   838           </a>
   839          </dd>
   840          <dd>
   841           <a href="#Consumer.StoreOffsets">
   842            func (c *Consumer) StoreOffsets(offsets []TopicPartition) (storedOffsets []TopicPartition, err error)
   843           </a>
   844          </dd>
   845          <dd>
   846           <a href="#Consumer.String">
   847            func (c *Consumer) String() string
   848           </a>
   849          </dd>
   850          <dd>
   851           <a href="#Consumer.Subscribe">
   852            func (c *Consumer) Subscribe(topic string, rebalanceCb RebalanceCb) error
   853           </a>
   854          </dd>
   855          <dd>
   856           <a href="#Consumer.SubscribeTopics">
   857            func (c *Consumer) SubscribeTopics(topics []string, rebalanceCb RebalanceCb) (err error)
   858           </a>
   859          </dd>
   860          <dd>
   861           <a href="#Consumer.Subscription">
   862            func (c *Consumer) Subscription() (topics []string, err error)
   863           </a>
   864          </dd>
   865          <dd>
   866           <a href="#Consumer.Unassign">
   867            func (c *Consumer) Unassign() (err error)
   868           </a>
   869          </dd>
   870          <dd>
   871           <a href="#Consumer.Unsubscribe">
   872            func (c *Consumer) Unsubscribe() (err error)
   873           </a>
   874          </dd>
   875          <dd>
   876           <a href="#ConsumerGroupMetadata">
   877            type ConsumerGroupMetadata
   878           </a>
   879          </dd>
   880          <dd>
   881           <a href="#NewTestConsumerGroupMetadata">
   882            func NewTestConsumerGroupMetadata(groupID string) (*ConsumerGroupMetadata, error)
   883           </a>
   884          </dd>
   885          <dd>
   886           <a href="#CreateACLResult">
   887            type CreateACLResult
   888           </a>
   889          </dd>
   890          <dd>
   891           <a href="#CreateACLsAdminOption">
   892            type CreateACLsAdminOption
   893           </a>
   894          </dd>
   895          <dd>
   896           <a href="#CreatePartitionsAdminOption">
   897            type CreatePartitionsAdminOption
   898           </a>
   899          </dd>
   900          <dd>
   901           <a href="#CreateTopicsAdminOption">
   902            type CreateTopicsAdminOption
   903           </a>
   904          </dd>
   905          <dd>
   906           <a href="#DeleteACLsAdminOption">
   907            type DeleteACLsAdminOption
   908           </a>
   909          </dd>
   910          <dd>
   911           <a href="#DeleteACLsResult">
   912            type DeleteACLsResult
   913           </a>
   914          </dd>
   915          <dd>
   916           <a href="#DeleteTopicsAdminOption">
   917            type DeleteTopicsAdminOption
   918           </a>
   919          </dd>
   920          <dd>
   921           <a href="#DescribeACLsAdminOption">
   922            type DescribeACLsAdminOption
   923           </a>
   924          </dd>
   925          <dd>
   926           <a href="#DescribeACLsResult">
   927            type DescribeACLsResult
   928           </a>
   929          </dd>
   930          <dd>
   931           <a href="#DescribeConfigsAdminOption">
   932            type DescribeConfigsAdminOption
   933           </a>
   934          </dd>
   935          <dd>
   936           <a href="#Error">
   937            type Error
   938           </a>
   939          </dd>
   940          <dd>
   941           <a href="#NewError">
   942            func NewError(code ErrorCode, str string, fatal bool) (err Error)
   943           </a>
   944          </dd>
   945          <dd>
   946           <a href="#Error.Code">
   947            func (e Error) Code() ErrorCode
   948           </a>
   949          </dd>
   950          <dd>
   951           <a href="#Error.Error">
   952            func (e Error) Error() string
   953           </a>
   954          </dd>
   955          <dd>
   956           <a href="#Error.IsFatal">
   957            func (e Error) IsFatal() bool
   958           </a>
   959          </dd>
   960          <dd>
   961           <a href="#Error.IsRetriable">
   962            func (e Error) IsRetriable() bool
   963           </a>
   964          </dd>
   965          <dd>
   966           <a href="#Error.String">
   967            func (e Error) String() string
   968           </a>
   969          </dd>
   970          <dd>
   971           <a href="#Error.TxnRequiresAbort">
   972            func (e Error) TxnRequiresAbort() bool
   973           </a>
   974          </dd>
   975          <dd>
   976           <a href="#ErrorCode">
   977            type ErrorCode
   978           </a>
   979          </dd>
   980          <dd>
   981           <a href="#ErrorCode.String">
   982            func (c ErrorCode) String() string
   983           </a>
   984          </dd>
   985          <dd>
   986           <a href="#Event">
   987            type Event
   988           </a>
   989          </dd>
   990          <dd>
   991           <a href="#Handle">
   992            type Handle
   993           </a>
   994          </dd>
   995          <dd>
   996           <a href="#Header">
   997            type Header
   998           </a>
   999          </dd>
  1000          <dd>
  1001           <a href="#Header.String">
  1002            func (h Header) String() string
  1003           </a>
  1004          </dd>
  1005          <dd>
  1006           <a href="#LogEvent">
  1007            type LogEvent
  1008           </a>
  1009          </dd>
  1010          <dd>
  1011           <a href="#LogEvent.String">
  1012            func (logEvent LogEvent) String() string
  1013           </a>
  1014          </dd>
  1015          <dd>
  1016           <a href="#Message">
  1017            type Message
  1018           </a>
  1019          </dd>
  1020          <dd>
  1021           <a href="#Message.String">
  1022            func (m *Message) String() string
  1023           </a>
  1024          </dd>
  1025          <dd>
  1026           <a href="#Metadata">
  1027            type Metadata
  1028           </a>
  1029          </dd>
  1030          <dd>
  1031           <a href="#MockCluster">
  1032            type MockCluster
  1033           </a>
  1034          </dd>
  1035          <dd>
  1036           <a href="#NewMockCluster">
  1037            func NewMockCluster(brokerCount int) (*MockCluster, error)
  1038           </a>
  1039          </dd>
  1040          <dd>
  1041           <a href="#MockCluster.BootstrapServers">
  1042            func (mc *MockCluster) BootstrapServers() string
  1043           </a>
  1044          </dd>
  1045          <dd>
  1046           <a href="#MockCluster.Close">
  1047            func (mc *MockCluster) Close()
  1048           </a>
  1049          </dd>
  1050          <dd>
  1051           <a href="#OAuthBearerToken">
  1052            type OAuthBearerToken
  1053           </a>
  1054          </dd>
  1055          <dd>
  1056           <a href="#OAuthBearerTokenRefresh">
  1057            type OAuthBearerTokenRefresh
  1058           </a>
  1059          </dd>
  1060          <dd>
  1061           <a href="#OAuthBearerTokenRefresh.String">
  1062            func (o OAuthBearerTokenRefresh) String() string
  1063           </a>
  1064          </dd>
  1065          <dd>
  1066           <a href="#Offset">
  1067            type Offset
  1068           </a>
  1069          </dd>
  1070          <dd>
  1071           <a href="#NewOffset">
  1072            func NewOffset(offset interface{}) (Offset, error)
  1073           </a>
  1074          </dd>
  1075          <dd>
  1076           <a href="#OffsetTail">
  1077            func OffsetTail(relativeOffset Offset) Offset
  1078           </a>
  1079          </dd>
  1080          <dd>
  1081           <a href="#Offset.Set">
  1082            func (o *Offset) Set(offset interface{}) error
  1083           </a>
  1084          </dd>
  1085          <dd>
  1086           <a href="#Offset.String">
  1087            func (o Offset) String() string
  1088           </a>
  1089          </dd>
  1090          <dd>
  1091           <a href="#OffsetsCommitted">
  1092            type OffsetsCommitted
  1093           </a>
  1094          </dd>
  1095          <dd>
  1096           <a href="#OffsetsCommitted.String">
  1097            func (o OffsetsCommitted) String() string
  1098           </a>
  1099          </dd>
  1100          <dd>
  1101           <a href="#PartitionEOF">
  1102            type PartitionEOF
  1103           </a>
  1104          </dd>
  1105          <dd>
  1106           <a href="#PartitionEOF.String">
  1107            func (p PartitionEOF) String() string
  1108           </a>
  1109          </dd>
  1110          <dd>
  1111           <a href="#PartitionMetadata">
  1112            type PartitionMetadata
  1113           </a>
  1114          </dd>
  1115          <dd>
  1116           <a href="#PartitionsSpecification">
  1117            type PartitionsSpecification
  1118           </a>
  1119          </dd>
  1120          <dd>
  1121           <a href="#Producer">
  1122            type Producer
  1123           </a>
  1124          </dd>
  1125          <dd>
  1126           <a href="#NewProducer">
  1127            func NewProducer(conf *ConfigMap) (*Producer, error)
  1128           </a>
  1129          </dd>
  1130          <dd>
  1131           <a href="#Producer.AbortTransaction">
  1132            func (p *Producer) AbortTransaction(ctx context.Context) error
  1133           </a>
  1134          </dd>
  1135          <dd>
  1136           <a href="#Producer.BeginTransaction">
  1137            func (p *Producer) BeginTransaction() error
  1138           </a>
  1139          </dd>
  1140          <dd>
  1141           <a href="#Producer.Close">
  1142            func (p *Producer) Close()
  1143           </a>
  1144          </dd>
  1145          <dd>
  1146           <a href="#Producer.CommitTransaction">
  1147            func (p *Producer) CommitTransaction(ctx context.Context) error
  1148           </a>
  1149          </dd>
  1150          <dd>
  1151           <a href="#Producer.Events">
  1152            func (p *Producer) Events() chan Event
  1153           </a>
  1154          </dd>
  1155          <dd>
  1156           <a href="#Producer.Flush">
  1157            func (p *Producer) Flush(timeoutMs int) int
  1158           </a>
  1159          </dd>
  1160          <dd>
  1161           <a href="#Producer.GetFatalError">
  1162            func (p *Producer) GetFatalError() error
  1163           </a>
  1164          </dd>
  1165          <dd>
  1166           <a href="#Producer.GetMetadata">
  1167            func (p *Producer) GetMetadata(topic *string, allTopics bool, timeoutMs int) (*Metadata, error)
  1168           </a>
  1169          </dd>
  1170          <dd>
  1171           <a href="#Producer.InitTransactions">
  1172            func (p *Producer) InitTransactions(ctx context.Context) error
  1173           </a>
  1174          </dd>
  1175          <dd>
  1176           <a href="#Producer.Len">
  1177            func (p *Producer) Len() int
  1178           </a>
  1179          </dd>
  1180          <dd>
  1181           <a href="#Producer.Logs">
  1182            func (p *Producer) Logs() chan LogEvent
  1183           </a>
  1184          </dd>
  1185          <dd>
  1186           <a href="#Producer.OffsetsForTimes">
  1187            func (p *Producer) OffsetsForTimes(times []TopicPartition, timeoutMs int) (offsets []TopicPartition, err error)
  1188           </a>
  1189          </dd>
  1190          <dd>
  1191           <a href="#Producer.Produce">
  1192            func (p *Producer) Produce(msg *Message, deliveryChan chan Event) error
  1193           </a>
  1194          </dd>
  1195          <dd>
  1196           <a href="#Producer.ProduceChannel">
  1197            func (p *Producer) ProduceChannel() chan *Message
  1198           </a>
  1199          </dd>
  1200          <dd>
  1201           <a href="#Producer.Purge">
  1202            func (p *Producer) Purge(flags int) error
  1203           </a>
  1204          </dd>
  1205          <dd>
  1206           <a href="#Producer.QueryWatermarkOffsets">
  1207            func (p *Producer) QueryWatermarkOffsets(topic string, partition int32, timeoutMs int) (low, high int64, err error)
  1208           </a>
  1209          </dd>
  1210          <dd>
  1211           <a href="#Producer.SendOffsetsToTransaction">
  1212            func (p *Producer) SendOffsetsToTransaction(ctx context.Context, offsets []TopicPartition, consumerMetadata *ConsumerGroupMetadata) error
  1213           </a>
  1214          </dd>
  1215          <dd>
  1216           <a href="#Producer.SetOAuthBearerToken">
  1217            func (p *Producer) SetOAuthBearerToken(oauthBearerToken OAuthBearerToken) error
  1218           </a>
  1219          </dd>
  1220          <dd>
  1221           <a href="#Producer.SetOAuthBearerTokenFailure">
  1222            func (p *Producer) SetOAuthBearerTokenFailure(errstr string) error
  1223           </a>
  1224          </dd>
  1225          <dd>
  1226           <a href="#Producer.String">
  1227            func (p *Producer) String() string
  1228           </a>
  1229          </dd>
  1230          <dd>
  1231           <a href="#Producer.TestFatalError">
  1232            func (p *Producer) TestFatalError(code ErrorCode, str string) ErrorCode
  1233           </a>
  1234          </dd>
  1235          <dd>
  1236           <a href="#RebalanceCb">
  1237            type RebalanceCb
  1238           </a>
  1239          </dd>
  1240          <dd>
  1241           <a href="#ResourcePatternType">
  1242            type ResourcePatternType
  1243           </a>
  1244          </dd>
  1245          <dd>
  1246           <a href="#ResourcePatternTypeFromString">
  1247            func ResourcePatternTypeFromString(patternTypeString string) (ResourcePatternType, error)
  1248           </a>
  1249          </dd>
  1250          <dd>
  1251           <a href="#ResourcePatternType.String">
  1252            func (t ResourcePatternType) String() string
  1253           </a>
  1254          </dd>
  1255          <dd>
  1256           <a href="#ResourceType">
  1257            type ResourceType
  1258           </a>
  1259          </dd>
  1260          <dd>
  1261           <a href="#ResourceTypeFromString">
  1262            func ResourceTypeFromString(typeString string) (ResourceType, error)
  1263           </a>
  1264          </dd>
  1265          <dd>
  1266           <a href="#ResourceType.String">
  1267            func (t ResourceType) String() string
  1268           </a>
  1269          </dd>
  1270          <dd>
  1271           <a href="#RevokedPartitions">
  1272            type RevokedPartitions
  1273           </a>
  1274          </dd>
  1275          <dd>
  1276           <a href="#RevokedPartitions.String">
  1277            func (e RevokedPartitions) String() string
  1278           </a>
  1279          </dd>
  1280          <dd>
  1281           <a href="#Stats">
  1282            type Stats
  1283           </a>
  1284          </dd>
  1285          <dd>
  1286           <a href="#Stats.String">
  1287            func (e Stats) String() string
  1288           </a>
  1289          </dd>
  1290          <dd>
  1291           <a href="#TimestampType">
  1292            type TimestampType
  1293           </a>
  1294          </dd>
  1295          <dd>
  1296           <a href="#TimestampType.String">
  1297            func (t TimestampType) String() string
  1298           </a>
  1299          </dd>
  1300          <dd>
  1301           <a href="#TopicMetadata">
  1302            type TopicMetadata
  1303           </a>
  1304          </dd>
  1305          <dd>
  1306           <a href="#TopicPartition">
  1307            type TopicPartition
  1308           </a>
  1309          </dd>
  1310          <dd>
  1311           <a href="#TopicPartition.String">
  1312            func (p TopicPartition) String() string
  1313           </a>
  1314          </dd>
  1315          <dd>
  1316           <a href="#TopicPartitions">
  1317            type TopicPartitions
  1318           </a>
  1319          </dd>
  1320          <dd>
  1321           <a href="#TopicPartitions.Len">
  1322            func (tps TopicPartitions) Len() int
  1323           </a>
  1324          </dd>
  1325          <dd>
  1326           <a href="#TopicPartitions.Less">
  1327            func (tps TopicPartitions) Less(i, j int) bool
  1328           </a>
  1329          </dd>
  1330          <dd>
  1331           <a href="#TopicPartitions.Swap">
  1332            func (tps TopicPartitions) Swap(i, j int)
  1333           </a>
  1334          </dd>
  1335          <dd>
  1336           <a href="#TopicResult">
  1337            type TopicResult
  1338           </a>
  1339          </dd>
  1340          <dd>
  1341           <a href="#TopicResult.String">
  1342            func (t TopicResult) String() string
  1343           </a>
  1344          </dd>
  1345          <dd>
  1346           <a href="#TopicSpecification">
  1347            type TopicSpecification
  1348           </a>
  1349          </dd>
  1350         </dl>
  1351        </div>
  1352        <!-- #manual-nav -->
  1353        <h3>
  1354         Package files
  1355        </h3>
  1356        <p>
  1357         <span style="font-size:90%">
  1358          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/00version.go">
  1359           00version.go
  1360          </a>
  1361          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go">
  1362           adminapi.go
  1363          </a>
  1364          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go">
  1365           adminoptions.go
  1366          </a>
  1367          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/build_glibc_linux.go">
  1368           build_glibc_linux.go
  1369          </a>
  1370          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/config.go">
  1371           config.go
  1372          </a>
  1373          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go">
  1374           consumer.go
  1375          </a>
  1376          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/context.go">
  1377           context.go
  1378          </a>
  1379          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error.go">
  1380           error.go
  1381          </a>
  1382          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error_gen.go">
  1383           error_gen.go
  1384          </a>
  1385          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go">
  1386           event.go
  1387          </a>
  1388          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/generated_errors.go">
  1389           generated_errors.go
  1390          </a>
  1391          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/handle.go">
  1392           handle.go
  1393          </a>
  1394          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/header.go">
  1395           header.go
  1396          </a>
  1397          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/kafka.go">
  1398           kafka.go
  1399          </a>
  1400          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/log.go">
  1401           log.go
  1402          </a>
  1403          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/message.go">
  1404           message.go
  1405          </a>
  1406          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/metadata.go">
  1407           metadata.go
  1408          </a>
  1409          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/misc.go">
  1410           misc.go
  1411          </a>
  1412          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/mockcluster.go">
  1413           mockcluster.go
  1414          </a>
  1415          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/offset.go">
  1416           offset.go
  1417          </a>
  1418          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go">
  1419           producer.go
  1420          </a>
  1421          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/testhelpers.go">
  1422           testhelpers.go
  1423          </a>
  1424          <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/time.go">
  1425           time.go
  1426          </a>
  1427         </span>
  1428        </p>
  1429       </div>
  1430       <!-- .expanded -->
  1431      </div>
  1432      <!-- #pkg-index -->
  1433      <h2 id="pkg-constants">
  1434       Constants
  1435      </h2>
  1436      <pre>const (
  1437      <span class="comment">// ResourceUnknown - Unknown</span>
  1438      <span id="ResourceUnknown">ResourceUnknown</span> = <a href="#ResourceType">ResourceType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESOURCE_UNKNOWN">RD_KAFKA_RESOURCE_UNKNOWN</a>)
  1439      <span class="comment">// ResourceAny - match any resource type (DescribeConfigs)</span>
  1440      <span id="ResourceAny">ResourceAny</span> = <a href="#ResourceType">ResourceType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESOURCE_ANY">RD_KAFKA_RESOURCE_ANY</a>)
  1441      <span class="comment">// ResourceTopic - Topic</span>
  1442      <span id="ResourceTopic">ResourceTopic</span> = <a href="#ResourceType">ResourceType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESOURCE_TOPIC">RD_KAFKA_RESOURCE_TOPIC</a>)
  1443      <span class="comment">// ResourceGroup - Group</span>
  1444      <span id="ResourceGroup">ResourceGroup</span> = <a href="#ResourceType">ResourceType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESOURCE_GROUP">RD_KAFKA_RESOURCE_GROUP</a>)
  1445      <span class="comment">// ResourceBroker - Broker</span>
  1446      <span id="ResourceBroker">ResourceBroker</span> = <a href="#ResourceType">ResourceType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESOURCE_BROKER">RD_KAFKA_RESOURCE_BROKER</a>)
  1447  )</pre>
  1448      <pre>const (
  1449      <span class="comment">// ConfigSourceUnknown is the default value</span>
  1450      <span id="ConfigSourceUnknown">ConfigSourceUnknown</span> = <a href="#ConfigSource">ConfigSource</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_CONFIG_SOURCE_UNKNOWN_CONFIG">RD_KAFKA_CONFIG_SOURCE_UNKNOWN_CONFIG</a>)
  1451      <span class="comment">// ConfigSourceDynamicTopic is dynamic topic config that is configured for a specific topic</span>
  1452      <span id="ConfigSourceDynamicTopic">ConfigSourceDynamicTopic</span> = <a href="#ConfigSource">ConfigSource</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_CONFIG_SOURCE_DYNAMIC_TOPIC_CONFIG">RD_KAFKA_CONFIG_SOURCE_DYNAMIC_TOPIC_CONFIG</a>)
  1453      <span class="comment">// ConfigSourceDynamicBroker is dynamic broker config that is configured for a specific broker</span>
  1454      <span id="ConfigSourceDynamicBroker">ConfigSourceDynamicBroker</span> = <a href="#ConfigSource">ConfigSource</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_CONFIG_SOURCE_DYNAMIC_BROKER_CONFIG">RD_KAFKA_CONFIG_SOURCE_DYNAMIC_BROKER_CONFIG</a>)
  1455      <span class="comment">// ConfigSourceDynamicDefaultBroker is dynamic broker config that is configured as default for all brokers in the cluster</span>
  1456      <span id="ConfigSourceDynamicDefaultBroker">ConfigSourceDynamicDefaultBroker</span> = <a href="#ConfigSource">ConfigSource</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_CONFIG_SOURCE_DYNAMIC_DEFAULT_BROKER_CONFIG">RD_KAFKA_CONFIG_SOURCE_DYNAMIC_DEFAULT_BROKER_CONFIG</a>)
  1457      <span class="comment">// ConfigSourceStaticBroker is static broker config provided as broker properties at startup (e.g. from server.properties file)</span>
  1458      <span id="ConfigSourceStaticBroker">ConfigSourceStaticBroker</span> = <a href="#ConfigSource">ConfigSource</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_CONFIG_SOURCE_STATIC_BROKER_CONFIG">RD_KAFKA_CONFIG_SOURCE_STATIC_BROKER_CONFIG</a>)
  1459      <span class="comment">// ConfigSourceDefault is built-in default configuration for configs that have a default value</span>
  1460      <span id="ConfigSourceDefault">ConfigSourceDefault</span> = <a href="#ConfigSource">ConfigSource</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_CONFIG_SOURCE_DEFAULT_CONFIG">RD_KAFKA_CONFIG_SOURCE_DEFAULT_CONFIG</a>)
  1461  )</pre>
  1462      <pre>const (
  1463      <span class="comment">// ResourcePatternTypeUnknown is a resource pattern type not known or not set.</span>
  1464      <span id="ResourcePatternTypeUnknown">ResourcePatternTypeUnknown</span> = <a href="#ResourcePatternType">ResourcePatternType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESOURCE_PATTERN_UNKNOWN">RD_KAFKA_RESOURCE_PATTERN_UNKNOWN</a>)
  1465      <span class="comment">// ResourcePatternTypeAny matches any resource, used for lookups.</span>
  1466      <span id="ResourcePatternTypeAny">ResourcePatternTypeAny</span> = <a href="#ResourcePatternType">ResourcePatternType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESOURCE_PATTERN_ANY">RD_KAFKA_RESOURCE_PATTERN_ANY</a>)
  1467      <span class="comment">// ResourcePatternTypeMatch will perform pattern matching</span>
  1468      <span id="ResourcePatternTypeMatch">ResourcePatternTypeMatch</span> = <a href="#ResourcePatternType">ResourcePatternType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESOURCE_PATTERN_MATCH">RD_KAFKA_RESOURCE_PATTERN_MATCH</a>)
  1469      <span class="comment">// ResourcePatternTypeLiteral matches a literal resource name</span>
  1470      <span id="ResourcePatternTypeLiteral">ResourcePatternTypeLiteral</span> = <a href="#ResourcePatternType">ResourcePatternType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESOURCE_PATTERN_LITERAL">RD_KAFKA_RESOURCE_PATTERN_LITERAL</a>)
  1471      <span class="comment">// ResourcePatternTypePrefixed matches a prefixed resource name</span>
  1472      <span id="ResourcePatternTypePrefixed">ResourcePatternTypePrefixed</span> = <a href="#ResourcePatternType">ResourcePatternType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESOURCE_PATTERN_PREFIXED">RD_KAFKA_RESOURCE_PATTERN_PREFIXED</a>)
  1473  )</pre>
  1474      <pre>const (
  1475      <span class="comment">// ACLOperationUnknown represents an unknown or unset operation</span>
  1476      <span id="ACLOperationUnknown">ACLOperationUnknown</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_UNKNOWN">RD_KAFKA_ACL_OPERATION_UNKNOWN</a>)
  1477      <span class="comment">// ACLOperationAny in a filter, matches any ACLOperation</span>
  1478      <span id="ACLOperationAny">ACLOperationAny</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_ANY">RD_KAFKA_ACL_OPERATION_ANY</a>)
  1479      <span class="comment">// ACLOperationAll represents all the operations</span>
  1480      <span id="ACLOperationAll">ACLOperationAll</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_ALL">RD_KAFKA_ACL_OPERATION_ALL</a>)
  1481      <span class="comment">// ACLOperationRead a read operation</span>
  1482      <span id="ACLOperationRead">ACLOperationRead</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_READ">RD_KAFKA_ACL_OPERATION_READ</a>)
  1483      <span class="comment">// ACLOperationWrite represents a write operation</span>
  1484      <span id="ACLOperationWrite">ACLOperationWrite</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_WRITE">RD_KAFKA_ACL_OPERATION_WRITE</a>)
  1485      <span class="comment">// ACLOperationCreate represents a create operation</span>
  1486      <span id="ACLOperationCreate">ACLOperationCreate</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_CREATE">RD_KAFKA_ACL_OPERATION_CREATE</a>)
  1487      <span class="comment">// ACLOperationDelete represents a delete operation</span>
  1488      <span id="ACLOperationDelete">ACLOperationDelete</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_DELETE">RD_KAFKA_ACL_OPERATION_DELETE</a>)
  1489      <span class="comment">// ACLOperationAlter represents an alter operation</span>
  1490      <span id="ACLOperationAlter">ACLOperationAlter</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_ALTER">RD_KAFKA_ACL_OPERATION_ALTER</a>)
  1491      <span class="comment">// ACLOperationDescribe represents a describe operation</span>
  1492      <span id="ACLOperationDescribe">ACLOperationDescribe</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_DESCRIBE">RD_KAFKA_ACL_OPERATION_DESCRIBE</a>)
  1493      <span class="comment">// ACLOperationClusterAction represents a cluster action operation</span>
  1494      <span id="ACLOperationClusterAction">ACLOperationClusterAction</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_CLUSTER_ACTION">RD_KAFKA_ACL_OPERATION_CLUSTER_ACTION</a>)
  1495      <span class="comment">// ACLOperationDescribeConfigs represents a describe configs operation</span>
  1496      <span id="ACLOperationDescribeConfigs">ACLOperationDescribeConfigs</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_DESCRIBE_CONFIGS">RD_KAFKA_ACL_OPERATION_DESCRIBE_CONFIGS</a>)
  1497      <span class="comment">// ACLOperationAlterConfigs represents an alter configs operation</span>
  1498      <span id="ACLOperationAlterConfigs">ACLOperationAlterConfigs</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_ALTER_CONFIGS">RD_KAFKA_ACL_OPERATION_ALTER_CONFIGS</a>)
  1499      <span class="comment">// ACLOperationIdempotentWrite represents an idempotent write operation</span>
  1500      <span id="ACLOperationIdempotentWrite">ACLOperationIdempotentWrite</span> = <a href="#ACLOperation">ACLOperation</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_OPERATION_IDEMPOTENT_WRITE">RD_KAFKA_ACL_OPERATION_IDEMPOTENT_WRITE</a>)
  1501  )</pre>
  1502      <pre>const (
  1503      <span class="comment">// ACLPermissionTypeUnknown represents an unknown ACLPermissionType</span>
  1504      <span id="ACLPermissionTypeUnknown">ACLPermissionTypeUnknown</span> = <a href="#ACLPermissionType">ACLPermissionType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_PERMISSION_TYPE_UNKNOWN">RD_KAFKA_ACL_PERMISSION_TYPE_UNKNOWN</a>)
  1505      <span class="comment">// ACLPermissionTypeAny in a filter, matches any ACLPermissionType</span>
  1506      <span id="ACLPermissionTypeAny">ACLPermissionTypeAny</span> = <a href="#ACLPermissionType">ACLPermissionType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_PERMISSION_TYPE_ANY">RD_KAFKA_ACL_PERMISSION_TYPE_ANY</a>)
  1507      <span class="comment">// ACLPermissionTypeDeny disallows access</span>
  1508      <span id="ACLPermissionTypeDeny">ACLPermissionTypeDeny</span> = <a href="#ACLPermissionType">ACLPermissionType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_PERMISSION_TYPE_DENY">RD_KAFKA_ACL_PERMISSION_TYPE_DENY</a>)
  1509      <span class="comment">// ACLPermissionTypeAllow grants access</span>
  1510      <span id="ACLPermissionTypeAllow">ACLPermissionTypeAllow</span> = <a href="#ACLPermissionType">ACLPermissionType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_ACL_PERMISSION_TYPE_ALLOW">RD_KAFKA_ACL_PERMISSION_TYPE_ALLOW</a>)
  1511  )</pre>
  1512      <pre>const (
  1513      <span class="comment">// TimestampNotAvailable indicates no timestamp was set, or not available due to lacking broker support</span>
  1514      <span id="TimestampNotAvailable">TimestampNotAvailable</span> = <a href="#TimestampType">TimestampType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_TIMESTAMP_NOT_AVAILABLE">RD_KAFKA_TIMESTAMP_NOT_AVAILABLE</a>)
  1515      <span class="comment">// TimestampCreateTime indicates timestamp set by producer (source time)</span>
  1516      <span id="TimestampCreateTime">TimestampCreateTime</span> = <a href="#TimestampType">TimestampType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_TIMESTAMP_CREATE_TIME">RD_KAFKA_TIMESTAMP_CREATE_TIME</a>)
  1517      <span class="comment">// TimestampLogAppendTime indicates timestamp set set by broker (store time)</span>
  1518      <span id="TimestampLogAppendTime">TimestampLogAppendTime</span> = <a href="#TimestampType">TimestampType</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_TIMESTAMP_LOG_APPEND_TIME">RD_KAFKA_TIMESTAMP_LOG_APPEND_TIME</a>)
  1519  )</pre>
  1520      <pre>const (
  1521      <span class="comment">// PurgeInFlight purges messages in-flight to or from the broker.</span>
  1522      <span class="comment">// Purging these messages will void any future acknowledgements from the</span>
  1523      <span class="comment">// broker, making it impossible for the application to know if these</span>
  1524      <span class="comment">// messages were successfully delivered or not.</span>
  1525      <span class="comment">// Retrying these messages may lead to duplicates.</span>
  1526      <span id="PurgeInFlight">PurgeInFlight</span> = <a href="https://pkg.go.dev/builtin/#int">int</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_PURGE_F_INFLIGHT">RD_KAFKA_PURGE_F_INFLIGHT</a>)
  1527  
  1528      <span class="comment">// PurgeQueue Purge messages in internal queues.</span>
  1529      <span id="PurgeQueue">PurgeQueue</span> = <a href="https://pkg.go.dev/builtin/#int">int</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_PURGE_F_QUEUE">RD_KAFKA_PURGE_F_QUEUE</a>)
  1530  
  1531      <span class="comment">// PurgeNonBlocking Don't wait for background thread queue purging to finish.</span>
  1532      <span id="PurgeNonBlocking">PurgeNonBlocking</span> = <a href="https://pkg.go.dev/builtin/#int">int</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_PURGE_F_NON_BLOCKING">RD_KAFKA_PURGE_F_NON_BLOCKING</a>)
  1533  )</pre>
  1534      <pre>const (
  1535      <span class="comment">// AlterOperationSet sets/overwrites the configuration setting.</span>
  1536      <span id="AlterOperationSet">AlterOperationSet</span> = <a href="https://pkg.go.dev/builtin/#iota">iota</a>
  1537  )</pre>
  1538      <p>
  1539       LibrdkafkaLinkInfo explains how librdkafka was linked to the Go client
  1540      </p>
  1541      <pre>const <span id="LibrdkafkaLinkInfo">LibrdkafkaLinkInfo</span> = "static glibc_linux from librdkafka-static-bundle-v1.9.2.tgz"</pre>
  1542      <p>
  1543       OffsetBeginning represents the earliest offset (logical)
  1544      </p>
  1545      <pre>const <span id="OffsetBeginning">OffsetBeginning</span> = <a href="#Offset">Offset</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_OFFSET_BEGINNING">RD_KAFKA_OFFSET_BEGINNING</a>)</pre>
  1546      <p>
  1547       OffsetEnd represents the latest offset (logical)
  1548      </p>
  1549      <pre>const <span id="OffsetEnd">OffsetEnd</span> = <a href="#Offset">Offset</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_OFFSET_END">RD_KAFKA_OFFSET_END</a>)</pre>
  1550      <p>
  1551       OffsetInvalid represents an invalid/unspecified offset
  1552      </p>
  1553      <pre>const <span id="OffsetInvalid">OffsetInvalid</span> = <a href="#Offset">Offset</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_OFFSET_INVALID">RD_KAFKA_OFFSET_INVALID</a>)</pre>
  1554      <p>
  1555       OffsetStored represents a stored offset
  1556      </p>
  1557      <pre>const <span id="OffsetStored">OffsetStored</span> = <a href="#Offset">Offset</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_OFFSET_STORED">RD_KAFKA_OFFSET_STORED</a>)</pre>
  1558      <p>
  1559       PartitionAny represents any partition (for partitioning),
  1560  or unspecified value (for all other cases)
  1561      </p>
  1562      <pre>const <span id="PartitionAny">PartitionAny</span> = <a href="https://pkg.go.dev/builtin/#int32">int32</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_PARTITION_UA">RD_KAFKA_PARTITION_UA</a>)</pre>
  1563      <h2 id="LibraryVersion">
  1564       func
  1565       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/kafka.go?s=15368:15403#L361">
  1566        LibraryVersion
  1567       </a>
  1568       <a class="permalink" href="#LibraryVersion">
  1569        ¶
  1570       </a>
  1571      </h2>
  1572      <pre>func LibraryVersion() (<a href="https://pkg.go.dev/builtin/#int">int</a>, <a href="https://pkg.go.dev/builtin/#string">string</a>)</pre>
  1573      <p>
  1574       LibraryVersion returns the underlying librdkafka library version as a
  1575  (version_int, version_str) tuple.
  1576      </p>
  1577      <h2 id="WriteErrorCodes">
  1578       func
  1579       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error_gen.go?s=1501:1533#L49">
  1580        WriteErrorCodes
  1581       </a>
  1582       <a class="permalink" href="#WriteErrorCodes">
  1583        ¶
  1584       </a>
  1585      </h2>
  1586      <pre>func WriteErrorCodes(f *<a href="https://pkg.go.dev/os/">os</a>.<a href="https://pkg.go.dev/os/#File">File</a>)</pre>
  1587      <p>
  1588       WriteErrorCodes writes Go error code constants to file from the
  1589  librdkafka error codes.
  1590  This function is not intended for public use.
  1591      </p>
  1592      <h2 id="ACLBinding">
  1593       type
  1594       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=17697:18355#L471">
  1595        ACLBinding
  1596       </a>
  1597       <a class="permalink" href="#ACLBinding">
  1598        ¶
  1599       </a>
  1600      </h2>
  1601      <p>
  1602       ACLBinding specifies the operation and permission type for a specific principal
  1603  over one or more resources of the same type. Used by `AdminClient.CreateACLs`,
  1604  returned by `AdminClient.DescribeACLs` and `AdminClient.DeleteACLs`.
  1605      </p>
  1606      <pre>type ACLBinding struct {
  1607  <span id="ACLBinding.Type"></span>    Type <a href="#ResourceType">ResourceType</a> <span class="comment">// The resource type.</span>
  1608      <span class="comment">// The resource name, which depends on the resource type.</span>
  1609      <span class="comment">// For ResourceBroker the resource name is the broker id.</span>
  1610  <span id="ACLBinding.Name"></span>    Name                <a href="https://pkg.go.dev/builtin/#string">string</a>
  1611  <span id="ACLBinding.ResourcePatternType"></span>    ResourcePatternType <a href="#ResourcePatternType">ResourcePatternType</a> <span class="comment">// The resource pattern, relative to the name.</span>
  1612  <span id="ACLBinding.Principal"></span>    Principal           <a href="https://pkg.go.dev/builtin/#string">string</a>              <span class="comment">// The principal this ACLBinding refers to.</span>
  1613  <span id="ACLBinding.Host"></span>    Host                <a href="https://pkg.go.dev/builtin/#string">string</a>              <span class="comment">// The host that the call is allowed to come from.</span>
  1614  <span id="ACLBinding.Operation"></span>    Operation           <a href="#ACLOperation">ACLOperation</a>        <span class="comment">// The operation/s specified by this binding.</span>
  1615  <span id="ACLBinding.PermissionType"></span>    PermissionType      <a href="#ACLPermissionType">ACLPermissionType</a>   <span class="comment">// The permission type for the specified operation.</span>
  1616  }
  1617  </pre>
  1618      <h2 id="ACLBindingFilter">
  1619       type
  1620       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=18542:18576#L485">
  1621        ACLBindingFilter
  1622       </a>
  1623       <a class="permalink" href="#ACLBindingFilter">
  1624        ¶
  1625       </a>
  1626      </h2>
  1627      <p>
  1628       ACLBindingFilter specifies a filter used to return a list of ACL bindings matching some or all of its attributes.
  1629  Used by `AdminClient.DescribeACLs` and `AdminClient.DeleteACLs`.
  1630      </p>
  1631      <pre>type ACLBindingFilter = <a href="#ACLBinding">ACLBinding</a></pre>
  1632      <h2 id="ACLBindingFilters">
  1633       type
  1634       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=18787:18828#L493">
  1635        ACLBindingFilters
  1636       </a>
  1637       <a class="permalink" href="#ACLBindingFilters">
  1638        ¶
  1639       </a>
  1640      </h2>
  1641      <p>
  1642       ACLBindingFilters is a slice of ACLBindingFilter that also implements
  1643  the sort interface
  1644      </p>
  1645      <pre>type ACLBindingFilters []<a href="#ACLBindingFilter">ACLBindingFilter</a></pre>
  1646      <h2 id="ACLBindings">
  1647       type
  1648       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=18661:18690#L489">
  1649        ACLBindings
  1650       </a>
  1651       <a class="permalink" href="#ACLBindings">
  1652        ¶
  1653       </a>
  1654      </h2>
  1655      <p>
  1656       ACLBindings is a slice of ACLBinding that also implements
  1657  the sort interface
  1658      </p>
  1659      <pre>type ACLBindings []<a href="#ACLBinding">ACLBinding</a></pre>
  1660      <h3 id="ACLBindings.Len">
  1661       func (ACLBindings)
  1662       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=18830:18860#L495">
  1663        Len
  1664       </a>
  1665       <a class="permalink" href="#ACLBindings.Len">
  1666        ¶
  1667       </a>
  1668      </h3>
  1669      <pre>func (a <a href="#ACLBindings">ACLBindings</a>) Len() <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  1670      <h3 id="ACLBindings.Less">
  1671       func (ACLBindings)
  1672       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=18881:18921#L499">
  1673        Less
  1674       </a>
  1675       <a class="permalink" href="#ACLBindings.Less">
  1676        ¶
  1677       </a>
  1678      </h3>
  1679      <pre>func (a <a href="#ACLBindings">ACLBindings</a>) Less(i, j <a href="https://pkg.go.dev/builtin/#int">int</a>) <a href="https://pkg.go.dev/builtin/#bool">bool</a></pre>
  1680      <h3 id="ACLBindings.Swap">
  1681       func (ACLBindings)
  1682       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=19521:19556#L524">
  1683        Swap
  1684       </a>
  1685       <a class="permalink" href="#ACLBindings.Swap">
  1686        ¶
  1687       </a>
  1688      </h3>
  1689      <pre>func (a <a href="#ACLBindings">ACLBindings</a>) Swap(i, j <a href="https://pkg.go.dev/builtin/#int">int</a>)</pre>
  1690      <h2 id="ACLOperation">
  1691       type
  1692       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=13203:13224#L365">
  1693        ACLOperation
  1694       </a>
  1695       <a class="permalink" href="#ACLOperation">
  1696        ¶
  1697       </a>
  1698      </h2>
  1699      <p>
  1700       ACLOperation enumerates the different types of ACL operation.
  1701      </p>
  1702      <pre>type ACLOperation <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  1703      <h3 id="ACLOperationFromString">
  1704       func
  1705       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=15209:15285#L403">
  1706        ACLOperationFromString
  1707       </a>
  1708       <a class="permalink" href="#ACLOperationFromString">
  1709        ¶
  1710       </a>
  1711      </h3>
  1712      <pre>func ACLOperationFromString(aclOperationString <a href="https://pkg.go.dev/builtin/#string">string</a>) (<a href="#ACLOperation">ACLOperation</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1713      <p>
  1714       ACLOperationFromString translates a ACL operation name to
  1715  a ACLOperation value.
  1716      </p>
  1717      <h3 id="ACLOperation.String">
  1718       func (ACLOperation)
  1719       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=15001:15038#L397">
  1720        String
  1721       </a>
  1722       <a class="permalink" href="#ACLOperation.String">
  1723        ¶
  1724       </a>
  1725      </h3>
  1726      <pre>func (o <a href="#ACLOperation">ACLOperation</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  1727      <p>
  1728       String returns the human-readable representation of an ACLOperation
  1729      </p>
  1730      <h2 id="ACLPermissionType">
  1731       type
  1732       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=16151:16177#L435">
  1733        ACLPermissionType
  1734       </a>
  1735       <a class="permalink" href="#ACLPermissionType">
  1736        ¶
  1737       </a>
  1738      </h2>
  1739      <p>
  1740       ACLPermissionType enumerates the different types of ACL permission types.
  1741      </p>
  1742      <pre>type ACLPermissionType <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  1743      <h3 id="ACLPermissionTypeFromString">
  1744       func
  1745       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=17052:17143#L455">
  1746        ACLPermissionTypeFromString
  1747       </a>
  1748       <a class="permalink" href="#ACLPermissionTypeFromString">
  1749        ¶
  1750       </a>
  1751      </h3>
  1752      <pre>func ACLPermissionTypeFromString(aclPermissionTypeString <a href="https://pkg.go.dev/builtin/#string">string</a>) (<a href="#ACLPermissionType">ACLPermissionType</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1753      <p>
  1754       ACLPermissionTypeFromString translates a ACL permission type name to
  1755  a ACLPermissionType value.
  1756      </p>
  1757      <h3 id="ACLPermissionType.String">
  1758       func (ACLPermissionType)
  1759       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=16813:16855#L449">
  1760        String
  1761       </a>
  1762       <a class="permalink" href="#ACLPermissionType.String">
  1763        ¶
  1764       </a>
  1765      </h3>
  1766      <pre>func (o <a href="#ACLPermissionType">ACLPermissionType</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  1767      <p>
  1768       String returns the human-readable representation of an ACLPermissionType
  1769      </p>
  1770      <h2 id="AdminClient">
  1771       type
  1772       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=2047:2148#L66">
  1773        AdminClient
  1774       </a>
  1775       <a class="permalink" href="#AdminClient">
  1776        ¶
  1777       </a>
  1778      </h2>
  1779      <p>
  1780       AdminClient is derived from an existing Producer or Consumer
  1781      </p>
  1782      <pre>type AdminClient struct {
  1783      <span class="comment">// contains filtered or unexported fields</span>
  1784  }
  1785  </pre>
  1786      <h3 id="NewAdminClient">
  1787       func
  1788       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=55075:55133#L1546">
  1789        NewAdminClient
  1790       </a>
  1791       <a class="permalink" href="#NewAdminClient">
  1792        ¶
  1793       </a>
  1794      </h3>
  1795      <pre>func NewAdminClient(conf *<a href="#ConfigMap">ConfigMap</a>) (*<a href="#AdminClient">AdminClient</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1796      <p>
  1797       NewAdminClient creats a new AdminClient instance with a new underlying client instance
  1798      </p>
  1799      <h3 id="NewAdminClientFromConsumer">
  1800       func
  1801       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=56598:56670#L1595">
  1802        NewAdminClientFromConsumer
  1803       </a>
  1804       <a class="permalink" href="#NewAdminClientFromConsumer">
  1805        ¶
  1806       </a>
  1807      </h3>
  1808      <pre>func NewAdminClientFromConsumer(c *<a href="#Consumer">Consumer</a>) (a *<a href="#AdminClient">AdminClient</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1809      <p>
  1810       NewAdminClientFromConsumer derives a new AdminClient from an existing Consumer instance.
  1811  The AdminClient will use the same configuration and connections as the parent instance.
  1812      </p>
  1813      <h3 id="NewAdminClientFromProducer">
  1814       func
  1815       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=56134:56206#L1582">
  1816        NewAdminClientFromProducer
  1817       </a>
  1818       <a class="permalink" href="#NewAdminClientFromProducer">
  1819        ¶
  1820       </a>
  1821      </h3>
  1822      <pre>func NewAdminClientFromProducer(p *<a href="#Producer">Producer</a>) (a *<a href="#AdminClient">AdminClient</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1823      <p>
  1824       NewAdminClientFromProducer derives a new AdminClient from an existing Producer instance.
  1825  The AdminClient will use the same configuration and connections as the parent instance.
  1826      </p>
  1827      <h3 id="AdminClient.AlterConfigs">
  1828       func (*AdminClient)
  1829       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=34443:34605#L983">
  1830        AlterConfigs
  1831       </a>
  1832       <a class="permalink" href="#AdminClient.AlterConfigs">
  1833        ¶
  1834       </a>
  1835      </h3>
  1836      <pre>func (a *<a href="#AdminClient">AdminClient</a>) AlterConfigs(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>, resources []<a href="#ConfigResource">ConfigResource</a>, options ...<a href="#AlterConfigsAdminOption">AlterConfigsAdminOption</a>) (result []<a href="#ConfigResourceResult">ConfigResourceResult</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1837      <p>
  1838       AlterConfigs alters/updates cluster resource configuration.
  1839      </p>
  1840      <p>
  1841       Updates are not transactional so they may succeed for a subset
  1842  of the provided resources while others fail.
  1843  The configuration for a particular resource is updated atomically,
  1844  replacing values using the provided ConfigEntrys and reverting
  1845  unspecified ConfigEntrys to their default values.
  1846      </p>
  1847      <p>
  1848       Requires broker version &gt;=0.11.0.0
  1849      </p>
  1850      <p>
  1851       AlterConfigs will replace all existing configuration for
  1852  the provided resources with the new configuration given,
  1853  reverting all other configuration to their default values.
  1854      </p>
  1855      <p>
  1856       Multiple resources and resource types may be set, but at most one
  1857  resource of type ResourceBroker is allowed per call since these
  1858  resource requests must be sent to the broker specified in the resource.
  1859      </p>
  1860      <h3 id="AdminClient.Close">
  1861       func (*AdminClient)
  1862       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=54799:54828#L1533">
  1863        Close
  1864       </a>
  1865       <a class="permalink" href="#AdminClient.Close">
  1866        ¶
  1867       </a>
  1868      </h3>
  1869      <pre>func (a *<a href="#AdminClient">AdminClient</a>) Close()</pre>
  1870      <p>
  1871       Close an AdminClient instance.
  1872      </p>
  1873      <h3 id="AdminClient.ClusterID">
  1874       func (*AdminClient)
  1875       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=23890:23972#L660">
  1876        ClusterID
  1877       </a>
  1878       <a class="permalink" href="#AdminClient.ClusterID">
  1879        ¶
  1880       </a>
  1881      </h3>
  1882      <pre>func (a *<a href="#AdminClient">AdminClient</a>) ClusterID(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>) (clusterID <a href="https://pkg.go.dev/builtin/#string">string</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1883      <p>
  1884       ClusterID returns the cluster ID as reported in broker metadata.
  1885      </p>
  1886      <p>
  1887       Note on cancellation: Although the underlying C function respects the
  1888  timeout, it currently cannot be manually cancelled. That means manually
  1889  cancelling the context will block until the C function call returns.
  1890      </p>
  1891      <p>
  1892       Requires broker version &gt;= 0.10.0.
  1893      </p>
  1894      <h3 id="AdminClient.ControllerID">
  1895       func (*AdminClient)
  1896       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=24882:24969#L692">
  1897        ControllerID
  1898       </a>
  1899       <a class="permalink" href="#AdminClient.ControllerID">
  1900        ¶
  1901       </a>
  1902      </h3>
  1903      <pre>func (a *<a href="#AdminClient">AdminClient</a>) ControllerID(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>) (controllerID <a href="https://pkg.go.dev/builtin/#int32">int32</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1904      <p>
  1905       ControllerID returns the broker ID of the current controller as reported in
  1906  broker metadata.
  1907      </p>
  1908      <p>
  1909       Note on cancellation: Although the underlying C function respects the
  1910  timeout, it currently cannot be manually cancelled. That means manually
  1911  cancelling the context will block until the C function call returns.
  1912      </p>
  1913      <p>
  1914       Requires broker version &gt;= 0.10.0.
  1915      </p>
  1916      <h3 id="AdminClient.CreateACLs">
  1917       func (*AdminClient)
  1918       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=47740:47890#L1342">
  1919        CreateACLs
  1920       </a>
  1921       <a class="permalink" href="#AdminClient.CreateACLs">
  1922        ¶
  1923       </a>
  1924      </h3>
  1925      <pre>func (a *<a href="#AdminClient">AdminClient</a>) CreateACLs(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>, aclBindings <a href="#ACLBindings">ACLBindings</a>, options ...<a href="#CreateACLsAdminOption">CreateACLsAdminOption</a>) (result []<a href="#CreateACLResult">CreateACLResult</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1926      <p>
  1927       CreateACLs creates one or more ACL bindings.
  1928      </p>
  1929      <p>
  1930       Parameters:
  1931      </p>
  1932      <pre>* `ctx` - context with the maximum amount of time to block, or nil for indefinite.
  1933  * `aclBindings` - A slice of ACL binding specifications to create.
  1934  * `options` - Create ACLs options
  1935  </pre>
  1936      <p>
  1937       Returns a slice of CreateACLResult with a ErrNoError ErrorCode when the operation was successful
  1938  plus an error that is not nil for client level errors
  1939      </p>
  1940      <h3 id="AdminClient.CreatePartitions">
  1941       func (*AdminClient)
  1942       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=31223:31394#L893">
  1943        CreatePartitions
  1944       </a>
  1945       <a class="permalink" href="#AdminClient.CreatePartitions">
  1946        ¶
  1947       </a>
  1948      </h3>
  1949      <pre>func (a *<a href="#AdminClient">AdminClient</a>) CreatePartitions(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>, partitions []<a href="#PartitionsSpecification">PartitionsSpecification</a>, options ...<a href="#CreatePartitionsAdminOption">CreatePartitionsAdminOption</a>) (result []<a href="#TopicResult">TopicResult</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1950      <p>
  1951       CreatePartitions creates additional partitions for topics.
  1952      </p>
  1953      <h3 id="AdminClient.CreateTopics">
  1954       func (*AdminClient)
  1955       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=25712:25866#L721">
  1956        CreateTopics
  1957       </a>
  1958       <a class="permalink" href="#AdminClient.CreateTopics">
  1959        ¶
  1960       </a>
  1961      </h3>
  1962      <pre>func (a *<a href="#AdminClient">AdminClient</a>) CreateTopics(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>, topics []<a href="#TopicSpecification">TopicSpecification</a>, options ...<a href="#CreateTopicsAdminOption">CreateTopicsAdminOption</a>) (result []<a href="#TopicResult">TopicResult</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1963      <p>
  1964       CreateTopics creates topics in cluster.
  1965      </p>
  1966      <p>
  1967       The list of TopicSpecification objects define the per-topic partition count, replicas, etc.
  1968      </p>
  1969      <p>
  1970       Topic creation is non-atomic and may succeed for some topics but fail for others,
  1971  make sure to check the result for topic-specific errors.
  1972      </p>
  1973      <p>
  1974       Note: TopicSpecification is analogous to NewTopic in the Java Topic Admin API.
  1975      </p>
  1976      <h3 id="AdminClient.DeleteACLs">
  1977       func (*AdminClient)
  1978       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=52785:52948#L1473">
  1979        DeleteACLs
  1980       </a>
  1981       <a class="permalink" href="#AdminClient.DeleteACLs">
  1982        ¶
  1983       </a>
  1984      </h3>
  1985      <pre>func (a *<a href="#AdminClient">AdminClient</a>) DeleteACLs(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>, aclBindingFilters <a href="#ACLBindingFilters">ACLBindingFilters</a>, options ...<a href="#DeleteACLsAdminOption">DeleteACLsAdminOption</a>) (result []<a href="#DeleteACLsResult">DeleteACLsResult</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  1986      <p>
  1987       DeleteACLs deletes ACL bindings matching one or more ACL binding filters.
  1988      </p>
  1989      <p>
  1990       Parameters:
  1991      </p>
  1992      <pre>* `ctx` - context with the maximum amount of time to block, or nil for indefinite.
  1993  * `aclBindingFilters` - a slice of ACL binding filters to match ACLs to delete.
  1994     string attributes match exact values or any string if set to empty string.
  1995     Enum attributes match exact values or any value if ending with `Any`.
  1996     If `ResourcePatternType` is set to `ResourcePatternTypeMatch` deletes ACL bindings with:
  1997     - `ResourcePatternTypeLiteral` pattern type with resource name equal to the given resource name
  1998     - `ResourcePatternTypeLiteral` pattern type with wildcard resource name that matches the given resource name
  1999     - `ResourcePatternTypePrefixed` pattern type with resource name that is a prefix of the given resource name
  2000  * `options` - Delete ACLs options
  2001  </pre>
  2002      <p>
  2003       Returns a slice of ACLBinding for each filter when the operation was successful
  2004  plus an error that is not `nil` for client level errors
  2005      </p>
  2006      <h3 id="AdminClient.DeleteTopics">
  2007       func (*AdminClient)
  2008       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=29450:29592#L835">
  2009        DeleteTopics
  2010       </a>
  2011       <a class="permalink" href="#AdminClient.DeleteTopics">
  2012        ¶
  2013       </a>
  2014      </h3>
  2015      <pre>func (a *<a href="#AdminClient">AdminClient</a>) DeleteTopics(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>, topics []<a href="https://pkg.go.dev/builtin/#string">string</a>, options ...<a href="#DeleteTopicsAdminOption">DeleteTopicsAdminOption</a>) (result []<a href="#TopicResult">TopicResult</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2016      <p>
  2017       DeleteTopics deletes a batch of topics.
  2018      </p>
  2019      <p>
  2020       This operation is not transactional and may succeed for a subset of topics while
  2021  failing others.
  2022  It may take several seconds after the DeleteTopics result returns success for
  2023  all the brokers to become aware that the topics are gone. During this time,
  2024  topic metadata and configuration may continue to return information about deleted topics.
  2025      </p>
  2026      <p>
  2027       Requires broker version &gt;= 0.10.1.0
  2028      </p>
  2029      <h3 id="AdminClient.DescribeACLs">
  2030       func (*AdminClient)
  2031       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=50547:50713#L1417">
  2032        DescribeACLs
  2033       </a>
  2034       <a class="permalink" href="#AdminClient.DescribeACLs">
  2035        ¶
  2036       </a>
  2037      </h3>
  2038      <pre>func (a *<a href="#AdminClient">AdminClient</a>) DescribeACLs(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>, aclBindingFilter <a href="#ACLBindingFilter">ACLBindingFilter</a>, options ...<a href="#DescribeACLsAdminOption">DescribeACLsAdminOption</a>) (result *<a href="#DescribeACLsResult">DescribeACLsResult</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2039      <p>
  2040       DescribeACLs matches ACL bindings by filter.
  2041      </p>
  2042      <p>
  2043       Parameters:
  2044      </p>
  2045      <pre>* `ctx` - context with the maximum amount of time to block, or nil for indefinite.
  2046  * `aclBindingFilter` - A filter with attributes that must match.
  2047     string attributes match exact values or any string if set to empty string.
  2048     Enum attributes match exact values or any value if ending with `Any`.
  2049     If `ResourcePatternType` is set to `ResourcePatternTypeMatch` returns ACL bindings with:
  2050     - `ResourcePatternTypeLiteral` pattern type with resource name equal to the given resource name
  2051     - `ResourcePatternTypeLiteral` pattern type with wildcard resource name that matches the given resource name
  2052     - `ResourcePatternTypePrefixed` pattern type with resource name that is a prefix of the given resource name
  2053  * `options` - Describe ACLs options
  2054  </pre>
  2055      <p>
  2056       Returns a slice of ACLBindings when the operation was successful
  2057  plus an error that is not `nil` for client level errors
  2058      </p>
  2059      <h3 id="AdminClient.DescribeConfigs">
  2060       func (*AdminClient)
  2061       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=37645:37813#L1081">
  2062        DescribeConfigs
  2063       </a>
  2064       <a class="permalink" href="#AdminClient.DescribeConfigs">
  2065        ¶
  2066       </a>
  2067      </h3>
  2068      <pre>func (a *<a href="#AdminClient">AdminClient</a>) DescribeConfigs(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>, resources []<a href="#ConfigResource">ConfigResource</a>, options ...<a href="#DescribeConfigsAdminOption">DescribeConfigsAdminOption</a>) (result []<a href="#ConfigResourceResult">ConfigResourceResult</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2069      <p>
  2070       DescribeConfigs retrieves configuration for cluster resources.
  2071      </p>
  2072      <p>
  2073       The returned configuration includes default values, use
  2074  ConfigEntryResult.IsDefault or ConfigEntryResult.Source to distinguish
  2075  default values from manually configured settings.
  2076      </p>
  2077      <p>
  2078       The value of config entries where .IsSensitive is true
  2079  will always be nil to avoid disclosing sensitive
  2080  information, such as security settings.
  2081      </p>
  2082      <p>
  2083       Configuration entries where .IsReadOnly is true can't be modified
  2084  (with AlterConfigs).
  2085      </p>
  2086      <p>
  2087       Synonym configuration entries are returned if the broker supports
  2088  it (broker version &gt;= 1.1.0). See .Synonyms.
  2089      </p>
  2090      <p>
  2091       Requires broker version &gt;=0.11.0.0
  2092      </p>
  2093      <p>
  2094       Multiple resources and resource types may be requested, but at most
  2095  one resource of type ResourceBroker is allowed per call
  2096  since these resource requests must be sent to the broker specified
  2097  in the resource.
  2098      </p>
  2099      <h3 id="AdminClient.GetMetadata">
  2100       func (*AdminClient)
  2101       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=39826:39924#L1144">
  2102        GetMetadata
  2103       </a>
  2104       <a class="permalink" href="#AdminClient.GetMetadata">
  2105        ¶
  2106       </a>
  2107      </h3>
  2108      <pre>func (a *<a href="#AdminClient">AdminClient</a>) GetMetadata(topic *<a href="https://pkg.go.dev/builtin/#string">string</a>, allTopics <a href="https://pkg.go.dev/builtin/#bool">bool</a>, timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) (*<a href="#Metadata">Metadata</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2109      <p>
  2110       GetMetadata queries broker for cluster and topic metadata.
  2111  If topic is non-nil only information about that topic is returned, else if
  2112  allTopics is false only information about locally used topics is returned,
  2113  else information about all topics is returned.
  2114  GetMetadata is equivalent to listTopics, describeTopics and describeCluster in the Java API.
  2115      </p>
  2116      <h3 id="AdminClient.SetOAuthBearerToken">
  2117       func (*AdminClient)
  2118       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=40850:40932#L1168">
  2119        SetOAuthBearerToken
  2120       </a>
  2121       <a class="permalink" href="#AdminClient.SetOAuthBearerToken">
  2122        ¶
  2123       </a>
  2124      </h3>
  2125      <pre>func (a *<a href="#AdminClient">AdminClient</a>) SetOAuthBearerToken(oauthBearerToken <a href="#OAuthBearerToken">OAuthBearerToken</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  2126      <p>
  2127       SetOAuthBearerToken sets the the data to be transmitted
  2128  to a broker during SASL/OAUTHBEARER authentication. It will return nil
  2129  on success, otherwise an error if:
  2130  1) the token data is invalid (meaning an expiration time in the past
  2131  or either a token value or an extension key or value that does not meet
  2132  the regular expression requirements as per
  2133       <a href="https://tools.ietf.org/html/rfc7628#section-3.1">
  2134        https://tools.ietf.org/html/rfc7628#section-3.1
  2135       </a>
  2136       );
  2137  2) SASL/OAUTHBEARER is not supported by the underlying librdkafka build;
  2138  3) SASL/OAUTHBEARER is supported but is not configured as the client's
  2139  authentication mechanism.
  2140      </p>
  2141      <h3 id="AdminClient.SetOAuthBearerTokenFailure">
  2142       func (*AdminClient)
  2143       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=41431:41500#L1179">
  2144        SetOAuthBearerTokenFailure
  2145       </a>
  2146       <a class="permalink" href="#AdminClient.SetOAuthBearerTokenFailure">
  2147        ¶
  2148       </a>
  2149      </h3>
  2150      <pre>func (a *<a href="#AdminClient">AdminClient</a>) SetOAuthBearerTokenFailure(errstr <a href="https://pkg.go.dev/builtin/#string">string</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  2151      <p>
  2152       SetOAuthBearerTokenFailure sets the error message describing why token
  2153  retrieval/setting failed; it also schedules a new token refresh event for 10
  2154  seconds later so the attempt may be retried. It will return nil on
  2155  success, otherwise an error if:
  2156  1) SASL/OAUTHBEARER is not supported by the underlying librdkafka build;
  2157  2) SASL/OAUTHBEARER is supported but is not configured as the client's
  2158  authentication mechanism.
  2159      </p>
  2160      <h3 id="AdminClient.String">
  2161       func (*AdminClient)
  2162       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=40050:40087#L1149">
  2163        String
  2164       </a>
  2165       <a class="permalink" href="#AdminClient.String">
  2166        ¶
  2167       </a>
  2168      </h3>
  2169      <pre>func (a *<a href="#AdminClient">AdminClient</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  2170      <p>
  2171       String returns a human readable name for an AdminClient instance
  2172      </p>
  2173      <h2 id="AdminOption">
  2174       type
  2175       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=7543:7623#L269">
  2176        AdminOption
  2177       </a>
  2178       <a class="permalink" href="#AdminOption">
  2179        ¶
  2180       </a>
  2181      </h2>
  2182      <p>
  2183       AdminOption is a generic type not to be used directly.
  2184      </p>
  2185      <p>
  2186       See CreateTopicsAdminOption et.al.
  2187      </p>
  2188      <pre>type AdminOption interface {
  2189      <span class="comment">// contains filtered or unexported methods</span>
  2190  }</pre>
  2191      <h2 id="AdminOptionOperationTimeout">
  2192       type
  2193       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=1227:1303#L33">
  2194        AdminOptionOperationTimeout
  2195       </a>
  2196       <a class="permalink" href="#AdminOptionOperationTimeout">
  2197        ¶
  2198       </a>
  2199      </h2>
  2200      <p>
  2201       AdminOptionOperationTimeout sets the broker's operation timeout, such as the
  2202  timeout for CreateTopics to complete the creation of topics on the controller
  2203  before returning a result to the application.
  2204      </p>
  2205      <p>
  2206       CreateTopics, DeleteTopics, CreatePartitions:
  2207  a value 0 will return immediately after triggering topic
  2208  creation, while &gt; 0 will wait this long for topic creation to propagate
  2209  in cluster.
  2210      </p>
  2211      <p>
  2212       Default: 0 (return immediately).
  2213      </p>
  2214      <p>
  2215       Valid for CreateTopics, DeleteTopics, CreatePartitions.
  2216      </p>
  2217      <pre>type AdminOptionOperationTimeout struct {
  2218      <span class="comment">// contains filtered or unexported fields</span>
  2219  }
  2220  </pre>
  2221      <h3 id="SetAdminOperationTimeout">
  2222       func
  2223       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=2574:2653#L79">
  2224        SetAdminOperationTimeout
  2225       </a>
  2226       <a class="permalink" href="#SetAdminOperationTimeout">
  2227        ¶
  2228       </a>
  2229      </h3>
  2230      <pre>func SetAdminOperationTimeout(t <a href="https://pkg.go.dev/time/">time</a>.<a href="https://pkg.go.dev/time/#Duration">Duration</a>) (ao <a href="#AdminOptionOperationTimeout">AdminOptionOperationTimeout</a>)</pre>
  2231      <p>
  2232       SetAdminOperationTimeout sets the broker's operation timeout, such as the
  2233  timeout for CreateTopics to complete the creation of topics on the controller
  2234  before returning a result to the application.
  2235      </p>
  2236      <p>
  2237       CreateTopics, DeleteTopics, CreatePartitions:
  2238  a value 0 will return immediately after triggering topic
  2239  creation, while &gt; 0 will wait this long for topic creation to propagate
  2240  in cluster.
  2241      </p>
  2242      <p>
  2243       Default: 0 (return immediately).
  2244      </p>
  2245      <p>
  2246       Valid for CreateTopics, DeleteTopics, CreatePartitions.
  2247      </p>
  2248      <h2 id="AdminOptionRequestTimeout">
  2249       type
  2250       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=2927:3001#L91">
  2251        AdminOptionRequestTimeout
  2252       </a>
  2253       <a class="permalink" href="#AdminOptionRequestTimeout">
  2254        ¶
  2255       </a>
  2256      </h2>
  2257      <p>
  2258       AdminOptionRequestTimeout sets the overall request timeout, including broker
  2259  lookup, request transmission, operation time on broker, and response.
  2260      </p>
  2261      <p>
  2262       Default: `socket.timeout.ms`.
  2263      </p>
  2264      <p>
  2265       Valid for all Admin API methods.
  2266      </p>
  2267      <pre>type AdminOptionRequestTimeout struct {
  2268      <span class="comment">// contains filtered or unexported fields</span>
  2269  }
  2270  </pre>
  2271      <h3 id="SetAdminRequestTimeout">
  2272       func
  2273       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=4073:4148#L135">
  2274        SetAdminRequestTimeout
  2275       </a>
  2276       <a class="permalink" href="#SetAdminRequestTimeout">
  2277        ¶
  2278       </a>
  2279      </h3>
  2280      <pre>func SetAdminRequestTimeout(t <a href="https://pkg.go.dev/time/">time</a>.<a href="https://pkg.go.dev/time/#Duration">Duration</a>) (ao <a href="#AdminOptionRequestTimeout">AdminOptionRequestTimeout</a>)</pre>
  2281      <p>
  2282       SetAdminRequestTimeout sets the overall request timeout, including broker
  2283  lookup, request transmission, operation time on broker, and response.
  2284      </p>
  2285      <p>
  2286       Default: `socket.timeout.ms`.
  2287      </p>
  2288      <p>
  2289       Valid for all Admin API methods.
  2290      </p>
  2291      <h2 id="AdminOptionValidateOnly">
  2292       type
  2293       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=4419:4482#L147">
  2294        AdminOptionValidateOnly
  2295       </a>
  2296       <a class="permalink" href="#AdminOptionValidateOnly">
  2297        ¶
  2298       </a>
  2299      </h2>
  2300      <p>
  2301       AdminOptionValidateOnly tells the broker to only validate the request,
  2302  without performing the requested operation (create topics, etc).
  2303      </p>
  2304      <p>
  2305       Default: false.
  2306      </p>
  2307      <p>
  2308       Valid for CreateTopics, CreatePartitions, AlterConfigs
  2309      </p>
  2310      <pre>type AdminOptionValidateOnly struct {
  2311      <span class="comment">// contains filtered or unexported fields</span>
  2312  }
  2313  </pre>
  2314      <h3 id="SetAdminValidateOnly">
  2315       func
  2316       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=5594:5667#L196">
  2317        SetAdminValidateOnly
  2318       </a>
  2319       <a class="permalink" href="#SetAdminValidateOnly">
  2320        ¶
  2321       </a>
  2322      </h3>
  2323      <pre>func SetAdminValidateOnly(validateOnly <a href="https://pkg.go.dev/builtin/#bool">bool</a>) (ao <a href="#AdminOptionValidateOnly">AdminOptionValidateOnly</a>)</pre>
  2324      <p>
  2325       SetAdminValidateOnly tells the broker to only validate the request,
  2326  without performing the requested operation (create topics, etc).
  2327      </p>
  2328      <p>
  2329       Default: false.
  2330      </p>
  2331      <p>
  2332       Valid for CreateTopics, DeleteTopics, CreatePartitions, AlterConfigs
  2333      </p>
  2334      <h2 id="AlterConfigsAdminOption">
  2335       type
  2336       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=6559:6675#L229">
  2337        AlterConfigsAdminOption
  2338       </a>
  2339       <a class="permalink" href="#AlterConfigsAdminOption">
  2340        ¶
  2341       </a>
  2342      </h2>
  2343      <p>
  2344       AlterConfigsAdminOption - see setters.
  2345      </p>
  2346      <p>
  2347       See SetAdminRequestTimeout, SetAdminValidateOnly, SetAdminIncremental.
  2348      </p>
  2349      <pre>type AlterConfigsAdminOption interface {
  2350      <span class="comment">// contains filtered or unexported methods</span>
  2351  }</pre>
  2352      <h2 id="AlterOperation">
  2353       type
  2354       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=7492:7515#L209">
  2355        AlterOperation
  2356       </a>
  2357       <a class="permalink" href="#AlterOperation">
  2358        ¶
  2359       </a>
  2360      </h2>
  2361      <p>
  2362       AlterOperation specifies the operation to perform on the ConfigEntry.
  2363  Currently only AlterOperationSet.
  2364      </p>
  2365      <pre>type AlterOperation <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  2366      <h3 id="AlterOperation.String">
  2367       func (AlterOperation)
  2368       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=7692:7731#L217">
  2369        String
  2370       </a>
  2371       <a class="permalink" href="#AlterOperation.String">
  2372        ¶
  2373       </a>
  2374      </h3>
  2375      <pre>func (o <a href="#AlterOperation">AlterOperation</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  2376      <p>
  2377       String returns the human-readable representation of an AlterOperation
  2378      </p>
  2379      <h2 id="AssignedPartitions">
  2380       type
  2381       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=2554:2617#L91">
  2382        AssignedPartitions
  2383       </a>
  2384       <a class="permalink" href="#AssignedPartitions">
  2385        ¶
  2386       </a>
  2387      </h2>
  2388      <p>
  2389       AssignedPartitions consumer group rebalance event: assigned partition set
  2390      </p>
  2391      <pre>type AssignedPartitions struct {
  2392  <span id="AssignedPartitions.Partitions"></span>    Partitions []<a href="#TopicPartition">TopicPartition</a>
  2393  }
  2394  </pre>
  2395      <h3 id="AssignedPartitions.String">
  2396       func (AssignedPartitions)
  2397       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=2619:2662#L95">
  2398        String
  2399       </a>
  2400       <a class="permalink" href="#AssignedPartitions.String">
  2401        ¶
  2402       </a>
  2403      </h3>
  2404      <pre>func (e <a href="#AssignedPartitions">AssignedPartitions</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  2405      <h2 id="BrokerMetadata">
  2406       type
  2407       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/metadata.go?s=1262:1327#L37">
  2408        BrokerMetadata
  2409       </a>
  2410       <a class="permalink" href="#BrokerMetadata">
  2411        ¶
  2412       </a>
  2413      </h2>
  2414      <p>
  2415       BrokerMetadata contains per-broker metadata
  2416      </p>
  2417      <pre>type BrokerMetadata struct {
  2418  <span id="BrokerMetadata.ID"></span>    ID   <a href="https://pkg.go.dev/builtin/#int32">int32</a>
  2419  <span id="BrokerMetadata.Host"></span>    Host <a href="https://pkg.go.dev/builtin/#string">string</a>
  2420  <span id="BrokerMetadata.Port"></span>    Port <a href="https://pkg.go.dev/builtin/#int">int</a>
  2421  }
  2422  </pre>
  2423      <h2 id="ConfigEntry">
  2424       type
  2425       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=7918:8145#L227">
  2426        ConfigEntry
  2427       </a>
  2428       <a class="permalink" href="#ConfigEntry">
  2429        ¶
  2430       </a>
  2431      </h2>
  2432      <p>
  2433       ConfigEntry holds parameters for altering a resource's configuration.
  2434      </p>
  2435      <pre>type ConfigEntry struct {
  2436  <span id="ConfigEntry.Name"></span>    <span class="comment">// Name of configuration entry, e.g., topic configuration property name.</span>
  2437      Name <a href="https://pkg.go.dev/builtin/#string">string</a>
  2438  <span id="ConfigEntry.Value"></span>    <span class="comment">// Value of configuration entry.</span>
  2439      Value <a href="https://pkg.go.dev/builtin/#string">string</a>
  2440  <span id="ConfigEntry.Operation"></span>    <span class="comment">// Operation to perform on the entry.</span>
  2441      Operation <a href="#AlterOperation">AlterOperation</a>
  2442  }
  2443  </pre>
  2444      <h3 id="StringMapToConfigEntries">
  2445       func
  2446       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=8298:8396#L238">
  2447        StringMapToConfigEntries
  2448       </a>
  2449       <a class="permalink" href="#StringMapToConfigEntries">
  2450        ¶
  2451       </a>
  2452      </h3>
  2453      <pre>func StringMapToConfigEntries(stringMap map[<a href="https://pkg.go.dev/builtin/#string">string</a>]<a href="https://pkg.go.dev/builtin/#string">string</a>, operation <a href="#AlterOperation">AlterOperation</a>) []<a href="#ConfigEntry">ConfigEntry</a></pre>
  2454      <p>
  2455       StringMapToConfigEntries creates a new map of ConfigEntry objects from the
  2456  provided string map. The AlterOperation is set on each created entry.
  2457      </p>
  2458      <h3 id="ConfigEntry.String">
  2459       func (ConfigEntry)
  2460       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=8627:8663#L249">
  2461        String
  2462       </a>
  2463       <a class="permalink" href="#ConfigEntry.String">
  2464        ¶
  2465       </a>
  2466      </h3>
  2467      <pre>func (c <a href="#ConfigEntry">ConfigEntry</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  2468      <p>
  2469       String returns a human-readable representation of a ConfigEntry.
  2470      </p>
  2471      <h2 id="ConfigEntryResult">
  2472       type
  2473       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=8843:9576#L255">
  2474        ConfigEntryResult
  2475       </a>
  2476       <a class="permalink" href="#ConfigEntryResult">
  2477        ¶
  2478       </a>
  2479      </h2>
  2480      <p>
  2481       ConfigEntryResult contains the result of a single configuration entry from a
  2482  DescribeConfigs request.
  2483      </p>
  2484      <pre>type ConfigEntryResult struct {
  2485  <span id="ConfigEntryResult.Name"></span>    <span class="comment">// Name of configuration entry, e.g., topic configuration property name.</span>
  2486      Name <a href="https://pkg.go.dev/builtin/#string">string</a>
  2487  <span id="ConfigEntryResult.Value"></span>    <span class="comment">// Value of configuration entry.</span>
  2488      Value <a href="https://pkg.go.dev/builtin/#string">string</a>
  2489  <span id="ConfigEntryResult.Source"></span>    <span class="comment">// Source indicates the configuration source.</span>
  2490      Source <a href="#ConfigSource">ConfigSource</a>
  2491  <span id="ConfigEntryResult.IsReadOnly"></span>    <span class="comment">// IsReadOnly indicates whether the configuration entry can be altered.</span>
  2492      IsReadOnly <a href="https://pkg.go.dev/builtin/#bool">bool</a>
  2493  <span id="ConfigEntryResult.IsSensitive"></span>    <span class="comment">// IsSensitive indicates whether the configuration entry contains sensitive information, in which case the value will be unset.</span>
  2494      IsSensitive <a href="https://pkg.go.dev/builtin/#bool">bool</a>
  2495  <span id="ConfigEntryResult.IsSynonym"></span>    <span class="comment">// IsSynonym indicates whether the configuration entry is a synonym for another configuration property.</span>
  2496      IsSynonym <a href="https://pkg.go.dev/builtin/#bool">bool</a>
  2497  <span id="ConfigEntryResult.Synonyms"></span>    <span class="comment">// Synonyms contains a map of configuration entries that are synonyms to this configuration entry.</span>
  2498      Synonyms map[<a href="https://pkg.go.dev/builtin/#string">string</a>]<a href="#ConfigEntryResult">ConfigEntryResult</a>
  2499  }
  2500  </pre>
  2501      <h3 id="ConfigEntryResult.String">
  2502       func (ConfigEntryResult)
  2503       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=9652:9694#L273">
  2504        String
  2505       </a>
  2506       <a class="permalink" href="#ConfigEntryResult.String">
  2507        ¶
  2508       </a>
  2509      </h3>
  2510      <pre>func (c <a href="#ConfigEntryResult">ConfigEntryResult</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  2511      <p>
  2512       String returns a human-readable representation of a ConfigEntryResult.
  2513      </p>
  2514      <h2 id="ConfigMap">
  2515       type
  2516       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/config.go?s=1394:1431#L36">
  2517        ConfigMap
  2518       </a>
  2519       <a class="permalink" href="#ConfigMap">
  2520        ¶
  2521       </a>
  2522      </h2>
  2523      <p>
  2524       ConfigMap is a map containing standard librdkafka configuration properties as documented in:
  2525       <a href="https://github.com/edenhill/librdkafka/tree/master/CONFIGURATION.md">
  2526        https://github.com/edenhill/librdkafka/tree/master/CONFIGURATION.md
  2527       </a>
  2528      </p>
  2529      <p>
  2530       The special property "default.topic.config" (optional) is a ConfigMap
  2531  containing default topic configuration properties.
  2532      </p>
  2533      <p>
  2534       The use of "default.topic.config" is deprecated,
  2535  topic configuration properties shall be specified in the standard ConfigMap.
  2536  For backwards compatibility, "default.topic.config" (if supplied)
  2537  takes precedence.
  2538      </p>
  2539      <pre>type ConfigMap map[<a href="https://pkg.go.dev/builtin/#string">string</a>]<a href="#ConfigValue">ConfigValue</a></pre>
  2540      <h3 id="ConfigMap.Get">
  2541       func (ConfigMap)
  2542       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/config.go?s=7594:7669#L268">
  2543        Get
  2544       </a>
  2545       <a class="permalink" href="#ConfigMap.Get">
  2546        ¶
  2547       </a>
  2548      </h3>
  2549      <pre>func (m <a href="#ConfigMap">ConfigMap</a>) Get(key <a href="https://pkg.go.dev/builtin/#string">string</a>, defval <a href="#ConfigValue">ConfigValue</a>) (<a href="#ConfigValue">ConfigValue</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2550      <p>
  2551       Get finds the given key in the ConfigMap and returns its value.
  2552  If the key is not found `defval` is returned.
  2553  If the key is found but the type does not match that of `defval` (unless nil)
  2554  an ErrInvalidArg error is returned.
  2555      </p>
  2556      <h3 id="ConfigMap.Set">
  2557       func (ConfigMap)
  2558       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/config.go?s=2062:2101#L58">
  2559        Set
  2560       </a>
  2561       <a class="permalink" href="#ConfigMap.Set">
  2562        ¶
  2563       </a>
  2564      </h3>
  2565      <pre>func (m <a href="#ConfigMap">ConfigMap</a>) Set(kv <a href="https://pkg.go.dev/builtin/#string">string</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  2566      <p>
  2567       Set implements flag.Set (command line argument parser) as a convenience
  2568  for `-X key=value` config.
  2569      </p>
  2570      <h3 id="ConfigMap.SetKey">
  2571       func (ConfigMap)
  2572       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/config.go?s=1619:1681#L42">
  2573        SetKey
  2574       </a>
  2575       <a class="permalink" href="#ConfigMap.SetKey">
  2576        ¶
  2577       </a>
  2578      </h3>
  2579      <pre>func (m <a href="#ConfigMap">ConfigMap</a>) SetKey(key <a href="https://pkg.go.dev/builtin/#string">string</a>, value <a href="#ConfigValue">ConfigValue</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  2580      <p>
  2581       SetKey sets configuration property key to value.
  2582      </p>
  2583      <p>
  2584       For user convenience a key prefixed with {topic}. will be
  2585  set on the "default.topic.config" sub-map, this use is deprecated.
  2586      </p>
  2587      <h2 id="ConfigResource">
  2588       type
  2589       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=6814:7209#L190">
  2590        ConfigResource
  2591       </a>
  2592       <a class="permalink" href="#ConfigResource">
  2593        ¶
  2594       </a>
  2595      </h2>
  2596      <p>
  2597       ConfigResource holds parameters for altering an Apache Kafka configuration resource
  2598      </p>
  2599      <pre>type ConfigResource struct {
  2600  <span id="ConfigResource.Type"></span>    <span class="comment">// Type of resource to set.</span>
  2601      Type <a href="#ResourceType">ResourceType</a>
  2602  <span id="ConfigResource.Name"></span>    <span class="comment">// Name of resource to set.</span>
  2603      Name <a href="https://pkg.go.dev/builtin/#string">string</a>
  2604  <span id="ConfigResource.Config"></span>    <span class="comment">// Config entries to set.</span>
  2605      <span class="comment">// Configuration updates are atomic, any configuration property not provided</span>
  2606      <span class="comment">// here will be reverted (by the broker) to its default value.</span>
  2607      <span class="comment">// Use DescribeConfigs to retrieve the list of current configuration entry values.</span>
  2608      Config []<a href="#ConfigEntry">ConfigEntry</a>
  2609  }
  2610  </pre>
  2611      <h3 id="ConfigResource.String">
  2612       func (ConfigResource)
  2613       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=7281:7320#L203">
  2614        String
  2615       </a>
  2616       <a class="permalink" href="#ConfigResource.String">
  2617        ¶
  2618       </a>
  2619      </h3>
  2620      <pre>func (c <a href="#ConfigResource">ConfigResource</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  2621      <p>
  2622       String returns a human-readable representation of a ConfigResource
  2623      </p>
  2624      <h2 id="ConfigResourceResult">
  2625       type
  2626       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=10822:11121#L306">
  2627        ConfigResourceResult
  2628       </a>
  2629       <a class="permalink" href="#ConfigResourceResult">
  2630        ¶
  2631       </a>
  2632      </h2>
  2633      <p>
  2634       ConfigResourceResult provides the result for a resource from a AlterConfigs or
  2635  DescribeConfigs request.
  2636      </p>
  2637      <pre>type ConfigResourceResult struct {
  2638  <span id="ConfigResourceResult.Type"></span>    <span class="comment">// Type of returned result resource.</span>
  2639      Type <a href="#ResourceType">ResourceType</a>
  2640  <span id="ConfigResourceResult.Name"></span>    <span class="comment">// Name of returned result resource.</span>
  2641      Name <a href="https://pkg.go.dev/builtin/#string">string</a>
  2642  <span id="ConfigResourceResult.Error"></span>    <span class="comment">// Error, if any, of returned result resource.</span>
  2643      Error <a href="#Error">Error</a>
  2644  <span id="ConfigResourceResult.Config"></span>    <span class="comment">// Config entries, if any, of returned result resource.</span>
  2645      Config map[<a href="https://pkg.go.dev/builtin/#string">string</a>]<a href="#ConfigEntryResult">ConfigEntryResult</a>
  2646  }
  2647  </pre>
  2648      <h3 id="ConfigResourceResult.String">
  2649       func (ConfigResourceResult)
  2650       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=11200:11245#L318">
  2651        String
  2652       </a>
  2653       <a class="permalink" href="#ConfigResourceResult.String">
  2654        ¶
  2655       </a>
  2656      </h3>
  2657      <pre>func (c <a href="#ConfigResourceResult">ConfigResourceResult</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  2658      <p>
  2659       String returns a human-readable representation of a ConfigResourceResult.
  2660      </p>
  2661      <h2 id="ConfigSource">
  2662       type
  2663       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=5389:5410#L167">
  2664        ConfigSource
  2665       </a>
  2666       <a class="permalink" href="#ConfigSource">
  2667        ¶
  2668       </a>
  2669      </h2>
  2670      <p>
  2671       ConfigSource represents an Apache Kafka config source
  2672      </p>
  2673      <pre>type ConfigSource <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  2674      <h3 id="ConfigSource.String">
  2675       func (ConfigSource)
  2676       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=6605:6642#L185">
  2677        String
  2678       </a>
  2679       <a class="permalink" href="#ConfigSource.String">
  2680        ¶
  2681       </a>
  2682      </h3>
  2683      <pre>func (t <a href="#ConfigSource">ConfigSource</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  2684      <p>
  2685       String returns the human-readable representation of a ConfigSource type
  2686      </p>
  2687      <h2 id="ConfigValue">
  2688       type
  2689       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/config.go?s=842:870#L24">
  2690        ConfigValue
  2691       </a>
  2692       <a class="permalink" href="#ConfigValue">
  2693        ¶
  2694       </a>
  2695      </h2>
  2696      <p>
  2697       ConfigValue supports the following types:
  2698      </p>
  2699      <pre>bool, int, string, any type with the standard String() interface
  2700  </pre>
  2701      <pre>type ConfigValue interface{}</pre>
  2702      <h2 id="Consumer">
  2703       type
  2704       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=1184:1431#L32">
  2705        Consumer
  2706       </a>
  2707       <a class="permalink" href="#Consumer">
  2708        ¶
  2709       </a>
  2710      </h2>
  2711      <p>
  2712       Consumer implements a High-level Apache Kafka Consumer instance
  2713      </p>
  2714      <pre>type Consumer struct {
  2715      <span class="comment">// contains filtered or unexported fields</span>
  2716  }
  2717  </pre>
  2718      <h3 id="NewConsumer">
  2719       func
  2720       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=15102:15154#L454">
  2721        NewConsumer
  2722       </a>
  2723       <a class="permalink" href="#NewConsumer">
  2724        ¶
  2725       </a>
  2726      </h3>
  2727      <pre>func NewConsumer(conf *<a href="#ConfigMap">ConfigMap</a>) (*<a href="#Consumer">Consumer</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2728      <p>
  2729       NewConsumer creates a new high-level Consumer instance.
  2730      </p>
  2731      <p>
  2732       conf is a *ConfigMap with standard librdkafka configuration properties.
  2733      </p>
  2734      <p>
  2735       Supported special configuration properties:
  2736      </p>
  2737      <pre>go.application.rebalance.enable (bool, false) - Forward rebalancing responsibility to application via the Events() channel.
  2738                                       If set to true the app must handle the AssignedPartitions and
  2739                                       RevokedPartitions events and call Assign() and Unassign()
  2740                                       respectively.
  2741  go.events.channel.enable (bool, false) - [deprecated] Enable the Events() channel. Messages and events will be pushed on the Events() channel and the Poll() interface will be disabled.
  2742  go.events.channel.size (int, 1000) - Events() channel size
  2743  go.logs.channel.enable (bool, false) - Forward log to Logs() channel.
  2744  go.logs.channel (chan kafka.LogEvent, nil) - Forward logs to application-provided channel instead of Logs(). Requires go.logs.channel.enable=true.
  2745  </pre>
  2746      <p>
  2747       WARNING: Due to the buffering nature of channels (and queues in general) the
  2748  use of the events channel risks receiving outdated events and
  2749  messages. Minimizing go.events.channel.size reduces the risk
  2750  and number of outdated events and messages but does not eliminate
  2751  the factor completely. With a channel size of 1 at most one
  2752  event or message may be outdated.
  2753      </p>
  2754      <h3 id="Consumer.Assign">
  2755       func (*Consumer)
  2756       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=3153:3219#L95">
  2757        Assign
  2758       </a>
  2759       <a class="permalink" href="#Consumer.Assign">
  2760        ¶
  2761       </a>
  2762      </h3>
  2763      <pre>func (c *<a href="#Consumer">Consumer</a>) Assign(partitions []<a href="#TopicPartition">TopicPartition</a>) (err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2764      <p>
  2765       Assign an atomic set of partitions to consume.
  2766      </p>
  2767      <p>
  2768       The .Offset field of each TopicPartition must either be set to an absolute
  2769  starting offset (&gt;= 0), or one of the logical offsets (`kafka.OffsetEnd` etc),
  2770  but should typically be set to `kafka.OffsetStored` to have the consumer
  2771  use the committed offset as a start position, with a fallback to
  2772  `auto.offset.reset` if there is no committed offset.
  2773      </p>
  2774      <p>
  2775       This replaces the current assignment.
  2776      </p>
  2777      <h3 id="Consumer.Assignment">
  2778       func (*Consumer)
  2779       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=20687:20759#L621">
  2780        Assignment
  2781       </a>
  2782       <a class="permalink" href="#Consumer.Assignment">
  2783        ¶
  2784       </a>
  2785      </h3>
  2786      <pre>func (c *<a href="#Consumer">Consumer</a>) Assignment() (partitions []<a href="#TopicPartition">TopicPartition</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2787      <p>
  2788       Assignment returns the current partition assignments
  2789      </p>
  2790      <h3 id="Consumer.AssignmentLost">
  2791       func (*Consumer)
  2792       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=5986:6026#L184">
  2793        AssignmentLost
  2794       </a>
  2795       <a class="permalink" href="#Consumer.AssignmentLost">
  2796        ¶
  2797       </a>
  2798      </h3>
  2799      <pre>func (c *<a href="#Consumer">Consumer</a>) AssignmentLost() <a href="https://pkg.go.dev/builtin/#bool">bool</a></pre>
  2800      <p>
  2801       AssignmentLost returns true if current partition assignment has been lost.
  2802  This method is only applicable for use with a subscribing consumer when
  2803  handling a rebalance event or callback.
  2804  Partitions that have been lost may already be owned by other members in the
  2805  group and therefore commiting offsets, for example, may fail.
  2806      </p>
  2807      <h3 id="Consumer.Close">
  2808       func (*Consumer)
  2809       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=13151:13189#L408">
  2810        Close
  2811       </a>
  2812       <a class="permalink" href="#Consumer.Close">
  2813        ¶
  2814       </a>
  2815      </h3>
  2816      <pre>func (c *<a href="#Consumer">Consumer</a>) Close() (err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2817      <p>
  2818       Close Consumer instance.
  2819  The object is no longer usable after this call.
  2820      </p>
  2821      <h3 id="Consumer.Commit">
  2822       func (*Consumer)
  2823       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=7731:7784#L239">
  2824        Commit
  2825       </a>
  2826       <a class="permalink" href="#Consumer.Commit">
  2827        ¶
  2828       </a>
  2829      </h3>
  2830      <pre>func (c *<a href="#Consumer">Consumer</a>) Commit() ([]<a href="#TopicPartition">TopicPartition</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2831      <p>
  2832       Commit offsets for currently assigned partitions
  2833  This is a blocking call.
  2834  Returns the committed offsets on success.
  2835      </p>
  2836      <h3 id="Consumer.CommitMessage">
  2837       func (*Consumer)
  2838       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=7948:8018#L246">
  2839        CommitMessage
  2840       </a>
  2841       <a class="permalink" href="#Consumer.CommitMessage">
  2842        ¶
  2843       </a>
  2844      </h3>
  2845      <pre>func (c *<a href="#Consumer">Consumer</a>) CommitMessage(m *<a href="#Message">Message</a>) ([]<a href="#TopicPartition">TopicPartition</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2846      <p>
  2847       CommitMessage commits offset based on the provided message.
  2848  This is a blocking call.
  2849  Returns the committed offsets on success.
  2850      </p>
  2851      <h3 id="Consumer.CommitOffsets">
  2852       func (*Consumer)
  2853       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=8364:8448#L258">
  2854        CommitOffsets
  2855       </a>
  2856       <a class="permalink" href="#Consumer.CommitOffsets">
  2857        ¶
  2858       </a>
  2859      </h3>
  2860      <pre>func (c *<a href="#Consumer">Consumer</a>) CommitOffsets(offsets []<a href="#TopicPartition">TopicPartition</a>) ([]<a href="#TopicPartition">TopicPartition</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2861      <p>
  2862       CommitOffsets commits the provided list of offsets
  2863  This is a blocking call.
  2864  Returns the committed offsets on success.
  2865      </p>
  2866      <h3 id="Consumer.Committed">
  2867       func (*Consumer)
  2868       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=21146:21256#L636">
  2869        Committed
  2870       </a>
  2871       <a class="permalink" href="#Consumer.Committed">
  2872        ¶
  2873       </a>
  2874      </h3>
  2875      <pre>func (c *<a href="#Consumer">Consumer</a>) Committed(partitions []<a href="#TopicPartition">TopicPartition</a>, timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) (offsets []<a href="#TopicPartition">TopicPartition</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2876      <p>
  2877       Committed retrieves committed offsets for the given set of partitions
  2878      </p>
  2879      <h3 id="Consumer.Events">
  2880       func (*Consumer)
  2881       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=11343:11381#L339">
  2882        Events
  2883       </a>
  2884       <a class="permalink" href="#Consumer.Events">
  2885        ¶
  2886       </a>
  2887      </h3>
  2888      <pre>func (c *<a href="#Consumer">Consumer</a>) Events() chan <a href="#Event">Event</a></pre>
  2889      <p>
  2890       Events returns the Events channel (if enabled)
  2891      </p>
  2892      <h3 id="Consumer.GetConsumerGroupMetadata">
  2893       func (*Consumer)
  2894       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=26041:26118#L756">
  2895        GetConsumerGroupMetadata
  2896       </a>
  2897       <a class="permalink" href="#Consumer.GetConsumerGroupMetadata">
  2898        ¶
  2899       </a>
  2900      </h3>
  2901      <pre>func (c *<a href="#Consumer">Consumer</a>) GetConsumerGroupMetadata() (*<a href="#ConsumerGroupMetadata">ConsumerGroupMetadata</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2902      <p>
  2903       GetConsumerGroupMetadata returns the consumer's current group metadata.
  2904  This object should be passed to the transactional producer's
  2905  SendOffsetsToTransaction() API.
  2906      </p>
  2907      <h3 id="Consumer.GetMetadata">
  2908       func (*Consumer)
  2909       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=18189:18284#L563">
  2910        GetMetadata
  2911       </a>
  2912       <a class="permalink" href="#Consumer.GetMetadata">
  2913        ¶
  2914       </a>
  2915      </h3>
  2916      <pre>func (c *<a href="#Consumer">Consumer</a>) GetMetadata(topic *<a href="https://pkg.go.dev/builtin/#string">string</a>, allTopics <a href="https://pkg.go.dev/builtin/#bool">bool</a>, timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) (*<a href="#Metadata">Metadata</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2917      <p>
  2918       GetMetadata queries broker for cluster and topic metadata.
  2919  If topic is non-nil only information about that topic is returned, else if
  2920  allTopics is false only information about locally used topics is returned,
  2921  else information about all topics is returned.
  2922  GetMetadata is equivalent to listTopics, describeTopics and describeCluster in the Java API.
  2923      </p>
  2924      <h3 id="Consumer.GetRebalanceProtocol">
  2925       func (*Consumer)
  2926       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=5481:5529#L170">
  2927        GetRebalanceProtocol
  2928       </a>
  2929       <a class="permalink" href="#Consumer.GetRebalanceProtocol">
  2930        ¶
  2931       </a>
  2932      </h3>
  2933      <pre>func (c *<a href="#Consumer">Consumer</a>) GetRebalanceProtocol() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  2934      <p>
  2935       GetRebalanceProtocol returns the current consumer group rebalance protocol,
  2936  which is either "EAGER" or "COOPERATIVE".
  2937  If the rebalance protocol is not known in the current state an empty string
  2938  is returned.
  2939  Should typically only be called during rebalancing.
  2940      </p>
  2941      <h3 id="Consumer.GetWatermarkOffsets">
  2942       func (*Consumer)
  2943       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=18989:19087#L576">
  2944        GetWatermarkOffsets
  2945       </a>
  2946       <a class="permalink" href="#Consumer.GetWatermarkOffsets">
  2947        ¶
  2948       </a>
  2949      </h3>
  2950      <pre>func (c *<a href="#Consumer">Consumer</a>) GetWatermarkOffsets(topic <a href="https://pkg.go.dev/builtin/#string">string</a>, partition <a href="https://pkg.go.dev/builtin/#int32">int32</a>) (low, high <a href="https://pkg.go.dev/builtin/#int64">int64</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2951      <p>
  2952       GetWatermarkOffsets returns the cached low and high offsets for the given topic
  2953  and partition.  The high offset is populated on every fetch response or via calling QueryWatermarkOffsets.
  2954  The low offset is populated every statistics.interval.ms if that value is set.
  2955  OffsetInvalid will be returned if there is no cached offset for either value.
  2956      </p>
  2957      <h3 id="Consumer.IncrementalAssign">
  2958       func (*Consumer)
  2959       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=4256:4333#L131">
  2960        IncrementalAssign
  2961       </a>
  2962       <a class="permalink" href="#Consumer.IncrementalAssign">
  2963        ¶
  2964       </a>
  2965      </h3>
  2966      <pre>func (c *<a href="#Consumer">Consumer</a>) IncrementalAssign(partitions []<a href="#TopicPartition">TopicPartition</a>) (err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2967      <p>
  2968       IncrementalAssign adds the specified partitions to the current set of
  2969  partitions to consume.
  2970      </p>
  2971      <p>
  2972       The .Offset field of each TopicPartition must either be set to an absolute
  2973  starting offset (&gt;= 0), or one of the logical offsets (`kafka.OffsetEnd` etc),
  2974  but should typically be set to `kafka.OffsetStored` to have the consumer
  2975  use the committed offset as a start position, with a fallback to
  2976  `auto.offset.reset` if there is no committed offset.
  2977      </p>
  2978      <p>
  2979       The new partitions must not be part of the current assignment.
  2980      </p>
  2981      <h3 id="Consumer.IncrementalUnassign">
  2982       func (*Consumer)
  2983       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=4846:4925#L151">
  2984        IncrementalUnassign
  2985       </a>
  2986       <a class="permalink" href="#Consumer.IncrementalUnassign">
  2987        ¶
  2988       </a>
  2989      </h3>
  2990      <pre>func (c *<a href="#Consumer">Consumer</a>) IncrementalUnassign(partitions []<a href="#TopicPartition">TopicPartition</a>) (err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  2991      <p>
  2992       IncrementalUnassign removes the specified partitions from the current set of
  2993  partitions to consume.
  2994      </p>
  2995      <p>
  2996       The .Offset field of the TopicPartition is ignored.
  2997      </p>
  2998      <p>
  2999       The removed partitions must be part of the current assignment.
  3000      </p>
  3001      <h3 id="Consumer.Logs">
  3002       func (*Consumer)
  3003       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=11466:11505#L344">
  3004        Logs
  3005       </a>
  3006       <a class="permalink" href="#Consumer.Logs">
  3007        ¶
  3008       </a>
  3009      </h3>
  3010      <pre>func (c *<a href="#Consumer">Consumer</a>) Logs() chan <a href="#LogEvent">LogEvent</a></pre>
  3011      <p>
  3012       Logs returns the log channel if enabled, or nil otherwise.
  3013      </p>
  3014      <h3 id="Consumer.OffsetsForTimes">
  3015       func (*Consumer)
  3016       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=19856:19967#L595">
  3017        OffsetsForTimes
  3018       </a>
  3019       <a class="permalink" href="#Consumer.OffsetsForTimes">
  3020        ¶
  3021       </a>
  3022      </h3>
  3023      <pre>func (c *<a href="#Consumer">Consumer</a>) OffsetsForTimes(times []<a href="#TopicPartition">TopicPartition</a>, timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) (offsets []<a href="#TopicPartition">TopicPartition</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3024      <p>
  3025       OffsetsForTimes looks up offsets by timestamp for the given partitions.
  3026      </p>
  3027      <p>
  3028       The returned offset for each partition is the earliest offset whose
  3029  timestamp is greater than or equal to the given timestamp in the
  3030  corresponding partition. If the provided timestamp exceeds that of the
  3031  last message in the partition, a value of -1 will be returned.
  3032      </p>
  3033      <p>
  3034       The timestamps to query are represented as `.Offset` in the `times`
  3035  argument and the looked up offsets are represented as `.Offset` in the returned
  3036  `offsets` list.
  3037      </p>
  3038      <p>
  3039       The function will block for at most timeoutMs milliseconds.
  3040      </p>
  3041      <p>
  3042       Duplicate Topic+Partitions are not supported.
  3043  Per-partition errors may be returned in the `.Error` field.
  3044      </p>
  3045      <h3 id="Consumer.Pause">
  3046       func (*Consumer)
  3047       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=22595:22660#L669">
  3048        Pause
  3049       </a>
  3050       <a class="permalink" href="#Consumer.Pause">
  3051        ¶
  3052       </a>
  3053      </h3>
  3054      <pre>func (c *<a href="#Consumer">Consumer</a>) Pause(partitions []<a href="#TopicPartition">TopicPartition</a>) (err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3055      <p>
  3056       Pause consumption for the provided list of partitions
  3057      </p>
  3058      <p>
  3059       Note that messages already enqueued on the consumer's Event channel
  3060  (if `go.events.channel.enable` has been set) will NOT be purged by
  3061  this call, set `go.events.channel.size` accordingly.
  3062      </p>
  3063      <h3 id="Consumer.Poll">
  3064       func (*Consumer)
  3065       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=11171:11223#L333">
  3066        Poll
  3067       </a>
  3068       <a class="permalink" href="#Consumer.Poll">
  3069        ¶
  3070       </a>
  3071      </h3>
  3072      <pre>func (c *<a href="#Consumer">Consumer</a>) Poll(timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) (event <a href="#Event">Event</a>)</pre>
  3073      <p>
  3074       Poll the consumer for messages or events.
  3075      </p>
  3076      <h3 id="hdr-Will_block_for_at_most_timeoutMs_milliseconds">
  3077       Will block for at most timeoutMs milliseconds
  3078      </h3>
  3079      <p>
  3080       The following callbacks may be triggered:
  3081      </p>
  3082      <pre>Subscribe()'s rebalanceCb
  3083  </pre>
  3084      <p>
  3085       Returns nil on timeout, else an Event
  3086      </p>
  3087      <h3 id="Consumer.Position">
  3088       func (*Consumer)
  3089       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=21955:22049#L653">
  3090        Position
  3091       </a>
  3092       <a class="permalink" href="#Consumer.Position">
  3093        ¶
  3094       </a>
  3095      </h3>
  3096      <pre>func (c *<a href="#Consumer">Consumer</a>) Position(partitions []<a href="#TopicPartition">TopicPartition</a>) (offsets []<a href="#TopicPartition">TopicPartition</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3097      <p>
  3098       Position returns the current consume position for the given partitions.
  3099  Typical use is to call Assignment() to get the partition list
  3100  and then pass it to Position() to get the current consume position for
  3101  each of the assigned partitions.
  3102  The consume position is the next message to read from the partition.
  3103  i.e., the offset of the last message seen by the application + 1.
  3104      </p>
  3105      <h3 id="Consumer.QueryWatermarkOffsets">
  3106       func (*Consumer)
  3107       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=18450:18565#L568">
  3108        QueryWatermarkOffsets
  3109       </a>
  3110       <a class="permalink" href="#Consumer.QueryWatermarkOffsets">
  3111        ¶
  3112       </a>
  3113      </h3>
  3114      <pre>func (c *<a href="#Consumer">Consumer</a>) QueryWatermarkOffsets(topic <a href="https://pkg.go.dev/builtin/#string">string</a>, partition <a href="https://pkg.go.dev/builtin/#int32">int32</a>, timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) (low, high <a href="https://pkg.go.dev/builtin/#int64">int64</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3115      <p>
  3116       QueryWatermarkOffsets queries the broker for the low and high offsets for the given topic and partition.
  3117      </p>
  3118      <h3 id="Consumer.ReadMessage">
  3119       func (*Consumer)
  3120       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=12314:12385#L366">
  3121        ReadMessage
  3122       </a>
  3123       <a class="permalink" href="#Consumer.ReadMessage">
  3124        ¶
  3125       </a>
  3126      </h3>
  3127      <pre>func (c *<a href="#Consumer">Consumer</a>) ReadMessage(timeout <a href="https://pkg.go.dev/time/">time</a>.<a href="https://pkg.go.dev/time/#Duration">Duration</a>) (*<a href="#Message">Message</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3128      <p>
  3129       ReadMessage polls the consumer for a message.
  3130      </p>
  3131      <p>
  3132       This is a convenience API that wraps Poll() and only returns
  3133  messages or errors. All other event types are discarded.
  3134      </p>
  3135      <p>
  3136       The call will block for at most `timeout` waiting for
  3137  a new message or error. `timeout` may be set to -1 for
  3138  indefinite wait.
  3139      </p>
  3140      <p>
  3141       Timeout is returned as (nil, err) where err is `err.(kafka.Error).Code() == kafka.ErrTimedOut`.
  3142      </p>
  3143      <p>
  3144       Messages are returned as (msg, nil),
  3145  while general errors are returned as (nil, err),
  3146  and partition-specific errors are returned as (msg, err) where
  3147  msg.TopicPartition provides partition-specific information (such as topic, partition and offset).
  3148      </p>
  3149      <p>
  3150       All other event types, such as PartitionEOF, AssignedPartitions, etc, are silently discarded.
  3151      </p>
  3152      <h3 id="Consumer.Resume">
  3153       func (*Consumer)
  3154       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=22971:23037#L680">
  3155        Resume
  3156       </a>
  3157       <a class="permalink" href="#Consumer.Resume">
  3158        ¶
  3159       </a>
  3160      </h3>
  3161      <pre>func (c *<a href="#Consumer">Consumer</a>) Resume(partitions []<a href="#TopicPartition">TopicPartition</a>) (err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3162      <p>
  3163       Resume consumption for the provided list of partitions
  3164      </p>
  3165      <h3 id="Consumer.Seek">
  3166       func (*Consumer)
  3167       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=10636:10706#L313">
  3168        Seek
  3169       </a>
  3170       <a class="permalink" href="#Consumer.Seek">
  3171        ¶
  3172       </a>
  3173      </h3>
  3174      <pre>func (c *<a href="#Consumer">Consumer</a>) Seek(partition <a href="#TopicPartition">TopicPartition</a>, timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  3175      <p>
  3176       Seek seeks the given topic partitions using the offset from the TopicPartition.
  3177      </p>
  3178      <p>
  3179       If timeoutMs is not 0 the call will wait this long for the
  3180  seek to be performed. If the timeout is reached the internal state
  3181  will be unknown and this function returns ErrTimedOut.
  3182  If timeoutMs is 0 it will initiate the seek but return
  3183  immediately without any error reporting (e.g., async).
  3184      </p>
  3185      <p>
  3186       Seek() may only be used for partitions already being consumed
  3187  (through Assign() or implicitly through a self-rebalanced Subscribe()).
  3188  To set the starting offset it is preferred to use Assign() and provide
  3189  a starting offset for each partition.
  3190      </p>
  3191      <p>
  3192       Returns an error on failure or nil otherwise.
  3193      </p>
  3194      <h3 id="Consumer.SetOAuthBearerToken">
  3195       func (*Consumer)
  3196       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=23887:23966#L700">
  3197        SetOAuthBearerToken
  3198       </a>
  3199       <a class="permalink" href="#Consumer.SetOAuthBearerToken">
  3200        ¶
  3201       </a>
  3202      </h3>
  3203      <pre>func (c *<a href="#Consumer">Consumer</a>) SetOAuthBearerToken(oauthBearerToken <a href="#OAuthBearerToken">OAuthBearerToken</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  3204      <p>
  3205       SetOAuthBearerToken sets the the data to be transmitted
  3206  to a broker during SASL/OAUTHBEARER authentication. It will return nil
  3207  on success, otherwise an error if:
  3208  1) the token data is invalid (meaning an expiration time in the past
  3209  or either a token value or an extension key or value that does not meet
  3210  the regular expression requirements as per
  3211       <a href="https://tools.ietf.org/html/rfc7628#section-3.1">
  3212        https://tools.ietf.org/html/rfc7628#section-3.1
  3213       </a>
  3214       );
  3215  2) SASL/OAUTHBEARER is not supported by the underlying librdkafka build;
  3216  3) SASL/OAUTHBEARER is supported but is not configured as the client's
  3217  authentication mechanism.
  3218      </p>
  3219      <h3 id="Consumer.SetOAuthBearerTokenFailure">
  3220       func (*Consumer)
  3221       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=24465:24531#L711">
  3222        SetOAuthBearerTokenFailure
  3223       </a>
  3224       <a class="permalink" href="#Consumer.SetOAuthBearerTokenFailure">
  3225        ¶
  3226       </a>
  3227      </h3>
  3228      <pre>func (c *<a href="#Consumer">Consumer</a>) SetOAuthBearerTokenFailure(errstr <a href="https://pkg.go.dev/builtin/#string">string</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  3229      <p>
  3230       SetOAuthBearerTokenFailure sets the error message describing why token
  3231  retrieval/setting failed; it also schedules a new token refresh event for 10
  3232  seconds later so the attempt may be retried. It will return nil on
  3233  success, otherwise an error if:
  3234  1) SASL/OAUTHBEARER is not supported by the underlying librdkafka build;
  3235  2) SASL/OAUTHBEARER is supported but is not configured as the client's
  3236  authentication mechanism.
  3237      </p>
  3238      <h3 id="Consumer.StoreMessage">
  3239       func (*Consumer)
  3240       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=9491:9578#L287">
  3241        StoreMessage
  3242       </a>
  3243       <a class="permalink" href="#Consumer.StoreMessage">
  3244        ¶
  3245       </a>
  3246      </h3>
  3247      <pre>func (c *<a href="#Consumer">Consumer</a>) StoreMessage(m *<a href="#Message">Message</a>) (storedOffsets []<a href="#TopicPartition">TopicPartition</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3248      <p>
  3249       StoreMessage stores offset based on the provided message.
  3250  This is a convenience method that uses StoreOffsets to do the actual work.
  3251      </p>
  3252      <h3 id="Consumer.StoreOffsets">
  3253       func (*Consumer)
  3254       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=8862:8963#L269">
  3255        StoreOffsets
  3256       </a>
  3257       <a class="permalink" href="#Consumer.StoreOffsets">
  3258        ¶
  3259       </a>
  3260      </h3>
  3261      <pre>func (c *<a href="#Consumer">Consumer</a>) StoreOffsets(offsets []<a href="#TopicPartition">TopicPartition</a>) (storedOffsets []<a href="#TopicPartition">TopicPartition</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3262      <p>
  3263       StoreOffsets stores the provided list of offsets that will be committed
  3264  to the offset store according to `auto.commit.interval.ms` or manual
  3265  offset-less Commit().
  3266      </p>
  3267      <p>
  3268       Returns the stored offsets on success. If at least one offset couldn't be stored,
  3269  an error and a list of offsets is returned. Each offset can be checked for
  3270  specific errors via its `.Error` member.
  3271      </p>
  3272      <h3 id="Consumer.String">
  3273       func (*Consumer)
  3274       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=1498:1532#L43">
  3275        String
  3276       </a>
  3277       <a class="permalink" href="#Consumer.String">
  3278        ¶
  3279       </a>
  3280      </h3>
  3281      <pre>func (c *<a href="#Consumer">Consumer</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  3282      <p>
  3283       Strings returns a human readable name for a Consumer instance
  3284      </p>
  3285      <h3 id="Consumer.Subscribe">
  3286       func (*Consumer)
  3287       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=1744:1817#L54">
  3288        Subscribe
  3289       </a>
  3290       <a class="permalink" href="#Consumer.Subscribe">
  3291        ¶
  3292       </a>
  3293      </h3>
  3294      <pre>func (c *<a href="#Consumer">Consumer</a>) Subscribe(topic <a href="https://pkg.go.dev/builtin/#string">string</a>, rebalanceCb <a href="#RebalanceCb">RebalanceCb</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  3295      <p>
  3296       Subscribe to a single topic
  3297  This replaces the current subscription
  3298      </p>
  3299      <h3 id="Consumer.SubscribeTopics">
  3300       func (*Consumer)
  3301       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=1984:2072#L60">
  3302        SubscribeTopics
  3303       </a>
  3304       <a class="permalink" href="#Consumer.SubscribeTopics">
  3305        ¶
  3306       </a>
  3307      </h3>
  3308      <pre>func (c *<a href="#Consumer">Consumer</a>) SubscribeTopics(topics []<a href="https://pkg.go.dev/builtin/#string">string</a>, rebalanceCb <a href="#RebalanceCb">RebalanceCb</a>) (err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3309      <p>
  3310       SubscribeTopics subscribes to the provided list of topics.
  3311  This replaces the current subscription.
  3312      </p>
  3313      <h3 id="Consumer.Subscription">
  3314       func (*Consumer)
  3315       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=20089:20151#L600">
  3316        Subscription
  3317       </a>
  3318       <a class="permalink" href="#Consumer.Subscription">
  3319        ¶
  3320       </a>
  3321      </h3>
  3322      <pre>func (c *<a href="#Consumer">Consumer</a>) Subscription() (topics []<a href="https://pkg.go.dev/builtin/#string">string</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3323      <p>
  3324       Subscription returns the current subscription as set by Subscribe()
  3325      </p>
  3326      <h3 id="Consumer.Unassign">
  3327       func (*Consumer)
  3328       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=3534:3575#L110">
  3329        Unassign
  3330       </a>
  3331       <a class="permalink" href="#Consumer.Unassign">
  3332        ¶
  3333       </a>
  3334      </h3>
  3335      <pre>func (c *<a href="#Consumer">Consumer</a>) Unassign() (err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3336      <p>
  3337       Unassign the current set of partitions to consume.
  3338      </p>
  3339      <h3 id="Consumer.Unsubscribe">
  3340       func (*Consumer)
  3341       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=2597:2641#L81">
  3342        Unsubscribe
  3343       </a>
  3344       <a class="permalink" href="#Consumer.Unsubscribe">
  3345        ¶
  3346       </a>
  3347      </h3>
  3348      <pre>func (c *<a href="#Consumer">Consumer</a>) Unsubscribe() (err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3349      <p>
  3350       Unsubscribe from the current subscription, if any.
  3351      </p>
  3352      <h2 id="ConsumerGroupMetadata">
  3353       type
  3354       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=24667:24723#L716">
  3355        ConsumerGroupMetadata
  3356       </a>
  3357       <a class="permalink" href="#ConsumerGroupMetadata">
  3358        ¶
  3359       </a>
  3360      </h2>
  3361      <p>
  3362       ConsumerGroupMetadata reflects the current consumer group member metadata.
  3363      </p>
  3364      <pre>type ConsumerGroupMetadata struct {
  3365      <span class="comment">// contains filtered or unexported fields</span>
  3366  }
  3367  </pre>
  3368      <h3 id="NewTestConsumerGroupMetadata">
  3369       func
  3370       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=26655:26736#L774">
  3371        NewTestConsumerGroupMetadata
  3372       </a>
  3373       <a class="permalink" href="#NewTestConsumerGroupMetadata">
  3374        ¶
  3375       </a>
  3376      </h3>
  3377      <pre>func NewTestConsumerGroupMetadata(groupID <a href="https://pkg.go.dev/builtin/#string">string</a>) (*<a href="#ConsumerGroupMetadata">ConsumerGroupMetadata</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  3378      <p>
  3379       NewTestConsumerGroupMetadata creates a new consumer group metadata instance
  3380  mainly for testing use.
  3381  Use GetConsumerGroupMetadata() to retrieve the real metadata.
  3382      </p>
  3383      <h2 id="CreateACLResult">
  3384       type
  3385       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=19645:19760#L529">
  3386        CreateACLResult
  3387       </a>
  3388       <a class="permalink" href="#CreateACLResult">
  3389        ¶
  3390       </a>
  3391      </h2>
  3392      <p>
  3393       CreateACLResult provides create ACL error information.
  3394      </p>
  3395      <pre>type CreateACLResult struct {
  3396  <span id="CreateACLResult.Error"></span>    <span class="comment">// Error, if any, of result. Check with `Error.Code() != ErrNoError`.</span>
  3397      Error <a href="#Error">Error</a>
  3398  }
  3399  </pre>
  3400      <h2 id="CreateACLsAdminOption">
  3401       type
  3402       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=6952:7064#L245">
  3403        CreateACLsAdminOption
  3404       </a>
  3405       <a class="permalink" href="#CreateACLsAdminOption">
  3406        ¶
  3407       </a>
  3408      </h2>
  3409      <p>
  3410       CreateACLsAdminOption - see setter.
  3411      </p>
  3412      <p>
  3413       See SetAdminRequestTimeout
  3414      </p>
  3415      <pre>type CreateACLsAdminOption interface {
  3416      <span class="comment">// contains filtered or unexported methods</span>
  3417  }</pre>
  3418      <h2 id="CreatePartitionsAdminOption">
  3419       type
  3420       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=6314:6438#L221">
  3421        CreatePartitionsAdminOption
  3422       </a>
  3423       <a class="permalink" href="#CreatePartitionsAdminOption">
  3424        ¶
  3425       </a>
  3426      </h2>
  3427      <p>
  3428       CreatePartitionsAdminOption - see setters.
  3429      </p>
  3430      <p>
  3431       See SetAdminRequestTimeout, SetAdminOperationTimeout, SetAdminValidateOnly.
  3432      </p>
  3433      <pre>type CreatePartitionsAdminOption interface {
  3434      <span class="comment">// contains filtered or unexported methods</span>
  3435  }</pre>
  3436      <h2 id="CreateTopicsAdminOption">
  3437       type
  3438       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=5848:5964#L205">
  3439        CreateTopicsAdminOption
  3440       </a>
  3441       <a class="permalink" href="#CreateTopicsAdminOption">
  3442        ¶
  3443       </a>
  3444      </h2>
  3445      <p>
  3446       CreateTopicsAdminOption - see setters.
  3447      </p>
  3448      <p>
  3449       See SetAdminRequestTimeout, SetAdminOperationTimeout, SetAdminValidateOnly.
  3450      </p>
  3451      <pre>type CreateTopicsAdminOption interface {
  3452      <span class="comment">// contains filtered or unexported methods</span>
  3453  }</pre>
  3454      <h2 id="DeleteACLsAdminOption">
  3455       type
  3456       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=7330:7442#L261">
  3457        DeleteACLsAdminOption
  3458       </a>
  3459       <a class="permalink" href="#DeleteACLsAdminOption">
  3460        ¶
  3461       </a>
  3462      </h2>
  3463      <p>
  3464       DeleteACLsAdminOption - see setter.
  3465      </p>
  3466      <p>
  3467       See SetAdminRequestTimeout
  3468      </p>
  3469      <pre>type DeleteACLsAdminOption interface {
  3470      <span class="comment">// contains filtered or unexported methods</span>
  3471  }</pre>
  3472      <h2 id="DeleteACLsResult">
  3473       type
  3474       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=20106:20148#L543">
  3475        DeleteACLsResult
  3476       </a>
  3477       <a class="permalink" href="#DeleteACLsResult">
  3478        ¶
  3479       </a>
  3480      </h2>
  3481      <p>
  3482       DeleteACLsResult provides delete ACLs result or error information.
  3483      </p>
  3484      <pre>type DeleteACLsResult = <a href="#DescribeACLsResult">DescribeACLsResult</a></pre>
  3485      <h2 id="DeleteTopicsAdminOption">
  3486       type
  3487       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=6068:6184#L213">
  3488        DeleteTopicsAdminOption
  3489       </a>
  3490       <a class="permalink" href="#DeleteTopicsAdminOption">
  3491        ¶
  3492       </a>
  3493      </h2>
  3494      <p>
  3495       DeleteTopicsAdminOption - see setters.
  3496      </p>
  3497      <p>
  3498       See SetAdminRequestTimeout, SetAdminOperationTimeout.
  3499      </p>
  3500      <pre>type DeleteTopicsAdminOption interface {
  3501      <span class="comment">// contains filtered or unexported methods</span>
  3502  }</pre>
  3503      <h2 id="DescribeACLsAdminOption">
  3504       type
  3505       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=7140:7256#L253">
  3506        DescribeACLsAdminOption
  3507       </a>
  3508       <a class="permalink" href="#DescribeACLsAdminOption">
  3509        ¶
  3510       </a>
  3511      </h2>
  3512      <p>
  3513       DescribeACLsAdminOption - see setter.
  3514      </p>
  3515      <p>
  3516       See SetAdminRequestTimeout
  3517      </p>
  3518      <pre>type DescribeACLsAdminOption interface {
  3519      <span class="comment">// contains filtered or unexported methods</span>
  3520  }</pre>
  3521      <h2 id="DescribeACLsResult">
  3522       type
  3523       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=19836:20034#L535">
  3524        DescribeACLsResult
  3525       </a>
  3526       <a class="permalink" href="#DescribeACLsResult">
  3527        ¶
  3528       </a>
  3529      </h2>
  3530      <p>
  3531       DescribeACLsResult provides describe ACLs result or error information.
  3532      </p>
  3533      <pre>type DescribeACLsResult struct {
  3534      <span class="comment">// Slice of ACL bindings matching the provided filter</span>
  3535  <span id="DescribeACLsResult.ACLBindings"></span>    ACLBindings <a href="#ACLBindings">ACLBindings</a>
  3536  <span id="DescribeACLsResult.Error"></span>    <span class="comment">// Error, if any, of result. Check with `Error.Code() != ErrNoError`.</span>
  3537      Error <a href="#Error">Error</a>
  3538  }
  3539  </pre>
  3540      <h2 id="DescribeConfigsAdminOption">
  3541       type
  3542       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminoptions.go?s=6756:6878#L237">
  3543        DescribeConfigsAdminOption
  3544       </a>
  3545       <a class="permalink" href="#DescribeConfigsAdminOption">
  3546        ¶
  3547       </a>
  3548      </h2>
  3549      <p>
  3550       DescribeConfigsAdminOption - see setters.
  3551      </p>
  3552      <p>
  3553       See SetAdminRequestTimeout.
  3554      </p>
  3555      <pre>type DescribeConfigsAdminOption interface {
  3556      <span class="comment">// contains filtered or unexported methods</span>
  3557  }</pre>
  3558      <h2 id="Error">
  3559       type
  3560       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error.go?s=907:1050#L25">
  3561        Error
  3562       </a>
  3563       <a class="permalink" href="#Error">
  3564        ¶
  3565       </a>
  3566      </h2>
  3567      <p>
  3568       Error provides a Kafka-specific error container
  3569      </p>
  3570      <pre>type Error struct {
  3571      <span class="comment">// contains filtered or unexported fields</span>
  3572  }
  3573  </pre>
  3574      <h3 id="NewError">
  3575       func
  3576       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error.go?s=1181:1246#L38">
  3577        NewError
  3578       </a>
  3579       <a class="permalink" href="#NewError">
  3580        ¶
  3581       </a>
  3582      </h3>
  3583      <pre>func NewError(code <a href="#ErrorCode">ErrorCode</a>, str <a href="https://pkg.go.dev/builtin/#string">string</a>, fatal <a href="https://pkg.go.dev/builtin/#bool">bool</a>) (err <a href="#Error">Error</a>)</pre>
  3584      <p>
  3585       NewError creates a new Error.
  3586      </p>
  3587      <h3 id="Error.Code">
  3588       func (Error)
  3589       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error.go?s=2925:2956#L101">
  3590        Code
  3591       </a>
  3592       <a class="permalink" href="#Error.Code">
  3593        ¶
  3594       </a>
  3595      </h3>
  3596      <pre>func (e <a href="#Error">Error</a>) Code() <a href="#ErrorCode">ErrorCode</a></pre>
  3597      <p>
  3598       Code returns the ErrorCode of an Error
  3599      </p>
  3600      <h3 id="Error.Error">
  3601       func (Error)
  3602       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error.go?s=2548:2577#L80">
  3603        Error
  3604       </a>
  3605       <a class="permalink" href="#Error.Error">
  3606        ¶
  3607       </a>
  3608      </h3>
  3609      <pre>func (e <a href="#Error">Error</a>) Error() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  3610      <p>
  3611       Error returns a human readable representation of an Error
  3612  Same as Error.String()
  3613      </p>
  3614      <h3 id="Error.IsFatal">
  3615       func (Error)
  3616       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error.go?s=3200:3229#L109">
  3617        IsFatal
  3618       </a>
  3619       <a class="permalink" href="#Error.IsFatal">
  3620        ¶
  3621       </a>
  3622      </h3>
  3623      <pre>func (e <a href="#Error">Error</a>) IsFatal() <a href="https://pkg.go.dev/builtin/#bool">bool</a></pre>
  3624      <p>
  3625       IsFatal returns true if the error is a fatal error.
  3626  A fatal error indicates the client instance is no longer operable and
  3627  should be terminated. Typical causes include non-recoverable
  3628  idempotent producer errors.
  3629      </p>
  3630      <h3 id="Error.IsRetriable">
  3631       func (Error)
  3632       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error.go?s=3408:3441#L116">
  3633        IsRetriable
  3634       </a>
  3635       <a class="permalink" href="#Error.IsRetriable">
  3636        ¶
  3637       </a>
  3638      </h3>
  3639      <pre>func (e <a href="#Error">Error</a>) IsRetriable() <a href="https://pkg.go.dev/builtin/#bool">bool</a></pre>
  3640      <p>
  3641       IsRetriable returns true if the operation that caused this error
  3642  may be retried.
  3643  This flag is currently only set by the Transactional producer API.
  3644      </p>
  3645      <h3 id="Error.String">
  3646       func (Error)
  3647       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error.go?s=2664:2694#L85">
  3648        String
  3649       </a>
  3650       <a class="permalink" href="#Error.String">
  3651        ¶
  3652       </a>
  3653      </h3>
  3654      <pre>func (e <a href="#Error">Error</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  3655      <p>
  3656       String returns a human readable representation of an Error
  3657      </p>
  3658      <h3 id="Error.TxnRequiresAbort">
  3659       func (Error)
  3660       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/error.go?s=3810:3848#L125">
  3661        TxnRequiresAbort
  3662       </a>
  3663       <a class="permalink" href="#Error.TxnRequiresAbort">
  3664        ¶
  3665       </a>
  3666      </h3>
  3667      <pre>func (e <a href="#Error">Error</a>) TxnRequiresAbort() <a href="https://pkg.go.dev/builtin/#bool">bool</a></pre>
  3668      <p>
  3669       TxnRequiresAbort returns true if the error is an abortable transaction error
  3670  that requires the application to abort the current transaction with
  3671  AbortTransaction() and start a new transaction with BeginTransaction()
  3672  if it wishes to proceed with transactional operations.
  3673  This flag is only set by the Transactional producer API.
  3674      </p>
  3675      <h2 id="ErrorCode">
  3676       type
  3677       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/generated_errors.go?s=283:301#L1">
  3678        ErrorCode
  3679       </a>
  3680       <a class="permalink" href="#ErrorCode">
  3681        ¶
  3682       </a>
  3683      </h2>
  3684      <p>
  3685       ErrorCode is the integer representation of local and broker error codes
  3686      </p>
  3687      <pre>type ErrorCode <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  3688      <pre>const (
  3689      <span class="comment">// ErrBadMsg Local: Bad message format</span>
  3690      <span id="ErrBadMsg">ErrBadMsg</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__BAD_MSG">RD_KAFKA_RESP_ERR__BAD_MSG</a>)
  3691      <span class="comment">// ErrBadCompression Local: Invalid compressed data</span>
  3692      <span id="ErrBadCompression">ErrBadCompression</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__BAD_COMPRESSION">RD_KAFKA_RESP_ERR__BAD_COMPRESSION</a>)
  3693      <span class="comment">// ErrDestroy Local: Broker handle destroyed</span>
  3694      <span id="ErrDestroy">ErrDestroy</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__DESTROY">RD_KAFKA_RESP_ERR__DESTROY</a>)
  3695      <span class="comment">// ErrFail Local: Communication failure with broker</span>
  3696      <span id="ErrFail">ErrFail</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__FAIL">RD_KAFKA_RESP_ERR__FAIL</a>)
  3697      <span class="comment">// ErrTransport Local: Broker transport failure</span>
  3698      <span id="ErrTransport">ErrTransport</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__TRANSPORT">RD_KAFKA_RESP_ERR__TRANSPORT</a>)
  3699      <span class="comment">// ErrCritSysResource Local: Critical system resource failure</span>
  3700      <span id="ErrCritSysResource">ErrCritSysResource</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__CRIT_SYS_RESOURCE">RD_KAFKA_RESP_ERR__CRIT_SYS_RESOURCE</a>)
  3701      <span class="comment">// ErrResolve Local: Host resolution failure</span>
  3702      <span id="ErrResolve">ErrResolve</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__RESOLVE">RD_KAFKA_RESP_ERR__RESOLVE</a>)
  3703      <span class="comment">// ErrMsgTimedOut Local: Message timed out</span>
  3704      <span id="ErrMsgTimedOut">ErrMsgTimedOut</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__MSG_TIMED_OUT">RD_KAFKA_RESP_ERR__MSG_TIMED_OUT</a>)
  3705      <span class="comment">// ErrPartitionEOF Broker: No more messages</span>
  3706      <span id="ErrPartitionEOF">ErrPartitionEOF</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__PARTITION_EOF">RD_KAFKA_RESP_ERR__PARTITION_EOF</a>)
  3707      <span class="comment">// ErrUnknownPartition Local: Unknown partition</span>
  3708      <span id="ErrUnknownPartition">ErrUnknownPartition</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__UNKNOWN_PARTITION">RD_KAFKA_RESP_ERR__UNKNOWN_PARTITION</a>)
  3709      <span class="comment">// ErrFs Local: File or filesystem error</span>
  3710      <span id="ErrFs">ErrFs</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__FS">RD_KAFKA_RESP_ERR__FS</a>)
  3711      <span class="comment">// ErrUnknownTopic Local: Unknown topic</span>
  3712      <span id="ErrUnknownTopic">ErrUnknownTopic</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__UNKNOWN_TOPIC">RD_KAFKA_RESP_ERR__UNKNOWN_TOPIC</a>)
  3713      <span class="comment">// ErrAllBrokersDown Local: All broker connections are down</span>
  3714      <span id="ErrAllBrokersDown">ErrAllBrokersDown</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__ALL_BROKERS_DOWN">RD_KAFKA_RESP_ERR__ALL_BROKERS_DOWN</a>)
  3715      <span class="comment">// ErrInvalidArg Local: Invalid argument or configuration</span>
  3716      <span id="ErrInvalidArg">ErrInvalidArg</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__INVALID_ARG">RD_KAFKA_RESP_ERR__INVALID_ARG</a>)
  3717      <span class="comment">// ErrTimedOut Local: Timed out</span>
  3718      <span id="ErrTimedOut">ErrTimedOut</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__TIMED_OUT">RD_KAFKA_RESP_ERR__TIMED_OUT</a>)
  3719      <span class="comment">// ErrQueueFull Local: Queue full</span>
  3720      <span id="ErrQueueFull">ErrQueueFull</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__QUEUE_FULL">RD_KAFKA_RESP_ERR__QUEUE_FULL</a>)
  3721      <span class="comment">// ErrIsrInsuff Local: ISR count insufficient</span>
  3722      <span id="ErrIsrInsuff">ErrIsrInsuff</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__ISR_INSUFF">RD_KAFKA_RESP_ERR__ISR_INSUFF</a>)
  3723      <span class="comment">// ErrNodeUpdate Local: Broker node update</span>
  3724      <span id="ErrNodeUpdate">ErrNodeUpdate</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__NODE_UPDATE">RD_KAFKA_RESP_ERR__NODE_UPDATE</a>)
  3725      <span class="comment">// ErrSsl Local: SSL error</span>
  3726      <span id="ErrSsl">ErrSsl</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__SSL">RD_KAFKA_RESP_ERR__SSL</a>)
  3727      <span class="comment">// ErrWaitCoord Local: Waiting for coordinator</span>
  3728      <span id="ErrWaitCoord">ErrWaitCoord</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__WAIT_COORD">RD_KAFKA_RESP_ERR__WAIT_COORD</a>)
  3729      <span class="comment">// ErrUnknownGroup Local: Unknown group</span>
  3730      <span id="ErrUnknownGroup">ErrUnknownGroup</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__UNKNOWN_GROUP">RD_KAFKA_RESP_ERR__UNKNOWN_GROUP</a>)
  3731      <span class="comment">// ErrInProgress Local: Operation in progress</span>
  3732      <span id="ErrInProgress">ErrInProgress</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__IN_PROGRESS">RD_KAFKA_RESP_ERR__IN_PROGRESS</a>)
  3733      <span class="comment">// ErrPrevInProgress Local: Previous operation in progress</span>
  3734      <span id="ErrPrevInProgress">ErrPrevInProgress</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__PREV_IN_PROGRESS">RD_KAFKA_RESP_ERR__PREV_IN_PROGRESS</a>)
  3735      <span class="comment">// ErrExistingSubscription Local: Existing subscription</span>
  3736      <span id="ErrExistingSubscription">ErrExistingSubscription</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__EXISTING_SUBSCRIPTION">RD_KAFKA_RESP_ERR__EXISTING_SUBSCRIPTION</a>)
  3737      <span class="comment">// ErrAssignPartitions Local: Assign partitions</span>
  3738      <span id="ErrAssignPartitions">ErrAssignPartitions</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__ASSIGN_PARTITIONS">RD_KAFKA_RESP_ERR__ASSIGN_PARTITIONS</a>)
  3739      <span class="comment">// ErrRevokePartitions Local: Revoke partitions</span>
  3740      <span id="ErrRevokePartitions">ErrRevokePartitions</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__REVOKE_PARTITIONS">RD_KAFKA_RESP_ERR__REVOKE_PARTITIONS</a>)
  3741      <span class="comment">// ErrConflict Local: Conflicting use</span>
  3742      <span id="ErrConflict">ErrConflict</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__CONFLICT">RD_KAFKA_RESP_ERR__CONFLICT</a>)
  3743      <span class="comment">// ErrState Local: Erroneous state</span>
  3744      <span id="ErrState">ErrState</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__STATE">RD_KAFKA_RESP_ERR__STATE</a>)
  3745      <span class="comment">// ErrUnknownProtocol Local: Unknown protocol</span>
  3746      <span id="ErrUnknownProtocol">ErrUnknownProtocol</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__UNKNOWN_PROTOCOL">RD_KAFKA_RESP_ERR__UNKNOWN_PROTOCOL</a>)
  3747      <span class="comment">// ErrNotImplemented Local: Not implemented</span>
  3748      <span id="ErrNotImplemented">ErrNotImplemented</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__NOT_IMPLEMENTED">RD_KAFKA_RESP_ERR__NOT_IMPLEMENTED</a>)
  3749      <span class="comment">// ErrAuthentication Local: Authentication failure</span>
  3750      <span id="ErrAuthentication">ErrAuthentication</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__AUTHENTICATION">RD_KAFKA_RESP_ERR__AUTHENTICATION</a>)
  3751      <span class="comment">// ErrNoOffset Local: No offset stored</span>
  3752      <span id="ErrNoOffset">ErrNoOffset</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__NO_OFFSET">RD_KAFKA_RESP_ERR__NO_OFFSET</a>)
  3753      <span class="comment">// ErrOutdated Local: Outdated</span>
  3754      <span id="ErrOutdated">ErrOutdated</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__OUTDATED">RD_KAFKA_RESP_ERR__OUTDATED</a>)
  3755      <span class="comment">// ErrTimedOutQueue Local: Timed out in queue</span>
  3756      <span id="ErrTimedOutQueue">ErrTimedOutQueue</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__TIMED_OUT_QUEUE">RD_KAFKA_RESP_ERR__TIMED_OUT_QUEUE</a>)
  3757      <span class="comment">// ErrUnsupportedFeature Local: Required feature not supported by broker</span>
  3758      <span id="ErrUnsupportedFeature">ErrUnsupportedFeature</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__UNSUPPORTED_FEATURE">RD_KAFKA_RESP_ERR__UNSUPPORTED_FEATURE</a>)
  3759      <span class="comment">// ErrWaitCache Local: Awaiting cache update</span>
  3760      <span id="ErrWaitCache">ErrWaitCache</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__WAIT_CACHE">RD_KAFKA_RESP_ERR__WAIT_CACHE</a>)
  3761      <span class="comment">// ErrIntr Local: Operation interrupted</span>
  3762      <span id="ErrIntr">ErrIntr</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__INTR">RD_KAFKA_RESP_ERR__INTR</a>)
  3763      <span class="comment">// ErrKeySerialization Local: Key serialization error</span>
  3764      <span id="ErrKeySerialization">ErrKeySerialization</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__KEY_SERIALIZATION">RD_KAFKA_RESP_ERR__KEY_SERIALIZATION</a>)
  3765      <span class="comment">// ErrValueSerialization Local: Value serialization error</span>
  3766      <span id="ErrValueSerialization">ErrValueSerialization</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__VALUE_SERIALIZATION">RD_KAFKA_RESP_ERR__VALUE_SERIALIZATION</a>)
  3767      <span class="comment">// ErrKeyDeserialization Local: Key deserialization error</span>
  3768      <span id="ErrKeyDeserialization">ErrKeyDeserialization</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__KEY_DESERIALIZATION">RD_KAFKA_RESP_ERR__KEY_DESERIALIZATION</a>)
  3769      <span class="comment">// ErrValueDeserialization Local: Value deserialization error</span>
  3770      <span id="ErrValueDeserialization">ErrValueDeserialization</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__VALUE_DESERIALIZATION">RD_KAFKA_RESP_ERR__VALUE_DESERIALIZATION</a>)
  3771      <span class="comment">// ErrPartial Local: Partial response</span>
  3772      <span id="ErrPartial">ErrPartial</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__PARTIAL">RD_KAFKA_RESP_ERR__PARTIAL</a>)
  3773      <span class="comment">// ErrReadOnly Local: Read-only object</span>
  3774      <span id="ErrReadOnly">ErrReadOnly</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__READ_ONLY">RD_KAFKA_RESP_ERR__READ_ONLY</a>)
  3775      <span class="comment">// ErrNoent Local: No such entry</span>
  3776      <span id="ErrNoent">ErrNoent</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__NOENT">RD_KAFKA_RESP_ERR__NOENT</a>)
  3777      <span class="comment">// ErrUnderflow Local: Read underflow</span>
  3778      <span id="ErrUnderflow">ErrUnderflow</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__UNDERFLOW">RD_KAFKA_RESP_ERR__UNDERFLOW</a>)
  3779      <span class="comment">// ErrInvalidType Local: Invalid type</span>
  3780      <span id="ErrInvalidType">ErrInvalidType</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__INVALID_TYPE">RD_KAFKA_RESP_ERR__INVALID_TYPE</a>)
  3781      <span class="comment">// ErrRetry Local: Retry operation</span>
  3782      <span id="ErrRetry">ErrRetry</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__RETRY">RD_KAFKA_RESP_ERR__RETRY</a>)
  3783      <span class="comment">// ErrPurgeQueue Local: Purged in queue</span>
  3784      <span id="ErrPurgeQueue">ErrPurgeQueue</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__PURGE_QUEUE">RD_KAFKA_RESP_ERR__PURGE_QUEUE</a>)
  3785      <span class="comment">// ErrPurgeInflight Local: Purged in flight</span>
  3786      <span id="ErrPurgeInflight">ErrPurgeInflight</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__PURGE_INFLIGHT">RD_KAFKA_RESP_ERR__PURGE_INFLIGHT</a>)
  3787      <span class="comment">// ErrFatal Local: Fatal error</span>
  3788      <span id="ErrFatal">ErrFatal</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__FATAL">RD_KAFKA_RESP_ERR__FATAL</a>)
  3789      <span class="comment">// ErrInconsistent Local: Inconsistent state</span>
  3790      <span id="ErrInconsistent">ErrInconsistent</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__INCONSISTENT">RD_KAFKA_RESP_ERR__INCONSISTENT</a>)
  3791      <span class="comment">// ErrGaplessGuarantee Local: Gap-less ordering would not be guaranteed if proceeding</span>
  3792      <span id="ErrGaplessGuarantee">ErrGaplessGuarantee</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__GAPLESS_GUARANTEE">RD_KAFKA_RESP_ERR__GAPLESS_GUARANTEE</a>)
  3793      <span class="comment">// ErrMaxPollExceeded Local: Maximum application poll interval (max.poll.interval.ms) exceeded</span>
  3794      <span id="ErrMaxPollExceeded">ErrMaxPollExceeded</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__MAX_POLL_EXCEEDED">RD_KAFKA_RESP_ERR__MAX_POLL_EXCEEDED</a>)
  3795      <span class="comment">// ErrUnknownBroker Local: Unknown broker</span>
  3796      <span id="ErrUnknownBroker">ErrUnknownBroker</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__UNKNOWN_BROKER">RD_KAFKA_RESP_ERR__UNKNOWN_BROKER</a>)
  3797      <span class="comment">// ErrNotConfigured Local: Functionality not configured</span>
  3798      <span id="ErrNotConfigured">ErrNotConfigured</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__NOT_CONFIGURED">RD_KAFKA_RESP_ERR__NOT_CONFIGURED</a>)
  3799      <span class="comment">// ErrFenced Local: This instance has been fenced by a newer instance</span>
  3800      <span id="ErrFenced">ErrFenced</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__FENCED">RD_KAFKA_RESP_ERR__FENCED</a>)
  3801      <span class="comment">// ErrApplication Local: Application generated error</span>
  3802      <span id="ErrApplication">ErrApplication</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__APPLICATION">RD_KAFKA_RESP_ERR__APPLICATION</a>)
  3803      <span class="comment">// ErrAssignmentLost Local: Group partition assignment lost</span>
  3804      <span id="ErrAssignmentLost">ErrAssignmentLost</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__ASSIGNMENT_LOST">RD_KAFKA_RESP_ERR__ASSIGNMENT_LOST</a>)
  3805      <span class="comment">// ErrNoop Local: No operation performed</span>
  3806      <span id="ErrNoop">ErrNoop</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__NOOP">RD_KAFKA_RESP_ERR__NOOP</a>)
  3807      <span class="comment">// ErrAutoOffsetReset Local: No offset to automatically reset to</span>
  3808      <span id="ErrAutoOffsetReset">ErrAutoOffsetReset</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR__AUTO_OFFSET_RESET">RD_KAFKA_RESP_ERR__AUTO_OFFSET_RESET</a>)
  3809      <span class="comment">// ErrUnknown Unknown broker error</span>
  3810      <span id="ErrUnknown">ErrUnknown</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNKNOWN">RD_KAFKA_RESP_ERR_UNKNOWN</a>)
  3811      <span class="comment">// ErrNoError Success</span>
  3812      <span id="ErrNoError">ErrNoError</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_NO_ERROR">RD_KAFKA_RESP_ERR_NO_ERROR</a>)
  3813      <span class="comment">// ErrOffsetOutOfRange Broker: Offset out of range</span>
  3814      <span id="ErrOffsetOutOfRange">ErrOffsetOutOfRange</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_OFFSET_OUT_OF_RANGE">RD_KAFKA_RESP_ERR_OFFSET_OUT_OF_RANGE</a>)
  3815      <span class="comment">// ErrInvalidMsg Broker: Invalid message</span>
  3816      <span id="ErrInvalidMsg">ErrInvalidMsg</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_MSG">RD_KAFKA_RESP_ERR_INVALID_MSG</a>)
  3817      <span class="comment">// ErrUnknownTopicOrPart Broker: Unknown topic or partition</span>
  3818      <span id="ErrUnknownTopicOrPart">ErrUnknownTopicOrPart</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNKNOWN_TOPIC_OR_PART">RD_KAFKA_RESP_ERR_UNKNOWN_TOPIC_OR_PART</a>)
  3819      <span class="comment">// ErrInvalidMsgSize Broker: Invalid message size</span>
  3820      <span id="ErrInvalidMsgSize">ErrInvalidMsgSize</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_MSG_SIZE">RD_KAFKA_RESP_ERR_INVALID_MSG_SIZE</a>)
  3821      <span class="comment">// ErrLeaderNotAvailable Broker: Leader not available</span>
  3822      <span id="ErrLeaderNotAvailable">ErrLeaderNotAvailable</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_LEADER_NOT_AVAILABLE">RD_KAFKA_RESP_ERR_LEADER_NOT_AVAILABLE</a>)
  3823      <span class="comment">// ErrNotLeaderForPartition Broker: Not leader for partition</span>
  3824      <span id="ErrNotLeaderForPartition">ErrNotLeaderForPartition</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_NOT_LEADER_FOR_PARTITION">RD_KAFKA_RESP_ERR_NOT_LEADER_FOR_PARTITION</a>)
  3825      <span class="comment">// ErrRequestTimedOut Broker: Request timed out</span>
  3826      <span id="ErrRequestTimedOut">ErrRequestTimedOut</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_REQUEST_TIMED_OUT">RD_KAFKA_RESP_ERR_REQUEST_TIMED_OUT</a>)
  3827      <span class="comment">// ErrBrokerNotAvailable Broker: Broker not available</span>
  3828      <span id="ErrBrokerNotAvailable">ErrBrokerNotAvailable</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_BROKER_NOT_AVAILABLE">RD_KAFKA_RESP_ERR_BROKER_NOT_AVAILABLE</a>)
  3829      <span class="comment">// ErrReplicaNotAvailable Broker: Replica not available</span>
  3830      <span id="ErrReplicaNotAvailable">ErrReplicaNotAvailable</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_REPLICA_NOT_AVAILABLE">RD_KAFKA_RESP_ERR_REPLICA_NOT_AVAILABLE</a>)
  3831      <span class="comment">// ErrMsgSizeTooLarge Broker: Message size too large</span>
  3832      <span id="ErrMsgSizeTooLarge">ErrMsgSizeTooLarge</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_MSG_SIZE_TOO_LARGE">RD_KAFKA_RESP_ERR_MSG_SIZE_TOO_LARGE</a>)
  3833      <span class="comment">// ErrStaleCtrlEpoch Broker: StaleControllerEpochCode</span>
  3834      <span id="ErrStaleCtrlEpoch">ErrStaleCtrlEpoch</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_STALE_CTRL_EPOCH">RD_KAFKA_RESP_ERR_STALE_CTRL_EPOCH</a>)
  3835      <span class="comment">// ErrOffsetMetadataTooLarge Broker: Offset metadata string too large</span>
  3836      <span id="ErrOffsetMetadataTooLarge">ErrOffsetMetadataTooLarge</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_OFFSET_METADATA_TOO_LARGE">RD_KAFKA_RESP_ERR_OFFSET_METADATA_TOO_LARGE</a>)
  3837      <span class="comment">// ErrNetworkException Broker: Broker disconnected before response received</span>
  3838      <span id="ErrNetworkException">ErrNetworkException</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_NETWORK_EXCEPTION">RD_KAFKA_RESP_ERR_NETWORK_EXCEPTION</a>)
  3839      <span class="comment">// ErrCoordinatorLoadInProgress Broker: Coordinator load in progress</span>
  3840      <span id="ErrCoordinatorLoadInProgress">ErrCoordinatorLoadInProgress</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_COORDINATOR_LOAD_IN_PROGRESS">RD_KAFKA_RESP_ERR_COORDINATOR_LOAD_IN_PROGRESS</a>)
  3841      <span class="comment">// ErrCoordinatorNotAvailable Broker: Coordinator not available</span>
  3842      <span id="ErrCoordinatorNotAvailable">ErrCoordinatorNotAvailable</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_COORDINATOR_NOT_AVAILABLE">RD_KAFKA_RESP_ERR_COORDINATOR_NOT_AVAILABLE</a>)
  3843      <span class="comment">// ErrNotCoordinator Broker: Not coordinator</span>
  3844      <span id="ErrNotCoordinator">ErrNotCoordinator</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_NOT_COORDINATOR">RD_KAFKA_RESP_ERR_NOT_COORDINATOR</a>)
  3845      <span class="comment">// ErrTopicException Broker: Invalid topic</span>
  3846      <span id="ErrTopicException">ErrTopicException</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_TOPIC_EXCEPTION">RD_KAFKA_RESP_ERR_TOPIC_EXCEPTION</a>)
  3847      <span class="comment">// ErrRecordListTooLarge Broker: Message batch larger than configured server segment size</span>
  3848      <span id="ErrRecordListTooLarge">ErrRecordListTooLarge</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_RECORD_LIST_TOO_LARGE">RD_KAFKA_RESP_ERR_RECORD_LIST_TOO_LARGE</a>)
  3849      <span class="comment">// ErrNotEnoughReplicas Broker: Not enough in-sync replicas</span>
  3850      <span id="ErrNotEnoughReplicas">ErrNotEnoughReplicas</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_NOT_ENOUGH_REPLICAS">RD_KAFKA_RESP_ERR_NOT_ENOUGH_REPLICAS</a>)
  3851      <span class="comment">// ErrNotEnoughReplicasAfterAppend Broker: Message(s) written to insufficient number of in-sync replicas</span>
  3852      <span id="ErrNotEnoughReplicasAfterAppend">ErrNotEnoughReplicasAfterAppend</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_NOT_ENOUGH_REPLICAS_AFTER_APPEND">RD_KAFKA_RESP_ERR_NOT_ENOUGH_REPLICAS_AFTER_APPEND</a>)
  3853      <span class="comment">// ErrInvalidRequiredAcks Broker: Invalid required acks value</span>
  3854      <span id="ErrInvalidRequiredAcks">ErrInvalidRequiredAcks</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_REQUIRED_ACKS">RD_KAFKA_RESP_ERR_INVALID_REQUIRED_ACKS</a>)
  3855      <span class="comment">// ErrIllegalGeneration Broker: Specified group generation id is not valid</span>
  3856      <span id="ErrIllegalGeneration">ErrIllegalGeneration</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_ILLEGAL_GENERATION">RD_KAFKA_RESP_ERR_ILLEGAL_GENERATION</a>)
  3857      <span class="comment">// ErrInconsistentGroupProtocol Broker: Inconsistent group protocol</span>
  3858      <span id="ErrInconsistentGroupProtocol">ErrInconsistentGroupProtocol</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INCONSISTENT_GROUP_PROTOCOL">RD_KAFKA_RESP_ERR_INCONSISTENT_GROUP_PROTOCOL</a>)
  3859      <span class="comment">// ErrInvalidGroupID Broker: Invalid group.id</span>
  3860      <span id="ErrInvalidGroupID">ErrInvalidGroupID</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_GROUP_ID">RD_KAFKA_RESP_ERR_INVALID_GROUP_ID</a>)
  3861      <span class="comment">// ErrUnknownMemberID Broker: Unknown member</span>
  3862      <span id="ErrUnknownMemberID">ErrUnknownMemberID</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNKNOWN_MEMBER_ID">RD_KAFKA_RESP_ERR_UNKNOWN_MEMBER_ID</a>)
  3863      <span class="comment">// ErrInvalidSessionTimeout Broker: Invalid session timeout</span>
  3864      <span id="ErrInvalidSessionTimeout">ErrInvalidSessionTimeout</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_SESSION_TIMEOUT">RD_KAFKA_RESP_ERR_INVALID_SESSION_TIMEOUT</a>)
  3865      <span class="comment">// ErrRebalanceInProgress Broker: Group rebalance in progress</span>
  3866      <span id="ErrRebalanceInProgress">ErrRebalanceInProgress</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_REBALANCE_IN_PROGRESS">RD_KAFKA_RESP_ERR_REBALANCE_IN_PROGRESS</a>)
  3867      <span class="comment">// ErrInvalidCommitOffsetSize Broker: Commit offset data size is not valid</span>
  3868      <span id="ErrInvalidCommitOffsetSize">ErrInvalidCommitOffsetSize</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_COMMIT_OFFSET_SIZE">RD_KAFKA_RESP_ERR_INVALID_COMMIT_OFFSET_SIZE</a>)
  3869      <span class="comment">// ErrTopicAuthorizationFailed Broker: Topic authorization failed</span>
  3870      <span id="ErrTopicAuthorizationFailed">ErrTopicAuthorizationFailed</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_TOPIC_AUTHORIZATION_FAILED">RD_KAFKA_RESP_ERR_TOPIC_AUTHORIZATION_FAILED</a>)
  3871      <span class="comment">// ErrGroupAuthorizationFailed Broker: Group authorization failed</span>
  3872      <span id="ErrGroupAuthorizationFailed">ErrGroupAuthorizationFailed</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_GROUP_AUTHORIZATION_FAILED">RD_KAFKA_RESP_ERR_GROUP_AUTHORIZATION_FAILED</a>)
  3873      <span class="comment">// ErrClusterAuthorizationFailed Broker: Cluster authorization failed</span>
  3874      <span id="ErrClusterAuthorizationFailed">ErrClusterAuthorizationFailed</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_CLUSTER_AUTHORIZATION_FAILED">RD_KAFKA_RESP_ERR_CLUSTER_AUTHORIZATION_FAILED</a>)
  3875      <span class="comment">// ErrInvalidTimestamp Broker: Invalid timestamp</span>
  3876      <span id="ErrInvalidTimestamp">ErrInvalidTimestamp</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_TIMESTAMP">RD_KAFKA_RESP_ERR_INVALID_TIMESTAMP</a>)
  3877      <span class="comment">// ErrUnsupportedSaslMechanism Broker: Unsupported SASL mechanism</span>
  3878      <span id="ErrUnsupportedSaslMechanism">ErrUnsupportedSaslMechanism</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNSUPPORTED_SASL_MECHANISM">RD_KAFKA_RESP_ERR_UNSUPPORTED_SASL_MECHANISM</a>)
  3879      <span class="comment">// ErrIllegalSaslState Broker: Request not valid in current SASL state</span>
  3880      <span id="ErrIllegalSaslState">ErrIllegalSaslState</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_ILLEGAL_SASL_STATE">RD_KAFKA_RESP_ERR_ILLEGAL_SASL_STATE</a>)
  3881      <span class="comment">// ErrUnsupportedVersion Broker: API version not supported</span>
  3882      <span id="ErrUnsupportedVersion">ErrUnsupportedVersion</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNSUPPORTED_VERSION">RD_KAFKA_RESP_ERR_UNSUPPORTED_VERSION</a>)
  3883      <span class="comment">// ErrTopicAlreadyExists Broker: Topic already exists</span>
  3884      <span id="ErrTopicAlreadyExists">ErrTopicAlreadyExists</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_TOPIC_ALREADY_EXISTS">RD_KAFKA_RESP_ERR_TOPIC_ALREADY_EXISTS</a>)
  3885      <span class="comment">// ErrInvalidPartitions Broker: Invalid number of partitions</span>
  3886      <span id="ErrInvalidPartitions">ErrInvalidPartitions</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_PARTITIONS">RD_KAFKA_RESP_ERR_INVALID_PARTITIONS</a>)
  3887      <span class="comment">// ErrInvalidReplicationFactor Broker: Invalid replication factor</span>
  3888      <span id="ErrInvalidReplicationFactor">ErrInvalidReplicationFactor</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_REPLICATION_FACTOR">RD_KAFKA_RESP_ERR_INVALID_REPLICATION_FACTOR</a>)
  3889      <span class="comment">// ErrInvalidReplicaAssignment Broker: Invalid replica assignment</span>
  3890      <span id="ErrInvalidReplicaAssignment">ErrInvalidReplicaAssignment</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_REPLICA_ASSIGNMENT">RD_KAFKA_RESP_ERR_INVALID_REPLICA_ASSIGNMENT</a>)
  3891      <span class="comment">// ErrInvalidConfig Broker: Configuration is invalid</span>
  3892      <span id="ErrInvalidConfig">ErrInvalidConfig</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_CONFIG">RD_KAFKA_RESP_ERR_INVALID_CONFIG</a>)
  3893      <span class="comment">// ErrNotController Broker: Not controller for cluster</span>
  3894      <span id="ErrNotController">ErrNotController</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_NOT_CONTROLLER">RD_KAFKA_RESP_ERR_NOT_CONTROLLER</a>)
  3895      <span class="comment">// ErrInvalidRequest Broker: Invalid request</span>
  3896      <span id="ErrInvalidRequest">ErrInvalidRequest</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_REQUEST">RD_KAFKA_RESP_ERR_INVALID_REQUEST</a>)
  3897      <span class="comment">// ErrUnsupportedForMessageFormat Broker: Message format on broker does not support request</span>
  3898      <span id="ErrUnsupportedForMessageFormat">ErrUnsupportedForMessageFormat</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNSUPPORTED_FOR_MESSAGE_FORMAT">RD_KAFKA_RESP_ERR_UNSUPPORTED_FOR_MESSAGE_FORMAT</a>)
  3899      <span class="comment">// ErrPolicyViolation Broker: Policy violation</span>
  3900      <span id="ErrPolicyViolation">ErrPolicyViolation</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_POLICY_VIOLATION">RD_KAFKA_RESP_ERR_POLICY_VIOLATION</a>)
  3901      <span class="comment">// ErrOutOfOrderSequenceNumber Broker: Broker received an out of order sequence number</span>
  3902      <span id="ErrOutOfOrderSequenceNumber">ErrOutOfOrderSequenceNumber</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_OUT_OF_ORDER_SEQUENCE_NUMBER">RD_KAFKA_RESP_ERR_OUT_OF_ORDER_SEQUENCE_NUMBER</a>)
  3903      <span class="comment">// ErrDuplicateSequenceNumber Broker: Broker received a duplicate sequence number</span>
  3904      <span id="ErrDuplicateSequenceNumber">ErrDuplicateSequenceNumber</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_DUPLICATE_SEQUENCE_NUMBER">RD_KAFKA_RESP_ERR_DUPLICATE_SEQUENCE_NUMBER</a>)
  3905      <span class="comment">// ErrInvalidProducerEpoch Broker: Producer attempted an operation with an old epoch</span>
  3906      <span id="ErrInvalidProducerEpoch">ErrInvalidProducerEpoch</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_PRODUCER_EPOCH">RD_KAFKA_RESP_ERR_INVALID_PRODUCER_EPOCH</a>)
  3907      <span class="comment">// ErrInvalidTxnState Broker: Producer attempted a transactional operation in an invalid state</span>
  3908      <span id="ErrInvalidTxnState">ErrInvalidTxnState</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_TXN_STATE">RD_KAFKA_RESP_ERR_INVALID_TXN_STATE</a>)
  3909      <span class="comment">// ErrInvalidProducerIDMapping Broker: Producer attempted to use a producer id which is not currently assigned to its transactional id</span>
  3910      <span id="ErrInvalidProducerIDMapping">ErrInvalidProducerIDMapping</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_PRODUCER_ID_MAPPING">RD_KAFKA_RESP_ERR_INVALID_PRODUCER_ID_MAPPING</a>)
  3911      <span class="comment">// ErrInvalidTransactionTimeout Broker: Transaction timeout is larger than the maximum value allowed by the broker's max.transaction.timeout.ms</span>
  3912      <span id="ErrInvalidTransactionTimeout">ErrInvalidTransactionTimeout</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_TRANSACTION_TIMEOUT">RD_KAFKA_RESP_ERR_INVALID_TRANSACTION_TIMEOUT</a>)
  3913      <span class="comment">// ErrConcurrentTransactions Broker: Producer attempted to update a transaction while another concurrent operation on the same transaction was ongoing</span>
  3914      <span id="ErrConcurrentTransactions">ErrConcurrentTransactions</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_CONCURRENT_TRANSACTIONS">RD_KAFKA_RESP_ERR_CONCURRENT_TRANSACTIONS</a>)
  3915      <span class="comment">// ErrTransactionCoordinatorFenced Broker: Indicates that the transaction coordinator sending a WriteTxnMarker is no longer the current coordinator for a given producer</span>
  3916      <span id="ErrTransactionCoordinatorFenced">ErrTransactionCoordinatorFenced</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_TRANSACTION_COORDINATOR_FENCED">RD_KAFKA_RESP_ERR_TRANSACTION_COORDINATOR_FENCED</a>)
  3917      <span class="comment">// ErrTransactionalIDAuthorizationFailed Broker: Transactional Id authorization failed</span>
  3918      <span id="ErrTransactionalIDAuthorizationFailed">ErrTransactionalIDAuthorizationFailed</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_TRANSACTIONAL_ID_AUTHORIZATION_FAILED">RD_KAFKA_RESP_ERR_TRANSACTIONAL_ID_AUTHORIZATION_FAILED</a>)
  3919      <span class="comment">// ErrSecurityDisabled Broker: Security features are disabled</span>
  3920      <span id="ErrSecurityDisabled">ErrSecurityDisabled</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_SECURITY_DISABLED">RD_KAFKA_RESP_ERR_SECURITY_DISABLED</a>)
  3921      <span class="comment">// ErrOperationNotAttempted Broker: Operation not attempted</span>
  3922      <span id="ErrOperationNotAttempted">ErrOperationNotAttempted</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_OPERATION_NOT_ATTEMPTED">RD_KAFKA_RESP_ERR_OPERATION_NOT_ATTEMPTED</a>)
  3923      <span class="comment">// ErrKafkaStorageError Broker: Disk error when trying to access log file on disk</span>
  3924      <span id="ErrKafkaStorageError">ErrKafkaStorageError</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_KAFKA_STORAGE_ERROR">RD_KAFKA_RESP_ERR_KAFKA_STORAGE_ERROR</a>)
  3925      <span class="comment">// ErrLogDirNotFound Broker: The user-specified log directory is not found in the broker config</span>
  3926      <span id="ErrLogDirNotFound">ErrLogDirNotFound</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_LOG_DIR_NOT_FOUND">RD_KAFKA_RESP_ERR_LOG_DIR_NOT_FOUND</a>)
  3927      <span class="comment">// ErrSaslAuthenticationFailed Broker: SASL Authentication failed</span>
  3928      <span id="ErrSaslAuthenticationFailed">ErrSaslAuthenticationFailed</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_SASL_AUTHENTICATION_FAILED">RD_KAFKA_RESP_ERR_SASL_AUTHENTICATION_FAILED</a>)
  3929      <span class="comment">// ErrUnknownProducerID Broker: Unknown Producer Id</span>
  3930      <span id="ErrUnknownProducerID">ErrUnknownProducerID</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNKNOWN_PRODUCER_ID">RD_KAFKA_RESP_ERR_UNKNOWN_PRODUCER_ID</a>)
  3931      <span class="comment">// ErrReassignmentInProgress Broker: Partition reassignment is in progress</span>
  3932      <span id="ErrReassignmentInProgress">ErrReassignmentInProgress</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_REASSIGNMENT_IN_PROGRESS">RD_KAFKA_RESP_ERR_REASSIGNMENT_IN_PROGRESS</a>)
  3933      <span class="comment">// ErrDelegationTokenAuthDisabled Broker: Delegation Token feature is not enabled</span>
  3934      <span id="ErrDelegationTokenAuthDisabled">ErrDelegationTokenAuthDisabled</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_AUTH_DISABLED">RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_AUTH_DISABLED</a>)
  3935      <span class="comment">// ErrDelegationTokenNotFound Broker: Delegation Token is not found on server</span>
  3936      <span id="ErrDelegationTokenNotFound">ErrDelegationTokenNotFound</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_NOT_FOUND">RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_NOT_FOUND</a>)
  3937      <span class="comment">// ErrDelegationTokenOwnerMismatch Broker: Specified Principal is not valid Owner/Renewer</span>
  3938      <span id="ErrDelegationTokenOwnerMismatch">ErrDelegationTokenOwnerMismatch</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_OWNER_MISMATCH">RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_OWNER_MISMATCH</a>)
  3939      <span class="comment">// ErrDelegationTokenRequestNotAllowed Broker: Delegation Token requests are not allowed on this connection</span>
  3940      <span id="ErrDelegationTokenRequestNotAllowed">ErrDelegationTokenRequestNotAllowed</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_REQUEST_NOT_ALLOWED">RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_REQUEST_NOT_ALLOWED</a>)
  3941      <span class="comment">// ErrDelegationTokenAuthorizationFailed Broker: Delegation Token authorization failed</span>
  3942      <span id="ErrDelegationTokenAuthorizationFailed">ErrDelegationTokenAuthorizationFailed</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_AUTHORIZATION_FAILED">RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_AUTHORIZATION_FAILED</a>)
  3943      <span class="comment">// ErrDelegationTokenExpired Broker: Delegation Token is expired</span>
  3944      <span id="ErrDelegationTokenExpired">ErrDelegationTokenExpired</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_EXPIRED">RD_KAFKA_RESP_ERR_DELEGATION_TOKEN_EXPIRED</a>)
  3945      <span class="comment">// ErrInvalidPrincipalType Broker: Supplied principalType is not supported</span>
  3946      <span id="ErrInvalidPrincipalType">ErrInvalidPrincipalType</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_PRINCIPAL_TYPE">RD_KAFKA_RESP_ERR_INVALID_PRINCIPAL_TYPE</a>)
  3947      <span class="comment">// ErrNonEmptyGroup Broker: The group is not empty</span>
  3948      <span id="ErrNonEmptyGroup">ErrNonEmptyGroup</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_NON_EMPTY_GROUP">RD_KAFKA_RESP_ERR_NON_EMPTY_GROUP</a>)
  3949      <span class="comment">// ErrGroupIDNotFound Broker: The group id does not exist</span>
  3950      <span id="ErrGroupIDNotFound">ErrGroupIDNotFound</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_GROUP_ID_NOT_FOUND">RD_KAFKA_RESP_ERR_GROUP_ID_NOT_FOUND</a>)
  3951      <span class="comment">// ErrFetchSessionIDNotFound Broker: The fetch session ID was not found</span>
  3952      <span id="ErrFetchSessionIDNotFound">ErrFetchSessionIDNotFound</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_FETCH_SESSION_ID_NOT_FOUND">RD_KAFKA_RESP_ERR_FETCH_SESSION_ID_NOT_FOUND</a>)
  3953      <span class="comment">// ErrInvalidFetchSessionEpoch Broker: The fetch session epoch is invalid</span>
  3954      <span id="ErrInvalidFetchSessionEpoch">ErrInvalidFetchSessionEpoch</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_FETCH_SESSION_EPOCH">RD_KAFKA_RESP_ERR_INVALID_FETCH_SESSION_EPOCH</a>)
  3955      <span class="comment">// ErrListenerNotFound Broker: No matching listener</span>
  3956      <span id="ErrListenerNotFound">ErrListenerNotFound</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_LISTENER_NOT_FOUND">RD_KAFKA_RESP_ERR_LISTENER_NOT_FOUND</a>)
  3957      <span class="comment">// ErrTopicDeletionDisabled Broker: Topic deletion is disabled</span>
  3958      <span id="ErrTopicDeletionDisabled">ErrTopicDeletionDisabled</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_TOPIC_DELETION_DISABLED">RD_KAFKA_RESP_ERR_TOPIC_DELETION_DISABLED</a>)
  3959      <span class="comment">// ErrFencedLeaderEpoch Broker: Leader epoch is older than broker epoch</span>
  3960      <span id="ErrFencedLeaderEpoch">ErrFencedLeaderEpoch</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_FENCED_LEADER_EPOCH">RD_KAFKA_RESP_ERR_FENCED_LEADER_EPOCH</a>)
  3961      <span class="comment">// ErrUnknownLeaderEpoch Broker: Leader epoch is newer than broker epoch</span>
  3962      <span id="ErrUnknownLeaderEpoch">ErrUnknownLeaderEpoch</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNKNOWN_LEADER_EPOCH">RD_KAFKA_RESP_ERR_UNKNOWN_LEADER_EPOCH</a>)
  3963      <span class="comment">// ErrUnsupportedCompressionType Broker: Unsupported compression type</span>
  3964      <span id="ErrUnsupportedCompressionType">ErrUnsupportedCompressionType</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNSUPPORTED_COMPRESSION_TYPE">RD_KAFKA_RESP_ERR_UNSUPPORTED_COMPRESSION_TYPE</a>)
  3965      <span class="comment">// ErrStaleBrokerEpoch Broker: Broker epoch has changed</span>
  3966      <span id="ErrStaleBrokerEpoch">ErrStaleBrokerEpoch</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_STALE_BROKER_EPOCH">RD_KAFKA_RESP_ERR_STALE_BROKER_EPOCH</a>)
  3967      <span class="comment">// ErrOffsetNotAvailable Broker: Leader high watermark is not caught up</span>
  3968      <span id="ErrOffsetNotAvailable">ErrOffsetNotAvailable</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_OFFSET_NOT_AVAILABLE">RD_KAFKA_RESP_ERR_OFFSET_NOT_AVAILABLE</a>)
  3969      <span class="comment">// ErrMemberIDRequired Broker: Group member needs a valid member ID</span>
  3970      <span id="ErrMemberIDRequired">ErrMemberIDRequired</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_MEMBER_ID_REQUIRED">RD_KAFKA_RESP_ERR_MEMBER_ID_REQUIRED</a>)
  3971      <span class="comment">// ErrPreferredLeaderNotAvailable Broker: Preferred leader was not available</span>
  3972      <span id="ErrPreferredLeaderNotAvailable">ErrPreferredLeaderNotAvailable</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_PREFERRED_LEADER_NOT_AVAILABLE">RD_KAFKA_RESP_ERR_PREFERRED_LEADER_NOT_AVAILABLE</a>)
  3973      <span class="comment">// ErrGroupMaxSizeReached Broker: Consumer group has reached maximum size</span>
  3974      <span id="ErrGroupMaxSizeReached">ErrGroupMaxSizeReached</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_GROUP_MAX_SIZE_REACHED">RD_KAFKA_RESP_ERR_GROUP_MAX_SIZE_REACHED</a>)
  3975      <span class="comment">// ErrFencedInstanceID Broker: Static consumer fenced by other consumer with same group.instance.id</span>
  3976      <span id="ErrFencedInstanceID">ErrFencedInstanceID</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_FENCED_INSTANCE_ID">RD_KAFKA_RESP_ERR_FENCED_INSTANCE_ID</a>)
  3977      <span class="comment">// ErrEligibleLeadersNotAvailable Broker: Eligible partition leaders are not available</span>
  3978      <span id="ErrEligibleLeadersNotAvailable">ErrEligibleLeadersNotAvailable</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_ELIGIBLE_LEADERS_NOT_AVAILABLE">RD_KAFKA_RESP_ERR_ELIGIBLE_LEADERS_NOT_AVAILABLE</a>)
  3979      <span class="comment">// ErrElectionNotNeeded Broker: Leader election not needed for topic partition</span>
  3980      <span id="ErrElectionNotNeeded">ErrElectionNotNeeded</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_ELECTION_NOT_NEEDED">RD_KAFKA_RESP_ERR_ELECTION_NOT_NEEDED</a>)
  3981      <span class="comment">// ErrNoReassignmentInProgress Broker: No partition reassignment is in progress</span>
  3982      <span id="ErrNoReassignmentInProgress">ErrNoReassignmentInProgress</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_NO_REASSIGNMENT_IN_PROGRESS">RD_KAFKA_RESP_ERR_NO_REASSIGNMENT_IN_PROGRESS</a>)
  3983      <span class="comment">// ErrGroupSubscribedToTopic Broker: Deleting offsets of a topic while the consumer group is subscribed to it</span>
  3984      <span id="ErrGroupSubscribedToTopic">ErrGroupSubscribedToTopic</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_GROUP_SUBSCRIBED_TO_TOPIC">RD_KAFKA_RESP_ERR_GROUP_SUBSCRIBED_TO_TOPIC</a>)
  3985      <span class="comment">// ErrInvalidRecord Broker: Broker failed to validate record</span>
  3986      <span id="ErrInvalidRecord">ErrInvalidRecord</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_RECORD">RD_KAFKA_RESP_ERR_INVALID_RECORD</a>)
  3987      <span class="comment">// ErrUnstableOffsetCommit Broker: There are unstable offsets that need to be cleared</span>
  3988      <span id="ErrUnstableOffsetCommit">ErrUnstableOffsetCommit</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNSTABLE_OFFSET_COMMIT">RD_KAFKA_RESP_ERR_UNSTABLE_OFFSET_COMMIT</a>)
  3989      <span class="comment">// ErrThrottlingQuotaExceeded Broker: Throttling quota has been exceeded</span>
  3990      <span id="ErrThrottlingQuotaExceeded">ErrThrottlingQuotaExceeded</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_THROTTLING_QUOTA_EXCEEDED">RD_KAFKA_RESP_ERR_THROTTLING_QUOTA_EXCEEDED</a>)
  3991      <span class="comment">// ErrProducerFenced Broker: There is a newer producer with the same transactionalId which fences the current one</span>
  3992      <span id="ErrProducerFenced">ErrProducerFenced</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_PRODUCER_FENCED">RD_KAFKA_RESP_ERR_PRODUCER_FENCED</a>)
  3993      <span class="comment">// ErrResourceNotFound Broker: Request illegally referred to resource that does not exist</span>
  3994      <span id="ErrResourceNotFound">ErrResourceNotFound</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_RESOURCE_NOT_FOUND">RD_KAFKA_RESP_ERR_RESOURCE_NOT_FOUND</a>)
  3995      <span class="comment">// ErrDuplicateResource Broker: Request illegally referred to the same resource twice</span>
  3996      <span id="ErrDuplicateResource">ErrDuplicateResource</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_DUPLICATE_RESOURCE">RD_KAFKA_RESP_ERR_DUPLICATE_RESOURCE</a>)
  3997      <span class="comment">// ErrUnacceptableCredential Broker: Requested credential would not meet criteria for acceptability</span>
  3998      <span id="ErrUnacceptableCredential">ErrUnacceptableCredential</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_UNACCEPTABLE_CREDENTIAL">RD_KAFKA_RESP_ERR_UNACCEPTABLE_CREDENTIAL</a>)
  3999      <span class="comment">// ErrInconsistentVoterSet Broker: Indicates that the either the sender or recipient of a voter-only request is not one of the expected voters</span>
  4000      <span id="ErrInconsistentVoterSet">ErrInconsistentVoterSet</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INCONSISTENT_VOTER_SET">RD_KAFKA_RESP_ERR_INCONSISTENT_VOTER_SET</a>)
  4001      <span class="comment">// ErrInvalidUpdateVersion Broker: Invalid update version</span>
  4002      <span id="ErrInvalidUpdateVersion">ErrInvalidUpdateVersion</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_INVALID_UPDATE_VERSION">RD_KAFKA_RESP_ERR_INVALID_UPDATE_VERSION</a>)
  4003      <span class="comment">// ErrFeatureUpdateFailed Broker: Unable to update finalized features due to server error</span>
  4004      <span id="ErrFeatureUpdateFailed">ErrFeatureUpdateFailed</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_FEATURE_UPDATE_FAILED">RD_KAFKA_RESP_ERR_FEATURE_UPDATE_FAILED</a>)
  4005      <span class="comment">// ErrPrincipalDeserializationFailure Broker: Request principal deserialization failed during forwarding</span>
  4006      <span id="ErrPrincipalDeserializationFailure">ErrPrincipalDeserializationFailure</span> <a href="#ErrorCode">ErrorCode</a> = <a href="#ErrorCode">ErrorCode</a>(<a href="https://pkg.go.dev/C/">C</a>.<a href="https://pkg.go.dev/C/#RD_KAFKA_RESP_ERR_PRINCIPAL_DESERIALIZATION_FAILURE">RD_KAFKA_RESP_ERR_PRINCIPAL_DESERIALIZATION_FAILURE</a>)
  4007  )</pre>
  4008      <h3 id="ErrorCode.String">
  4009       func (ErrorCode)
  4010       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/generated_errors.go?s=370:404#L4">
  4011        String
  4012       </a>
  4013       <a class="permalink" href="#ErrorCode.String">
  4014        ¶
  4015       </a>
  4016      </h3>
  4017      <pre>func (c <a href="#ErrorCode">ErrorCode</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  4018      <p>
  4019       String returns a human readable representation of an error code
  4020      </p>
  4021      <h2 id="Event">
  4022       type
  4023       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=2222:2327#L74">
  4024        Event
  4025       </a>
  4026       <a class="permalink" href="#Event">
  4027        ¶
  4028       </a>
  4029      </h2>
  4030      <p>
  4031       Event generic interface
  4032      </p>
  4033      <pre>type Event interface {
  4034      <span class="comment">// String returns a human-readable representation of the event</span>
  4035      String() <a href="https://pkg.go.dev/builtin/#string">string</a>
  4036  }</pre>
  4037      <h2 id="Handle">
  4038       type
  4039       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/handle.go?s=1832:3101#L46">
  4040        Handle
  4041       </a>
  4042       <a class="permalink" href="#Handle">
  4043        ¶
  4044       </a>
  4045      </h2>
  4046      <p>
  4047       Handle represents a generic client handle containing common parts for
  4048  both Producer and Consumer.
  4049      </p>
  4050      <pre>type Handle interface {
  4051      <span class="comment">// SetOAuthBearerToken sets the the data to be transmitted</span>
  4052      <span class="comment">// to a broker during SASL/OAUTHBEARER authentication. It will return nil</span>
  4053      <span class="comment">// on success, otherwise an error if:</span>
  4054      <span class="comment">// 1) the token data is invalid (meaning an expiration time in the past</span>
  4055      <span class="comment">// or either a token value or an extension key or value that does not meet</span>
  4056      <span class="comment">// the regular expression requirements as per</span>
  4057      <span class="comment">// https://tools.ietf.org/html/rfc7628#section-3.1);</span>
  4058      <span class="comment">// 2) SASL/OAUTHBEARER is not supported by the underlying librdkafka build;</span>
  4059      <span class="comment">// 3) SASL/OAUTHBEARER is supported but is not configured as the client's</span>
  4060      <span class="comment">// authentication mechanism.</span>
  4061      SetOAuthBearerToken(oauthBearerToken <a href="#OAuthBearerToken">OAuthBearerToken</a>) <a href="https://pkg.go.dev/builtin/#error">error</a>
  4062  
  4063      <span class="comment">// SetOAuthBearerTokenFailure sets the error message describing why token</span>
  4064      <span class="comment">// retrieval/setting failed; it also schedules a new token refresh event for 10</span>
  4065      <span class="comment">// seconds later so the attempt may be retried. It will return nil on</span>
  4066      <span class="comment">// success, otherwise an error if:</span>
  4067      <span class="comment">// 1) SASL/OAUTHBEARER is not supported by the underlying librdkafka build;</span>
  4068      <span class="comment">// 2) SASL/OAUTHBEARER is supported but is not configured as the client's</span>
  4069      <span class="comment">// authentication mechanism.</span>
  4070      SetOAuthBearerTokenFailure(errstr <a href="https://pkg.go.dev/builtin/#string">string</a>) <a href="https://pkg.go.dev/builtin/#error">error</a>
  4071      <span class="comment">// contains filtered or unexported methods</span>
  4072  }</pre>
  4073      <h2 id="Header">
  4074       type
  4075       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/header.go?s=1264:1384#L32">
  4076        Header
  4077       </a>
  4078       <a class="permalink" href="#Header">
  4079        ¶
  4080       </a>
  4081      </h2>
  4082      <p>
  4083       Header represents a single Kafka message header.
  4084      </p>
  4085      <p>
  4086       Message headers are made up of a list of Header elements, retaining their original insert
  4087  order and allowing for duplicate Keys.
  4088      </p>
  4089      <p>
  4090       Key is a human readable string identifying the header.
  4091  Value is the key's binary value, Kafka does not put any restrictions on the format of
  4092  of the Value but it should be made relatively compact.
  4093  The value may be a byte array, empty, or nil.
  4094      </p>
  4095      <p>
  4096       NOTE: Message headers are not available on producer delivery report messages.
  4097      </p>
  4098      <pre>type Header struct {
  4099  <span id="Header.Key"></span>    Key   <a href="https://pkg.go.dev/builtin/#string">string</a> <span class="comment">// Header name (utf-8 string)</span>
  4100  <span id="Header.Value"></span>    Value []<a href="https://pkg.go.dev/builtin/#byte">byte</a> <span class="comment">// Header value (nil, empty, or binary)</span>
  4101  }
  4102  </pre>
  4103      <h3 id="Header.String">
  4104       func (Header)
  4105       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/header.go?s=1517:1548#L39">
  4106        String
  4107       </a>
  4108       <a class="permalink" href="#Header.String">
  4109        ¶
  4110       </a>
  4111      </h3>
  4112      <pre>func (h <a href="#Header">Header</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  4113      <p>
  4114       String returns the Header Key and data in a human representable possibly truncated form
  4115  suitable for displaying to the user.
  4116      </p>
  4117      <h2 id="LogEvent">
  4118       type
  4119       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/log.go?s=153:471#L4">
  4120        LogEvent
  4121       </a>
  4122       <a class="permalink" href="#LogEvent">
  4123        ¶
  4124       </a>
  4125      </h2>
  4126      <p>
  4127       LogEvent represent the log from librdkafka internal log queue
  4128      </p>
  4129      <pre>type LogEvent struct {
  4130  <span id="LogEvent.Name"></span>    Name      <a href="https://pkg.go.dev/builtin/#string">string</a>    <span class="comment">// Name of client instance</span>
  4131  <span id="LogEvent.Tag"></span>    Tag       <a href="https://pkg.go.dev/builtin/#string">string</a>    <span class="comment">// Log tag that provides context to the log Message (e.g., "METADATA" or "GRPCOORD")</span>
  4132  <span id="LogEvent.Message"></span>    Message   <a href="https://pkg.go.dev/builtin/#string">string</a>    <span class="comment">// Log message</span>
  4133  <span id="LogEvent.Level"></span>    Level     <a href="https://pkg.go.dev/builtin/#int">int</a>       <span class="comment">// Log syslog level, lower is more critical.</span>
  4134  <span id="LogEvent.Timestamp"></span>    Timestamp <a href="https://pkg.go.dev/time/">time</a>.<a href="https://pkg.go.dev/time/#Time">Time</a> <span class="comment">// Log timestamp</span>
  4135  }
  4136  </pre>
  4137      <h3 id="LogEvent.String">
  4138       func (LogEvent)
  4139       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/log.go?s=2032:2072#L71">
  4140        String
  4141       </a>
  4142       <a class="permalink" href="#LogEvent.String">
  4143        ¶
  4144       </a>
  4145      </h3>
  4146      <pre>func (logEvent <a href="#LogEvent">LogEvent</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  4147      <h2 id="Message">
  4148       type
  4149       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/message.go?s=2118:2327#L63">
  4150        Message
  4151       </a>
  4152       <a class="permalink" href="#Message">
  4153        ¶
  4154       </a>
  4155      </h2>
  4156      <p>
  4157       Message represents a Kafka message
  4158      </p>
  4159      <pre>type Message struct {
  4160  <span id="Message.TopicPartition"></span>    TopicPartition <a href="#TopicPartition">TopicPartition</a>
  4161  <span id="Message.Value"></span>    Value          []<a href="https://pkg.go.dev/builtin/#byte">byte</a>
  4162  <span id="Message.Key"></span>    Key            []<a href="https://pkg.go.dev/builtin/#byte">byte</a>
  4163  <span id="Message.Timestamp"></span>    Timestamp      <a href="https://pkg.go.dev/time/">time</a>.<a href="https://pkg.go.dev/time/#Time">Time</a>
  4164  <span id="Message.TimestampType"></span>    TimestampType  <a href="#TimestampType">TimestampType</a>
  4165  <span id="Message.Opaque"></span>    Opaque         interface{}
  4166  <span id="Message.Headers"></span>    Headers        []<a href="#Header">Header</a>
  4167  }
  4168  </pre>
  4169      <h3 id="Message.String">
  4170       func (*Message)
  4171       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/message.go?s=2433:2466#L75">
  4172        String
  4173       </a>
  4174       <a class="permalink" href="#Message.String">
  4175        ¶
  4176       </a>
  4177      </h3>
  4178      <pre>func (m *<a href="#Message">Message</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  4179      <p>
  4180       String returns a human readable representation of a Message.
  4181  Key and payload are not represented.
  4182      </p>
  4183      <h2 id="Metadata">
  4184       type
  4185       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/metadata.go?s=1719:1838#L60">
  4186        Metadata
  4187       </a>
  4188       <a class="permalink" href="#Metadata">
  4189        ¶
  4190       </a>
  4191      </h2>
  4192      <p>
  4193       Metadata contains broker and topic metadata for all (matching) topics
  4194      </p>
  4195      <pre>type Metadata struct {
  4196  <span id="Metadata.Brokers"></span>    Brokers []<a href="#BrokerMetadata">BrokerMetadata</a>
  4197  <span id="Metadata.Topics"></span>    Topics  map[<a href="https://pkg.go.dev/builtin/#string">string</a>]<a href="#TopicMetadata">TopicMetadata</a>
  4198  
  4199  <span id="Metadata.OriginatingBroker"></span>    OriginatingBroker <a href="#BrokerMetadata">BrokerMetadata</a>
  4200  }
  4201  </pre>
  4202      <h2 id="MockCluster">
  4203       type
  4204       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/mockcluster.go?s=810:898#L20">
  4205        MockCluster
  4206       </a>
  4207       <a class="permalink" href="#MockCluster">
  4208        ¶
  4209       </a>
  4210      </h2>
  4211      <p>
  4212       MockCluster represents a Kafka mock cluster instance which can be used
  4213  for testing.
  4214      </p>
  4215      <pre>type MockCluster struct {
  4216      <span class="comment">// contains filtered or unexported fields</span>
  4217  }
  4218  </pre>
  4219      <h3 id="NewMockCluster">
  4220       func
  4221       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/mockcluster.go?s=1510:1568#L41">
  4222        NewMockCluster
  4223       </a>
  4224       <a class="permalink" href="#NewMockCluster">
  4225        ¶
  4226       </a>
  4227      </h3>
  4228      <pre>func NewMockCluster(brokerCount <a href="https://pkg.go.dev/builtin/#int">int</a>) (*<a href="#MockCluster">MockCluster</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  4229      <p>
  4230       NewMockCluster provides a mock Kafka cluster with a configurable
  4231  number of brokers that support a reasonable subset of Kafka protocol
  4232  operations, error injection, etc.
  4233      </p>
  4234      <p>
  4235       Mock clusters provide localhost listeners that can be used as the bootstrap
  4236  servers by multiple Kafka client instances.
  4237      </p>
  4238      <p>
  4239       Currently supported functionality:
  4240  - Producer
  4241  - Idempotent Producer
  4242  - Transactional Producer
  4243  - Low-level consumer
  4244  - High-level balanced consumer groups with offset commits
  4245  - Topic Metadata and auto creation
  4246      </p>
  4247      <p>
  4248       Warning THIS IS AN EXPERIMENTAL API, SUBJECT TO CHANGE OR REMOVAL.
  4249      </p>
  4250      <h3 id="MockCluster.BootstrapServers">
  4251       func (*MockCluster)
  4252       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/mockcluster.go?s=2217:2265#L66">
  4253        BootstrapServers
  4254       </a>
  4255       <a class="permalink" href="#MockCluster.BootstrapServers">
  4256        ¶
  4257       </a>
  4258      </h3>
  4259      <pre>func (mc *<a href="#MockCluster">MockCluster</a>) BootstrapServers() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  4260      <p>
  4261       BootstrapServers returns the bootstrap.servers property for this MockCluster
  4262      </p>
  4263      <h3 id="MockCluster.Close">
  4264       func (*MockCluster)
  4265       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/mockcluster.go?s=2376:2406#L71">
  4266        Close
  4267       </a>
  4268       <a class="permalink" href="#MockCluster.Close">
  4269        ¶
  4270       </a>
  4271      </h3>
  4272      <pre>func (mc *<a href="#MockCluster">MockCluster</a>) Close()</pre>
  4273      <p>
  4274       Close and destroy the MockCluster
  4275      </p>
  4276      <h2 id="OAuthBearerToken">
  4277       type
  4278       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/handle.go?s=846:1726#L25">
  4279        OAuthBearerToken
  4280       </a>
  4281       <a class="permalink" href="#OAuthBearerToken">
  4282        ¶
  4283       </a>
  4284      </h2>
  4285      <p>
  4286       OAuthBearerToken represents the data to be transmitted
  4287  to a broker during SASL/OAUTHBEARER authentication.
  4288      </p>
  4289      <pre>type OAuthBearerToken struct {
  4290      <span class="comment">// Token value, often (but not necessarily) a JWS compact serialization</span>
  4291      <span class="comment">// as per https://tools.ietf.org/html/rfc7515#section-3.1; it must meet</span>
  4292      <span class="comment">// the regular expression for a SASL/OAUTHBEARER value defined at</span>
  4293      <span class="comment">// https://tools.ietf.org/html/rfc7628#section-3.1</span>
  4294  <span id="OAuthBearerToken.TokenValue"></span>    TokenValue <a href="https://pkg.go.dev/builtin/#string">string</a>
  4295      <span class="comment">// Metadata about the token indicating when it expires (local time);</span>
  4296      <span class="comment">// it must represent a time in the future</span>
  4297  <span id="OAuthBearerToken.Expiration"></span>    Expiration <a href="https://pkg.go.dev/time/">time</a>.<a href="https://pkg.go.dev/time/#Time">Time</a>
  4298      <span class="comment">// Metadata about the token indicating the Kafka principal name</span>
  4299      <span class="comment">// to which it applies (for example, "admin")</span>
  4300  <span id="OAuthBearerToken.Principal"></span>    Principal <a href="https://pkg.go.dev/builtin/#string">string</a>
  4301      <span class="comment">// SASL extensions, if any, to be communicated to the broker during</span>
  4302      <span class="comment">// authentication (all keys and values of which must meet the regular</span>
  4303      <span class="comment">// expressions defined at https://tools.ietf.org/html/rfc7628#section-3.1,</span>
  4304      <span class="comment">// and it must not contain the reserved "auth" key)</span>
  4305  <span id="OAuthBearerToken.Extensions"></span>    Extensions map[<a href="https://pkg.go.dev/builtin/#string">string</a>]<a href="https://pkg.go.dev/builtin/#string">string</a>
  4306  }
  4307  </pre>
  4308      <h2 id="OAuthBearerTokenRefresh">
  4309       type
  4310       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=3560:3678#L128">
  4311        OAuthBearerTokenRefresh
  4312       </a>
  4313       <a class="permalink" href="#OAuthBearerTokenRefresh">
  4314        ¶
  4315       </a>
  4316      </h2>
  4317      <p>
  4318       OAuthBearerTokenRefresh indicates token refresh is required
  4319      </p>
  4320      <pre>type OAuthBearerTokenRefresh struct {
  4321  <span id="OAuthBearerTokenRefresh.Config"></span>    <span class="comment">// Config is the value of the sasl.oauthbearer.config property</span>
  4322      Config <a href="https://pkg.go.dev/builtin/#string">string</a>
  4323  }
  4324  </pre>
  4325      <h3 id="OAuthBearerTokenRefresh.String">
  4326       func (OAuthBearerTokenRefresh)
  4327       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=3680:3728#L133">
  4328        String
  4329       </a>
  4330       <a class="permalink" href="#OAuthBearerTokenRefresh.String">
  4331        ¶
  4332       </a>
  4333      </h3>
  4334      <pre>func (o <a href="#OAuthBearerTokenRefresh">OAuthBearerTokenRefresh</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  4335      <h2 id="Offset">
  4336       type
  4337       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/offset.go?s=856:873#L25">
  4338        Offset
  4339       </a>
  4340       <a class="permalink" href="#Offset">
  4341        ¶
  4342       </a>
  4343      </h2>
  4344      <p>
  4345       Offset type (int64) with support for canonical names
  4346      </p>
  4347      <pre>type Offset <a href="https://pkg.go.dev/builtin/#int64">int64</a></pre>
  4348      <h3 id="NewOffset">
  4349       func
  4350       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/offset.go?s=1920:1970#L68">
  4351        NewOffset
  4352       </a>
  4353       <a class="permalink" href="#NewOffset">
  4354        ¶
  4355       </a>
  4356      </h3>
  4357      <pre>func NewOffset(offset interface{}) (<a href="#Offset">Offset</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  4358      <p>
  4359       NewOffset creates a new Offset using the provided logical string, or an
  4360  absolute int64 offset value.
  4361  Logical offsets: "beginning", "earliest", "end", "latest", "unset", "invalid", "stored"
  4362      </p>
  4363      <h3 id="OffsetTail">
  4364       func
  4365       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/offset.go?s=2706:2751#L107">
  4366        OffsetTail
  4367       </a>
  4368       <a class="permalink" href="#OffsetTail">
  4369        ¶
  4370       </a>
  4371      </h3>
  4372      <pre>func OffsetTail(relativeOffset <a href="#Offset">Offset</a>) <a href="#Offset">Offset</a></pre>
  4373      <p>
  4374       OffsetTail returns the logical offset relativeOffset from current end of partition
  4375      </p>
  4376      <h3 id="Offset.Set">
  4377       func (*Offset)
  4378       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/offset.go?s=1598:1644#L55">
  4379        Set
  4380       </a>
  4381       <a class="permalink" href="#Offset.Set">
  4382        ¶
  4383       </a>
  4384      </h3>
  4385      <pre>func (o *<a href="#Offset">Offset</a>) Set(offset interface{}) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  4386      <p>
  4387       Set offset value, see NewOffset()
  4388      </p>
  4389      <h3 id="Offset.String">
  4390       func (Offset)
  4391       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/offset.go?s=1310:1341#L39">
  4392        String
  4393       </a>
  4394       <a class="permalink" href="#Offset.String">
  4395        ¶
  4396       </a>
  4397      </h3>
  4398      <pre>func (o <a href="#Offset">Offset</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  4399      <h2 id="OffsetsCommitted">
  4400       type
  4401       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=3306:3379#L118">
  4402        OffsetsCommitted
  4403       </a>
  4404       <a class="permalink" href="#OffsetsCommitted">
  4405        ¶
  4406       </a>
  4407      </h2>
  4408      <p>
  4409       OffsetsCommitted reports committed offsets
  4410      </p>
  4411      <pre>type OffsetsCommitted struct {
  4412  <span id="OffsetsCommitted.Error"></span>    Error   <a href="https://pkg.go.dev/builtin/#error">error</a>
  4413  <span id="OffsetsCommitted.Offsets"></span>    Offsets []<a href="#TopicPartition">TopicPartition</a>
  4414  }
  4415  </pre>
  4416      <h3 id="OffsetsCommitted.String">
  4417       func (OffsetsCommitted)
  4418       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=3381:3422#L123">
  4419        String
  4420       </a>
  4421       <a class="permalink" href="#OffsetsCommitted.String">
  4422        ¶
  4423       </a>
  4424      </h3>
  4425      <pre>func (o <a href="#OffsetsCommitted">OffsetsCommitted</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  4426      <h2 id="PartitionEOF">
  4427       type
  4428       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=3131:3163#L111">
  4429        PartitionEOF
  4430       </a>
  4431       <a class="permalink" href="#PartitionEOF">
  4432        ¶
  4433       </a>
  4434      </h2>
  4435      <p>
  4436       PartitionEOF consumer reached end of partition
  4437  Needs to be explicitly enabled by setting the `enable.partition.eof`
  4438  configuration property to true.
  4439      </p>
  4440      <pre>type PartitionEOF <a href="#TopicPartition">TopicPartition</a></pre>
  4441      <h3 id="PartitionEOF.String">
  4442       func (PartitionEOF)
  4443       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=3165:3202#L113">
  4444        String
  4445       </a>
  4446       <a class="permalink" href="#PartitionEOF.String">
  4447        ¶
  4448       </a>
  4449      </h3>
  4450      <pre>func (p <a href="#PartitionEOF">PartitionEOF</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  4451      <h2 id="PartitionMetadata">
  4452       type
  4453       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/metadata.go?s=1382:1499#L44">
  4454        PartitionMetadata
  4455       </a>
  4456       <a class="permalink" href="#PartitionMetadata">
  4457        ¶
  4458       </a>
  4459      </h2>
  4460      <p>
  4461       PartitionMetadata contains per-partition metadata
  4462      </p>
  4463      <pre>type PartitionMetadata struct {
  4464  <span id="PartitionMetadata.ID"></span>    ID       <a href="https://pkg.go.dev/builtin/#int32">int32</a>
  4465  <span id="PartitionMetadata.Error"></span>    Error    <a href="#Error">Error</a>
  4466  <span id="PartitionMetadata.Leader"></span>    Leader   <a href="https://pkg.go.dev/builtin/#int32">int32</a>
  4467  <span id="PartitionMetadata.Replicas"></span>    Replicas []<a href="https://pkg.go.dev/builtin/#int32">int32</a>
  4468  <span id="PartitionMetadata.Isrs"></span>    Isrs     []<a href="https://pkg.go.dev/builtin/#int32">int32</a>
  4469  }
  4470  </pre>
  4471      <h2 id="PartitionsSpecification">
  4472       type
  4473       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=3606:4120#L115">
  4474        PartitionsSpecification
  4475       </a>
  4476       <a class="permalink" href="#PartitionsSpecification">
  4477        ¶
  4478       </a>
  4479      </h2>
  4480      <p>
  4481       PartitionsSpecification holds parameters for creating additional partitions for a topic.
  4482  PartitionsSpecification is analogous to NewPartitions in the Java Topic Admin API.
  4483      </p>
  4484      <pre>type PartitionsSpecification struct {
  4485  <span id="PartitionsSpecification.Topic"></span>    <span class="comment">// Topic to create more partitions for.</span>
  4486      Topic <a href="https://pkg.go.dev/builtin/#string">string</a>
  4487      <span class="comment">// New partition count for topic, must be higher than current partition count.</span>
  4488  <span id="PartitionsSpecification.IncreaseTo"></span>    IncreaseTo <a href="https://pkg.go.dev/builtin/#int">int</a>
  4489      <span class="comment">// (Optional) Explicit replica assignment. The outer array is</span>
  4490      <span class="comment">// indexed by the new partition index (i.e., 0 for the first added</span>
  4491      <span class="comment">// partition), while the inner per-partition array</span>
  4492      <span class="comment">// contains the replica broker ids. The first broker in each</span>
  4493      <span class="comment">// broker id list will be the preferred replica.</span>
  4494  <span id="PartitionsSpecification.ReplicaAssignment"></span>    ReplicaAssignment [][]<a href="https://pkg.go.dev/builtin/#int32">int32</a>
  4495  }
  4496  </pre>
  4497      <h2 id="Producer">
  4498       type
  4499       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=3609:3778#L122">
  4500        Producer
  4501       </a>
  4502       <a class="permalink" href="#Producer">
  4503        ¶
  4504       </a>
  4505      </h2>
  4506      <p>
  4507       Producer implements a High-level Apache Kafka Producer instance
  4508      </p>
  4509      <pre>type Producer struct {
  4510      <span class="comment">// contains filtered or unexported fields</span>
  4511  }
  4512  </pre>
  4513      <h3 id="NewProducer">
  4514       func
  4515       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=14023:14075#L424">
  4516        NewProducer
  4517       </a>
  4518       <a class="permalink" href="#NewProducer">
  4519        ¶
  4520       </a>
  4521      </h3>
  4522      <pre>func NewProducer(conf *<a href="#ConfigMap">ConfigMap</a>) (*<a href="#Producer">Producer</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  4523      <p>
  4524       NewProducer creates a new high-level Producer instance.
  4525      </p>
  4526      <p>
  4527       conf is a *ConfigMap with standard librdkafka configuration properties.
  4528      </p>
  4529      <p>
  4530       Supported special configuration properties (type, default):
  4531      </p>
  4532      <pre>go.batch.producer (bool, false) - EXPERIMENTAL: Enable batch producer (for increased performance).
  4533                                    These batches do not relate to Kafka message batches in any way.
  4534                                    Note: timestamps and headers are not supported with this interface.
  4535  go.delivery.reports (bool, true) - Forward per-message delivery reports to the
  4536                                     Events() channel.
  4537  go.delivery.report.fields (string, "key,value") - Comma separated list of fields to enable for delivery reports.
  4538                                      Allowed values: all, none (or empty string), key, value, headers
  4539                                      Warning: There is a performance penalty to include headers in the delivery report.
  4540  go.events.channel.size (int, 1000000) - Events().
  4541  go.produce.channel.size (int, 1000000) - ProduceChannel() buffer size (in number of messages)
  4542  go.logs.channel.enable (bool, false) - Forward log to Logs() channel.
  4543  go.logs.channel (chan kafka.LogEvent, nil) - Forward logs to application-provided channel instead of Logs(). Requires go.logs.channel.enable=true.
  4544  </pre>
  4545      <h3 id="Producer.AbortTransaction">
  4546       func (*Producer)
  4547       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=30707:30769#L900">
  4548        AbortTransaction
  4549       </a>
  4550       <a class="permalink" href="#Producer.AbortTransaction">
  4551        ¶
  4552       </a>
  4553      </h3>
  4554      <pre>func (p *<a href="#Producer">Producer</a>) AbortTransaction(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  4555      <p>
  4556       AbortTransaction aborts the ongoing transaction.
  4557      </p>
  4558      <p>
  4559       This function should also be used to recover from non-fatal abortable
  4560  transaction errors.
  4561      </p>
  4562      <p>
  4563       Any outstanding messages will be purged and fail with
  4564  `ErrPurgeInflight` or `ErrPurgeQueue`.
  4565      </p>
  4566      <p>
  4567       Parameters:
  4568      </p>
  4569      <pre>* `ctx` - The maximum amount of time to block, or nil for indefinite.
  4570  </pre>
  4571      <p>
  4572       Note: This function will block until all outstanding messages are purged
  4573  and the transaction abort request has been successfully
  4574  handled by the transaction coordinator, or until the `ctx` expires,
  4575  which ever comes first. On timeout the application may
  4576  call the function again.
  4577      </p>
  4578      <p>
  4579       Note: Will automatically call `Purge()` and `Flush()` to ensure all queued
  4580  and in-flight messages are purged before attempting to abort the transaction.
  4581  The application MUST serve the `producer.Events()` channel for delivery
  4582  reports in a separate go-routine during this time.
  4583      </p>
  4584      <p>
  4585       Returns nil on success or an error object on failure.
  4586  Check whether the returned error object permits retrying
  4587  by calling `err.(kafka.Error).IsRetriable()`, or whether a fatal error
  4588  has been raised by calling `err.(kafka.Error).IsFatal()`.
  4589      </p>
  4590      <h3 id="Producer.BeginTransaction">
  4591       func (*Producer)
  4592       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=25048:25091#L763">
  4593        BeginTransaction
  4594       </a>
  4595       <a class="permalink" href="#Producer.BeginTransaction">
  4596        ¶
  4597       </a>
  4598      </h3>
  4599      <pre>func (p *<a href="#Producer">Producer</a>) BeginTransaction() <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  4600      <p>
  4601       BeginTransaction starts a new transaction.
  4602      </p>
  4603      <p>
  4604       `InitTransactions()` must have been called successfully (once)
  4605  before this function is called.
  4606      </p>
  4607      <p>
  4608       Any messages produced, offsets sent (`SendOffsetsToTransaction()`),
  4609  etc, after the successful return of this function will be part of
  4610  the transaction and committed or aborted atomatically.
  4611      </p>
  4612      <p>
  4613       Finish the transaction by calling `CommitTransaction()` or
  4614  abort the transaction by calling `AbortTransaction()`.
  4615      </p>
  4616      <p>
  4617       Returns nil on success or an error object on failure.
  4618  Check whether a fatal error has been raised by
  4619  calling `err.(kafka.Error).IsFatal()`.
  4620      </p>
  4621      <p>
  4622       Note: With the transactional producer, `Produce()`, et.al, are only
  4623  allowed during an on-going transaction, as started with this function.
  4624  Any produce call outside an on-going transaction, or for a failed
  4625  transaction, will fail.
  4626      </p>
  4627      <h3 id="Producer.Close">
  4628       func (*Producer)
  4629       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=10439:10465#L345">
  4630        Close
  4631       </a>
  4632       <a class="permalink" href="#Producer.Close">
  4633        ¶
  4634       </a>
  4635      </h3>
  4636      <pre>func (p *<a href="#Producer">Producer</a>) Close()</pre>
  4637      <p>
  4638       Close a Producer instance.
  4639  The Producer object or its channels are no longer usable after this call.
  4640      </p>
  4641      <h3 id="Producer.CommitTransaction">
  4642       func (*Producer)
  4643       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=29291:29354#L864">
  4644        CommitTransaction
  4645       </a>
  4646       <a class="permalink" href="#Producer.CommitTransaction">
  4647        ¶
  4648       </a>
  4649      </h3>
  4650      <pre>func (p *<a href="#Producer">Producer</a>) CommitTransaction(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  4651      <p>
  4652       CommitTransaction commits the current transaction.
  4653      </p>
  4654      <p>
  4655       Any outstanding messages will be flushed (delivered) before actually
  4656  committing the transaction.
  4657      </p>
  4658      <p>
  4659       If any of the outstanding messages fail permanently the current
  4660  transaction will enter the abortable error state and this
  4661  function will return an abortable error, in this case the application
  4662  must call `AbortTransaction()` before attempting a new
  4663  transaction with `BeginTransaction()`.
  4664      </p>
  4665      <p>
  4666       Parameters:
  4667      </p>
  4668      <pre>* `ctx` - The maximum amount of time to block, or nil for indefinite.
  4669  </pre>
  4670      <p>
  4671       Note: This function will block until all outstanding messages are
  4672  delivered and the transaction commit request has been successfully
  4673  handled by the transaction coordinator, or until the `ctx` expires,
  4674  which ever comes first. On timeout the application may
  4675  call the function again.
  4676      </p>
  4677      <p>
  4678       Note: Will automatically call `Flush()` to ensure all queued
  4679  messages are delivered before attempting to commit the transaction.
  4680  The application MUST serve the `producer.Events()` channel for delivery
  4681  reports in a separate go-routine during this time.
  4682      </p>
  4683      <p>
  4684       Returns nil on success or an error object on failure.
  4685  Check whether the returned error object permits retrying
  4686  by calling `err.(kafka.Error).IsRetriable()`, or whether an abortable
  4687  or fatal error has been raised by calling
  4688  `err.(kafka.Error).TxnRequiresAbort()` or `err.(kafka.Error).IsFatal()`
  4689  respectively.
  4690      </p>
  4691      <h3 id="Producer.Events">
  4692       func (*Producer)
  4693       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=9069:9107#L300">
  4694        Events
  4695       </a>
  4696       <a class="permalink" href="#Producer.Events">
  4697        ¶
  4698       </a>
  4699      </h3>
  4700      <pre>func (p *<a href="#Producer">Producer</a>) Events() chan <a href="#Event">Event</a></pre>
  4701      <p>
  4702       Events returns the Events channel (read)
  4703      </p>
  4704      <h3 id="Producer.Flush">
  4705       func (*Producer)
  4706       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=9935:9978#L325">
  4707        Flush
  4708       </a>
  4709       <a class="permalink" href="#Producer.Flush">
  4710        ¶
  4711       </a>
  4712      </h3>
  4713      <pre>func (p *<a href="#Producer">Producer</a>) Flush(timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  4714      <p>
  4715       Flush and wait for outstanding messages and requests to complete delivery.
  4716  Includes messages on ProduceChannel.
  4717  Runs until value reaches zero or on timeoutMs.
  4718  Returns the number of outstanding events still un-flushed.
  4719      </p>
  4720      <h3 id="Producer.GetFatalError">
  4721       func (*Producer)
  4722       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=20655:20695#L661">
  4723        GetFatalError
  4724       </a>
  4725       <a class="permalink" href="#Producer.GetFatalError">
  4726        ¶
  4727       </a>
  4728      </h3>
  4729      <pre>func (p *<a href="#Producer">Producer</a>) GetFatalError() <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  4730      <p>
  4731       GetFatalError returns an Error object if the client instance has raised a fatal error, else nil.
  4732      </p>
  4733      <h3 id="Producer.GetMetadata">
  4734       func (*Producer)
  4735       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=19238:19333#L631">
  4736        GetMetadata
  4737       </a>
  4738       <a class="permalink" href="#Producer.GetMetadata">
  4739        ¶
  4740       </a>
  4741      </h3>
  4742      <pre>func (p *<a href="#Producer">Producer</a>) GetMetadata(topic *<a href="https://pkg.go.dev/builtin/#string">string</a>, allTopics <a href="https://pkg.go.dev/builtin/#bool">bool</a>, timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) (*<a href="#Metadata">Metadata</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  4743      <p>
  4744       GetMetadata queries broker for cluster and topic metadata.
  4745  If topic is non-nil only information about that topic is returned, else if
  4746  allTopics is false only information about locally used topics is returned,
  4747  else information about all topics is returned.
  4748  GetMetadata is equivalent to listTopics, describeTopics and describeCluster in the Java API.
  4749      </p>
  4750      <h3 id="Producer.InitTransactions">
  4751       func (*Producer)
  4752       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=23950:24012#L733">
  4753        InitTransactions
  4754       </a>
  4755       <a class="permalink" href="#Producer.InitTransactions">
  4756        ¶
  4757       </a>
  4758      </h3>
  4759      <pre>func (p *<a href="#Producer">Producer</a>) InitTransactions(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  4760      <p>
  4761       InitTransactions Initializes transactions for the producer instance.
  4762      </p>
  4763      <p>
  4764       This function ensures any transactions initiated by previous instances
  4765  of the producer with the same `transactional.id` are completed.
  4766  If the previous instance failed with a transaction in progress the
  4767  previous transaction will be aborted.
  4768  This function needs to be called before any other transactional or
  4769  produce functions are called when the `transactional.id` is configured.
  4770      </p>
  4771      <p>
  4772       If the last transaction had begun completion (following transaction commit)
  4773  but not yet finished, this function will await the previous transaction's
  4774  completion.
  4775      </p>
  4776      <p>
  4777       When any previous transactions have been fenced this function
  4778  will acquire the internal producer id and epoch, used in all future
  4779  transactional messages issued by this producer instance.
  4780      </p>
  4781      <p>
  4782       Upon successful return from this function the application has to perform at
  4783  least one of the following operations within `transaction.timeout.ms` to
  4784  avoid timing out the transaction on the broker:
  4785      </p>
  4786      <pre>* `Produce()` (et.al)
  4787  * `SendOffsetsToTransaction()`
  4788  * `CommitTransaction()`
  4789  * `AbortTransaction()`
  4790  </pre>
  4791      <p>
  4792       Parameters:
  4793      </p>
  4794      <pre>* `ctx` - The maximum time to block, or nil for indefinite.
  4795            On timeout the operation may continue in the background,
  4796            depending on state, and it is okay to call `InitTransactions()`
  4797            again.
  4798  </pre>
  4799      <p>
  4800       Returns nil on success or an error on failure.
  4801  Check whether the returned error object permits retrying
  4802  by calling `err.(kafka.Error).IsRetriable()`, or whether a fatal
  4803  error has been raised by calling `err.(kafka.Error).IsFatal()`.
  4804      </p>
  4805      <h3 id="Producer.Len">
  4806       func (*Producer)
  4807       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=9585:9613#L317">
  4808        Len
  4809       </a>
  4810       <a class="permalink" href="#Producer.Len">
  4811        ¶
  4812       </a>
  4813      </h3>
  4814      <pre>func (p *<a href="#Producer">Producer</a>) Len() <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  4815      <p>
  4816       Len returns the number of messages and requests waiting to be transmitted to the broker
  4817  as well as delivery reports queued for the application.
  4818  Includes messages on ProduceChannel.
  4819      </p>
  4820      <h3 id="Producer.Logs">
  4821       func (*Producer)
  4822       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=9185:9224#L305">
  4823        Logs
  4824       </a>
  4825       <a class="permalink" href="#Producer.Logs">
  4826        ¶
  4827       </a>
  4828      </h3>
  4829      <pre>func (p *<a href="#Producer">Producer</a>) Logs() chan <a href="#LogEvent">LogEvent</a></pre>
  4830      <p>
  4831       Logs returns the Log channel (if enabled), else nil
  4832      </p>
  4833      <h3 id="Producer.OffsetsForTimes">
  4834       func (*Producer)
  4835       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=20393:20504#L656">
  4836        OffsetsForTimes
  4837       </a>
  4838       <a class="permalink" href="#Producer.OffsetsForTimes">
  4839        ¶
  4840       </a>
  4841      </h3>
  4842      <pre>func (p *<a href="#Producer">Producer</a>) OffsetsForTimes(times []<a href="#TopicPartition">TopicPartition</a>, timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) (offsets []<a href="#TopicPartition">TopicPartition</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  4843      <p>
  4844       OffsetsForTimes looks up offsets by timestamp for the given partitions.
  4845      </p>
  4846      <p>
  4847       The returned offset for each partition is the earliest offset whose
  4848  timestamp is greater than or equal to the given timestamp in the
  4849  corresponding partition. If the provided timestamp exceeds that of the
  4850  last message in the partition, a value of -1 will be returned.
  4851      </p>
  4852      <p>
  4853       The timestamps to query are represented as `.Offset` in the `times`
  4854  argument and the looked up offsets are represented as `.Offset` in the returned
  4855  `offsets` list.
  4856      </p>
  4857      <p>
  4858       The function will block for at most timeoutMs milliseconds.
  4859      </p>
  4860      <p>
  4861       Duplicate Topic+Partitions are not supported.
  4862  Per-partition errors may be returned in the `.Error` field.
  4863      </p>
  4864      <h3 id="Producer.Produce">
  4865       func (*Producer)
  4866       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=8165:8236#L274">
  4867        Produce
  4868       </a>
  4869       <a class="permalink" href="#Producer.Produce">
  4870        ¶
  4871       </a>
  4872      </h3>
  4873      <pre>func (p *<a href="#Producer">Producer</a>) Produce(msg *<a href="#Message">Message</a>, deliveryChan chan <a href="#Event">Event</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  4874      <p>
  4875       Produce single message.
  4876  This is an asynchronous call that enqueues the message on the internal
  4877  transmit queue, thus returning immediately.
  4878  The delivery report will be sent on the provided deliveryChan if specified,
  4879  or on the Producer object's Events() channel if not.
  4880  msg.Timestamp requires librdkafka &gt;= 0.9.4 (else returns ErrNotImplemented),
  4881  api.version.request=true, and broker &gt;= 0.10.0.0.
  4882  msg.Headers requires librdkafka &gt;= 0.11.4 (else returns ErrNotImplemented),
  4883  api.version.request=true, and broker &gt;= 0.11.0.0.
  4884  Returns an error if message could not be enqueued.
  4885      </p>
  4886      <h3 id="Producer.ProduceChannel">
  4887       func (*Producer)
  4888       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=9315:9364#L310">
  4889        ProduceChannel
  4890       </a>
  4891       <a class="permalink" href="#Producer.ProduceChannel">
  4892        ¶
  4893       </a>
  4894      </h3>
  4895      <pre>func (p *<a href="#Producer">Producer</a>) ProduceChannel() chan *<a href="#Message">Message</a></pre>
  4896      <p>
  4897       ProduceChannel returns the produce *Message channel (write)
  4898      </p>
  4899      <h3 id="Producer.Purge">
  4900       func (*Producer)
  4901       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=12448:12489#L397">
  4902        Purge
  4903       </a>
  4904       <a class="permalink" href="#Producer.Purge">
  4905        ¶
  4906       </a>
  4907      </h3>
  4908      <pre>func (p *<a href="#Producer">Producer</a>) Purge(flags <a href="https://pkg.go.dev/builtin/#int">int</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  4909      <p>
  4910       Purge messages currently handled by this producer instance.
  4911      </p>
  4912      <p>
  4913       flags is a combination of PurgeQueue, PurgeInFlight and PurgeNonBlocking.
  4914      </p>
  4915      <p>
  4916       The application will need to call Poll(), Flush() or read the Events() channel
  4917  after this call to serve delivery reports for the purged messages.
  4918      </p>
  4919      <p>
  4920       Messages purged from internal queues fail with the delivery report
  4921  error code set to ErrPurgeQueue, while purged messages that
  4922  are in-flight to or from the broker will fail with the error code set to
  4923  ErrPurgeInflight.
  4924      </p>
  4925      <p>
  4926       Warning: Purging messages that are in-flight to or from the broker
  4927  will ignore any sub-sequent acknowledgement for these messages
  4928  received from the broker, effectively making it impossible
  4929  for the application to know if the messages were successfully
  4930  produced or not. This may result in duplicate messages if the
  4931  application retries these messages at a later time.
  4932      </p>
  4933      <p>
  4934       Note: This call may block for a short time while background thread
  4935  queues are purged.
  4936      </p>
  4937      <p>
  4938       Returns nil on success, ErrInvalidArg if the purge flags are invalid or unknown.
  4939      </p>
  4940      <h3 id="Producer.QueryWatermarkOffsets">
  4941       func (*Producer)
  4942       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=19496:19611#L637">
  4943        QueryWatermarkOffsets
  4944       </a>
  4945       <a class="permalink" href="#Producer.QueryWatermarkOffsets">
  4946        ¶
  4947       </a>
  4948      </h3>
  4949      <pre>func (p *<a href="#Producer">Producer</a>) QueryWatermarkOffsets(topic <a href="https://pkg.go.dev/builtin/#string">string</a>, partition <a href="https://pkg.go.dev/builtin/#int32">int32</a>, timeoutMs <a href="https://pkg.go.dev/builtin/#int">int</a>) (low, high <a href="https://pkg.go.dev/builtin/#int64">int64</a>, err <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  4950      <p>
  4951       QueryWatermarkOffsets returns the broker's low and high offsets for the given topic
  4952  and partition.
  4953      </p>
  4954      <h3 id="Producer.SendOffsetsToTransaction">
  4955       func (*Producer)
  4956       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=27154:27291#L808">
  4957        SendOffsetsToTransaction
  4958       </a>
  4959       <a class="permalink" href="#Producer.SendOffsetsToTransaction">
  4960        ¶
  4961       </a>
  4962      </h3>
  4963      <pre>func (p *<a href="#Producer">Producer</a>) SendOffsetsToTransaction(ctx <a href="https://pkg.go.dev/context/">context</a>.<a href="https://pkg.go.dev/context/#Context">Context</a>, offsets []<a href="#TopicPartition">TopicPartition</a>, consumerMetadata *<a href="#ConsumerGroupMetadata">ConsumerGroupMetadata</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  4964      <p>
  4965       SendOffsetsToTransaction sends a list of topic partition offsets to the
  4966  consumer group coordinator for `consumerMetadata`, and marks the offsets
  4967  as part part of the current transaction.
  4968  These offsets will be considered committed only if the transaction is
  4969  committed successfully.
  4970      </p>
  4971      <p>
  4972       The offsets should be the next message your application will consume,
  4973  i.e., the last processed message's offset + 1 for each partition.
  4974  Either track the offsets manually during processing or use
  4975  `consumer.Position()` (on the consumer) to get the current offsets for
  4976  the partitions assigned to the consumer.
  4977      </p>
  4978      <p>
  4979       Use this method at the end of a consume-transform-produce loop prior
  4980  to committing the transaction with `CommitTransaction()`.
  4981      </p>
  4982      <p>
  4983       Parameters:
  4984      </p>
  4985      <pre>* `ctx` - The maximum amount of time to block, or nil for indefinite.
  4986  * `offsets` - List of offsets to commit to the consumer group upon
  4987                successful commit of the transaction. Offsets should be
  4988                the next message to consume, e.g., last processed message + 1.
  4989  * `consumerMetadata` - The current consumer group metadata as returned by
  4990                `consumer.GetConsumerGroupMetadata()` on the consumer
  4991                instance the provided offsets were consumed from.
  4992  </pre>
  4993      <p>
  4994       Note: The consumer must disable auto commits (set `enable.auto.commit` to false on the consumer).
  4995      </p>
  4996      <p>
  4997       Note: Logical and invalid offsets (e.g., OffsetInvalid) in
  4998  `offsets` will be ignored. If there are no valid offsets in
  4999  `offsets` the function will return nil and no action will be taken.
  5000      </p>
  5001      <p>
  5002       Returns nil on success or an error object on failure.
  5003  Check whether the returned error object permits retrying
  5004  by calling `err.(kafka.Error).IsRetriable()`, or whether an abortable
  5005  or fatal error has been raised by calling
  5006  `err.(kafka.Error).TxnRequiresAbort()` or `err.(kafka.Error).IsFatal()`
  5007  respectively.
  5008      </p>
  5009      <h3 id="Producer.SetOAuthBearerToken">
  5010       func (*Producer)
  5011       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=21556:21635#L681">
  5012        SetOAuthBearerToken
  5013       </a>
  5014       <a class="permalink" href="#Producer.SetOAuthBearerToken">
  5015        ¶
  5016       </a>
  5017      </h3>
  5018      <pre>func (p *<a href="#Producer">Producer</a>) SetOAuthBearerToken(oauthBearerToken <a href="#OAuthBearerToken">OAuthBearerToken</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  5019      <p>
  5020       SetOAuthBearerToken sets the the data to be transmitted
  5021  to a broker during SASL/OAUTHBEARER authentication. It will return nil
  5022  on success, otherwise an error if:
  5023  1) the token data is invalid (meaning an expiration time in the past
  5024  or either a token value or an extension key or value that does not meet
  5025  the regular expression requirements as per
  5026       <a href="https://tools.ietf.org/html/rfc7628#section-3.1">
  5027        https://tools.ietf.org/html/rfc7628#section-3.1
  5028       </a>
  5029       );
  5030  2) SASL/OAUTHBEARER is not supported by the underlying librdkafka build;
  5031  3) SASL/OAUTHBEARER is supported but is not configured as the client's
  5032  authentication mechanism.
  5033      </p>
  5034      <h3 id="Producer.SetOAuthBearerTokenFailure">
  5035       func (*Producer)
  5036       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=22134:22200#L692">
  5037        SetOAuthBearerTokenFailure
  5038       </a>
  5039       <a class="permalink" href="#Producer.SetOAuthBearerTokenFailure">
  5040        ¶
  5041       </a>
  5042      </h3>
  5043      <pre>func (p *<a href="#Producer">Producer</a>) SetOAuthBearerTokenFailure(errstr <a href="https://pkg.go.dev/builtin/#string">string</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  5044      <p>
  5045       SetOAuthBearerTokenFailure sets the error message describing why token
  5046  retrieval/setting failed; it also schedules a new token refresh event for 10
  5047  seconds later so the attempt may be retried. It will return nil on
  5048  success, otherwise an error if:
  5049  1) SASL/OAUTHBEARER is not supported by the underlying librdkafka build;
  5050  2) SASL/OAUTHBEARER is supported but is not configured as the client's
  5051  authentication mechanism.
  5052      </p>
  5053      <h3 id="Producer.String">
  5054       func (*Producer)
  5055       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=3844:3878#L132">
  5056        String
  5057       </a>
  5058       <a class="permalink" href="#Producer.String">
  5059        ¶
  5060       </a>
  5061      </h3>
  5062      <pre>func (p *<a href="#Producer">Producer</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  5063      <p>
  5064       String returns a human readable name for a Producer instance
  5065      </p>
  5066      <h3 id="Producer.TestFatalError">
  5067       func (*Producer)
  5068       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/producer.go?s=20846:20917#L667">
  5069        TestFatalError
  5070       </a>
  5071       <a class="permalink" href="#Producer.TestFatalError">
  5072        ¶
  5073       </a>
  5074      </h3>
  5075      <pre>func (p *<a href="#Producer">Producer</a>) TestFatalError(code <a href="#ErrorCode">ErrorCode</a>, str <a href="https://pkg.go.dev/builtin/#string">string</a>) <a href="#ErrorCode">ErrorCode</a></pre>
  5076      <p>
  5077       TestFatalError triggers a fatal error in the underlying client.
  5078  This is to be used strictly for testing purposes.
  5079      </p>
  5080      <h2 id="RebalanceCb">
  5081       type
  5082       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/consumer.go?s=1070:1115#L29">
  5083        RebalanceCb
  5084       </a>
  5085       <a class="permalink" href="#RebalanceCb">
  5086        ¶
  5087       </a>
  5088      </h2>
  5089      <p>
  5090       RebalanceCb provides a per-Subscribe*() rebalance event callback.
  5091  The passed Event will be either AssignedPartitions or RevokedPartitions
  5092      </p>
  5093      <pre>type RebalanceCb func(*<a href="#Consumer">Consumer</a>, <a href="#Event">Event</a>) <a href="https://pkg.go.dev/builtin/#error">error</a></pre>
  5094      <h2 id="ResourcePatternType">
  5095       type
  5096       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=11534:11562#L327">
  5097        ResourcePatternType
  5098       </a>
  5099       <a class="permalink" href="#ResourcePatternType">
  5100        ¶
  5101       </a>
  5102      </h2>
  5103      <p>
  5104       ResourcePatternType enumerates the different types of Kafka resource patterns.
  5105      </p>
  5106      <pre>type ResourcePatternType <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  5107      <h3 id="ResourcePatternTypeFromString">
  5108       func
  5109       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=12662:12751#L349">
  5110        ResourcePatternTypeFromString
  5111       </a>
  5112       <a class="permalink" href="#ResourcePatternTypeFromString">
  5113        ¶
  5114       </a>
  5115      </h3>
  5116      <pre>func ResourcePatternTypeFromString(patternTypeString <a href="https://pkg.go.dev/builtin/#string">string</a>) (<a href="#ResourcePatternType">ResourcePatternType</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  5117      <p>
  5118       ResourcePatternTypeFromString translates a resource pattern type name to
  5119  a ResourcePatternType value.
  5120      </p>
  5121      <h3 id="ResourcePatternType.String">
  5122       func (ResourcePatternType)
  5123       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=12411:12455#L343">
  5124        String
  5125       </a>
  5126       <a class="permalink" href="#ResourcePatternType.String">
  5127        ¶
  5128       </a>
  5129      </h3>
  5130      <pre>func (t <a href="#ResourcePatternType">ResourcePatternType</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  5131      <p>
  5132       String returns the human-readable representation of a ResourcePatternType
  5133      </p>
  5134      <h2 id="ResourceType">
  5135       type
  5136       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=4179:4200#L129">
  5137        ResourceType
  5138       </a>
  5139       <a class="permalink" href="#ResourceType">
  5140        ¶
  5141       </a>
  5142      </h2>
  5143      <p>
  5144       ResourceType represents an Apache Kafka resource type
  5145      </p>
  5146      <pre>type ResourceType <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  5147      <h3 id="ResourceTypeFromString">
  5148       func
  5149       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=4955:5023#L151">
  5150        ResourceTypeFromString
  5151       </a>
  5152       <a class="permalink" href="#ResourceTypeFromString">
  5153        ¶
  5154       </a>
  5155      </h3>
  5156      <pre>func ResourceTypeFromString(typeString <a href="https://pkg.go.dev/builtin/#string">string</a>) (<a href="#ResourceType">ResourceType</a>, <a href="https://pkg.go.dev/builtin/#error">error</a>)</pre>
  5157      <p>
  5158       ResourceTypeFromString translates a resource type name/string to
  5159  a ResourceType value.
  5160      </p>
  5161      <h3 id="ResourceType.String">
  5162       func (ResourceType)
  5163       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=4740:4777#L145">
  5164        String
  5165       </a>
  5166       <a class="permalink" href="#ResourceType.String">
  5167        ¶
  5168       </a>
  5169      </h3>
  5170      <pre>func (t <a href="#ResourceType">ResourceType</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  5171      <p>
  5172       String returns the human-readable representation of a ResourceType
  5173      </p>
  5174      <h2 id="RevokedPartitions">
  5175       type
  5176       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=2803:2865#L100">
  5177        RevokedPartitions
  5178       </a>
  5179       <a class="permalink" href="#RevokedPartitions">
  5180        ¶
  5181       </a>
  5182      </h2>
  5183      <p>
  5184       RevokedPartitions consumer group rebalance event: revoked partition set
  5185      </p>
  5186      <pre>type RevokedPartitions struct {
  5187  <span id="RevokedPartitions.Partitions"></span>    Partitions []<a href="#TopicPartition">TopicPartition</a>
  5188  }
  5189  </pre>
  5190      <h3 id="RevokedPartitions.String">
  5191       func (RevokedPartitions)
  5192       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=2867:2909#L104">
  5193        String
  5194       </a>
  5195       <a class="permalink" href="#RevokedPartitions.String">
  5196        ¶
  5197       </a>
  5198      </h3>
  5199      <pre>func (e <a href="#RevokedPartitions">RevokedPartitions</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  5200      <h2 id="Stats">
  5201       type
  5202       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=2380:2419#L82">
  5203        Stats
  5204       </a>
  5205       <a class="permalink" href="#Stats">
  5206        ¶
  5207       </a>
  5208      </h2>
  5209      <p>
  5210       Stats statistics event
  5211      </p>
  5212      <pre>type Stats struct {
  5213      <span class="comment">// contains filtered or unexported fields</span>
  5214  }
  5215  </pre>
  5216      <h3 id="Stats.String">
  5217       func (Stats)
  5218       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/event.go?s=2421:2451#L86">
  5219        String
  5220       </a>
  5221       <a class="permalink" href="#Stats.String">
  5222        ¶
  5223       </a>
  5224      </h3>
  5225      <pre>func (e <a href="#Stats">Stats</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  5226      <h2 id="TimestampType">
  5227       type
  5228       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/message.go?s=1324:1346#L38">
  5229        TimestampType
  5230       </a>
  5231       <a class="permalink" href="#TimestampType">
  5232        ¶
  5233       </a>
  5234      </h2>
  5235      <p>
  5236       TimestampType is a the Message timestamp type or source
  5237      </p>
  5238      <pre>type TimestampType <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  5239      <h3 id="TimestampType.String">
  5240       func (TimestampType)
  5241       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/message.go?s=1840:1878#L49">
  5242        String
  5243       </a>
  5244       <a class="permalink" href="#TimestampType.String">
  5245        ¶
  5246       </a>
  5247      </h3>
  5248      <pre>func (t <a href="#TimestampType">TimestampType</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  5249      <h2 id="TopicMetadata">
  5250       type
  5251       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/metadata.go?s=1546:1644#L53">
  5252        TopicMetadata
  5253       </a>
  5254       <a class="permalink" href="#TopicMetadata">
  5255        ¶
  5256       </a>
  5257      </h2>
  5258      <p>
  5259       TopicMetadata contains per-topic metadata
  5260      </p>
  5261      <pre>type TopicMetadata struct {
  5262  <span id="TopicMetadata.Topic"></span>    Topic      <a href="https://pkg.go.dev/builtin/#string">string</a>
  5263  <span id="TopicMetadata.Partitions"></span>    Partitions []<a href="#PartitionMetadata">PartitionMetadata</a>
  5264  <span id="TopicMetadata.Error"></span>    Error      <a href="#Error">Error</a>
  5265  }
  5266  </pre>
  5267      <h2 id="TopicPartition">
  5268       type
  5269       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/kafka.go?s=12721:12841#L267">
  5270        TopicPartition
  5271       </a>
  5272       <a class="permalink" href="#TopicPartition">
  5273        ¶
  5274       </a>
  5275      </h2>
  5276      <p>
  5277       TopicPartition is a generic placeholder for a Topic+Partition and optionally Offset.
  5278      </p>
  5279      <pre>type TopicPartition struct {
  5280  <span id="TopicPartition.Topic"></span>    Topic     *<a href="https://pkg.go.dev/builtin/#string">string</a>
  5281  <span id="TopicPartition.Partition"></span>    Partition <a href="https://pkg.go.dev/builtin/#int32">int32</a>
  5282  <span id="TopicPartition.Offset"></span>    Offset    <a href="#Offset">Offset</a>
  5283  <span id="TopicPartition.Metadata"></span>    Metadata  *<a href="https://pkg.go.dev/builtin/#string">string</a>
  5284  <span id="TopicPartition.Error"></span>    Error     <a href="https://pkg.go.dev/builtin/#error">error</a>
  5285  }
  5286  </pre>
  5287      <h3 id="TopicPartition.String">
  5288       func (TopicPartition)
  5289       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/kafka.go?s=12843:12882#L275">
  5290        String
  5291       </a>
  5292       <a class="permalink" href="#TopicPartition.String">
  5293        ¶
  5294       </a>
  5295      </h3>
  5296      <pre>func (p <a href="#TopicPartition">TopicPartition</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  5297      <h2 id="TopicPartitions">
  5298       type
  5299       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/kafka.go?s=13211:13248#L290">
  5300        TopicPartitions
  5301       </a>
  5302       <a class="permalink" href="#TopicPartitions">
  5303        ¶
  5304       </a>
  5305      </h2>
  5306      <p>
  5307       TopicPartitions is a slice of TopicPartitions that also implements
  5308  the sort interface
  5309      </p>
  5310      <pre>type TopicPartitions []<a href="#TopicPartition">TopicPartition</a></pre>
  5311      <h3 id="TopicPartitions.Len">
  5312       func (TopicPartitions)
  5313       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/kafka.go?s=13250:13286#L292">
  5314        Len
  5315       </a>
  5316       <a class="permalink" href="#TopicPartitions.Len">
  5317        ¶
  5318       </a>
  5319      </h3>
  5320      <pre>func (tps <a href="#TopicPartitions">TopicPartitions</a>) Len() <a href="https://pkg.go.dev/builtin/#int">int</a></pre>
  5321      <h3 id="TopicPartitions.Less">
  5322       func (TopicPartitions)
  5323       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/kafka.go?s=13309:13355#L296">
  5324        Less
  5325       </a>
  5326       <a class="permalink" href="#TopicPartitions.Less">
  5327        ¶
  5328       </a>
  5329      </h3>
  5330      <pre>func (tps <a href="#TopicPartitions">TopicPartitions</a>) Less(i, j <a href="https://pkg.go.dev/builtin/#int">int</a>) <a href="https://pkg.go.dev/builtin/#bool">bool</a></pre>
  5331      <h3 id="TopicPartitions.Swap">
  5332       func (TopicPartitions)
  5333       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/kafka.go?s=13516:13557#L305">
  5334        Swap
  5335       </a>
  5336       <a class="permalink" href="#TopicPartitions.Swap">
  5337        ¶
  5338       </a>
  5339      </h3>
  5340      <pre>func (tps <a href="#TopicPartitions">TopicPartitions</a>) Swap(i, j <a href="https://pkg.go.dev/builtin/#int">int</a>)</pre>
  5341      <h2 id="TopicResult">
  5342       type
  5343       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=2345:2485#L79">
  5344        TopicResult
  5345       </a>
  5346       <a class="permalink" href="#TopicResult">
  5347        ¶
  5348       </a>
  5349      </h2>
  5350      <p>
  5351       TopicResult provides per-topic operation result (error) information.
  5352      </p>
  5353      <pre>type TopicResult struct {
  5354  <span id="TopicResult.Topic"></span>    <span class="comment">// Topic name</span>
  5355      Topic <a href="https://pkg.go.dev/builtin/#string">string</a>
  5356  <span id="TopicResult.Error"></span>    <span class="comment">// Error, if any, of result. Check with `Error.Code() != ErrNoError`.</span>
  5357      Error <a href="#Error">Error</a>
  5358  }
  5359  </pre>
  5360      <h3 id="TopicResult.String">
  5361       func (TopicResult)
  5362       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=2555:2591#L87">
  5363        String
  5364       </a>
  5365       <a class="permalink" href="#TopicResult.String">
  5366        ¶
  5367       </a>
  5368      </h3>
  5369      <pre>func (t <a href="#TopicResult">TopicResult</a>) String() <a href="https://pkg.go.dev/builtin/#string">string</a></pre>
  5370      <p>
  5371       String returns a human-readable representation of a TopicResult.
  5372      </p>
  5373      <h2 id="TopicSpecification">
  5374       type
  5375       <a href="https://github.com/confluentinc/confluent-kafka-go/blob/v1.9.2/kafka/adminapi.go?s=2835:3426#L96">
  5376        TopicSpecification
  5377       </a>
  5378       <a class="permalink" href="#TopicSpecification">
  5379        ¶
  5380       </a>
  5381      </h2>
  5382      <p>
  5383       TopicSpecification holds parameters for creating a new topic.
  5384  TopicSpecification is analogous to NewTopic in the Java Topic Admin API.
  5385      </p>
  5386      <pre>type TopicSpecification struct {
  5387  <span id="TopicSpecification.Topic"></span>    <span class="comment">// Topic name to create.</span>
  5388      Topic <a href="https://pkg.go.dev/builtin/#string">string</a>
  5389      <span class="comment">// Number of partitions in topic.</span>
  5390  <span id="TopicSpecification.NumPartitions"></span>    NumPartitions <a href="https://pkg.go.dev/builtin/#int">int</a>
  5391      <span class="comment">// Default replication factor for the topic's partitions, or zero</span>
  5392      <span class="comment">// if an explicit ReplicaAssignment is set.</span>
  5393  <span id="TopicSpecification.ReplicationFactor"></span>    ReplicationFactor <a href="https://pkg.go.dev/builtin/#int">int</a>
  5394      <span class="comment">// (Optional) Explicit replica assignment. The outer array is</span>
  5395      <span class="comment">// indexed by the partition number, while the inner per-partition array</span>
  5396      <span class="comment">// contains the replica broker ids. The first broker in each</span>
  5397      <span class="comment">// broker id list will be the preferred replica.</span>
  5398  <span id="TopicSpecification.ReplicaAssignment"></span>    ReplicaAssignment [][]<a href="https://pkg.go.dev/builtin/#int32">int32</a>
  5399      <span class="comment">// Topic configuration.</span>
  5400  <span id="TopicSpecification.Config"></span>    Config map[<a href="https://pkg.go.dev/builtin/#string">string</a>]<a href="https://pkg.go.dev/builtin/#string">string</a>
  5401  }
  5402  </pre>
  5403      <div id="footer">
  5404       Build version go1.14.
  5405       <br/>
  5406       Except as
  5407       <a href="https://developers.google.com/site-policies#restrictions">
  5408        noted
  5409       </a>
  5410       ,
  5411  the content of this page is licensed under the
  5412  Creative Commons Attribution 3.0 License,
  5413  and code is licensed under a
  5414       <a href="https://go.dev/LICENSE">
  5415        BSD license
  5416       </a>
  5417       .
  5418       <br/>
  5419       <a href="https://golang.org/doc/tos.html">
  5420        Terms of Service
  5421       </a>
  5422       |
  5423       <a href="https://www.google.com/intl/en/policies/privacy/">
  5424        Privacy Policy
  5425       </a>
  5426      </div>
  5427     </div>
  5428     <!-- .container -->
  5429    </div>
  5430    <!-- #page -->
  5431   </body>
  5432  </html>
  5433