- name() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
-
Returns the name of this configuration.
- name() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Return the config name.
- name() - Method in class org.apache.kafka.clients.admin.NewTopic
-
The name of the topic to be created.
- name() - Method in class org.apache.kafka.clients.admin.TopicDescription
-
The name of the topic.
- name() - Method in class org.apache.kafka.clients.admin.TopicListing
-
The name of the topic.
- name() - Method in class org.apache.kafka.clients.admin.UserScramCredentialsDescription
-
- name() - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
Unique name for this assignor (e.g.
- name() - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
-
- name() - Method in class org.apache.kafka.clients.consumer.RangeAssignor
-
- name() - Method in class org.apache.kafka.clients.consumer.RoundRobinAssignor
-
- name() - Method in class org.apache.kafka.clients.consumer.StickyAssignor
-
- name - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- name() - Method in class org.apache.kafka.common.config.ConfigResource
-
Return the resource name.
- name() - Method in class org.apache.kafka.common.config.ConfigValue
-
- name() - Method in class org.apache.kafka.common.MetricName
-
- name() - Method in class org.apache.kafka.common.MetricNameTemplate
-
Get the name of the metric.
- name() - Method in class org.apache.kafka.common.metrics.CompoundStat.NamedMeasurable
-
- name() - Method in class org.apache.kafka.common.metrics.Sensor
-
The name this sensor is registered with.
- name - Variable in enum org.apache.kafka.common.metrics.Sensor.RecordingLevel
-
an english description of the api--this is for debugging and can change
- name() - Method in class org.apache.kafka.common.metrics.stats.Frequency
-
Get the name of this metric.
- name() - Method in class org.apache.kafka.common.metrics.stats.Percentile
-
- name() - Method in class org.apache.kafka.common.resource.Resource
-
Return the resource name.
- name() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- name() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- name - Variable in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
Name of the security protocol.
- name() - Method in interface org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntity
-
Returns the name of this entity.
- NamedMeasurable(MetricName, Measurable) - Constructor for class org.apache.kafka.common.metrics.CompoundStat.NamedMeasurable
-
- names() - Method in class org.apache.kafka.clients.admin.ListTopicsResult
-
Return a future which yields a collection of topic names.
- names() - Method in class org.apache.kafka.common.config.ConfigDef
-
Returns unmodifiable set of properties names defined in this
ConfigDef
- names() - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
- NAMESPACE - Static variable in interface org.apache.kafka.common.metrics.MetricsContext
-
- namesToListings() - Method in class org.apache.kafka.clients.admin.ListTopicsResult
-
Return a future which yields a map of topic names to TopicListing objects.
- NETTY_SSL_ENGINE_FACTORY_CLASS - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- NETWORK_THREAD_PREFIX - Static variable in class org.apache.kafka.clients.producer.KafkaProducer
-
- NetworkException - Exception in org.apache.kafka.common.errors
-
A misc.
- NetworkException() - Constructor for exception org.apache.kafka.common.errors.NetworkException
-
- NetworkException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NetworkException
-
- NetworkException(String) - Constructor for exception org.apache.kafka.common.errors.NetworkException
-
- NetworkException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NetworkException
-
- NewClusterLink - Class in org.apache.kafka.clients.admin
-
A new cluster link to be created via Admin#createClusterLinks(Collection, CreateClusterLinksOptions)
.
- NewClusterLink(String, String, Map<String, String>) - Constructor for class org.apache.kafka.clients.admin.NewClusterLink
-
Creates a new cluster link with the specified configs.
- NewMirrorTopic - Class in org.apache.kafka.clients.admin
-
Supplemental new topic data for creating a topic that is a mirror of another.
- NewMirrorTopic(String, String) - Constructor for class org.apache.kafka.clients.admin.NewMirrorTopic
-
Prepares a new topic that'll mirror its data from a source topic.
- NewPartitionReassignment - Class in org.apache.kafka.clients.admin
-
- NewPartitionReassignment(List<Integer>) - Constructor for class org.apache.kafka.clients.admin.NewPartitionReassignment
-
- NewPartitions - Class in org.apache.kafka.clients.admin
-
- newSample(long) - Method in class org.apache.kafka.common.metrics.stats.Frequencies
-
- newSample(long) - Method in class org.apache.kafka.common.metrics.stats.Percentiles
-
- newSample(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
-
- NewTopic - Class in org.apache.kafka.clients.admin
-
- NewTopic(String, int, short) - Constructor for class org.apache.kafka.clients.admin.NewTopic
-
A new topic with the specified replication factor and number of partitions.
- NewTopic(String, Optional<Integer>, Optional<Short>) - Constructor for class org.apache.kafka.clients.admin.NewTopic
-
A new topic that optionally defaults numPartitions
and replicationFactor
to
the broker configurations for num.partitions
and default.replication.factor
respectively.
- NewTopic(String, Map<Integer, List<Integer>>) - Constructor for class org.apache.kafka.clients.admin.NewTopic
-
A new topic with the specified replica assignment configuration.
- NO_DEFAULT_VALUE - Static variable in class org.apache.kafka.common.config.ConfigDef
-
A unique Java object which represents the lack of a default value.
- NO_SASL_EXTENSIONS - Static variable in class org.apache.kafka.common.security.auth.SaslExtensions
-
An "empty" instance indicating no SASL extensions
- NO_TIMESTAMP - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
-
- Node - Class in org.apache.kafka.common
-
Information about a Kafka node
- Node(int, String, int) - Constructor for class org.apache.kafka.common.Node
-
- Node(int, String, int, String) - Constructor for class org.apache.kafka.common.Node
-
- nodeById(int) - Method in class org.apache.kafka.common.Cluster
-
Get the node by the node id (or null if the node is not online or does not exist)
- nodeIfOnline(TopicPartition, int) - Method in class org.apache.kafka.common.Cluster
-
Get the node by node id if the replica for the given partition is online
- nodes() - Method in class org.apache.kafka.clients.admin.DescribeClusterResult
-
Returns a future which yields a collection of nodes.
- nodes() - Method in class org.apache.kafka.common.Cluster
-
- NON_RECONFIGURABLE_CONFIGS - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- NonEmptyString() - Constructor for class org.apache.kafka.common.config.ConfigDef.NonEmptyString
-
- NonEmptyStringWithoutControlChars() - Constructor for class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
-
- nonEmptyStringWithoutControlChars() - Static method in class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
-
- nonInternalValues() - Method in class org.apache.kafka.common.config.AbstractConfig
-
- NonNullValidator() - Constructor for class org.apache.kafka.common.config.ConfigDef.NonNullValidator
-
- noNode() - Static method in class org.apache.kafka.common.Node
-
- NoOffsetForPartitionException - Exception in org.apache.kafka.clients.consumer
-
Indicates that there is no stored offset for a partition and no defined offset
reset policy.
- NoOffsetForPartitionException(TopicPartition) - Constructor for exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
-
- NoOffsetForPartitionException(Collection<TopicPartition>) - Constructor for exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
-
- NoReassignmentInProgressException - Exception in org.apache.kafka.common.errors
-
Thrown if a reassignment cannot be cancelled because none is in progress.
- NoReassignmentInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.NoReassignmentInProgressException
-
- NoReassignmentInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NoReassignmentInProgressException
-
- NotControllerException - Exception in org.apache.kafka.common.errors
-
- NotControllerException(String) - Constructor for exception org.apache.kafka.common.errors.NotControllerException
-
- NotControllerException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotControllerException
-
- NotCoordinatorException - Exception in org.apache.kafka.common.errors
-
In the context of the group coordinator, the broker returns this error code if it receives an offset fetch
or commit request for a group it's not the coordinator of.
- NotCoordinatorException(String) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorException
-
- NotCoordinatorException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotCoordinatorException
-
- NotEnoughReplicasAfterAppendException - Exception in org.apache.kafka.common.errors
-
Number of insync replicas for the partition is lower than min.insync.replicas This exception is raised when the low
ISR size is discovered *after* the message was already appended to the log.
- NotEnoughReplicasAfterAppendException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
-
- NotEnoughReplicasException - Exception in org.apache.kafka.common.errors
-
Number of insync replicas for the partition is lower than min.insync.replicas
- NotEnoughReplicasException() - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
-
- NotEnoughReplicasException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
-
- NotEnoughReplicasException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
-
- NotEnoughReplicasException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasException
-
- NotLeaderForPartitionException - Exception in org.apache.kafka.common.errors
-
- NotLeaderForPartitionException() - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
-
Deprecated.
- NotLeaderForPartitionException(String) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
-
Deprecated.
- NotLeaderForPartitionException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
-
Deprecated.
- NotLeaderForPartitionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
-
Deprecated.
- NotLeaderOrFollowerException - Exception in org.apache.kafka.common.errors
-
Broker returns this error if a request could not be processed because the broker is not the leader
or follower for a topic partition.
- NotLeaderOrFollowerException() - Constructor for exception org.apache.kafka.common.errors.NotLeaderOrFollowerException
-
- NotLeaderOrFollowerException(String) - Constructor for exception org.apache.kafka.common.errors.NotLeaderOrFollowerException
-
- NotLeaderOrFollowerException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderOrFollowerException
-
- NotLeaderOrFollowerException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderOrFollowerException
-
- NULL_CHECKSUM - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
-
- NULL_SIZE - Static variable in class org.apache.kafka.clients.consumer.ConsumerRecord
-
- numPartitions(String) - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
-
Returns a future that provides number of partitions in the topic when the request completes.
- numPartitions() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
-
- numPartitions() - Method in class org.apache.kafka.clients.admin.MirrorTopicDescription
-
The number of partitions for the mirror topic.
- numPartitions() - Method in class org.apache.kafka.clients.admin.NewTopic
-
The number of partitions for the new topic or -1 if a replica assignment has been specified.
- numPartitions() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Return the number of partitions to create or null if replicaAssignments is not null.
- OAUTHBEARER_MECHANISM - Static variable in class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
-
The SASL Mechanism name for OAuth 2: OAUTHBEARER
- OAuthBearerExtensionsValidatorCallback - Class in org.apache.kafka.common.security.oauthbearer
-
A
Callback
for use by the
SaslServer
implementation when it
needs to validate the SASL extensions for the OAUTHBEARER mechanism
Callback handlers should use the
OAuthBearerExtensionsValidatorCallback.valid(String)
method to communicate valid extensions back to the SASL server.
- OAuthBearerExtensionsValidatorCallback(OAuthBearerToken, SaslExtensions) - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
- OAuthBearerLoginModule - Class in org.apache.kafka.common.security.oauthbearer
-
The LoginModule
for the SASL/OAUTHBEARER mechanism.
- OAuthBearerLoginModule() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerLoginModule
-
- OAuthBearerToken - Interface in org.apache.kafka.common.security.oauthbearer
-
The
b64token
value as defined in
RFC 6750 Section
2.1 along with the token's specific scope and lifetime and principal
name.
- OAuthBearerTokenCallback - Class in org.apache.kafka.common.security.oauthbearer
-
A Callback
for use by the SaslClient
and Login
implementations when they require an OAuth 2 bearer token.
- OAuthBearerTokenCallback() - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
-
- OAuthBearerValidatorCallback - Class in org.apache.kafka.common.security.oauthbearer
-
A Callback
for use by the SaslServer
implementation when it
needs to provide an OAuth 2 bearer token compact serialization for
validation.
- OAuthBearerValidatorCallback(String) - Constructor for class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
-
Constructor
- observers() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
-
Get the replica observers which are asynchronously replicated.
- observers() - Method in class org.apache.kafka.common.PartitionInfo
-
The complete set of observers for this partition regardless of whether they are alive or up-to-date
- observers() - Method in class org.apache.kafka.common.TopicPartitionInfo
-
Return the observer replicas of the partition.
- of(ConfigDef.Validator...) - Static method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
-
- of(String, int, Node, Node[], Node[], Node[], Node[]) - Static method in class org.apache.kafka.common.PartitionInfo
-
- ofDefaultEntity(String) - Static method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
-
Constructs and returns a filter component that matches the built-in default entity name
for the entity type.
- ofEntity(String, String) - Static method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
-
Constructs and returns a filter component that exactly matches the provided entity
name for the entity type.
- ofEntityType(String) - Static method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
-
Constructs and returns a filter component that matches any specified name for the
entity type.
- offlineReplicas() - Method in class org.apache.kafka.common.PartitionInfo
-
The subset of the replicas that are offline
- offset() - Method in class org.apache.kafka.clients.admin.ListOffsetsResult.ListOffsetsResultInfo
-
- offset() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The position of this record in the corresponding Kafka partition.
- offset() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
- offset() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
- offset() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The offset of the record in the topic/partition.
- offset() - Method in exception org.apache.kafka.common.errors.RecordDeserializationException
-
- OffsetAndMetadata - Class in org.apache.kafka.clients.consumer
-
The Kafka offset commit API allows users to provide additional metadata (in the form of a string)
when an offset is committed.
- OffsetAndMetadata(long, Optional<Integer>, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
Construct a new OffsetAndMetadata object for committing through
KafkaConsumer
.
- OffsetAndMetadata(long, String) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
Construct a new OffsetAndMetadata object for committing through
KafkaConsumer
.
- OffsetAndMetadata(long) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
Construct a new OffsetAndMetadata object for committing through
KafkaConsumer
.
- OffsetAndTimestamp - Class in org.apache.kafka.clients.consumer
-
A container class for offset and timestamp.
- OffsetAndTimestamp(long, long) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
- OffsetAndTimestamp(long, long, Optional<Integer>) - Constructor for class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
- OffsetCommitCallback - Interface in org.apache.kafka.clients.consumer
-
A callback interface that the user can implement to trigger custom actions when a commit request completes.
- offsetLag() - Method in class org.apache.kafka.clients.admin.ReplicaInfo
-
The lag of the log's LEO with respect to the partition's
high watermark (if it is the current log for the partition)
or the current replica's LEO (if it is the
future log
for the partition).
- OffsetMetadataTooLarge - Exception in org.apache.kafka.common.errors
-
The client has tried to save its offset with associated metadata larger than the maximum size allowed by the server.
- OffsetMetadataTooLarge() - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
-
- OffsetMetadataTooLarge(String) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
-
- OffsetMetadataTooLarge(Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
-
- OffsetMetadataTooLarge(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetMetadataTooLarge
-
- OffsetNotAvailableException - Exception in org.apache.kafka.common.errors
-
Indicates that the leader is not able to guarantee monotonically increasing offsets
due to the high watermark lagging behind the epoch start offset after a recent leader election
- OffsetNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.OffsetNotAvailableException
-
- OffsetOutOfRangeException - Exception in org.apache.kafka.clients.consumer
-
No reset policy has been defined, and the offsets for these partitions are either larger or smaller
than the range of offsets the server has for the given partition.
- OffsetOutOfRangeException(Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
-
- OffsetOutOfRangeException(String, Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
-
- OffsetOutOfRangeException - Exception in org.apache.kafka.common.errors
-
No reset policy has been defined, and the offsets for these partitions are either larger or smaller
than the range of offsets the server has for the given partition.
- OffsetOutOfRangeException(String) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
-
- OffsetOutOfRangeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
-
- offsetOutOfRangePartitions() - Method in exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
-
Get a map of the topic partitions and the respective out-of-range fetch offsets.
- OffsetResetStrategy - Enum in org.apache.kafka.clients.consumer
-
- offsetsForTimes(Map<TopicPartition, Long>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- offsetsForTimes(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Look up the offsets for the given partitions by timestamp.
- offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Look up the offsets for the given partitions by timestamp.
- offsetsForTimes(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- OffsetSpec - Class in org.apache.kafka.clients.admin
-
- OffsetSpec() - Constructor for class org.apache.kafka.clients.admin.OffsetSpec
-
- OffsetSpec.EarliestSpec - Class in org.apache.kafka.clients.admin
-
- OffsetSpec.LatestSpec - Class in org.apache.kafka.clients.admin
-
- OffsetSpec.MaxTimestampSpec - Class in org.apache.kafka.clients.admin
-
- OffsetSpec.TimestampSpec - Class in org.apache.kafka.clients.admin
-
- OffsetTieredException - Exception in org.apache.kafka.common.errors
-
- OffsetTieredException(String) - Constructor for exception org.apache.kafka.common.errors.OffsetTieredException
-
- OffsetTieredException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetTieredException
-
- ofReplicasAndObservers(List<Integer>, List<Integer>) - Static method in class org.apache.kafka.clients.admin.NewPartitionReassignment
-
- ofReplicasAndObservers(int, Node, List<Node>, List<Node>, List<Node>) - Static method in class org.apache.kafka.common.TopicPartitionInfo
-
- ofTopicIds(Collection<Uuid>) - Static method in class org.apache.kafka.common.TopicCollection
-
- ofTopicNames(Collection<String>) - Static method in class org.apache.kafka.common.TopicCollection
-
- oldest(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
-
- onAcknowledgement(RecordMetadata, Exception) - Method in interface org.apache.kafka.clients.producer.ProducerInterceptor
-
This method is called when the record sent to the server has been acknowledged, or when sending the record fails before
it gets sent to the server.
- onAssignment(ConsumerPartitionAssignor.Assignment, ConsumerGroupMetadata) - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
Callback which is invoked when a group member receives its assignment from the leader.
- onAssignment(ConsumerPartitionAssignor.Assignment, ConsumerGroupMetadata) - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
-
- onAssignment(ConsumerPartitionAssignor.Assignment, ConsumerGroupMetadata) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
-
- onChange(String, ConfigData) - Method in interface org.apache.kafka.common.config.ConfigChangeCallback
-
Performs an action when configuration data changes.
- onCommit(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.apache.kafka.clients.consumer.ConsumerInterceptor
-
This is called when offsets get committed.
- onComplete(Map<TopicPartition, OffsetAndMetadata>, Exception) - Method in interface org.apache.kafka.clients.consumer.OffsetCommitCallback
-
A callback method the user can implement to provide asynchronous handling of commit request completion.
- onCompletion(RecordMetadata, Exception) - Method in interface org.apache.kafka.clients.producer.Callback
-
A callback method the user can implement to provide asynchronous handling of request completion.
- onConsume(ConsumerRecords<K, V>) - Method in interface org.apache.kafka.clients.consumer.ConsumerInterceptor
-
- onNewBatch(String, Cluster, int) - Method in interface org.apache.kafka.clients.producer.Partitioner
-
Notifies the partitioner a new batch is about to be created.
- onNewBatch(String, Cluster, int) - Method in class org.apache.kafka.clients.producer.UniformStickyPartitioner
-
If a batch completed for the current sticky partition, change the sticky partition.
- onPartitionsAssigned(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
-
A callback method the user can implement to provide handling of customized offsets on completion of a successful
partition re-assignment.
- onPartitionsLost(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
-
A callback method you can implement to provide handling of cleaning up resources for partitions that have already
been reassigned to other consumers.
- onPartitionsRevoked(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceListener
-
A callback method the user can implement to provide handling of offset commits to a customized store.
- onSend(ProducerRecord<K, V>) - Method in interface org.apache.kafka.clients.producer.ProducerInterceptor
-
- onUpdate(ClusterResource) - Method in interface org.apache.kafka.common.ClusterResourceListener
-
A callback method that a user can implement to get updates for
ClusterResource
.
- Op(String, Double) - Constructor for class org.apache.kafka.common.quota.ClientQuotaAlteration.Op
-
- operation() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
Return the AclOperation.
- operation() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Return the AclOperation.
- operation() - Method in class org.apache.kafka.server.authorizer.Action
-
- OperationNotAttemptedException - Exception in org.apache.kafka.common.errors
-
Indicates that the broker did not attempt to execute this operation.
- OperationNotAttemptedException(String) - Constructor for exception org.apache.kafka.common.errors.OperationNotAttemptedException
-
- ops() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration
-
- opType() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
-
- opType() - Method in class org.apache.kafka.clients.admin.ExclusionOp
-
- opType() - Method in class org.apache.kafka.clients.admin.ExclusionOpResult
-
- orderInGroup - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- org.apache.kafka.clients.admin - package org.apache.kafka.clients.admin
-
- org.apache.kafka.clients.consumer - package org.apache.kafka.clients.consumer
-
- org.apache.kafka.clients.producer - package org.apache.kafka.clients.producer
-
- org.apache.kafka.common - package org.apache.kafka.common
-
- org.apache.kafka.common.acl - package org.apache.kafka.common.acl
-
- org.apache.kafka.common.annotation - package org.apache.kafka.common.annotation
-
- org.apache.kafka.common.config - package org.apache.kafka.common.config
-
- org.apache.kafka.common.config.provider - package org.apache.kafka.common.config.provider
-
- org.apache.kafka.common.errors - package org.apache.kafka.common.errors
-
- org.apache.kafka.common.header - package org.apache.kafka.common.header
-
- org.apache.kafka.common.metrics - package org.apache.kafka.common.metrics
-
- org.apache.kafka.common.metrics.stats - package org.apache.kafka.common.metrics.stats
-
- org.apache.kafka.common.quota - package org.apache.kafka.common.quota
-
- org.apache.kafka.common.resource - package org.apache.kafka.common.resource
-
- org.apache.kafka.common.security.auth - package org.apache.kafka.common.security.auth
-
- org.apache.kafka.common.security.oauthbearer - package org.apache.kafka.common.security.oauthbearer
-
- org.apache.kafka.common.security.plain - package org.apache.kafka.common.security.plain
-
- org.apache.kafka.common.security.scram - package org.apache.kafka.common.security.scram
-
- org.apache.kafka.common.security.token.delegation - package org.apache.kafka.common.security.token.delegation
-
- org.apache.kafka.common.serialization - package org.apache.kafka.common.serialization
-
- org.apache.kafka.server.authorizer - package org.apache.kafka.server.authorizer
-
- org.apache.kafka.server.policy - package org.apache.kafka.server.policy
-
- org.apache.kafka.server.quota - package org.apache.kafka.server.quota
-
- originals() - Method in class org.apache.kafka.common.config.AbstractConfig
-
- originals(Map<String, Object>) - Method in class org.apache.kafka.common.config.AbstractConfig
-
- originalsStrings() - Method in class org.apache.kafka.common.config.AbstractConfig
-
Get all the original settings, ensuring that all values are of type String.
- originalsWithPrefix(String) - Method in class org.apache.kafka.common.config.AbstractConfig
-
Gets all original settings with the given prefix, stripping the prefix before adding it to the output.
- originalsWithPrefix(String, boolean) - Method in class org.apache.kafka.common.config.AbstractConfig
-
Gets all original settings with the given prefix.
- OtherChecksumTypeException - Exception in org.apache.kafka.common.errors
-
- OtherChecksumTypeException(String) - Constructor for exception org.apache.kafka.common.errors.OtherChecksumTypeException
-
- OutOfOrderSequenceException - Exception in org.apache.kafka.common.errors
-
This exception indicates that the broker received an unexpected sequence number from the producer,
which means that data may have been lost.
- OutOfOrderSequenceException(String) - Constructor for exception org.apache.kafka.common.errors.OutOfOrderSequenceException
-
- ownedPartitions() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- owner() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- ownerAsString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- ownerOrRenewer(KafkaPrincipal) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- owners(List<KafkaPrincipal>) - Method in class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
-
if owners is null, all the user owned tokens and tokens where user have Describe permission
will be returned.
- owners() - Method in class org.apache.kafka.clients.admin.DescribeDelegationTokenOptions
-
- parse(String) - Static method in enum org.apache.kafka.clients.admin.TransactionState
-
- parse(Map<?, ?>) - Method in class org.apache.kafka.common.config.ConfigDef
-
Parse and validate configs against this configuration definition.
- parse(String) - Static method in enum org.apache.kafka.common.ConsumerGroupState
-
Parse a string into a consumer group state.
- parseType(String, Object, ConfigDef.Type) - Static method in class org.apache.kafka.common.config.ConfigDef
-
Parse a value according to its expected type.
- partition() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The partition from which this record is received
- partition(String, Object, byte[], Object, byte[], Cluster) - Method in interface org.apache.kafka.clients.producer.Partitioner
-
Compute the partition for the given record.
- partition() - Method in class org.apache.kafka.clients.producer.ProducerRecord
-
- partition() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The partition the record was sent to
- partition(String, Object, byte[], Object, byte[], Cluster) - Method in class org.apache.kafka.clients.producer.RoundRobinPartitioner
-
Compute the partition for the given record.
- partition(String, Object, byte[], Object, byte[], Cluster) - Method in class org.apache.kafka.clients.producer.UniformStickyPartitioner
-
Compute the partition for the given record.
- partition(TopicPartition) - Method in class org.apache.kafka.common.Cluster
-
Get the metadata for the specified partition
- partition() - Method in class org.apache.kafka.common.PartitionInfo
-
The partition id
- partition() - Method in class org.apache.kafka.common.TopicPartition
-
- partition() - Method in class org.apache.kafka.common.TopicPartitionInfo
-
Return the partition id.
- partition() - Method in class org.apache.kafka.common.TopicPartitionReplica
-
- PARTITION_ASSIGNMENT_STRATEGY_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
partition.assignment.strategy
- partitionAssignor() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
The consumer group partition assignor.
- partitionCountForTopic(String) - Method in class org.apache.kafka.common.Cluster
-
Get the number of partitions for the given topic.
- Partitioner - Interface in org.apache.kafka.clients.producer
-
Partitioner Interface
- PARTITIONER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
partitioner.class
- PartitionInfo - Class in org.apache.kafka.common
-
This is used to describe per-partition state in the MetadataResponse.
- PartitionInfo(String, int, Node, Node[], Node[]) - Constructor for class org.apache.kafka.common.PartitionInfo
-
- PartitionInfo(String, int, Node, Node[], Node[], Node[]) - Constructor for class org.apache.kafka.common.PartitionInfo
-
- PartitionProducerState(List<ProducerState>) - Constructor for class org.apache.kafka.clients.admin.DescribeProducersResult.PartitionProducerState
-
- PartitionReassignment - Class in org.apache.kafka.clients.admin
-
- PartitionReassignment(List<Integer>, List<Integer>, List<Integer>, List<Integer>) - Constructor for class org.apache.kafka.clients.admin.PartitionReassignment
-
- PartitionReassignment(List<Integer>, List<Integer>, List<Integer>) - Constructor for class org.apache.kafka.clients.admin.PartitionReassignment
-
- partitionReassignmentsStatus() - Method in class org.apache.kafka.clients.admin.BrokerAdditionDescription
-
The detailed, current status of the broker addition operation's status.
- PartitionReassignmentsStatus - Enum in org.apache.kafka.clients.admin
-
Denotes the status of the partition reassignments of a given Confluent Balancer operation.
- partitionResult(TopicPartition) - Method in class org.apache.kafka.clients.admin.AlterConsumerGroupOffsetsResult
-
Return a future which can be used to check the result for a given partition.
- partitionResult(TopicPartition) - Method in class org.apache.kafka.clients.admin.DeleteConsumerGroupOffsetsResult
-
Return a future which can be used to check the result for a given partition.
- partitionResult(TopicPartition) - Method in class org.apache.kafka.clients.admin.DescribeProducersResult
-
- partitionResult(TopicPartition) - Method in class org.apache.kafka.clients.admin.ListOffsetsResult
-
Return a future which can be used to check the result for a given partition.
- PartitionResult - Class in org.apache.kafka.clients.admin
-
- PartitionResult(List<ReplicaStatus>) - Constructor for class org.apache.kafka.clients.admin.PartitionResult
-
- PartitionResult(ReplicaStatusResponseData.ReplicaStatusPartitionResponse) - Constructor for class org.apache.kafka.clients.admin.PartitionResult
-
- PartitionResult(int, int, List<ReplicaStatus>) - Constructor for class org.apache.kafka.clients.admin.PartitionResult
-
- partitionResults() - Method in class org.apache.kafka.clients.admin.ReplicaStatusResult
-
- partitions() - Method in class org.apache.kafka.clients.admin.ElectLeadersResult
-
Get a future for the topic partitions for which a leader election was attempted.
- partitions() - Method in class org.apache.kafka.clients.admin.TopicDescription
-
A list of partitions where the index represents the partition id and the element contains leadership and replica
information for that partition.
- partitions() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment
-
- partitions() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
-
Get the partitions which have records contained in this record set.
- partitions() - Method in exception org.apache.kafka.clients.consumer.InvalidOffsetException
-
- partitions() - Method in exception org.apache.kafka.clients.consumer.NoOffsetForPartitionException
-
returns all partitions for which no offests are defined.
- partitions() - Method in exception org.apache.kafka.clients.consumer.OffsetOutOfRangeException
-
- partitionsFor(String) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- partitionsFor(String, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- partitionsFor(String) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get metadata about the partitions for a given topic.
- partitionsFor(String, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get metadata about the partitions for a given topic.
- partitionsFor(String) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- partitionsFor(String, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- partitionsFor(String) - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Get the partition metadata for the given topic.
- partitionsFor(String) - Method in class org.apache.kafka.clients.producer.MockProducer
-
- partitionsFor(String) - Method in interface org.apache.kafka.clients.producer.Producer
-
- partitionsForException - Variable in class org.apache.kafka.clients.producer.MockProducer
-
- partitionsForNode(int) - Method in class org.apache.kafka.common.Cluster
-
Get the list of partitions whose leader is this node
- partitionsForTopic(String) - Method in class org.apache.kafka.common.Cluster
-
Get the list of partitions for this topic
- partitionsToOffsetAndMetadata() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsResult
-
Return a future which yields a map of topic partitions to OffsetAndMetadata objects.
- password() - Method in class org.apache.kafka.clients.admin.UserScramCredentialUpsertion
-
- password() - Method in class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
-
Returns the password provided by the client during SASL/PLAIN authentication
- pattern() - Method in class org.apache.kafka.common.acl.AclBinding
-
- patternFilter() - Method in class org.apache.kafka.common.acl.AclBindingFilter
-
- PatternType - Enum in org.apache.kafka.common.resource
-
Resource pattern type.
- patternType() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- patternType() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- pause(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- pause(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Suspend fetching from the requested partitions.
- pause(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- paused() - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- paused() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
- paused() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- Percentile - Class in org.apache.kafka.common.metrics.stats
-
- Percentile(MetricName, double) - Constructor for class org.apache.kafka.common.metrics.stats.Percentile
-
- percentile() - Method in class org.apache.kafka.common.metrics.stats.Percentile
-
- Percentiles - Class in org.apache.kafka.common.metrics.stats
-
A compound stat that reports one or more percentiles
- Percentiles(int, double, Percentiles.BucketSizing, Percentile...) - Constructor for class org.apache.kafka.common.metrics.stats.Percentiles
-
- Percentiles(int, double, double, Percentiles.BucketSizing, Percentile...) - Constructor for class org.apache.kafka.common.metrics.stats.Percentiles
-
- Percentiles.BucketSizing - Enum in org.apache.kafka.common.metrics.stats
-
- permissionType() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
Return the AclPermissionType.
- permissionType() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Return the AclPermissionType.
- PlainAuthenticateCallback - Class in org.apache.kafka.common.security.plain
-
- PlainAuthenticateCallback(char[]) - Constructor for class org.apache.kafka.common.security.plain.PlainAuthenticateCallback
-
Creates a callback with the password provided by the client
- PlainLoginModule - Class in org.apache.kafka.common.security.plain
-
- PlainLoginModule() - Constructor for class org.apache.kafka.common.security.plain.PlainLoginModule
-
- PlaintextAuthenticationContext - Class in org.apache.kafka.common.security.auth
-
- PlaintextAuthenticationContext(InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
-
- PolicyViolationException - Exception in org.apache.kafka.common.errors
-
Exception thrown if a create topics request does not satisfy the configured policy for a topic.
- PolicyViolationException(String) - Constructor for exception org.apache.kafka.common.errors.PolicyViolationException
-
- PolicyViolationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.PolicyViolationException
-
- poll(long) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
Deprecated.
- poll(Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- poll(long) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
- poll(Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Fetch data for the topics or partitions specified using one of the subscribe/assign APIs.
- poll(long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
Deprecated.
- poll(Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- port() - Method in class org.apache.kafka.common.Endpoint
-
Returns the port to which the listener is bound.
- port - Variable in class org.apache.kafka.common.Node
-
- port() - Method in class org.apache.kafka.common.Node
-
The port for this node
- position(TopicPartition) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- position(TopicPartition, Duration) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- position(TopicPartition) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get the offset of the next record that will be fetched (if a record with that offset exists).
- position(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get the offset of the next record that will be fetched (if a record with that offset exists).
- position(TopicPartition) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- position(TopicPartition, Duration) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- PositionOutOfRangeException - Exception in org.apache.kafka.common.errors
-
- PositionOutOfRangeException(String) - Constructor for exception org.apache.kafka.common.errors.PositionOutOfRangeException
-
- PositionOutOfRangeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.PositionOutOfRangeException
-
- postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.admin.AdminClientConfig
-
- postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.clients.producer.ProducerConfig
-
- postProcessParsedConfig(Map<String, Object>) - Method in class org.apache.kafka.common.config.AbstractConfig
-
Called directly after user configs got parsed (and thus default values got set).
- PREALLOCATE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- PREALLOCATE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- PREFER_TIER_FETCH_MS_CONFIG - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- PREFER_TIER_FETCH_MS_DOC - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- PreferredLeaderNotAvailableException - Exception in org.apache.kafka.common.errors
-
- PreferredLeaderNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.PreferredLeaderNotAvailableException
-
- PreferredLeaderNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.PreferredLeaderNotAvailableException
-
- previousEvenClusterLoadStatus() - Method in class org.apache.kafka.clients.admin.EvenClusterLoadStatusDescription
-
- previousStatusLastUpdatetimeMs() - Method in class org.apache.kafka.clients.admin.EvenClusterLoadStatusDescription
-
- principal() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
Return the principal for this entry.
- principal() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
Return the principal or null.
- principal() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns authenticated principal for the connection on which request was received.
- principal() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
-
- PrincipalDeserializationException - Exception in org.apache.kafka.common.errors
-
Exception used to indicate a kafka principal deserialization failure during request forwarding.
- PrincipalDeserializationException(String) - Constructor for exception org.apache.kafka.common.errors.PrincipalDeserializationException
-
- PrincipalDeserializationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.PrincipalDeserializationException
-
- principalName() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
-
The name of the principal to which this credential applies
- Producer<K,V> - Interface in org.apache.kafka.clients.producer
-
- PRODUCER_METRIC_GROUP_NAME - Static variable in class org.apache.kafka.clients.producer.KafkaProducer
-
- ProducerConfig - Class in org.apache.kafka.clients.producer
-
Configuration for the Kafka Producer.
- ProducerConfig(Properties) - Constructor for class org.apache.kafka.clients.producer.ProducerConfig
-
- ProducerConfig(Map<String, Object>) - Constructor for class org.apache.kafka.clients.producer.ProducerConfig
-
- producerEpoch() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
-
- producerEpoch() - Method in class org.apache.kafka.clients.admin.ProducerState
-
- producerEpoch() - Method in class org.apache.kafka.clients.admin.TransactionDescription
-
- ProducerFencedException - Exception in org.apache.kafka.common.errors
-
This fatal exception indicates that another producer with the same transactional.id
has been
started.
- ProducerFencedException(String) - Constructor for exception org.apache.kafka.common.errors.ProducerFencedException
-
- producerId() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
-
- producerId() - Method in class org.apache.kafka.clients.admin.ProducerState
-
- producerId() - Method in class org.apache.kafka.clients.admin.TransactionDescription
-
- producerId() - Method in class org.apache.kafka.clients.admin.TransactionListing
-
- ProducerInterceptor<K,V> - Interface in org.apache.kafka.clients.producer
-
A plugin interface that allows you to intercept (and possibly mutate) the records received by the producer before
they are published to the Kafka cluster.
- ProducerRecord<K,V> - Class in org.apache.kafka.clients.producer
-
A key/value pair to be sent to Kafka.
- ProducerRecord(String, Integer, Long, K, V, Iterable<Header>) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Creates a record with a specified timestamp to be sent to a specified topic and partition
- ProducerRecord(String, Integer, Long, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Creates a record with a specified timestamp to be sent to a specified topic and partition
- ProducerRecord(String, Integer, K, V, Iterable<Header>) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Creates a record to be sent to a specified topic and partition
- ProducerRecord(String, Integer, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Creates a record to be sent to a specified topic and partition
- ProducerRecord(String, K, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Create a record to be sent to Kafka
- ProducerRecord(String, V) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
-
Create a record with no key
- ProducerState - Class in org.apache.kafka.clients.admin
-
- ProducerState(long, int, int, long, OptionalInt, OptionalLong) - Constructor for class org.apache.kafka.clients.admin.ProducerState
-
- purgeObsoleteSamples(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
-
- rack - Variable in class org.apache.kafka.common.Node
-
- rack() - Method in class org.apache.kafka.common.Node
-
The rack for this node
- randomUuid() - Static method in class org.apache.kafka.common.Uuid
-
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
- RANGE_ASSIGNOR_NAME - Static variable in class org.apache.kafka.clients.consumer.RangeAssignor
-
- RangeAssignor - Class in org.apache.kafka.clients.consumer
-
The range assignor works on a per-topic basis.
- RangeAssignor() - Constructor for class org.apache.kafka.clients.consumer.RangeAssignor
-
- Rate - Class in org.apache.kafka.common.metrics.stats
-
The rate of the given quantity.
- Rate() - Constructor for class org.apache.kafka.common.metrics.stats.Rate
-
- Rate(TimeUnit) - Constructor for class org.apache.kafka.common.metrics.stats.Rate
-
- Rate(SampledStat) - Constructor for class org.apache.kafka.common.metrics.stats.Rate
-
- Rate(TimeUnit, SampledStat) - Constructor for class org.apache.kafka.common.metrics.stats.Rate
-
- reader(String) - Method in class org.apache.kafka.common.config.provider.FileConfigProvider
-
- reason() - Method in class org.apache.kafka.clients.admin.DescribeBrokerReplicaExclusionsResult.BrokerReplicaExclusionDescription
-
- reason() - Method in class org.apache.kafka.clients.admin.ExclusionOp
-
- reason() - Method in class org.apache.kafka.clients.admin.ExclusionOpResult
-
- ReassignmentInProgressException - Exception in org.apache.kafka.common.errors
-
Thrown if a request cannot be completed because a partition reassignment is in progress.
- ReassignmentInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.ReassignmentInProgressException
-
- ReassignmentInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ReassignmentInProgressException
-
- reassignments() - Method in class org.apache.kafka.clients.admin.ListPartitionReassignmentsResult
-
Return a future which yields a map containing each partition's reassignments
- reassignmentsStatus() - Method in class org.apache.kafka.clients.admin.BrokerRemovalDescription
-
The status of the partition reassignments, draining replicas out of the to be removed broker.
- rebalance(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
Simulate a rebalance event.
- RebalanceInProgressException - Exception in org.apache.kafka.common.errors
-
- RebalanceInProgressException() - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
-
- RebalanceInProgressException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
-
- RebalanceInProgressException(String) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
-
- RebalanceInProgressException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalanceInProgressException
-
- RebalancePlanComputationException - Exception in org.apache.kafka.common.errors
-
An error occurred while computing the rebalance plan for removing a broker.
- RebalancePlanComputationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RebalancePlanComputationException
-
- RebalancePlanComputationException(String) - Constructor for exception org.apache.kafka.common.errors.RebalancePlanComputationException
-
- RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
receive.buffer.bytes
- RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
receive.buffer.bytes
- recommendedValues() - Method in class org.apache.kafka.common.config.ConfigValue
-
- recommendedValues(List<Object>) - Method in class org.apache.kafka.common.config.ConfigValue
-
- recommender - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- Reconfigurable - Interface in org.apache.kafka.common
-
Interface for reconfigurable classes that support dynamic configuration.
- RECONFIGURABLE_CONFIGS - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- RECONFIGURABLE_CONFIGS - Static variable in class org.apache.kafka.common.metrics.JmxReporter
-
- reconfigurableConfigs() - Method in class org.apache.kafka.common.DelegatingReconfigurable
-
- reconfigurableConfigs() - Method in class org.apache.kafka.common.metrics.JmxReporter
-
- reconfigurableConfigs() - Method in interface org.apache.kafka.common.metrics.MetricsReporter
-
- reconfigurableConfigs() - Method in interface org.apache.kafka.common.Reconfigurable
-
Returns the names of configs that may be reconfigured.
- reconfigurableConfigs() - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
-
Returns the names of configs that may be reconfigured.
- reconfigure(Map<String, ?>) - Method in class org.apache.kafka.common.DelegatingReconfigurable
-
- reconfigure(Map<String, ?>) - Method in class org.apache.kafka.common.metrics.JmxReporter
-
- reconfigure(Map<String, ?>) - Method in interface org.apache.kafka.common.metrics.MetricsReporter
-
- reconfigure(Map<String, ?>) - Method in interface org.apache.kafka.common.Reconfigurable
-
Reconfigures this instance with the given key-value pairs.
- RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
reconnect.backoff.max.ms
- RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
reconnect.backoff.max.ms
- RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
reconnect.backoff.max.ms
- RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
reconnect.backoff.ms
- RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
reconnect.backoff.ms
- RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
reconnect.backoff.ms
- record() - Method in class org.apache.kafka.common.metrics.Sensor
-
Record an occurrence, this is just short-hand for
record(1.0)
- record(double) - Method in class org.apache.kafka.common.metrics.Sensor
-
Record a value with this sensor
- record(double, long) - Method in class org.apache.kafka.common.metrics.Sensor
-
Record a value at a known time.
- record(double, long, boolean) - Method in class org.apache.kafka.common.metrics.Sensor
-
Record a value at a known time.
- record(MetricConfig, double, long) - Method in interface org.apache.kafka.common.metrics.Stat
-
Record the given value
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.CumulativeCount
-
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.CumulativeSum
-
- record(double) - Method in class org.apache.kafka.common.metrics.stats.Histogram
-
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Meter
-
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Rate
-
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
-
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.TokenBucket
-
- record(MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Value
-
- RecordBatchTooLargeException - Exception in org.apache.kafka.common.errors
-
This record batch is larger than the maximum allowable size
- RecordBatchTooLargeException() - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
-
- RecordBatchTooLargeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
-
- RecordBatchTooLargeException(String) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
-
- RecordBatchTooLargeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordBatchTooLargeException
-
- RecordDeserializationException - Exception in org.apache.kafka.common.errors
-
This exception is raised for any error that occurs while deserializing records received by the consumer using
the configured
Deserializer
.
- RecordDeserializationException(TopicPartition, long, String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordDeserializationException
-
- recordLevel() - Method in class org.apache.kafka.common.metrics.MetricConfig
-
- recordLevel(Sensor.RecordingLevel) - Method in class org.apache.kafka.common.metrics.MetricConfig
-
- RecordMetadata - Class in org.apache.kafka.clients.producer
-
The metadata for a record that has been acknowledged by the server
- RecordMetadata(TopicPartition, long, int, long, int, int) - Constructor for class org.apache.kafka.clients.producer.RecordMetadata
-
Creates a new instance with the provided parameters.
- RecordMetadata(TopicPartition, long, long, long, Long, int, int) - Constructor for class org.apache.kafka.clients.producer.RecordMetadata
-
- records(TopicPartition) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
-
Get just the records for the given partition
- records(String) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
-
Get just the records for the given topic
- RecordsToDelete - Class in org.apache.kafka.clients.admin
-
- RecordTooLargeException - Exception in org.apache.kafka.common.errors
-
This record is larger than the maximum allowable size
- RecordTooLargeException() - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
-
- RecordTooLargeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
-
- RecordTooLargeException(String) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
-
- RecordTooLargeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
-
- RecordTooLargeException(String, Map<TopicPartition, Long>) - Constructor for exception org.apache.kafka.common.errors.RecordTooLargeException
-
- recordTooLargePartitions() - Method in exception org.apache.kafka.common.errors.RecordTooLargeException
-
- relogin() - Method in interface org.apache.kafka.common.security.auth.Login
-
- REMOTE_LOG_STORAGE_ENABLE_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- REMOTE_LOG_STORAGE_ENABLE_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- remoteClusterId() - Method in class org.apache.kafka.clients.admin.ClusterLinkListing
-
- removalError() - Method in class org.apache.kafka.clients.admin.BrokerRemovalDescription
-
The error that failed the broker removal operation.
- remove(String) - Method in interface org.apache.kafka.common.header.Headers
-
Removes all headers for the given key returning if the operation succeeded.
- removeAll() - Method in class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
-
- removeBrokers(List<Integer>) - Method in interface org.apache.kafka.clients.admin.ConfluentAdmin
-
Drain data off a given set of brokers and remove them from the cluster via shutdown.
- removeBrokers(List<Integer>, RemoveBrokersOptions) - Method in interface org.apache.kafka.clients.admin.ConfluentAdmin
-
Drain data off a given set of brokers and remove them from the cluster via shutdown.
- removeBrokers(List<Integer>, RemoveBrokersOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- RemoveBrokersOptions - Class in org.apache.kafka.clients.admin
-
- RemoveBrokersOptions() - Constructor for class org.apache.kafka.clients.admin.RemoveBrokersOptions
-
- RemoveBrokersResult - Class in org.apache.kafka.clients.admin
-
- RemoveBrokersResult(Map<Integer, KafkaFuture<Void>>) - Constructor for class org.apache.kafka.clients.admin.RemoveBrokersResult
-
- removeMembersFromConsumerGroup(String, RemoveMembersFromConsumerGroupOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Remove members from the consumer group by given member identities.
- removeMembersFromConsumerGroup(String, RemoveMembersFromConsumerGroupOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- RemoveMembersFromConsumerGroupOptions - Class in org.apache.kafka.clients.admin
-
- RemoveMembersFromConsumerGroupOptions(Collection<MemberToRemove>) - Constructor for class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
-
- RemoveMembersFromConsumerGroupOptions() - Constructor for class org.apache.kafka.clients.admin.RemoveMembersFromConsumerGroupOptions
-
- RemoveMembersFromConsumerGroupResult - Class in org.apache.kafka.clients.admin
-
- removeMetric(MetricName) - Method in class org.apache.kafka.common.metrics.Metrics
-
Remove a metric if it exists and return it.
- removeQuota(ClientQuotaType, ClientQuotaEntity) - Method in interface org.apache.kafka.server.quota.ClientQuotaCallback
-
Quota configuration removal callback that is invoked when quota configuration for an entity is
removed in ZooKeeper.
- removeReporter(MetricsReporter) - Method in class org.apache.kafka.common.metrics.Metrics
-
Remove a MetricReporter
- removeSensor(String) - Method in class org.apache.kafka.common.metrics.Metrics
-
Remove a sensor (if it exists), associated metrics and its children.
- removingReplicas() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
-
The brokers that we are removing this partition from as part of a reassignment.
- renewDelegationToken(byte[]) - Method in interface org.apache.kafka.clients.admin.Admin
-
Renew a Delegation Token.
- renewDelegationToken(byte[], RenewDelegationTokenOptions) - Method in interface org.apache.kafka.clients.admin.Admin
-
Renew a Delegation Token.
- renewDelegationToken(byte[], RenewDelegationTokenOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- RenewDelegationTokenOptions - Class in org.apache.kafka.clients.admin
-
- RenewDelegationTokenOptions() - Constructor for class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
-
- RenewDelegationTokenResult - Class in org.apache.kafka.clients.admin
-
- renewers(List<KafkaPrincipal>) - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
-
- renewers() - Method in class org.apache.kafka.clients.admin.CreateDelegationTokenOptions
-
- renewers() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- renewersAsString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- renewTimePeriodMs(long) - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
-
- renewTimePeriodMs() - Method in class org.apache.kafka.clients.admin.RenewDelegationTokenOptions
-
- ReplicaInfo - Class in org.apache.kafka.clients.admin
-
A description of a replica on a particular broker.
- ReplicaInfo(long, long, boolean) - Constructor for class org.apache.kafka.clients.admin.ReplicaInfo
-
- replicaInfos() - Method in class org.apache.kafka.clients.admin.LogDirDescription
-
A map from topic partition to replica information for that partition
in this log directory.
- ReplicaNotAvailableException - Exception in org.apache.kafka.common.errors
-
The replica is not available for the requested topic partition.
- ReplicaNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
-
- ReplicaNotAvailableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
-
- ReplicaNotAvailableException(Throwable) - Constructor for exception org.apache.kafka.common.errors.ReplicaNotAvailableException
-
- replicas() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
-
The brokers which this partition currently resides on.
- replicas() - Method in class org.apache.kafka.clients.admin.PartitionResult
-
- replicas() - Method in class org.apache.kafka.common.PartitionInfo
-
The complete set of replicas for this partition regardless of whether they are alive or up-to-date
- replicas() - Method in class org.apache.kafka.common.TopicPartitionInfo
-
Return the replicas of the partition in the same order as the replica assignment.
- replicasAssignments() - Method in class org.apache.kafka.clients.admin.NewTopic
-
A map from partition id to replica ids (i.e.
- replicasAssignments() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Return a map from partition id to replica (broker) ids or null if numPartitions and replicationFactor are
set instead.
- replicaStatus(Set<TopicPartition>, ReplicaStatusOptions) - Method in interface org.apache.kafka.clients.admin.ConfluentAdmin
-
Retrieves the status of the replicas for a set of partitions, including observers.
- replicaStatus(Set<TopicPartition>, ReplicaStatusOptions) - Method in class org.apache.kafka.clients.admin.KafkaAdminClient
-
- ReplicaStatusOptions - Class in org.apache.kafka.clients.admin
-
- ReplicaStatusOptions() - Constructor for class org.apache.kafka.clients.admin.ReplicaStatusOptions
-
- ReplicaStatusResult - Class in org.apache.kafka.clients.admin
-
- ReplicaStatusResult(Map<TopicPartition, KafkaFuture<PartitionResult>>) - Constructor for class org.apache.kafka.clients.admin.ReplicaStatusResult
-
- replicationFactor(String) - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
-
Returns a future that provides replication factor for the topic when the request completes.
- replicationFactor() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
-
- replicationFactor() - Method in class org.apache.kafka.clients.admin.NewTopic
-
The replication factor for the new topic or -1 if a replica assignment has been specified.
- replicationFactor() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Return the number of replicas to create or null if replicaAssignments is not null.
- reporters() - Method in class org.apache.kafka.common.metrics.Metrics
-
- REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
request.timeout.ms
- REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
request.timeout.ms
- REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
request.timeout.ms
- RequestMetadata(ConfigResource, Map<String, String>) - Constructor for class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
-
Create an instance of this class with the provided parameters.
- RequestMetadata(ConfigResource, Map<String, String>, KafkaPrincipal) - Constructor for class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
-
Confluent constructor for propagating principal to policy until KIP-201 is implemented
- RequestMetadata(String, Integer, Short, Map<Integer, List<Integer>>, Map<String, String>) - Constructor for class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Create an instance of this class with the provided parameters.
- requestType() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
16-bit API key of the request from the request header.
- requestVersion() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns the request version from the request header.
- reset(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
-
- resetShouldRebalance() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- resource() - Method in exception org.apache.kafka.common.errors.DuplicateResourceException
-
- resource() - Method in exception org.apache.kafka.common.errors.ResourceNotFoundException
-
- Resource - Class in org.apache.kafka.common.resource
-
Represents a cluster resource with a tuple of (type, name).
- Resource(ResourceType, String) - Constructor for class org.apache.kafka.common.resource.Resource
-
Create an instance of this class with the provided parameters.
- resource() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
-
- ResourceNotFoundException - Exception in org.apache.kafka.common.errors
-
Exception thrown due to a request for a resource that does not exist.
- ResourceNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.ResourceNotFoundException
-
Constructor
- ResourceNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ResourceNotFoundException
-
- ResourceNotFoundException(String, String) - Constructor for exception org.apache.kafka.common.errors.ResourceNotFoundException
-
Constructor
- ResourceNotFoundException(String, String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ResourceNotFoundException
-
Constructor
- ResourcePattern - Class in org.apache.kafka.common.resource
-
Represents a pattern that is used by ACLs to match zero or more
Resources
.
- ResourcePattern(ResourceType, String, PatternType) - Constructor for class org.apache.kafka.common.resource.ResourcePattern
-
Create a pattern using the supplied parameters.
- resourcePattern() - Method in class org.apache.kafka.server.authorizer.Action
-
- ResourcePatternFilter - Class in org.apache.kafka.common.resource
-
- ResourcePatternFilter(ResourceType, String, PatternType) - Constructor for class org.apache.kafka.common.resource.ResourcePatternFilter
-
Create a filter using the supplied parameters.
- resourceReferenceCount() - Method in class org.apache.kafka.server.authorizer.Action
-
Number of times the resource being authorized is referenced within the request.
- resourceType() - Method in class org.apache.kafka.common.resource.Resource
-
Return the resource type.
- resourceType() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- resourceType() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- ResourceType - Enum in org.apache.kafka.common.resource
-
Represents a type of resource which an ACL can be applied to.
- result() - Method in class org.apache.kafka.clients.admin.AlterBrokerReplicaExclusionsResult
-
- result() - Method in class org.apache.kafka.clients.admin.CreateClusterLinksResult
-
Returns a map from link name to the future status of the operation.
- result() - Method in class org.apache.kafka.clients.admin.DeleteClusterLinksResult
-
Returns a map from link name to the future status of the operation.
- result() - Method in class org.apache.kafka.clients.admin.DescribeMirrorsResult
-
Returns a map from topic to its mirror topic description.
- result() - Method in class org.apache.kafka.clients.admin.ListClusterLinksResult
-
Returns a future collection of cluster links.
- result() - Method in class org.apache.kafka.clients.admin.ListMirrorsResult
-
A list of the mirrored topics.
- result() - Method in class org.apache.kafka.clients.admin.ReplicaStatusResult
-
Returns a map from topic and partition to the status of each of its replicas.
- resume(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- resume(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
- resume(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- RETENTION_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- RETENTION_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- RETENTION_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- RETENTION_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- RetriableCommitFailedException - Exception in org.apache.kafka.clients.consumer
-
- RetriableCommitFailedException(Throwable) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
-
- RetriableCommitFailedException(String) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
-
- RetriableCommitFailedException(String, Throwable) - Constructor for exception org.apache.kafka.clients.consumer.RetriableCommitFailedException
-
- RetriableException - Exception in org.apache.kafka.common.errors
-
A retriable exception is a transient exception that if retried may succeed.
- RetriableException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.RetriableException
-
- RetriableException(String) - Constructor for exception org.apache.kafka.common.errors.RetriableException
-
- RetriableException(Throwable) - Constructor for exception org.apache.kafka.common.errors.RetriableException
-
- RetriableException() - Constructor for exception org.apache.kafka.common.errors.RetriableException
-
- RETRIES_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- RETRIES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
retries
- RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
retry.backoff.ms
- RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
retry.backoff.ms
- RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
retry.backoff.ms
- retryOnQuotaViolation(boolean) - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
-
Set to true if quota violation should be automatically retried.
- retryOnQuotaViolation(boolean) - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
-
Set to true if quota violation should be automatically retried.
- retryOnQuotaViolation(boolean) - Method in class org.apache.kafka.clients.admin.DeleteTopicsOptions
-
Set to true if quota violation should be automatically retried.
- ROUNDROBIN_ASSIGNOR_NAME - Static variable in class org.apache.kafka.clients.consumer.RoundRobinAssignor
-
- RoundRobinAssignor - Class in org.apache.kafka.clients.consumer
-
The round robin assignor lays out all the available partitions and all the available consumers.
- RoundRobinAssignor() - Constructor for class org.apache.kafka.clients.consumer.RoundRobinAssignor
-
- RoundRobinPartitioner - Class in org.apache.kafka.clients.producer
-
The "Round-Robin" partitioner
This partitioning strategy can be used when user wants
to distribute the writes to all partitions equally.
- RoundRobinPartitioner() - Constructor for class org.apache.kafka.clients.producer.RoundRobinPartitioner
-
- salt() - Method in class org.apache.kafka.clients.admin.UserScramCredentialUpsertion
-
- salt() - Method in class org.apache.kafka.common.security.scram.ScramCredential
-
Returns the salt used to process this credential using the SCRAM algorithm.
- Sample(double, long) - Constructor for class org.apache.kafka.common.metrics.stats.SampledStat.Sample
-
- SampledStat - Class in org.apache.kafka.common.metrics.stats
-
A SampledStat records a single scalar value measured over one or more samples.
- SampledStat(double) - Constructor for class org.apache.kafka.common.metrics.stats.SampledStat
-
- SampledStat.Sample - Class in org.apache.kafka.common.metrics.stats
-
- samples() - Method in class org.apache.kafka.common.metrics.MetricConfig
-
- samples(int) - Method in class org.apache.kafka.common.metrics.MetricConfig
-
- samples - Variable in class org.apache.kafka.common.metrics.stats.SampledStat
-
- SASL_CLIENT_CALLBACK_HANDLER_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_CLIENT_CALLBACK_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_JAAS_CONFIG - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_JAAS_CONFIG_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_KINIT_CMD - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_KINIT_CMD_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_MIN_TIME_BEFORE_RELOGIN - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_MIN_TIME_BEFORE_RELOGIN_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_SERVICE_NAME - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_SERVICE_NAME_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_TICKET_RENEW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_TICKET_RENEW_JITTER_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_TICKET_RENEW_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_KERBEROS_TICKET_RENEW_WINDOW_FACTOR_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_CALLBACK_HANDLER_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_CALLBACK_HANDLER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_CLASS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_BUFFER_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_BUFFER_SECONDS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_MIN_PERIOD_SECONDS - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_MIN_PERIOD_SECONDS_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_WINDOW_FACTOR - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_WINDOW_FACTOR_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_WINDOW_JITTER - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_LOGIN_REFRESH_WINDOW_JITTER_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SASL_MECHANISM - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
SASL mechanism configuration - standard mechanism names are listed
here.
- SASL_MECHANISM_DOC - Static variable in class org.apache.kafka.common.config.SaslConfigs
-
- SaslAuthenticationContext - Class in org.apache.kafka.common.security.auth
-
- SaslAuthenticationContext(SaslServer, SecurityProtocol, InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.SaslAuthenticationContext
-
- SaslAuthenticationContext(SaslServer, SecurityProtocol, InetAddress, String, Optional<SSLSession>) - Constructor for class org.apache.kafka.common.security.auth.SaslAuthenticationContext
-
- SaslAuthenticationException - Exception in org.apache.kafka.common.errors
-
This exception indicates that SASL authentication has failed.
- SaslAuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.SaslAuthenticationException
-
- SaslAuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SaslAuthenticationException
-
- SaslAuthenticationException(String, Throwable, AuthenticationErrorInfo) - Constructor for exception org.apache.kafka.common.errors.SaslAuthenticationException
-
- SaslAuthenticationException(String, AuthenticationErrorInfo) - Constructor for exception org.apache.kafka.common.errors.SaslAuthenticationException
-
- SaslConfigs - Class in org.apache.kafka.common.config
-
- SaslConfigs() - Constructor for class org.apache.kafka.common.config.SaslConfigs
-
- SaslExtensions - Class in org.apache.kafka.common.security.auth
-
A simple immutable value object class holding customizable SASL extensions
- SaslExtensions(Map<String, String>) - Constructor for class org.apache.kafka.common.security.auth.SaslExtensions
-
- SaslExtensionsCallback - Class in org.apache.kafka.common.security.auth
-
Optional callback used for SASL mechanisms if any extensions need to be set
in the SASL exchange.
- SaslExtensionsCallback() - Constructor for class org.apache.kafka.common.security.auth.SaslExtensionsCallback
-
- scheduleNopPollTask() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- schedulePollTask(Runnable) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
Schedule a task to be executed during a poll().
- scope() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
-
- ScramCredential - Class in org.apache.kafka.common.security.scram
-
SCRAM credential class that encapsulates the credential data persisted for each user that is
accessible to the server.
- ScramCredential(byte[], byte[], byte[], int) - Constructor for class org.apache.kafka.common.security.scram.ScramCredential
-
Constructs a new credential.
- scramCredential(ScramCredential) - Method in class org.apache.kafka.common.security.scram.ScramCredentialCallback
-
Sets the SCRAM credential for this instance.
- scramCredential() - Method in class org.apache.kafka.common.security.scram.ScramCredentialCallback
-
Returns the SCRAM credential if set on this instance.
- ScramCredentialCallback - Class in org.apache.kafka.common.security.scram
-
Callback used for SCRAM mechanisms.
- ScramCredentialCallback() - Constructor for class org.apache.kafka.common.security.scram.ScramCredentialCallback
-
- ScramCredentialInfo - Class in org.apache.kafka.clients.admin
-
Mechanism and iterations for a SASL/SCRAM credential associated with a user.
- ScramCredentialInfo(ScramMechanism, int) - Constructor for class org.apache.kafka.clients.admin.ScramCredentialInfo
-
- ScramExtensionsCallback - Class in org.apache.kafka.common.security.scram
-
Optional callback used for SCRAM mechanisms if any extensions need to be set
in the SASL/SCRAM exchange.
- ScramExtensionsCallback() - Constructor for class org.apache.kafka.common.security.scram.ScramExtensionsCallback
-
- ScramLoginModule - Class in org.apache.kafka.common.security.scram
-
- ScramLoginModule() - Constructor for class org.apache.kafka.common.security.scram.ScramLoginModule
-
- ScramMechanism - Enum in org.apache.kafka.clients.admin
-
Representation of a SASL/SCRAM Mechanism.
- SECURITY_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
security.providers
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
security.providers
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
security.providers
- SECURITY_PROVIDERS_CONFIG - Static variable in class org.apache.kafka.common.config.SecurityConfig
-
- SECURITY_PROVIDERS_DOC - Static variable in class org.apache.kafka.common.config.SecurityConfig
-
- SecurityConfig - Class in org.apache.kafka.common.config
-
Contains the common security config for SSL and SASL
- SecurityConfig() - Constructor for class org.apache.kafka.common.config.SecurityConfig
-
- SecurityDisabledException - Exception in org.apache.kafka.common.errors
-
An error indicating that security is disabled on the broker.
- SecurityDisabledException(String) - Constructor for exception org.apache.kafka.common.errors.SecurityDisabledException
-
- SecurityDisabledException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SecurityDisabledException
-
- securityProtocol() - Method in class org.apache.kafka.common.Endpoint
-
Returns the security protocol of this endpoint.
- securityProtocol() - Method in interface org.apache.kafka.common.security.auth.AuthenticationContext
-
Underlying security protocol of the authentication session.
- securityProtocol() - Method in class org.apache.kafka.common.security.auth.PlaintextAuthenticationContext
-
- securityProtocol() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
-
- SecurityProtocol - Enum in org.apache.kafka.common.security.auth
-
- securityProtocol() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
-
- securityProtocol() - Method in interface org.apache.kafka.server.authorizer.AuthorizableRequestContext
-
Returns the security protocol for the listener on which request was received.
- SecurityProviderCreator - Interface in org.apache.kafka.common.security.auth
-
An interface for generating security providers.
- seek(TopicPartition, long) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- seek(TopicPartition, OffsetAndMetadata) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- seek(TopicPartition, long) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Overrides the fetch offsets that the consumer will use on the next
poll(timeout)
.
- seek(TopicPartition, OffsetAndMetadata) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Overrides the fetch offsets that the consumer will use on the next
poll(timeout)
.
- seek(TopicPartition, long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- seek(TopicPartition, OffsetAndMetadata) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- seekToBeginning(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- seekToBeginning(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Seek to the first offset for each of the given partitions.
- seekToBeginning(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- seekToEnd(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- seekToEnd(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Seek to the last offset for each of the given partitions.
- seekToEnd(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- SEGMENT_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_INDEX_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_INDEX_BYTES_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_JITTER_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_JITTER_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_MS_CONFIG - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_MS_DOC - Static variable in class org.apache.kafka.common.config.TopicConfig
-
- SEGMENT_SPECULATIVE_PREFETCH_ENABLE_CONFIG - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- SEGMENT_SPECULATIVE_PREFETCH_ENABLE_DOC - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- send(ProducerRecord<K, V>) - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Asynchronously send a record to a topic.
- send(ProducerRecord<K, V>, Callback) - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Asynchronously send a record to a topic and invoke the provided callback when the send has been acknowledged.
- send(ProducerRecord<K, V>) - Method in class org.apache.kafka.clients.producer.MockProducer
-
Adds the record to the list of sent records.
- send(ProducerRecord<K, V>, Callback) - Method in class org.apache.kafka.clients.producer.MockProducer
-
Adds the record to the list of sent records.
- send(ProducerRecord<K, V>) - Method in interface org.apache.kafka.clients.producer.Producer
-
- send(ProducerRecord<K, V>, Callback) - Method in interface org.apache.kafka.clients.producer.Producer
-
- SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
- SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
send.buffer.bytes
- SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
send.buffer.bytes
- sendException - Variable in class org.apache.kafka.clients.producer.MockProducer
-
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.apache.kafka.clients.producer.KafkaProducer
-
Sends a list of specified offsets to the consumer group coordinator, and also marks
those offsets as part of the current transaction.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.apache.kafka.clients.producer.MockProducer
-
Deprecated.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in class org.apache.kafka.clients.producer.MockProducer
-
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in interface org.apache.kafka.clients.producer.Producer
-
Deprecated.
- sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, ConsumerGroupMetadata) - Method in interface org.apache.kafka.clients.producer.Producer
-
- sendOffsetsToTransactionException - Variable in class org.apache.kafka.clients.producer.MockProducer
-
- sensor(String) - Method in class org.apache.kafka.common.metrics.Metrics
-
Get or create a sensor with the given unique name and no parent sensors.
- sensor(String, Sensor.RecordingLevel) - Method in class org.apache.kafka.common.metrics.Metrics
-
Get or create a sensor with the given unique name and no parent sensors and with a given
recording level.
- sensor(String, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
-
Get or create a sensor with the given unique name and zero or more parent sensors.
- sensor(String, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
-
Get or create a sensor with the given unique name and zero or more parent sensors.
- sensor(String, MetricConfig, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
-
Get or create a sensor with the given unique name and zero or more parent sensors.
- sensor(String, MetricConfig, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
-
Get or create a sensor with the given unique name and zero or more parent sensors.
- sensor(String, MetricConfig, long, Sensor.RecordingLevel, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
-
Get or create a sensor with the given unique name and zero or more parent sensors.
- sensor(String, MetricConfig, long, Sensor...) - Method in class org.apache.kafka.common.metrics.Metrics
-
Get or create a sensor with the given unique name and zero or more parent sensors.
- Sensor - Class in org.apache.kafka.common.metrics
-
A sensor applies a continuous sequence of numerical values to a set of associated metrics.
- Sensor.RecordingLevel - Enum in org.apache.kafka.common.metrics
-
- sentOffsets() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- Serde<T> - Interface in org.apache.kafka.common.serialization
-
The interface for wrapping a serializer and deserializer for the given data type.
- serdeFrom(Class<T>) - Static method in class org.apache.kafka.common.serialization.Serdes
-
- serdeFrom(Serializer<T>, Deserializer<T>) - Static method in class org.apache.kafka.common.serialization.Serdes
-
Construct a serde object from separate serializer and deserializer
- Serdes - Class in org.apache.kafka.common.serialization
-
Factory for creating serializers / deserializers.
- Serdes() - Constructor for class org.apache.kafka.common.serialization.Serdes
-
- Serdes.ByteArraySerde - Class in org.apache.kafka.common.serialization
-
- Serdes.ByteBufferSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.BytesSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.DoubleSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.FloatSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.IntegerSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.ListSerde<Inner> - Class in org.apache.kafka.common.serialization
-
- Serdes.LongSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.ShortSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.StringSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.UUIDSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.VoidSerde - Class in org.apache.kafka.common.serialization
-
- Serdes.WrapperSerde<T> - Class in org.apache.kafka.common.serialization
-
- SerializationException - Exception in org.apache.kafka.common.errors
-
Any exception during serialization in the producer
- SerializationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SerializationException
-
- SerializationException(String) - Constructor for exception org.apache.kafka.common.errors.SerializationException
-
- SerializationException(Throwable) - Constructor for exception org.apache.kafka.common.errors.SerializationException
-
- SerializationException() - Constructor for exception org.apache.kafka.common.errors.SerializationException
-
- serialize(KafkaPrincipal) - Method in interface org.apache.kafka.common.security.auth.KafkaPrincipalSerde
-
- serialize(String, byte[]) - Method in class org.apache.kafka.common.serialization.ByteArraySerializer
-
- serialize(String, ByteBuffer) - Method in class org.apache.kafka.common.serialization.ByteBufferSerializer
-
- serialize(String, Bytes) - Method in class org.apache.kafka.common.serialization.BytesSerializer
-
- serialize(String, Double) - Method in class org.apache.kafka.common.serialization.DoubleSerializer
-
- serialize(String, Float) - Method in class org.apache.kafka.common.serialization.FloatSerializer
-
- serialize(String, Integer) - Method in class org.apache.kafka.common.serialization.IntegerSerializer
-
- serialize(String, List<Inner>) - Method in class org.apache.kafka.common.serialization.ListSerializer
-
- serialize(String, Long) - Method in class org.apache.kafka.common.serialization.LongSerializer
-
- serialize(String, T) - Method in interface org.apache.kafka.common.serialization.Serializer
-
Convert data
into a byte array.
- serialize(String, Headers, T) - Method in interface org.apache.kafka.common.serialization.Serializer
-
Convert data
into a byte array.
- serialize(String, Short) - Method in class org.apache.kafka.common.serialization.ShortSerializer
-
- serialize(String, String) - Method in class org.apache.kafka.common.serialization.StringSerializer
-
- serialize(String, UUID) - Method in class org.apache.kafka.common.serialization.UUIDSerializer
-
- serialize(String, Void) - Method in class org.apache.kafka.common.serialization.VoidSerializer
-
- serializedKeySize() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The size of the serialized, uncompressed key in bytes.
- serializedKeySize() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The size of the serialized, uncompressed key in bytes.
- serializedValueSize() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The size of the serialized, uncompressed value in bytes.
- serializedValueSize() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The size of the serialized, uncompressed value in bytes.
- serializer() - Method in interface org.apache.kafka.common.serialization.Serde
-
- serializer() - Method in class org.apache.kafka.common.serialization.Serdes.WrapperSerde
-
- Serializer<T> - Interface in org.apache.kafka.common.serialization
-
An interface for converting objects to bytes.
- server() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
-
- serverKey() - Method in class org.apache.kafka.common.security.scram.ScramCredential
-
Server key computed from the client password using the SCRAM algorithm.
- serviceName() - Method in interface org.apache.kafka.common.security.auth.Login
-
Returns the service name to be used for SASL.
- session() - Method in class org.apache.kafka.common.security.auth.SslAuthenticationContext
-
- SESSION_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
session.timeout.ms
- setException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- setExpiryTimestamp(long) - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- setGroupInstanceId(Optional<String>) - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- setMockMetrics(MetricName, Metric) - Method in class org.apache.kafka.clients.producer.MockProducer
-
Set a mock metric for testing purpose
- setOffsetsException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- setPollException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- setPositionException(KafkaException) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- Short() - Static method in class org.apache.kafka.common.serialization.Serdes
-
A serde for nullable Short
type.
- ShortDeserializer - Class in org.apache.kafka.common.serialization
-
- ShortDeserializer() - Constructor for class org.apache.kafka.common.serialization.ShortDeserializer
-
- ShortSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.ShortSerde
-
- ShortSerializer - Class in org.apache.kafka.common.serialization
-
- ShortSerializer() - Constructor for class org.apache.kafka.common.serialization.ShortSerializer
-
- shouldBeRebuilt(Map<String, Object>) - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
-
Returns true if SSLEngine
needs to be rebuilt.
- shouldListInternal() - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
-
Return true if we should list internal topics.
- shouldRebalance() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- shouldRecord(int) - Method in enum org.apache.kafka.common.metrics.Sensor.RecordingLevel
-
- shouldRecord() - Method in class org.apache.kafka.common.metrics.Sensor
-
- shouldRetryOnQuotaViolation() - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
-
Returns true if quota violation should be automatically retried.
- shouldRetryOnQuotaViolation() - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
-
Returns true if quota violation should be automatically retried.
- shouldRetryOnQuotaViolation() - Method in class org.apache.kafka.clients.admin.DeleteTopicsOptions
-
Returns true if quota violation should be automatically retried.
- shouldShutdownBrokers - Variable in class org.apache.kafka.clients.admin.RemoveBrokersOptions
-
- shouldShutdownBrokers() - Method in class org.apache.kafka.clients.admin.RemoveBrokersOptions
-
Returns whether the broker removal operation should shut down the removed brokers at the end
of the process.
- shouldShutdownBrokers(boolean) - Method in class org.apache.kafka.clients.admin.RemoveBrokersOptions
-
Sets whether the broker removal operation should shut down the removed brokers at the end
of the process.
- shouldValidateOnly() - Method in class org.apache.kafka.clients.admin.AlterConfigsOptions
-
Return true if the request should be validated without altering the configs.
- shouldValidateOnly() - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
-
Return true if the request should be validated without creating the topic.
- shutdownStatus() - Method in class org.apache.kafka.clients.admin.BrokerRemovalDescription
-
The status of the broker shutdown subtask of the broker removal operation.
- SimpleRate - Class in org.apache.kafka.common.metrics.stats
-
A simple rate the rate is incrementally calculated
based on the elapsed time between the earliest reading
and now.
- SimpleRate() - Constructor for class org.apache.kafka.common.metrics.stats.SimpleRate
-
- size() - Method in class org.apache.kafka.clients.admin.ReplicaInfo
-
The total size of the log segments in this replica in bytes.
- SnapshotNotFoundException - Exception in org.apache.kafka.common.errors
-
- SnapshotNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.SnapshotNotFoundException
-
- SnapshotNotFoundException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SnapshotNotFoundException
-
- SOCKET_CONNECTION_SETUP_TIMEOUT_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
socket.connection.setup.timeout.max.ms
- SOCKET_CONNECTION_SETUP_TIMEOUT_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
socket.connection.setup.timeout.max.ms
- SOCKET_CONNECTION_SETUP_TIMEOUT_MAX_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
socket.connection.setup.timeout.max.ms
- SOCKET_CONNECTION_SETUP_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.admin.AdminClientConfig
-
socket.connection.setup.timeout.ms
- SOCKET_CONNECTION_SETUP_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
socket.connection.setup.timeout.ms
- SOCKET_CONNECTION_SETUP_TIMEOUT_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
socket.connection.setup.timeout.ms
- source() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
-
Returns the source of this configuration.
- source() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Return the source of this configuration entry.
- SSL_CIPHER_SUITES_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_CIPHER_SUITES_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENABLED_PROTOCOLS_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENABLED_PROTOCOLS_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENDPOINT_IDENTIFICATION_ALGORITHM_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENGINE_BUILDER_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENGINE_FACTORY_CLASS_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_ENGINE_FACTORY_CLASS_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEY_PASSWORD_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEY_PASSWORD_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYMANAGER_ALGORITHM_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYMANAGER_ALGORITHM_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_CERTIFICATE_CHAIN_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_CERTIFICATE_CHAIN_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_KEY_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_KEY_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_LOCATION_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_LOCATION_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_PASSWORD_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_PASSWORD_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_KEYSTORE_TYPE_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_PROTOCOL_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_PROTOCOL_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_PROVIDER_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_PROVIDER_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_SECURE_RANDOM_IMPLEMENTATION_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_SECURE_RANDOM_IMPLEMENTATION_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTMANAGER_ALGORITHM_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTMANAGER_ALGORITHM_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_CERTIFICATES_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_CERTIFICATES_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_LOCATION_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_LOCATION_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_PASSWORD_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_PASSWORD_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_TYPE_CONFIG - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SSL_TRUSTSTORE_TYPE_DOC - Static variable in class org.apache.kafka.common.config.SslConfigs
-
- SslAuthenticationContext - Class in org.apache.kafka.common.security.auth
-
- SslAuthenticationContext(SSLSession, InetAddress, String) - Constructor for class org.apache.kafka.common.security.auth.SslAuthenticationContext
-
- SslAuthenticationException - Exception in org.apache.kafka.common.errors
-
This exception indicates that SSL handshake has failed.
- SslAuthenticationException(String) - Constructor for exception org.apache.kafka.common.errors.SslAuthenticationException
-
- SslAuthenticationException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.SslAuthenticationException
-
- SslAuthenticationException(String, AuthenticationErrorInfo) - Constructor for exception org.apache.kafka.common.errors.SslAuthenticationException
-
- SslAuthenticationException(String, Throwable, AuthenticationErrorInfo) - Constructor for exception org.apache.kafka.common.errors.SslAuthenticationException
-
- SslClientAuth - Enum in org.apache.kafka.common.config
-
Describes whether the server should require or request client authentication.
- SslConfigs - Class in org.apache.kafka.common.config
-
- SslConfigs() - Constructor for class org.apache.kafka.common.config.SslConfigs
-
- SslEngineFactory - Interface in org.apache.kafka.common.security.auth
-
Plugin interface for allowing creation of SSLEngine
object in a custom way.
- sslSession() - Method in class org.apache.kafka.common.security.auth.SaslAuthenticationContext
-
Returns SSL session for the connection if security protocol is SASL_SSL.
- StaleBrokerEpochException - Exception in org.apache.kafka.common.errors
-
- StaleBrokerEpochException(String) - Constructor for exception org.apache.kafka.common.errors.StaleBrokerEpochException
-
- StaleBrokerEpochException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.StaleBrokerEpochException
-
- start(AuthorizerServerInfo) - Method in interface org.apache.kafka.server.authorizer.Authorizer
-
Starts loading authorization metadata and returns futures that can be used to wait until
metadata for authorizing requests on each listener is available.
- startTimeMs() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
-
When the credential became valid, in terms of the number of milliseconds
since the epoch, if known, otherwise null.
- stat() - Method in class org.apache.kafka.common.metrics.CompoundStat.NamedMeasurable
-
- Stat - Interface in org.apache.kafka.common.metrics
-
A Stat is a quantity such as average, max, etc that is computed off the stream of updates to a sensor
- stat - Variable in class org.apache.kafka.common.metrics.stats.Rate
-
- state() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
The consumer group state, or UNKNOWN if the state is too new for us to parse.
- state() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
-
Consumer Group state
- state() - Method in class org.apache.kafka.clients.admin.MirrorTopicDescription
-
The current state of topic mirroring.
- state() - Method in class org.apache.kafka.clients.admin.TransactionDescription
-
- state() - Method in class org.apache.kafka.clients.admin.TransactionListing
-
- states() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsOptions
-
Returns the list of States that are requested or empty if no states have been specified
- stateTimeMs() - Method in class org.apache.kafka.clients.admin.MirrorTopicDescription
-
The time, in milliseconds from epoch, when the last state transition happened.
- stats() - Method in interface org.apache.kafka.common.metrics.CompoundStat
-
- stats() - Method in class org.apache.kafka.common.metrics.Sensor
-
- stats() - Method in class org.apache.kafka.common.metrics.stats.Frequencies
-
- stats() - Method in class org.apache.kafka.common.metrics.stats.Meter
-
- stats() - Method in class org.apache.kafka.common.metrics.stats.Percentiles
-
- STICKY_ASSIGNOR_NAME - Static variable in class org.apache.kafka.clients.consumer.StickyAssignor
-
- StickyAssignor - Class in org.apache.kafka.clients.consumer
-
The sticky assignor serves two purposes.
- StickyAssignor() - Constructor for class org.apache.kafka.clients.consumer.StickyAssignor
-
- stoppedLogEndOffsets() - Method in class org.apache.kafka.clients.admin.MirrorTopicDescription
-
The set of log end offsets when the mirror topic is stopped in the ascending order of the
partition ids.
- storedKey() - Method in class org.apache.kafka.common.security.scram.ScramCredential
-
Stored key computed from the client password using the SCRAM algorithm.
- strict() - Method in class org.apache.kafka.common.quota.ClientQuotaFilter
-
- String() - Static method in class org.apache.kafka.common.serialization.Serdes
-
A serde for nullable String
type.
- StringDeserializer - Class in org.apache.kafka.common.serialization
-
String encoding defaults to UTF8 and can be customized by setting the property key.deserializer.encoding,
value.deserializer.encoding or deserializer.encoding.
- StringDeserializer() - Constructor for class org.apache.kafka.common.serialization.StringDeserializer
-
- StringSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.StringSerde
-
- StringSerializer - Class in org.apache.kafka.common.serialization
-
String encoding defaults to UTF8 and can be customized by setting the property key.serializer.encoding,
value.serializer.encoding or serializer.encoding.
- StringSerializer() - Constructor for class org.apache.kafka.common.serialization.StringSerializer
-
- subject() - Method in interface org.apache.kafka.common.security.auth.Login
-
Returns the authenticated subject of this login context.
- subscribe(Collection<String>) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- subscribe(Collection<String>, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- subscribe(Pattern, ConsumerRebalanceListener) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- subscribe(Pattern) - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Subscribe to the given list of topics to get dynamically
assigned partitions.
- subscribe(Collection<String>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Subscribe to the given list of topics to get dynamically assigned partitions.
- subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
- subscribe(Pattern) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Subscribe to all topics matching specified pattern to get dynamically assigned partitions.
- subscribe(Collection<String>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- subscribe(Pattern) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- subscribe(String, Set<String>, ConfigChangeCallback) - Method in interface org.apache.kafka.common.config.provider.ConfigProvider
-
Subscribes to changes for the given keys at the given path (optional operation).
- subscription() - Method in interface org.apache.kafka.clients.consumer.Consumer
-
- Subscription(List<String>, ByteBuffer, List<TopicPartition>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- Subscription(List<String>, ByteBuffer) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- Subscription(List<String>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- subscription() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
-
Get the current subscription.
- subscription() - Method in class org.apache.kafka.clients.consumer.MockConsumer
-
- subscriptionUserData(Set<String>) - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
- subscriptionUserData(Set<String>) - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
-
- subscriptionUserData(Set<String>) - Method in class org.apache.kafka.clients.consumer.StickyAssignor
-
- SUCCESS - Static variable in class org.apache.kafka.server.authorizer.AclCreateResult
-
- supportedFeatures() - Method in class org.apache.kafka.clients.admin.FeatureMetadata
-
Returns a map of supported feature versions.
- supportedProtocols() - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
- supportedProtocols() - Method in class org.apache.kafka.clients.consumer.CooperativeStickyAssignor
-
- SupportedVersionRange - Class in org.apache.kafka.clients.admin
-
Represents a range of versions that a particular broker supports for some feature.
- synonyms() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Returns all config values that may be used as the value of this config along with their source,
in the order of precedence.
- tags() - Method in class org.apache.kafka.common.ConfluentNode
-
The tags of this node
- tags(Node) - Static method in class org.apache.kafka.common.ConfluentNode
-
Returns the tags if the node is a ConfluentNode or an empty map if not.
- tags() - Method in class org.apache.kafka.common.MetricName
-
- tags() - Method in class org.apache.kafka.common.MetricNameTemplate
-
Get the set of tag names for the metric.
- tags() - Method in class org.apache.kafka.common.metrics.MetricConfig
-
- tags(Map<String, String>) - Method in class org.apache.kafka.common.metrics.MetricConfig
-
- targetObservers() - Method in class org.apache.kafka.clients.admin.NewPartitionReassignment
-
- targetReplicas() - Method in class org.apache.kafka.clients.admin.NewPartitionReassignment
-
- thenApply(KafkaFuture.BaseFunction<T, R>) - Method in class org.apache.kafka.common.KafkaFuture
-
Returns a new KafkaFuture that, when this future completes normally, is executed with this
futures's result as the argument to the supplied function.
- thenApply(KafkaFuture.Function<T, R>) - Method in class org.apache.kafka.common.KafkaFuture
-
- throttleTimeMs() - Method in exception org.apache.kafka.common.errors.ThrottlingQuotaExceededException
-
- ThrottlingQuotaExceededException - Exception in org.apache.kafka.common.errors
-
Exception thrown if an operation on a resource exceeds the throttling quota.
- ThrottlingQuotaExceededException(String) - Constructor for exception org.apache.kafka.common.errors.ThrottlingQuotaExceededException
-
- ThrottlingQuotaExceededException(int, String) - Constructor for exception org.apache.kafka.common.errors.ThrottlingQuotaExceededException
-
- TIER_ENABLE_CONFIG - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TIER_ENABLE_DOC - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TIER_LOCAL_HOTSET_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TIER_LOCAL_HOTSET_BYTES_DOC - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TIER_LOCAL_HOTSET_MS_CONFIG - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TIER_LOCAL_HOTSET_MS_DOC - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TIER_SEGMENT_HOTSET_ROLL_MIN_BYTES_CONFIG - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TIER_SEGMENT_HOTSET_ROLL_MIN_BYTES_DOC - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TimeoutException - Exception in org.apache.kafka.common.errors
-
Indicates that a request timed out.
- TimeoutException() - Constructor for exception org.apache.kafka.common.errors.TimeoutException
-
- TimeoutException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
-
- TimeoutException(String) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
-
- TimeoutException(Throwable) - Constructor for exception org.apache.kafka.common.errors.TimeoutException
-
- timeoutMs - Variable in class org.apache.kafka.clients.admin.AbstractOptions
-
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.AbstractOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs() - Method in class org.apache.kafka.clients.admin.AbstractOptions
-
The timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.AlterConfigsOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.CreateAclsOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DeleteAclsOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DeleteTopicsOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeAclsOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeClusterOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeConfigsOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.DescribeTopicsOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timeoutMs(Integer) - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
-
Set the timeout in milliseconds for this operation or null
if the default api timeout for the
AdminClient should be used.
- timestamp() - Method in class org.apache.kafka.clients.admin.ListOffsetsResult.ListOffsetsResultInfo
-
- timestamp() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The timestamp of this record
- timestamp() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
- timestamp() - Method in class org.apache.kafka.clients.producer.ProducerRecord
-
- timestamp() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The timestamp of the record in the topic/partition.
- timestampType() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The timestamp type of this record
- timeWindow(long, TimeUnit) - Method in class org.apache.kafka.common.metrics.MetricConfig
-
- timeWindowMs() - Method in class org.apache.kafka.common.metrics.MetricConfig
-
- toArray() - Method in interface org.apache.kafka.common.header.Headers
-
Returns all headers as an array, in the order they were added in.
- toBin(double) - Method in interface org.apache.kafka.common.metrics.stats.Histogram.BinScheme
-
Determine the 0-based bin number in which the supplied value should be placed.
- toBin(double) - Method in class org.apache.kafka.common.metrics.stats.Histogram.ConstantBinScheme
-
- toBin(double) - Method in class org.apache.kafka.common.metrics.stats.Histogram.LinearBinScheme
-
- toCompletionStage() - Method in class org.apache.kafka.common.KafkaFuture
-
Gets a CompletionStage
with the same completion properties as this KafkaFuture
.
- toEnrichedRst() - Method in class org.apache.kafka.common.config.ConfigDef
-
Configs with new metadata (group, orderInGroup, dependents) formatted with reStructuredText, suitable for embedding in Sphinx
documentation.
- toEnum(String) - Static method in enum org.apache.kafka.clients.admin.BalancerOperationStatus
-
- toEnum(String) - Static method in enum org.apache.kafka.clients.admin.BalancerStatus
-
- toEnum(String) - Static method in enum org.apache.kafka.clients.admin.BrokerReplicaExclusionStatus
-
- toEnum(String) - Static method in enum org.apache.kafka.clients.admin.BrokerShutdownStatus
-
- toEnum(String) - Static method in enum org.apache.kafka.clients.admin.EvenClusterLoadStatus
-
- toEnum(String) - Static method in enum org.apache.kafka.clients.admin.PartitionReassignmentsStatus
-
- toFilter() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
Create a filter which matches only this AccessControlEntry.
- toFilter() - Method in class org.apache.kafka.common.acl.AclBinding
-
Create a filter which matches only this AclBinding.
- toFilter() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- toHtml() - Method in class org.apache.kafka.common.config.ConfigDef
-
- toHtml(int, Function<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
-
Converts this config into an HTML list that can be embedded into docs.
- toHtml(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
-
Converts this config into an HTML list that can be embedded into docs.
- toHtml(int, Function<String, String>, Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
-
Converts this config into an HTML list that can be embedded into docs.
- toHtmlTable() - Method in class org.apache.kafka.common.config.ConfigDef
-
- toHtmlTable(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
-
Converts this config into an HTML table that can be embedded into docs.
- toHtmlTable(String, Iterable<MetricNameTemplate>) - Static method in class org.apache.kafka.common.metrics.Metrics
-
Use the specified domain and metric name templates to generate an HTML table documenting the metrics.
- token() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
- token() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
-
Return the (potentially null) token
- token(OAuthBearerToken) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerTokenCallback
-
Set the token.
- token() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
-
Return the (potentially null) token
- token(OAuthBearerToken) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
-
Set the token.
- TOKEN_AUTH_CONFIG - Static variable in class org.apache.kafka.common.security.scram.ScramLoginModule
-
- tokenAuthenticated(boolean) - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
-
- tokenAuthenticated() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
-
- TokenBucket - Class in org.apache.kafka.common.metrics.stats
-
- TokenBucket() - Constructor for class org.apache.kafka.common.metrics.stats.TokenBucket
-
- TokenBucket(TimeUnit) - Constructor for class org.apache.kafka.common.metrics.stats.TokenBucket
-
- tokenId() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- tokenInfo() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
-
- TokenInformation - Class in org.apache.kafka.common.security.token.delegation
-
A class representing a delegation token details.
- TokenInformation(String, KafkaPrincipal, Collection<KafkaPrincipal>, long, long, long) - Constructor for class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- tokenValue() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerValidatorCallback
-
Return the (always non-null) token value
- topic() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The topic this record is received from (never null)
- topic() - Method in class org.apache.kafka.clients.producer.ProducerRecord
-
- topic() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
The topic the record was appended to
- topic() - Method in class org.apache.kafka.common.PartitionInfo
-
The topic name
- topic() - Method in class org.apache.kafka.common.TopicPartition
-
- topic() - Method in class org.apache.kafka.common.TopicPartitionReplica
-
- topic() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
Return the name of the topic to create.
- TOPIC_NAME_STRATEGY - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TOPIC_PLACEMENT_CONSTRAINTS_CONFIG - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TOPIC_PLACEMENT_CONSTRAINTS_DOC - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TOPIC_PLACEMENT_CONSTRAINTS_RAW_CONFIG - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- TopicAuthorizationException - Exception in org.apache.kafka.common.errors
-
- TopicAuthorizationException(String, Set<String>) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
-
- TopicAuthorizationException(Set<String>) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
-
- TopicAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.TopicAuthorizationException
-
- TopicCollection - Class in org.apache.kafka.common
-
A class used to represent a collection of topics.
- TopicCollection.TopicIdCollection - Class in org.apache.kafka.common
-
A class used to represent a collection of topics defined by their topic ID.
- TopicCollection.TopicNameCollection - Class in org.apache.kafka.common
-
A class used to represent a collection of topics defined by their topic name.
- TopicConfig - Class in org.apache.kafka.common.config
-
Keys that can be used to configure a topic.
- TopicConfig() - Constructor for class org.apache.kafka.common.config.TopicConfig
-
- TopicDeletionDisabledException - Exception in org.apache.kafka.common.errors
-
- TopicDeletionDisabledException() - Constructor for exception org.apache.kafka.common.errors.TopicDeletionDisabledException
-
- TopicDeletionDisabledException(String) - Constructor for exception org.apache.kafka.common.errors.TopicDeletionDisabledException
-
- TopicDescription - Class in org.apache.kafka.clients.admin
-
A detailed description of a single topic in the cluster.
- TopicDescription(String, boolean, List<TopicPartitionInfo>) - Constructor for class org.apache.kafka.clients.admin.TopicDescription
-
Create an instance with the specified parameters.
- TopicDescription(String, boolean, List<TopicPartitionInfo>, Set<AclOperation>) - Constructor for class org.apache.kafka.clients.admin.TopicDescription
-
Create an instance with the specified parameters.
- TopicDescription(String, boolean, List<TopicPartitionInfo>, Set<AclOperation>, Uuid) - Constructor for class org.apache.kafka.clients.admin.TopicDescription
-
- TopicExistsException - Exception in org.apache.kafka.common.errors
-
- TopicExistsException(String) - Constructor for exception org.apache.kafka.common.errors.TopicExistsException
-
- TopicExistsException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TopicExistsException
-
- topicId(String) - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
-
Returns a future that provides topic ID for the topic when the request completes.
- topicId() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
-
- topicId() - Method in class org.apache.kafka.clients.admin.TopicDescription
-
- topicId(String) - Method in class org.apache.kafka.common.Cluster
-
- topicId() - Method in class org.apache.kafka.common.TopicIdPartition
-
- TopicIdPartition - Class in org.apache.kafka.common
-
This represents universally unique identifier with topic id for a topic partition.
- TopicIdPartition(Uuid, TopicPartition) - Constructor for class org.apache.kafka.common.TopicIdPartition
-
- topicIds() - Method in class org.apache.kafka.common.Cluster
-
- topicIds() - Method in class org.apache.kafka.common.TopicCollection.TopicIdCollection
-
- topicIdValues() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
-
- TopicListing - Class in org.apache.kafka.clients.admin
-
A listing of a topic in the cluster.
- TopicListing(String, boolean) - Constructor for class org.apache.kafka.clients.admin.TopicListing
-
Create an instance with the specified parameters.
- TopicMetadataAndConfig(Uuid, int, int, Config) - Constructor for class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
-
- TopicMetadataAndConfig(ApiException) - Constructor for class org.apache.kafka.clients.admin.CreateTopicsResult.TopicMetadataAndConfig
-
- topicNames() - Method in class org.apache.kafka.common.TopicCollection.TopicNameCollection
-
- topicNameValues() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
-
- topicPartition() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
-
- topicPartition() - Method in exception org.apache.kafka.common.errors.RecordDeserializationException
-
- topicPartition() - Method in class org.apache.kafka.common.TopicIdPartition
-
- TopicPartition - Class in org.apache.kafka.common
-
A topic name and partition number
- TopicPartition(String, int) - Constructor for class org.apache.kafka.common.TopicPartition
-
- TopicPartitionInfo - Class in org.apache.kafka.common
-
A class containing leadership, replicas and ISR information for a topic partition.
- TopicPartitionInfo(int, Node, List<Node>, List<Node>) - Constructor for class org.apache.kafka.common.TopicPartitionInfo
-
Create an instance of this class with the provided parameters.
- TopicPartitionReplica - Class in org.apache.kafka.common
-
The topic name, partition number and the brokerId of the replica
- TopicPartitionReplica(String, int, int) - Constructor for class org.apache.kafka.common.TopicPartitionReplica
-
- topicPartitions(List<TopicPartition>) - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
-
Set the topic partitions to list as part of the result.
- topicPartitions() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupOffsetsOptions
-
Returns a list of topic partitions to add as part of the result.
- topicPartitions() - Method in class org.apache.kafka.clients.admin.MemberAssignment
-
The topic partitions assigned to a group member.
- topicPartitions() - Method in class org.apache.kafka.clients.admin.TransactionDescription
-
- topics() - Method in class org.apache.kafka.clients.admin.ClusterLinkListing
-
The topics that are linked with the cluster link, otherwise if empty, then the
topics weren't requested.
- topics() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- topics() - Method in class org.apache.kafka.common.Cluster
-
Get all topics.
- toRst() - Method in class org.apache.kafka.common.config.ConfigDef
-
Get the configs formatted with reStructuredText, suitable for embedding in Sphinx
documentation.
- toString() - Method in class org.apache.kafka.clients.admin.AbortTransactionOptions
-
- toString() - Method in class org.apache.kafka.clients.admin.AbortTransactionSpec
-
- toString() - Method in class org.apache.kafka.clients.admin.AlterConfigOp
-
- toString() - Method in class org.apache.kafka.clients.admin.BalancerOperationError
-
- toString() - Method in class org.apache.kafka.clients.admin.BalancerStatusDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.BrokerAdditionDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.BrokerRemovalDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.BrokerRemovalError
-
- toString() - Method in class org.apache.kafka.clients.admin.ClusterLinkListing
-
- toString() - Method in class org.apache.kafka.clients.admin.Config
-
- toString() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
-
- toString() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Override toString to redact sensitive value.
- toString() - Method in class org.apache.kafka.clients.admin.ConsumerGroupDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.ConsumerGroupListing
-
- toString() - Method in class org.apache.kafka.clients.admin.DescribeProducersOptions
-
- toString() - Method in class org.apache.kafka.clients.admin.DescribeProducersResult.PartitionProducerState
-
- toString() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult.ReplicaLogDirInfo
-
- toString() - Method in class org.apache.kafka.clients.admin.DescribeTransactionsOptions
-
- toString() - Method in class org.apache.kafka.clients.admin.EvenClusterLoadStatusDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.ExclusionOp
-
- toString() - Method in class org.apache.kafka.clients.admin.ExclusionOperationError
-
- toString() - Method in class org.apache.kafka.clients.admin.ExclusionOpResult
-
- toString() - Method in class org.apache.kafka.clients.admin.FeatureMetadata
-
- toString() - Method in class org.apache.kafka.clients.admin.FeatureUpdate
-
- toString() - Method in class org.apache.kafka.clients.admin.FinalizedVersionRange
-
- toString() - Method in class org.apache.kafka.clients.admin.ListOffsetsResult.ListOffsetsResultInfo
-
- toString() - Method in class org.apache.kafka.clients.admin.ListTopicsOptions
-
- toString() - Method in class org.apache.kafka.clients.admin.ListTransactionsOptions
-
- toString() - Method in class org.apache.kafka.clients.admin.LogDirDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.MemberAssignment
-
- toString() - Method in class org.apache.kafka.clients.admin.MemberDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.MirrorTopicDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.NewClusterLink
-
- toString() - Method in class org.apache.kafka.clients.admin.NewMirrorTopic
-
- toString() - Method in class org.apache.kafka.clients.admin.NewPartitions
-
- toString() - Method in class org.apache.kafka.clients.admin.NewTopic
-
- toString() - Method in class org.apache.kafka.clients.admin.PartitionReassignment
-
- toString() - Method in class org.apache.kafka.clients.admin.ProducerState
-
- toString() - Method in class org.apache.kafka.clients.admin.RecordsToDelete
-
- toString() - Method in class org.apache.kafka.clients.admin.ReplicaInfo
-
- toString() - Method in class org.apache.kafka.clients.admin.ScramCredentialInfo
-
- toString() - Method in class org.apache.kafka.clients.admin.SupportedVersionRange
-
- toString() - Method in class org.apache.kafka.clients.admin.TopicDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.TopicListing
-
- toString() - Method in class org.apache.kafka.clients.admin.TransactionDescription
-
- toString() - Method in class org.apache.kafka.clients.admin.TransactionListing
-
- toString() - Method in enum org.apache.kafka.clients.admin.TransactionState
-
- toString() - Method in class org.apache.kafka.clients.admin.UserScramCredentialsDescription
-
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerGroupMetadata
-
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Assignment
-
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupAssignment
-
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.GroupSubscription
-
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.Subscription
-
- toString() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
- toString() - Method in class org.apache.kafka.clients.consumer.OffsetAndMetadata
-
- toString() - Method in class org.apache.kafka.clients.consumer.OffsetAndTimestamp
-
- toString() - Method in class org.apache.kafka.clients.producer.ProducerRecord
-
- toString() - Method in class org.apache.kafka.clients.producer.RecordMetadata
-
- toString() - Method in class org.apache.kafka.common.acl.AccessControlEntry
-
- toString() - Method in class org.apache.kafka.common.acl.AccessControlEntryFilter
-
- toString() - Method in class org.apache.kafka.common.acl.AclBinding
-
- toString() - Method in class org.apache.kafka.common.acl.AclBindingFilter
-
- toString() - Method in class org.apache.kafka.common.Cluster
-
- toString() - Method in class org.apache.kafka.common.ClusterResource
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.CaseInsensitiveValidString
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.CompositeValidator
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.LambdaValidator
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyString
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.NonNullValidator
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.Range
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.ValidList
-
- toString() - Method in class org.apache.kafka.common.config.ConfigDef.ValidString
-
- toString() - Method in class org.apache.kafka.common.config.ConfigResource
-
- toString() - Method in class org.apache.kafka.common.config.ConfigValue
-
- toString() - Method in class org.apache.kafka.common.ConfluentNode
-
- toString() - Method in enum org.apache.kafka.common.ConsumerGroupState
-
- toString() - Method in class org.apache.kafka.common.Endpoint
-
- toString() - Method in class org.apache.kafka.common.MetricName
-
- toString() - Method in class org.apache.kafka.common.MetricNameTemplate
-
- toString() - Method in class org.apache.kafka.common.metrics.Quota
-
- toString() - Method in exception org.apache.kafka.common.metrics.QuotaViolationException
-
- toString() - Method in class org.apache.kafka.common.metrics.stats.CumulativeSum
-
- toString() - Method in class org.apache.kafka.common.metrics.stats.Frequency
-
- toString() - Method in class org.apache.kafka.common.metrics.stats.Histogram
-
- toString() - Method in class org.apache.kafka.common.metrics.stats.Meter
-
- toString() - Method in class org.apache.kafka.common.metrics.stats.Rate
-
- toString() - Method in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
-
- toString() - Method in class org.apache.kafka.common.metrics.stats.SampledStat
-
- toString() - Method in class org.apache.kafka.common.metrics.stats.TokenBucket
-
- toString() - Method in class org.apache.kafka.common.Node
-
- toString() - Method in class org.apache.kafka.common.PartitionInfo
-
- toString() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration.Op
-
- toString() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration
-
- toString() - Method in class org.apache.kafka.common.quota.ClientQuotaEntity
-
- toString() - Method in class org.apache.kafka.common.quota.ClientQuotaFilter
-
- toString() - Method in class org.apache.kafka.common.quota.ClientQuotaFilterComponent
-
- toString() - Method in class org.apache.kafka.common.resource.Resource
-
- toString() - Method in class org.apache.kafka.common.resource.ResourcePattern
-
- toString() - Method in class org.apache.kafka.common.resource.ResourcePatternFilter
-
- toString() - Method in class org.apache.kafka.common.security.auth.KafkaPrincipal
-
- toString() - Method in class org.apache.kafka.common.security.auth.SaslExtensions
-
- toString() - Method in class org.apache.kafka.common.security.token.delegation.DelegationToken
-
- toString() - Method in class org.apache.kafka.common.security.token.delegation.TokenInformation
-
- toString() - Method in class org.apache.kafka.common.TopicIdPartition
-
- toString() - Method in class org.apache.kafka.common.TopicPartition
-
- toString() - Method in class org.apache.kafka.common.TopicPartitionInfo
-
- toString() - Method in class org.apache.kafka.common.TopicPartitionReplica
-
- toString() - Method in class org.apache.kafka.common.Uuid
-
Returns a base64 string encoding of the UUID.
- toString() - Method in class org.apache.kafka.server.authorizer.Action
-
- toString() - Method in class org.apache.kafka.server.policy.AlterConfigPolicy.RequestMetadata
-
- toString() - Method in class org.apache.kafka.server.policy.CreateTopicPolicy.RequestMetadata
-
- totalCount() - Method in class org.apache.kafka.clients.admin.NewPartitions
-
The total number of partitions after the operation succeeds.
- TRACE_LOG_LEVEL - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
The TRACE
level designates finer-grained
informational events than the DEBUG
level.
- TRANSACTION_TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
transaction.timeout.ms
- TRANSACTION_TIMEOUT_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
- transactionAborted() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- TransactionAbortedException - Exception in org.apache.kafka.common.errors
-
This is the Exception thrown when we are aborting any undrained batches during
a transaction which is aborted without any underlying cause - which likely means that the user chose to abort.
- TransactionAbortedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TransactionAbortedException
-
- TransactionAbortedException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionAbortedException
-
- TransactionAbortedException() - Constructor for exception org.apache.kafka.common.errors.TransactionAbortedException
-
- TRANSACTIONAL_ID_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
transactional.id
- TRANSACTIONAL_ID_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
- transactionalId() - Method in class org.apache.kafka.clients.admin.TransactionListing
-
- TransactionalIdAuthorizationException - Exception in org.apache.kafka.common.errors
-
- TransactionalIdAuthorizationException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionalIdAuthorizationException
-
- TransactionalIdNotFoundException - Exception in org.apache.kafka.common.errors
-
- TransactionalIdNotFoundException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionalIdNotFoundException
-
- transactionCommitted() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- TransactionCoordinatorFencedException - Exception in org.apache.kafka.common.errors
-
- TransactionCoordinatorFencedException(String) - Constructor for exception org.apache.kafka.common.errors.TransactionCoordinatorFencedException
-
- TransactionCoordinatorFencedException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.TransactionCoordinatorFencedException
-
- TransactionDescription - Class in org.apache.kafka.clients.admin
-
- TransactionDescription(int, TransactionState, long, int, long, OptionalLong, Set<TopicPartition>) - Constructor for class org.apache.kafka.clients.admin.TransactionDescription
-
- transactionInFlight() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- transactionInitialized() - Method in class org.apache.kafka.clients.producer.MockProducer
-
- TransactionListing - Class in org.apache.kafka.clients.admin
-
- TransactionListing(String, long, TransactionState) - Constructor for class org.apache.kafka.clients.admin.TransactionListing
-
- transactionStartTimeMs() - Method in class org.apache.kafka.clients.admin.TransactionDescription
-
- TransactionState - Enum in org.apache.kafka.clients.admin
-
- transactionTimeoutMs() - Method in class org.apache.kafka.clients.admin.TransactionDescription
-
- transform(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigTransformer
-
Transforms the given configuration data by using the
ConfigProvider
instances to
look up values to replace the variables in the pattern.
- truststore() - Method in interface org.apache.kafka.common.security.auth.SslEngineFactory
-
Returns truststore configured for this factory.
- ttl() - Method in class org.apache.kafka.common.config.ConfigData
-
Returns the TTL (in milliseconds).
- ttls() - Method in class org.apache.kafka.common.config.ConfigTransformerResult
-
Returns the TTL values (in milliseconds) returned from the ConfigProvider instances for a given set of paths.
- type() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Return the config data type.
- type() - Method in enum org.apache.kafka.clients.admin.ScramMechanism
-
- type - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- type() - Method in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- type() - Method in class org.apache.kafka.common.config.ConfigResource
-
Return the resource type.
- typeOf(String) - Method in class org.apache.kafka.common.config.AbstractConfig
-
- valid() - Method in class org.apache.kafka.clients.admin.ListConsumerGroupsResult
-
Returns a future which yields just the valid listings.
- valid(String) - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
Validates a specific extension in the original inputExtensions
map
- VALID_LOG_LEVELS - Static variable in class org.apache.kafka.common.config.LogLevelConfig
-
- validate(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
-
Validate the current configuration values with the configuration definition.
- validate(AlterConfigPolicy.RequestMetadata) - Method in interface org.apache.kafka.server.policy.AlterConfigPolicy
-
Validate the request parameters and throw a PolicyViolationException
with a suitable error
message if the alter configs request parameters for the provided resource do not satisfy this policy.
- validate(CreateTopicPolicy.RequestMetadata) - Method in interface org.apache.kafka.server.policy.CreateTopicPolicy
-
Validate the request parameters and throw a PolicyViolationException
with a suitable error
message if the create topics request parameters for the provided topic do not satisfy this policy.
- validateAll(Map<String, String>) - Method in class org.apache.kafka.common.config.ConfigDef
-
- validatedExtensions() - Method in class org.apache.kafka.common.security.oauthbearer.OAuthBearerExtensionsValidatorCallback
-
- validateLink() - Method in class org.apache.kafka.clients.admin.CreateClusterLinksOptions
-
Whether to validate the links to the clusters before creation.
- validateLink(boolean) - Method in class org.apache.kafka.clients.admin.CreateClusterLinksOptions
-
Sets whether to validate the links to the clusters before creation.
- validateOnly() - Method in class org.apache.kafka.clients.admin.AlterClientQuotasOptions
-
Returns whether the request should be validated without altering the configs.
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.AlterClientQuotasOptions
-
Sets whether the request should be validated without altering the configs.
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.AlterConfigsOptions
-
Set to true if the request should be validated without altering the configs.
- validateOnly() - Method in class org.apache.kafka.clients.admin.AlterMirrorsOptions
-
Whether to validate the mirror control operation, but not actually perform it.
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.AlterMirrorsOptions
-
Sets whether to validate the mirror control operation, but not actually perform it.
- validateOnly() - Method in class org.apache.kafka.clients.admin.CreateClusterLinksOptions
-
Whether to validate that the cluster links can be created, but not actually create them.
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.CreateClusterLinksOptions
-
Sets whether to validate that the cluster links can be created, but not actually create them.
- validateOnly() - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
-
Return true if the request should be validated without creating new partitions.
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.CreatePartitionsOptions
-
Set to true if the request should be validated without creating new partitions.
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.CreateTopicsOptions
-
Set to true if the request should be validated without creating the topic.
- validateOnly() - Method in class org.apache.kafka.clients.admin.DeleteClusterLinksOptions
-
Whether to validate that the cluster links can be deleted, but not actually delete them.
- validateOnly(boolean) - Method in class org.apache.kafka.clients.admin.DeleteClusterLinksOptions
-
Sets whether to validate that the cluster links can be deleted, but not actually delete them.
- validateReconfiguration(Map<String, ?>) - Method in class org.apache.kafka.common.DelegatingReconfigurable
-
- validateReconfiguration(Map<String, ?>) - Method in class org.apache.kafka.common.metrics.JmxReporter
-
- validateReconfiguration(Map<String, ?>) - Method in interface org.apache.kafka.common.metrics.MetricsReporter
-
- validateReconfiguration(Map<String, ?>) - Method in interface org.apache.kafka.common.Reconfigurable
-
Validates the provided configuration.
- validator - Variable in class org.apache.kafka.common.config.ConfigDef.ConfigKey
-
- validValues(String, Map<String, Object>) - Method in interface org.apache.kafka.common.config.ConfigDef.Recommender
-
The valid values for the configuration given the current configuration values.
- value() - Method in class org.apache.kafka.clients.admin.ConfigEntry.ConfigSynonym
-
Returns the value of this configuration, which may be null if the configuration is sensitive.
- value() - Method in class org.apache.kafka.clients.admin.ConfigEntry
-
Return the value or null.
- value() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
-
The value
- value() - Method in class org.apache.kafka.clients.producer.ProducerRecord
-
- value() - Method in class org.apache.kafka.common.config.ConfigValue
-
- value(Object) - Method in class org.apache.kafka.common.config.ConfigValue
-
- value - Variable in enum org.apache.kafka.common.ElectionType
-
- value() - Method in interface org.apache.kafka.common.header.Header
-
- value(MetricConfig, long) - Method in interface org.apache.kafka.common.metrics.Gauge
-
Returns the current value associated with this gauge.
- value() - Method in exception org.apache.kafka.common.metrics.QuotaViolationException
-
- value(double) - Method in class org.apache.kafka.common.metrics.stats.Histogram
-
- value(MetricConfig, long, double) - Method in class org.apache.kafka.common.metrics.stats.Percentiles
-
- value - Variable in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
-
- Value - Class in org.apache.kafka.common.metrics.stats
-
An instantaneous value.
- Value() - Constructor for class org.apache.kafka.common.metrics.stats.Value
-
- value() - Method in class org.apache.kafka.common.quota.ClientQuotaAlteration.Op
-
- value() - Method in interface org.apache.kafka.common.security.oauthbearer.OAuthBearerToken
-
- VALUE_DESERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
value.deserializer
- VALUE_DESERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
-
- VALUE_SCHEMA_VALIDATION_CONFIG - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- VALUE_SCHEMA_VALIDATION_DOC - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- VALUE_SERIALIZER_CLASS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
value.serializer
- VALUE_SERIALIZER_CLASS_DOC - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
-
- VALUE_SUBJECT_NAME_STRATEGY_CONFIG - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- VALUE_SUBJECT_NAME_STRATEGY_DOC - Static variable in class org.apache.kafka.common.config.ConfluentTopicConfig
-
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.AlterConfigOp.OpType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.AlterMirrorOp
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.BalancerOperationStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.BalancerStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.BrokerReplicaExclusionStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.BrokerShutdownStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.EvenClusterLoadStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.ExclusionOp.OpType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.MirrorTopicDescription.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.PartitionReassignmentsStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.ScramMechanism
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.admin.TransactionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.clients.consumer.OffsetResetStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.acl.AclOperation
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.acl.AclPermissionType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Importance
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigDef.Width
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.config.SslClientAuth
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.ConsumerGroupState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.ElectionType
-
Returns the enum constant of this type with the specified name.
- valueOf(byte) - Static method in enum org.apache.kafka.common.ElectionType
-
- valueOf(String) - Static method in enum org.apache.kafka.common.IsolationLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.metrics.Sensor.RecordingLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.metrics.stats.Percentiles.BucketSizing
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.resource.PatternType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.resource.ResourceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.server.authorizer.AuthorizationResult
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.kafka.server.quota.ClientQuotaType
-
Returns the enum constant of this type with the specified name.
- values() - Method in class org.apache.kafka.clients.admin.AlterClientQuotasResult
-
Returns a map from quota entity to a future which can be used to check the status of the operation.
- values() - Static method in enum org.apache.kafka.clients.admin.AlterConfigOp.OpType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.kafka.clients.admin.AlterConfigsResult
-
Return a map from resources to futures which can be used to check the status of the operation on each resource.
- values() - Static method in enum org.apache.kafka.clients.admin.AlterMirrorOp
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.kafka.clients.admin.AlterMirrorsResult
-
- values() - Method in class org.apache.kafka.clients.admin.AlterPartitionReassignmentsResult
-
Return a map from partitions to futures which can be used to check the status of the reassignment.
- values() - Method in class org.apache.kafka.clients.admin.AlterReplicaLogDirsResult
-
- values() - Method in class org.apache.kafka.clients.admin.AlterUserScramCredentialsResult
-
Return a map from user names to futures, which can be used to check the status of the alteration(s)
for each user.
- values() - Static method in enum org.apache.kafka.clients.admin.BalancerOperationStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.admin.BalancerStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.admin.BrokerReplicaExclusionStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.admin.BrokerShutdownStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigSource
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.admin.ConfigEntry.ConfigType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.kafka.clients.admin.CreateAclsResult
-
Return a map from ACL bindings to futures which can be used to check the status of the creation of each ACL
binding.
- values() - Method in class org.apache.kafka.clients.admin.CreatePartitionsResult
-
Return a map from topic names to futures, which can be used to check the status of individual
partition creations.
- values() - Method in class org.apache.kafka.clients.admin.CreateTopicsResult
-
Return a map from topic names to futures, which can be used to check the status of individual
topic creations.
- values() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult.FilterResults
-
Return a list of delete ACLs results for a given filter.
- values() - Method in class org.apache.kafka.clients.admin.DeleteAclsResult
-
Return a map from acl filters to futures which can be used to check the status of the deletions by each
filter.
- values() - Method in class org.apache.kafka.clients.admin.DeleteTopicsResult
-
Deprecated.
- values() - Method in class org.apache.kafka.clients.admin.DescribeAclsResult
-
Return a future containing the ACLs requested.
- values() - Method in class org.apache.kafka.clients.admin.DescribeConfigsResult
-
Return a map from resources to futures which can be used to check the status of the configuration for each
resource.
- values() - Method in class org.apache.kafka.clients.admin.DescribeLogDirsResult
-
- values() - Method in class org.apache.kafka.clients.admin.DescribeReplicaLogDirsResult
-
Return a map from replica to future which can be used to check the log directory information of individual replicas
- values() - Method in class org.apache.kafka.clients.admin.DescribeTopicsResult
-
Return a map from topic names to futures which can be used to check the status of
individual topics.
- values() - Static method in enum org.apache.kafka.clients.admin.EvenClusterLoadStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.admin.ExclusionOp.OpType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.admin.MirrorTopicDescription.State
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.admin.PartitionReassignmentsStatus
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.kafka.clients.admin.RemoveBrokersResult
-
Return a map of broker ids to futures which can be used to check the status of individual broker removals.
- values() - Static method in enum org.apache.kafka.clients.admin.ScramMechanism
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.admin.TransactionState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.kafka.clients.admin.UpdateFeaturesResult
-
- values() - Static method in enum org.apache.kafka.clients.consumer.ConsumerPartitionAssignor.RebalanceProtocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.clients.consumer.OffsetResetStrategy
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.acl.AclOperation
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.acl.AclPermissionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.kafka.common.config.AbstractConfig
-
- values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Importance
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.config.ConfigDef.Width
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.config.ConfigResource.Type
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- VALUES - Static variable in enum org.apache.kafka.common.config.SslClientAuth
-
- values() - Static method in enum org.apache.kafka.common.config.SslClientAuth
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.ConsumerGroupState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.ElectionType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.IsolationLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.metrics.Sensor.RecordingLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.metrics.stats.Percentiles.BucketSizing
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.resource.PatternType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.resource.ResourceType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.common.security.auth.SecurityProtocol
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.server.authorizer.AuthorizationResult
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.server.quota.ClientQuotaEntity.ConfigEntityType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.kafka.server.quota.ClientQuotaType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- valuesWithPrefixAllOrNothing(String) - Method in class org.apache.kafka.common.config.AbstractConfig
-
If at least one key with prefix
exists, all prefixed values will be parsed and put into map.
- valuesWithPrefixOverride(String) - Method in class org.apache.kafka.common.config.AbstractConfig
-
Put all keys that do not start with prefix
and their parsed values in the result map and then
put all the remaining keys with the prefix stripped and their parsed values in the result map.
- version() - Method in interface org.apache.kafka.clients.consumer.ConsumerPartitionAssignor
-
Return the version of the assignor which indicates how the user metadata encodings
and the assignment algorithm gets evolved.
- visible(String, Map<String, Object>) - Method in interface org.apache.kafka.common.config.ConfigDef.Recommender
-
Set the visibility of the configuration given the current configuration values.
- visible() - Method in class org.apache.kafka.common.config.ConfigValue
-
- visible(boolean) - Method in class org.apache.kafka.common.config.ConfigValue
-
- Void() - Static method in class org.apache.kafka.common.serialization.Serdes
-
A serde for Void
type.
- VoidDeserializer - Class in org.apache.kafka.common.serialization
-
- VoidDeserializer() - Constructor for class org.apache.kafka.common.serialization.VoidDeserializer
-
- VoidSerde() - Constructor for class org.apache.kafka.common.serialization.Serdes.VoidSerde
-
- VoidSerializer - Class in org.apache.kafka.common.serialization
-
- VoidSerializer() - Constructor for class org.apache.kafka.common.serialization.VoidSerializer
-