A B C D E F G H I J K L M N O P Q R S T U V W

A

abs(int) - Static method in class org.apache.kafka.common.utils.Utils
Get the absolute value of the given number.
AbstractConfig - Class in org.apache.kafka.common.config
A convenient base class for configurations to extend.
AbstractConfig(ConfigDef, Map<?, ?>) - Constructor for class org.apache.kafka.common.config.AbstractConfig
 
AbstractIterator<T> - Class in org.apache.kafka.common.utils
A base class that simplifies implementing an iterator
AbstractIterator() - Constructor for class org.apache.kafka.common.utils.AbstractIterator
 
AbstractRequestResponse - Class in org.apache.kafka.common.requests
 
AbstractRequestResponse(Struct) - Constructor for class org.apache.kafka.common.requests.AbstractRequestResponse
 
acceptable(double) - Method in class org.apache.kafka.common.metrics.Quota
 
acks() - Method in class org.apache.kafka.common.requests.ProduceRequest
 
ACKS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
acks
add(String) - Method in class org.apache.kafka.clients.producer.internals.Metadata
Add the topic to maintain in the metadata
add(CompoundStat) - Method in class org.apache.kafka.common.metrics.Sensor
Register a compound statistic with this sensor with no config override
add(CompoundStat, MetricConfig) - Method in class org.apache.kafka.common.metrics.Sensor
Register a compound statistic with this sensor which yields multiple measurable quantities (like a histogram)
add(String, MeasurableStat) - Method in class org.apache.kafka.common.metrics.Sensor
Add a metric with default configuration and no description.
add(String, String, MeasurableStat) - Method in class org.apache.kafka.common.metrics.Sensor
Add a metric with default configuration.
add(String, MeasurableStat, MetricConfig) - Method in class org.apache.kafka.common.metrics.Sensor
Add a metric to this sensor with no description.
add(String, String, MeasurableStat, MetricConfig) - Method in class org.apache.kafka.common.metrics.Sensor
Register a metric with this sensor
addMetric(String, Measurable) - Method in class org.apache.kafka.common.metrics.Metrics
Add a metric to monitor an object that implements measurable.
addMetric(String, String, Measurable) - Method in class org.apache.kafka.common.metrics.Metrics
Add a metric to monitor an object that implements measurable.
addMetric(String, MetricConfig, Measurable) - Method in class org.apache.kafka.common.metrics.Metrics
Add a metric to monitor an object that implements measurable.
addMetric(String, String, MetricConfig, Measurable) - Method in class org.apache.kafka.common.metrics.Metrics
Add a metric to monitor an object that implements measurable.
addReporter(MetricsReporter) - Method in class org.apache.kafka.common.metrics.Metrics
Add a MetricReporter
allDone() - Method in class org.apache.kafka.common.utils.AbstractIterator
 
allocate(int) - Method in class org.apache.kafka.clients.producer.internals.BufferPool
Allocate a buffer of the given size.
ApiException - Exception in org.apache.kafka.common.errors
Any API exception that is part of the public protocol and should be a subclass of this class and be part of this package.
ApiException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException(String) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException(Throwable) - Constructor for exception org.apache.kafka.common.errors.ApiException
 
ApiException() - Constructor for exception org.apache.kafka.common.errors.ApiException
 
apiKey() - Method in class org.apache.kafka.common.requests.RequestHeader
 
ApiKeys - Enum in org.apache.kafka.common.protocol
Identifiers for all the Kafka APIs
apiVersion() - Method in class org.apache.kafka.common.requests.RequestHeader
 
append(TopicPartition, byte[], byte[], CompressionType, Callback) - Method in class org.apache.kafka.clients.producer.internals.RecordAccumulator
Add a record to the accumulator, return the append result
append(long, Record) - Method in class org.apache.kafka.common.record.MemoryRecords
Append the given record and offset to the buffer
append(long, byte[], byte[]) - Method in class org.apache.kafka.common.record.MemoryRecords
Append a new record and offset to the buffer
ArrayOf - Class in org.apache.kafka.common.protocol.types
Represents a type for an array of a particular type
ArrayOf(Type) - Constructor for class org.apache.kafka.common.protocol.types.ArrayOf
 
assignedPartitions() - Method in class org.apache.kafka.common.requests.JoinGroupResponse
 
atLeast(Number) - Static method in class org.apache.kafka.common.config.ConfigDef.Range
A numeric range that checks only the lower bound
attachment() - Method in class org.apache.kafka.clients.ClientRequest
 
attempts - Variable in class org.apache.kafka.clients.producer.internals.RecordBatch
 
ATTRIBUTE_LENGTH - Static variable in class org.apache.kafka.common.record.Record
 
attributes() - Method in class org.apache.kafka.common.record.Record
The attributes stored with this record
ATTRIBUTES_OFFSET - Static variable in class org.apache.kafka.common.record.Record
 
AUTO_COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The frequency in milliseconds that the consumer offsets are committed to Kafka.
AUTO_OFFSET_RESET_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
What to do when there is no initial offset in Kafka or if an offset is out of range: smallest: automatically reset the offset to the smallest offset largest: automatically reset the offset to the largest offset disable: throw exception to the consumer if no previous offset is found for the consumer's group anything else: throw exception to the consumer.
available() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
availableMemory() - Method in class org.apache.kafka.clients.producer.internals.BufferPool
the total free memory both unallocated and in the free list
Avg - Class in org.apache.kafka.common.metrics.stats
A SampledStat that maintains a simple average over its samples.
Avg() - Constructor for class org.apache.kafka.common.metrics.stats.Avg
 
await() - Method in class org.apache.kafka.clients.producer.internals.ProduceRequestResult
Await the completion of this request
await(long, TimeUnit) - Method in class org.apache.kafka.clients.producer.internals.ProduceRequestResult
Await the completion of this request (up to the given time interval)
awaitUpdate(int, long) - Method in class org.apache.kafka.clients.producer.internals.Metadata
Wait for metadata update until the current version is larger than the last version we know of

B

baseOffset() - Method in class org.apache.kafka.clients.producer.internals.ProduceRequestResult
The base offset for the request (the first offset in the record set)
baseOffset - Variable in class org.apache.kafka.common.requests.ProduceResponse.PartitionResponse
 
BATCH_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
batch.size
batchIsFull - Variable in class org.apache.kafka.clients.producer.internals.RecordAccumulator.RecordAppendResult
 
between(Number, Number) - Static method in class org.apache.kafka.common.config.ConfigDef.Range
A numeric range that checks both the upper and lower bound
bins() - Method in interface org.apache.kafka.common.metrics.stats.Histogram.BinScheme
 
bins() - Method in class org.apache.kafka.common.metrics.stats.Histogram.ConstantBinScheme
 
bins() - Method in class org.apache.kafka.common.metrics.stats.Histogram.LinearBinScheme
 
BLOCK_HASH_MISMATCH - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
BLOCK_ON_BUFFER_FULL_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
block.on.buffer.full
BLOCKSIZE_1MB - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
BLOCKSIZE_256KB - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
BLOCKSIZE_4MB - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
BLOCKSIZE_64KB - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
body() - Method in class org.apache.kafka.common.requests.RequestSend
 
bootstrap(List<InetSocketAddress>) - Static method in class org.apache.kafka.common.Cluster
Create a "bootstrap" cluster using the given list of host/ports
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
A list of URLs to use for establishing the initial connection to the cluster.
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
bootstrap.servers
bound() - Method in class org.apache.kafka.common.metrics.Quota
 
BROKER - Static variable in class org.apache.kafka.common.protocol.Protocol
 
buffer() - Method in class org.apache.kafka.common.record.ByteBufferOutputStream
 
buffer() - Method in class org.apache.kafka.common.record.Compressor
 
buffer() - Method in class org.apache.kafka.common.record.MemoryRecords
Get the byte buffer that backs this records instance
buffer() - Method in class org.apache.kafka.common.record.Record
 
BUFFER_MEMORY_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
buffer.memory
BufferExhaustedException - Exception in org.apache.kafka.clients.producer
This exception is thrown if the producer is in non-blocking mode and the rate of data production exceeds the rate at which data can be sent for long enough for the alloted buffer to be exhausted.
BufferExhaustedException(String) - Constructor for exception org.apache.kafka.clients.producer.BufferExhaustedException
 
BufferPool - Class in org.apache.kafka.clients.producer.internals
A pool of ByteBuffers kept under a given memory limit.
BufferPool(long, int, boolean, Metrics, Time) - Constructor for class org.apache.kafka.clients.producer.internals.BufferPool
Create a new buffer pool
buffers - Variable in class org.apache.kafka.common.network.ByteBufferSend
 
ByteBufferInputStream - Class in org.apache.kafka.common.record
A byte buffer backed input outputStream
ByteBufferInputStream(ByteBuffer) - Constructor for class org.apache.kafka.common.record.ByteBufferInputStream
 
ByteBufferOutputStream - Class in org.apache.kafka.common.record
A byte buffer backed output outputStream
ByteBufferOutputStream(ByteBuffer) - Constructor for class org.apache.kafka.common.record.ByteBufferOutputStream
 
ByteBufferReceive - Class in org.apache.kafka.common.network
A receive backed by an array of ByteBuffers
ByteBufferReceive(int, ByteBuffer...) - Constructor for class org.apache.kafka.common.network.ByteBufferReceive
 
ByteBufferSend - Class in org.apache.kafka.common.network
A send backed by an array of byte buffers
ByteBufferSend(int, ByteBuffer...) - Constructor for class org.apache.kafka.common.network.ByteBufferSend
 
BYTES - Static variable in class org.apache.kafka.common.protocol.types.Type
 

C

Callback - Interface in org.apache.kafka.clients.producer
A callback interface that the user can implement to allow code to execute when the request is complete.
cancel(boolean) - Method in class org.apache.kafka.clients.producer.internals.FutureRecordMetadata
 
capacity() - Method in class org.apache.kafka.common.record.MemoryRecords
Return the capacity of the buffer
checksum() - Method in class org.apache.kafka.common.record.Record
Retrieve the previously computed CRC for this record
clear() - Method in class org.apache.kafka.clients.producer.MockProducer
Clear the stored history of sent records
clear() - Method in class org.apache.kafka.common.metrics.stats.Histogram
 
clear() - Method in class org.apache.kafka.common.protocol.types.Struct
Empty all the values from this record
clear() - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The id string to pass to the server when making requests.
CLIENT_ID_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
client.id
clientId() - Method in class org.apache.kafka.common.requests.RequestHeader
 
ClientRequest - Class in org.apache.kafka.clients
A request being sent to the server.
ClientRequest(long, boolean, RequestSend, Object) - Constructor for class org.apache.kafka.clients.ClientRequest
 
ClientResponse - Class in org.apache.kafka.clients
A response from the server.
ClientResponse(ClientRequest, long, boolean, Struct) - Constructor for class org.apache.kafka.clients.ClientResponse
 
ClientUtils - Class in org.apache.kafka.common.utils
 
ClientUtils() - Constructor for class org.apache.kafka.common.utils.ClientUtils
 
close() - Method in interface org.apache.kafka.clients.consumer.Consumer
Close this consumer
close() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
 
close() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
close() - Method in interface org.apache.kafka.clients.KafkaClient
Close the client and disconnect from all nodes
close() - Method in class org.apache.kafka.clients.NetworkClient
Close the network client
close() - Method in class org.apache.kafka.clients.producer.internals.RecordAccumulator
Close this accumulator and force all the record buffers to be drained
close() - Method in class org.apache.kafka.clients.producer.KafkaProducer
Close this producer.
close() - Method in class org.apache.kafka.clients.producer.MockProducer
 
close() - Method in interface org.apache.kafka.clients.producer.Producer
Close this producer
close() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
close() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
close() - Method in class org.apache.kafka.common.metrics.JmxReporter
 
close() - Method in class org.apache.kafka.common.metrics.Metrics
Close this metrics repository.
close() - Method in interface org.apache.kafka.common.metrics.MetricsReporter
Called when the metrics repository is closed.
close() - Method in interface org.apache.kafka.common.network.Selectable
Close this selector
close() - Method in class org.apache.kafka.common.network.Selector
Close this selector and all associated connections
close() - Method in class org.apache.kafka.common.record.Compressor
 
close() - Method in class org.apache.kafka.common.record.MemoryRecords
Close this batch for no more appends
CLOSED_STREAM - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
Cluster - Class in org.apache.kafka.common
A representation of a subset of the nodes, topics, and partitions in the Kafka cluster.
Cluster(Collection<Node>, Collection<PartitionInfo>) - Constructor for class org.apache.kafka.common.Cluster
Create a new cluster with the given nodes and partitions
cluster() - Method in class org.apache.kafka.common.requests.MetadataResponse
 
code() - Method in enum org.apache.kafka.common.protocol.Errors
The error code for the exception
CollectionUtils - Class in org.apache.kafka.common.utils
 
CollectionUtils() - Constructor for class org.apache.kafka.common.utils.CollectionUtils
 
combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Avg
 
combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Count
 
combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Max
 
combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Min
 
combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Percentiles
 
combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Rate.SampledTotal
 
combine(List<SampledStat.Sample>, MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
commit(boolean) - Method in interface org.apache.kafka.clients.consumer.Consumer
Commits offsets returned on the last poll() for the subscribed list of topics and partitions.
commit(Map<TopicPartition, Long>, boolean) - Method in interface org.apache.kafka.clients.consumer.Consumer
Commits the specified offsets for the specified list of topics and partitions to Kafka.
commit(Map<TopicPartition, Long>, boolean) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commits the specified offsets for the specified list of topics and partitions to Kafka.
commit(boolean) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Commits offsets returned on the last poll() for the subscribed list of topics and partitions.
commit(Map<TopicPartition, Long>, boolean) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
commit(boolean) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
committed(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
Fetches the last committed offsets for the input list of partitions
committed(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Fetches the last committed offsets of partitions that the consumer currently consumes.
committed(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
complete() - Method in class org.apache.kafka.common.network.ByteBufferReceive
 
complete() - Method in class org.apache.kafka.common.network.NetworkReceive
 
complete() - Method in interface org.apache.kafka.common.network.Receive
Are we done receiving data?
completed() - Method in class org.apache.kafka.clients.producer.internals.ProduceRequestResult
Has the request completed?
completed() - Method in class org.apache.kafka.common.network.ByteBufferSend
 
completed() - Method in interface org.apache.kafka.common.network.Send
Is this send complete?
completedReceives() - Method in interface org.apache.kafka.common.network.Selectable
The list of receives that completed on the last poll() call.
completedReceives() - Method in class org.apache.kafka.common.network.Selector
 
completedSends() - Method in interface org.apache.kafka.common.network.Selectable
The list of sends that completed on the last poll() call.
completedSends() - Method in class org.apache.kafka.common.network.Selector
 
completeNext() - Method in class org.apache.kafka.clients.producer.MockProducer
Complete the earliest uncompleted call successfully.
CompoundStat - Interface in org.apache.kafka.common.metrics
A compound stat is a stat where a single measurement and associated data structure feeds many metrics.
CompoundStat.NamedMeasurable - Class in org.apache.kafka.common.metrics
 
CompoundStat.NamedMeasurable(String, String, Measurable) - Constructor for class org.apache.kafka.common.metrics.CompoundStat.NamedMeasurable
 
COMPRESSION_CODEC_MASK - Static variable in class org.apache.kafka.common.record.Record
Specifies the mask for the compression code.
COMPRESSION_TYPE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
compression.type
compressionRate() - Method in class org.apache.kafka.common.record.Compressor
 
compressionRate() - Method in class org.apache.kafka.common.record.MemoryRecords
The compression rate of this record set
CompressionType - Enum in org.apache.kafka.common.record
The compression type to use
compressionType() - Method in class org.apache.kafka.common.record.Record
The compression type used with this record
Compressor - Class in org.apache.kafka.common.record
 
Compressor(ByteBuffer, CompressionType, int) - Constructor for class org.apache.kafka.common.record.Compressor
 
Compressor(ByteBuffer, CompressionType) - Constructor for class org.apache.kafka.common.record.Compressor
 
computeAttributes(CompressionType) - Static method in class org.apache.kafka.common.record.Record
 
computeChecksum(ByteBuffer, int, int) - Static method in class org.apache.kafka.common.record.Record
Compute the checksum of the record from the record contents
computeChecksum(byte[], byte[], CompressionType, int, int) - Static method in class org.apache.kafka.common.record.Record
Compute the checksum of the record from the attributes, key and value payloads
computeChecksum() - Method in class org.apache.kafka.common.record.Record
Compute the checksum of the record from the record contents
config(MetricConfig) - Method in class org.apache.kafka.common.metrics.KafkaMetric
 
ConfigDef - Class in org.apache.kafka.common.config
This class is used for specifying the set of expected configurations, their type, their defaults, their documentation, and any special validation logic used for checking the correctness of the values the user provides.
ConfigDef() - Constructor for class org.apache.kafka.common.config.ConfigDef
 
ConfigDef.Importance - Enum in org.apache.kafka.common.config
 
ConfigDef.Range - Class in org.apache.kafka.common.config
Validation logic for numeric ranges
ConfigDef.Type - Enum in org.apache.kafka.common.config
The config types
ConfigDef.Validator - Interface in org.apache.kafka.common.config
Validation logic the user may provide
ConfigDef.ValidString - Class in org.apache.kafka.common.config
 
ConfigException - Exception in org.apache.kafka.common.config
Thrown if the user supplies an invalid configuration
ConfigException(String) - Constructor for exception org.apache.kafka.common.config.ConfigException
 
ConfigException(String, Object) - Constructor for exception org.apache.kafka.common.config.ConfigException
 
ConfigException(String, Object, String) - Constructor for exception org.apache.kafka.common.config.ConfigException
 
Configurable - Interface in org.apache.kafka.common
A Mix-in style interface for classes that are instantiated by reflection and need to take configuration parameters
configure(Map<String, ?>) - Method in interface org.apache.kafka.common.Configurable
Configure this class with the given key-value pairs
configure(Map<String, ?>) - Method in class org.apache.kafka.common.metrics.JmxReporter
 
connect(int, InetSocketAddress, int, int) - Method in interface org.apache.kafka.common.network.Selectable
Begin establishing a socket connection to the given address identified by the given address
connect(int, InetSocketAddress, int, int) - Method in class org.apache.kafka.common.network.Selector
Begin connecting to the given address and add the connection to this selector associated with the given id number.
connected() - Method in interface org.apache.kafka.common.network.Selectable
The list of connections that completed their connection on the last poll() call.
connected() - Method in class org.apache.kafka.common.network.Selector
 
Consumer - Interface in org.apache.kafka.clients.consumer
 
CONSUMER_METADATA_REQUEST - Static variable in class org.apache.kafka.common.protocol.Protocol
 
CONSUMER_METADATA_REQUEST_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
CONSUMER_METADATA_RESPONSE - Static variable in class org.apache.kafka.common.protocol.Protocol
 
CONSUMER_METADATA_RESPONSE_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
ConsumerConfig - Class in org.apache.kafka.clients.consumer
The consumer configuration keys
consumerId() - Method in class org.apache.kafka.common.requests.HeartbeatRequest
 
consumerId() - Method in class org.apache.kafka.common.requests.JoinGroupRequest
 
consumerId() - Method in class org.apache.kafka.common.requests.JoinGroupResponse
 
consumerId() - Method in class org.apache.kafka.common.requests.OffsetCommitRequest
 
ConsumerMetadataRequest - Class in org.apache.kafka.common.requests
 
ConsumerMetadataRequest(String) - Constructor for class org.apache.kafka.common.requests.ConsumerMetadataRequest
 
ConsumerMetadataRequest(Struct) - Constructor for class org.apache.kafka.common.requests.ConsumerMetadataRequest
 
ConsumerMetadataResponse - Class in org.apache.kafka.common.requests
 
ConsumerMetadataResponse(short, Node) - Constructor for class org.apache.kafka.common.requests.ConsumerMetadataResponse
 
ConsumerMetadataResponse(Struct) - Constructor for class org.apache.kafka.common.requests.ConsumerMetadataResponse
 
ConsumerRebalanceCallback - Interface in org.apache.kafka.clients.consumer
A callback interface that the user can implement to manage customized offsets on the start and end of every rebalance operation.
ConsumerRecord - Class in org.apache.kafka.clients.consumer
A key/value pair to be received from Kafka.
ConsumerRecord(String, int, byte[], byte[], long) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition
ConsumerRecord(String, int, byte[], long) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Create a record with no key
ConsumerRecord(String, int, Exception) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecord
Creates a record with an error code
ConsumerRecords - Class in org.apache.kafka.clients.consumer
A container that holds the list ConsumerRecord per partition for a particular topic.
ConsumerRecords(String, Map<Integer, List<ConsumerRecord>>) - Constructor for class org.apache.kafka.clients.consumer.ConsumerRecords
 
containsKey(Object) - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
containsValue(Object) - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
CopyOnWriteMap<K,V> - Class in org.apache.kafka.common.utils
A simple read-optimized map implementation that synchronizes only writes and does a full copy on each modification
CopyOnWriteMap() - Constructor for class org.apache.kafka.common.utils.CopyOnWriteMap
 
CopyOnWriteMap(Map<K, V>) - Constructor for class org.apache.kafka.common.utils.CopyOnWriteMap
 
correlationId() - Method in class org.apache.kafka.common.requests.RequestHeader
 
correlationId() - Method in class org.apache.kafka.common.requests.ResponseHeader
 
CorruptRecordException - Exception in org.apache.kafka.common.errors
This exception indicates a record has failed it's internal CRC check, this generally indicates network or disk corruption.
CorruptRecordException() - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(String) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(Throwable) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
CorruptRecordException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.CorruptRecordException
 
Count - Class in org.apache.kafka.common.metrics.stats
A SampledStat that maintains a simple count of what it has seen.
Count() - Constructor for class org.apache.kafka.common.metrics.stats.Count
 
counts() - Method in class org.apache.kafka.common.metrics.stats.Histogram
 
Crc32 - Class in org.apache.kafka.common.utils
This class was taken from Hadoop org.apache.hadoop.util.PureJavaCrc32 A pure-java implementation of the CRC32 checksum that uses the same polynomial as the built-in native CRC32.
Crc32() - Constructor for class org.apache.kafka.common.utils.Crc32
Create a new PureJavaCrc32 object.
crc32(byte[]) - Static method in class org.apache.kafka.common.utils.Crc32
Compute the CRC32 of the byte array
crc32(byte[], int, int) - Static method in class org.apache.kafka.common.utils.Crc32
Compute the CRC32 of the segment of the byte array given by the specified size and offset
CRC_LENGTH - Static variable in class org.apache.kafka.common.record.Record
 
CRC_OFFSET - Static variable in class org.apache.kafka.common.record.Record
The current offset and size for all the fixed-length fields
createdMs - Variable in class org.apache.kafka.clients.producer.internals.RecordBatch
 
createdTime() - Method in class org.apache.kafka.clients.ClientRequest
 
CURR_VERSION - Static variable in class org.apache.kafka.common.protocol.Protocol
 
current(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
CURRENT_MAGIC_VALUE - Static variable in class org.apache.kafka.common.record.Record
The current "magic" value
currentRequestSchema(int) - Static method in class org.apache.kafka.common.protocol.ProtoUtils
 
currentResponseSchema(int) - Static method in class org.apache.kafka.common.protocol.ProtoUtils
 
curSchema - Static variable in class org.apache.kafka.common.requests.ConsumerMetadataRequest
 
curSchema - Static variable in class org.apache.kafka.common.requests.FetchRequest
 
curSchema - Static variable in class org.apache.kafka.common.requests.FetchResponse
 
curSchema - Static variable in class org.apache.kafka.common.requests.HeartbeatRequest
 
curSchema - Static variable in class org.apache.kafka.common.requests.JoinGroupRequest
 
curSchema - Static variable in class org.apache.kafka.common.requests.JoinGroupResponse
 
curSchema - Static variable in class org.apache.kafka.common.requests.ListOffsetRequest
 
curSchema - Static variable in class org.apache.kafka.common.requests.ListOffsetResponse
 
curSchema - Static variable in class org.apache.kafka.common.requests.MetadataRequest
 
curSchema - Static variable in class org.apache.kafka.common.requests.OffsetCommitRequest
 
curSchema - Static variable in class org.apache.kafka.common.requests.OffsetCommitResponse
 
curSchema - Static variable in class org.apache.kafka.common.requests.OffsetFetchRequest
 
curSchema - Static variable in class org.apache.kafka.common.requests.OffsetFetchResponse
 
curSchema - Static variable in class org.apache.kafka.common.requests.ProduceRequest
 

D

deallocate(ByteBuffer, int) - Method in class org.apache.kafka.clients.producer.internals.BufferPool
Return buffers to the pool.
deallocate(ByteBuffer) - Method in class org.apache.kafka.clients.producer.internals.BufferPool
 
deallocate(RecordBatch) - Method in class org.apache.kafka.clients.producer.internals.RecordAccumulator
Deallocate the record batch
DEFAULT_CONSUMER_ID - Static variable in class org.apache.kafka.common.requests.OffsetCommitRequest
 
DEFAULT_CONSUMER_ID - Static variable in class org.apache.kafka.common.requests.OffsetFetchRequest
 
DEFAULT_GENERATION_ID - Static variable in class org.apache.kafka.common.requests.OffsetCommitRequest
 
DEFAULT_GENERATION_ID - Static variable in class org.apache.kafka.common.requests.OffsetFetchRequest
 
defaultValue - Variable in class org.apache.kafka.common.protocol.types.Field
 
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a new configuration with no special validation logic
define(String, ConfigDef.Type, ConfigDef.Validator, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a required parameter with no default value
define(String, ConfigDef.Type, ConfigDef.Importance, String) - Method in class org.apache.kafka.common.config.ConfigDef
Define a required parameter with no default value and no special validation logic
description() - Method in interface org.apache.kafka.common.Metric
A description of what is measured...this will be "" if no description was given
description() - Method in class org.apache.kafka.common.metrics.CompoundStat.NamedMeasurable
 
description() - Method in class org.apache.kafka.common.metrics.KafkaMetric
 
description() - Method in class org.apache.kafka.common.metrics.stats.Percentile
 
DESCRIPTOR_HASH_MISMATCH - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
destination() - Method in class org.apache.kafka.common.network.ByteBufferSend
 
destination() - Method in interface org.apache.kafka.common.network.Send
The numeric id for the destination of this send
disconnect(int) - Method in interface org.apache.kafka.common.network.Selectable
Begin disconnecting the connection identified by the given id
disconnect(int) - Method in class org.apache.kafka.common.network.Selector
Disconnect any connections for the given id (if there are any).
disconnected() - Method in interface org.apache.kafka.common.network.Selectable
The list of connections that finished disconnecting on the last poll() call.
disconnected() - Method in class org.apache.kafka.common.network.Selector
 
doc - Variable in class org.apache.kafka.common.protocol.types.Field
 
done(TopicPartition, long, RuntimeException) - Method in class org.apache.kafka.clients.producer.internals.ProduceRequestResult
Mark this request as complete and unblock any threads waiting on its completion.
done(long, RuntimeException) - Method in class org.apache.kafka.clients.producer.internals.RecordBatch
Complete the request
drain(Cluster, Set<Node>, int, long) - Method in class org.apache.kafka.clients.producer.internals.RecordAccumulator
Drain all the data for the given nodes and collate them into a list of batches that will fit within the specified size on a per-node basis.
drainedMs - Variable in class org.apache.kafka.clients.producer.internals.RecordBatch
 

E

empty() - Static method in class org.apache.kafka.common.Cluster
Create an empty cluster instance with no nodes and no topic-partitions.
emptyRecords(ByteBuffer, CompressionType, int) - Static method in class org.apache.kafka.common.record.MemoryRecords
 
emptyRecords(ByteBuffer, CompressionType) - Static method in class org.apache.kafka.common.record.MemoryRecords
 
ENABLE_AUTO_COMMIT_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
If true, periodically commit to Kafka the offsets of messages already returned by the consumer.
ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.Range
 
ensureValid(String, Object) - Method in interface org.apache.kafka.common.config.ConfigDef.Validator
 
ensureValid(String, Object) - Method in class org.apache.kafka.common.config.ConfigDef.ValidString
 
ensureValid() - Method in class org.apache.kafka.common.record.Record
Throw an InvalidRecordException if isValid is false for this record
entrySet() - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
equals(Object) - Method in class org.apache.kafka.common.Node
 
equals(Object) - Method in class org.apache.kafka.common.protocol.types.Struct
 
equals(Object) - Method in class org.apache.kafka.common.record.Record
 
equals(Object) - Method in class org.apache.kafka.common.requests.AbstractRequestResponse
 
equals(Object) - Method in class org.apache.kafka.common.TopicPartition
 
error() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
 
error(TopicPartition) - Method in class org.apache.kafka.clients.consumer.OffsetMetadata
 
error() - Method in class org.apache.kafka.clients.producer.internals.ProduceRequestResult
The error thrown (generally on the server) while processing this request
errorCode() - Method in class org.apache.kafka.common.requests.ConsumerMetadataResponse
 
errorCode - Variable in class org.apache.kafka.common.requests.FetchResponse.PartitionData
 
errorCode() - Method in class org.apache.kafka.common.requests.HeartbeatResponse
 
errorCode() - Method in class org.apache.kafka.common.requests.JoinGroupResponse
 
errorCode - Variable in class org.apache.kafka.common.requests.ListOffsetResponse.PartitionData
 
errorCode - Variable in class org.apache.kafka.common.requests.OffsetFetchResponse.PartitionData
 
errorCode - Variable in class org.apache.kafka.common.requests.ProduceResponse.PartitionResponse
 
ErrorLoggingCallback - Class in org.apache.kafka.clients.producer.internals
 
ErrorLoggingCallback(String, byte[], byte[], boolean) - Constructor for class org.apache.kafka.clients.producer.internals.ErrorLoggingCallback
 
errorNext(RuntimeException) - Method in class org.apache.kafka.clients.producer.MockProducer
Complete the earliest uncompleted call with the given error.
Errors - Enum in org.apache.kafka.common.protocol
This class contains all the client-server errors--those errors that must be sent from the server to the client.
errors() - Method in class org.apache.kafka.common.requests.MetadataResponse
 
estimatedBytesWritten() - Method in class org.apache.kafka.common.record.Compressor
 
eventCount - Variable in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
eventWindow() - Method in class org.apache.kafka.common.metrics.MetricConfig
 
eventWindow(long) - Method in class org.apache.kafka.common.metrics.MetricConfig
 
exception() - Method in enum org.apache.kafka.common.protocol.Errors
An instance of the exception
expectResponse() - Method in class org.apache.kafka.clients.ClientRequest
 

F

fetch() - Method in class org.apache.kafka.clients.producer.internals.Metadata
Get the current cluster info without blocking
FETCH_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The minimum amount of memory that should be used to fetch at least one message for a partition.
FETCH_MAX_WAIT_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The maximum amount of time the server will block before answering the fetch request if there isn't sufficient data to immediately satisfy ConsumerConfig.FETCH_MIN_BYTES_CONFIG.
FETCH_MIN_BYTES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The minimum amount of data the server should return for a fetch request.
FETCH_REQUEST - Static variable in class org.apache.kafka.common.protocol.Protocol
 
FETCH_REQUEST_PARTITION_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
FETCH_REQUEST_TOPIC_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
FETCH_REQUEST_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
FETCH_RESPONSE - Static variable in class org.apache.kafka.common.protocol.Protocol
 
FETCH_RESPONSE_PARTITION_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
FETCH_RESPONSE_TOPIC_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
FETCH_RESPONSE_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
fetchData() - Method in class org.apache.kafka.common.requests.FetchRequest
 
FetchRequest - Class in org.apache.kafka.common.requests
 
FetchRequest(int, int, int, Map<TopicPartition, FetchRequest.PartitionData>) - Constructor for class org.apache.kafka.common.requests.FetchRequest
 
FetchRequest(Struct) - Constructor for class org.apache.kafka.common.requests.FetchRequest
 
FetchRequest.PartitionData - Class in org.apache.kafka.common.requests
 
FetchRequest.PartitionData(long, int) - Constructor for class org.apache.kafka.common.requests.FetchRequest.PartitionData
 
FetchResponse - Class in org.apache.kafka.common.requests
 
FetchResponse(Map<TopicPartition, FetchResponse.PartitionData>) - Constructor for class org.apache.kafka.common.requests.FetchResponse
 
FetchResponse(Struct) - Constructor for class org.apache.kafka.common.requests.FetchResponse
 
FetchResponse.PartitionData - Class in org.apache.kafka.common.requests
 
FetchResponse.PartitionData(short, long, ByteBuffer) - Constructor for class org.apache.kafka.common.requests.FetchResponse.PartitionData
 
Field - Class in org.apache.kafka.common.protocol.types
A field in a schema
Field(int, String, Type, String, Object, Schema) - Constructor for class org.apache.kafka.common.protocol.types.Field
 
Field(int, String, Type, String, Object) - Constructor for class org.apache.kafka.common.protocol.types.Field
 
Field(String, Type, String, Object) - Constructor for class org.apache.kafka.common.protocol.types.Field
 
Field(String, Type, String) - Constructor for class org.apache.kafka.common.protocol.types.Field
 
Field(String, Type) - Constructor for class org.apache.kafka.common.protocol.types.Field
 
fields() - Method in class org.apache.kafka.common.protocol.types.Schema
Get all the fields in this schema
fillInStackTrace() - Method in exception org.apache.kafka.common.errors.ApiException
 
flush() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
forCode(short) - Static method in enum org.apache.kafka.common.protocol.Errors
Throw the exception if there is one
forException(Throwable) - Static method in enum org.apache.kafka.common.protocol.Errors
Return the error instance associated with this exception (or UKNOWN if there is none)
forId(int) - Static method in enum org.apache.kafka.common.protocol.ApiKeys
 
forId(int) - Static method in enum org.apache.kafka.common.record.CompressionType
 
formatAddress(String, Integer) - Static method in class org.apache.kafka.common.utils.Utils
Formats hostname and port number as a "host:port" address string, surrounding IPv6 addresses with braces '[', ']'
forName(String) - Static method in enum org.apache.kafka.common.record.CompressionType
 
fromBin(int) - Method in interface org.apache.kafka.common.metrics.stats.Histogram.BinScheme
 
fromBin(int) - Method in class org.apache.kafka.common.metrics.stats.Histogram.ConstantBinScheme
 
fromBin(int) - Method in class org.apache.kafka.common.metrics.stats.Histogram.LinearBinScheme
 
fromByte(byte) - Static method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.BD
 
fromByte(byte) - Static method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.FLG
 
future - Variable in class org.apache.kafka.clients.producer.internals.RecordAccumulator.RecordAppendResult
 
FutureRecordMetadata - Class in org.apache.kafka.clients.producer.internals
The future result of a record send
FutureRecordMetadata(ProduceRequestResult, long) - Constructor for class org.apache.kafka.clients.producer.internals.FutureRecordMetadata
 

G

generationId() - Method in class org.apache.kafka.common.requests.JoinGroupResponse
 
generationId() - Method in class org.apache.kafka.common.requests.OffsetCommitRequest
 
get() - Method in class org.apache.kafka.clients.producer.internals.FutureRecordMetadata
 
get(long, TimeUnit) - Method in class org.apache.kafka.clients.producer.internals.FutureRecordMetadata
 
get(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
get(int) - Method in class org.apache.kafka.common.protocol.types.Schema
Get a field by its slot in the record array
get(String) - Method in class org.apache.kafka.common.protocol.types.Schema
Get a field by its name
get(Field) - Method in class org.apache.kafka.common.protocol.types.Struct
Get the value for the field directly by the field index with no lookup needed (faster!)
get(String) - Method in class org.apache.kafka.common.protocol.types.Struct
Get the record value for the field with the given name by doing a hash table lookup (slower!)
get(Object) - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
getArray(Field) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getArray(String) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getBlockMaximumSize() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.BD
 
getBoolean(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getBytes(Field) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getBytes(String) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getClass(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getConfiguredInstance(String, Class<T>) - Method in class org.apache.kafka.common.config.AbstractConfig
Get a configured instance of the give class specified by the given configuration key.
getConfiguredInstances(String, Class<T>) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getDouble(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getHost(String) - Static method in class org.apache.kafka.common.utils.Utils
Extracts the hostname from a "host:port" address string.
getInt(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getInt(Field) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getInt(String) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getList(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getLong(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getLong(Field) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getLong(String) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getPort(String) - Static method in class org.apache.kafka.common.utils.Utils
Extracts the port number from a "host:port" address string.
getSensor(String) - Method in class org.apache.kafka.common.metrics.Metrics
Get the sensor with the given name if it exists
getShort(Field) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getShort(String) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getString(String) - Method in class org.apache.kafka.common.config.AbstractConfig
 
getString(Field) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getString(String) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getStruct(Field) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getStruct(String) - Method in class org.apache.kafka.common.protocol.types.Struct
 
getValue() - Method in class org.apache.kafka.common.utils.Crc32
 
getVersion() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.FLG
 
GROUP_ID_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The identifier of the group this consumer belongs to.
groupDataByTopic(Map<TopicPartition, T>) - Static method in class org.apache.kafka.common.utils.CollectionUtils
group data by topic
groupDataByTopic(List<TopicPartition>) - Static method in class org.apache.kafka.common.utils.CollectionUtils
group partitions by topic
groupGenerationId() - Method in class org.apache.kafka.common.requests.HeartbeatRequest
 
groupId() - Method in class org.apache.kafka.common.requests.ConsumerMetadataRequest
 
groupId() - Method in class org.apache.kafka.common.requests.HeartbeatRequest
 
groupId() - Method in class org.apache.kafka.common.requests.JoinGroupRequest
 
groupId() - Method in class org.apache.kafka.common.requests.OffsetCommitRequest
 
groupId() - Method in class org.apache.kafka.common.requests.OffsetFetchRequest
 

H

hasField(String) - Method in class org.apache.kafka.common.protocol.types.Struct
Check if the struct contains a field.
hashCode() - Method in class org.apache.kafka.common.Node
 
hashCode() - Method in class org.apache.kafka.common.protocol.types.Struct
 
hashCode() - Method in class org.apache.kafka.common.record.Record
 
hashCode() - Method in class org.apache.kafka.common.requests.AbstractRequestResponse
 
hashCode() - Method in class org.apache.kafka.common.TopicPartition
 
hasKey() - Method in class org.apache.kafka.common.record.Record
Does the record have a key?
hasNext() - Method in class org.apache.kafka.common.utils.AbstractIterator
 
hasResponse() - Method in class org.apache.kafka.clients.ClientResponse
 
hasRoomFor(byte[], byte[]) - Method in class org.apache.kafka.common.record.MemoryRecords
Check if we have room for a new record containing the given key/value pair Note that the return value is based on the estimate of the bytes written to the compressor, which may not be accurate if compression is really used.
hasUnsent() - Method in class org.apache.kafka.clients.producer.internals.RecordAccumulator
 
header() - Method in class org.apache.kafka.common.requests.RequestSend
 
HEADER_SIZE - Static variable in class org.apache.kafka.common.record.Record
The size for the record header
HEARTBEAT_FREQUENCY - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The number of times a consumer sends a heartbeat to the co-ordinator broker within a ConsumerConfig.SESSION_TIMEOUT_MS time window.
HEARTBEAT_REQUEST - Static variable in class org.apache.kafka.common.protocol.Protocol
 
HEARTBEAT_REQUEST_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
HEARTBEAT_RESPONSE - Static variable in class org.apache.kafka.common.protocol.Protocol
 
HEARTBEAT_RESPONSE_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
HeartbeatRequest - Class in org.apache.kafka.common.requests
 
HeartbeatRequest(String, int, String) - Constructor for class org.apache.kafka.common.requests.HeartbeatRequest
 
HeartbeatRequest(Struct) - Constructor for class org.apache.kafka.common.requests.HeartbeatRequest
 
HeartbeatResponse - Class in org.apache.kafka.common.requests
 
HeartbeatResponse(short) - Constructor for class org.apache.kafka.common.requests.HeartbeatResponse
 
HeartbeatResponse(Struct) - Constructor for class org.apache.kafka.common.requests.HeartbeatResponse
 
highWatermark - Variable in class org.apache.kafka.common.requests.FetchResponse.PartitionData
 
Histogram - Class in org.apache.kafka.common.metrics.stats
 
Histogram(Histogram.BinScheme) - Constructor for class org.apache.kafka.common.metrics.stats.Histogram
 
Histogram.BinScheme - Interface in org.apache.kafka.common.metrics.stats
 
Histogram.ConstantBinScheme - Class in org.apache.kafka.common.metrics.stats
 
Histogram.ConstantBinScheme(int, double, double) - Constructor for class org.apache.kafka.common.metrics.stats.Histogram.ConstantBinScheme
 
Histogram.LinearBinScheme - Class in org.apache.kafka.common.metrics.stats
 
Histogram.LinearBinScheme(int, double) - Constructor for class org.apache.kafka.common.metrics.stats.Histogram.LinearBinScheme
 
history() - Method in class org.apache.kafka.clients.producer.MockProducer
Get the list of sent records since the last call to MockProducer.clear()
host() - Method in class org.apache.kafka.common.Node
The host name for this node

I

id() - Method in class org.apache.kafka.common.Node
The node id of this node
id - Variable in enum org.apache.kafka.common.protocol.ApiKeys
the perminant and immutable id of an API--this can't change ever
id - Variable in enum org.apache.kafka.common.record.CompressionType
 
in(List<String>) - Static method in class org.apache.kafka.common.config.ConfigDef.ValidString
 
inFlightRequestCount() - Method in interface org.apache.kafka.clients.KafkaClient
The number of currently in-flight requests for which we have not yet returned a response
inFlightRequestCount() - Method in class org.apache.kafka.clients.NetworkClient
Get the number of in-flight requests
init(List<KafkaMetric>) - Method in class org.apache.kafka.common.metrics.JmxReporter
 
init(List<KafkaMetric>) - Method in interface org.apache.kafka.common.metrics.MetricsReporter
This is called when the reporter is first registered to initially register all existing metrics
initialValue - Variable in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
initiateClose() - Method in class org.apache.kafka.clients.producer.internals.Sender
Start closing the sender (won't actually complete until all data is sent out)
instance(Field) - Method in class org.apache.kafka.common.protocol.types.Struct
Create a struct for the schema of a container type (struct or array).
instance(String) - Method in class org.apache.kafka.common.protocol.types.Struct
Create a struct instance for the given field which must be a container type (struct or array)
inSyncReplicas() - Method in class org.apache.kafka.common.PartitionInfo
The subset of the replicas that are in sync, that is caught-up to the leader and ready to take over as leader if the leader should fail
INT16 - Static variable in class org.apache.kafka.common.protocol.types.Type
 
INT32 - Static variable in class org.apache.kafka.common.protocol.types.Type
 
INT64 - Static variable in class org.apache.kafka.common.protocol.types.Type
 
INT8 - Static variable in class org.apache.kafka.common.protocol.types.Type
 
InvalidMetadataException - Exception in org.apache.kafka.common.errors
An exception that may indicate the client's metadata is out of date
InvalidMetadataException() - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidMetadataException
 
InvalidRecordException - Exception in org.apache.kafka.common.record
 
InvalidRecordException(String) - Constructor for exception org.apache.kafka.common.record.InvalidRecordException
 
InvalidTopicException - Exception in org.apache.kafka.common.errors
The client has attempted to perform an operation on an invalid topic.
InvalidTopicException() - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(String) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
InvalidTopicException(Throwable) - Constructor for exception org.apache.kafka.common.errors.InvalidTopicException
 
isBlockChecksumSet() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.FLG
 
isBlockIndependenceSet() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.FLG
 
isCancelled() - Method in class org.apache.kafka.clients.producer.internals.FutureRecordMetadata
 
isComplete(long, MetricConfig) - Method in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
isContentChecksumSet() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.FLG
 
isContentSizeSet() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.FLG
 
isDone() - Method in class org.apache.kafka.clients.producer.internals.FutureRecordMetadata
 
isEmpty() - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
isFull() - Method in class org.apache.kafka.common.record.MemoryRecords
 
isPresetDictionarySet() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.FLG
 
isReady(Node, long) - Method in interface org.apache.kafka.clients.KafkaClient
Check if we are currently ready to send another request to the given node but don't attempt to connect if we aren't.
isReady(Node, long) - Method in class org.apache.kafka.clients.NetworkClient
Check if the node with the given id is ready to send more requests.
isUpperBound() - Method in class org.apache.kafka.common.metrics.Quota
 
isValid() - Method in class org.apache.kafka.common.record.Record
Returns true if the crc stored with the record matches the crc computed off the record contents
iterableRecords(ByteBuffer) - Static method in class org.apache.kafka.common.record.MemoryRecords
 
iterator() - Method in class org.apache.kafka.common.record.MemoryRecords
 

J

JmxReporter - Class in org.apache.kafka.common.metrics
Register metrics in JMX as dynamic mbeans based on the metric names
JmxReporter() - Constructor for class org.apache.kafka.common.metrics.JmxReporter
 
JmxReporter(String) - Constructor for class org.apache.kafka.common.metrics.JmxReporter
Create a JMX reporter that prefixes all metrics with the given string.
JOIN_GROUP_REQUEST - Static variable in class org.apache.kafka.common.protocol.Protocol
 
JOIN_GROUP_REQUEST_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
JOIN_GROUP_RESPONSE - Static variable in class org.apache.kafka.common.protocol.Protocol
 
JOIN_GROUP_RESPONSE_TOPIC_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
JOIN_GROUP_RESPONSE_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
JoinGroupRequest - Class in org.apache.kafka.common.requests
 
JoinGroupRequest(String, int, List<String>, String, String) - Constructor for class org.apache.kafka.common.requests.JoinGroupRequest
 
JoinGroupRequest(Struct) - Constructor for class org.apache.kafka.common.requests.JoinGroupRequest
 
JoinGroupResponse - Class in org.apache.kafka.common.requests
 
JoinGroupResponse(short, int, String, List<TopicPartition>) - Constructor for class org.apache.kafka.common.requests.JoinGroupResponse
 
JoinGroupResponse(short) - Constructor for class org.apache.kafka.common.requests.JoinGroupResponse
 
JoinGroupResponse(Struct) - Constructor for class org.apache.kafka.common.requests.JoinGroupResponse
 

K

KafkaClient - Interface in org.apache.kafka.clients
The interface for NetworkClient
KafkaConsumer - Class in org.apache.kafka.clients.consumer
A Kafka client that consumes records from a Kafka cluster.
KafkaConsumer(Map<String, Object>) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a set of key-value pairs as configuration.
KafkaConsumer(Map<String, Object>, ConsumerRebalanceCallback) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a set of key-value pairs as configuration and a ConsumerRebalanceCallback implementation
KafkaConsumer(Properties) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a Properties object as configuration.
KafkaConsumer(Properties, ConsumerRebalanceCallback) - Constructor for class org.apache.kafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a Properties object as configuration and a ConsumerRebalanceCallback implementation.
KafkaException - Exception in org.apache.kafka.common
The base class of all other Kafka exceptions
KafkaException(String, Throwable) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException(String) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException(Throwable) - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaException() - Constructor for exception org.apache.kafka.common.KafkaException
 
KafkaLZ4BlockInputStream - Class in org.apache.kafka.common.message
A partial implementation of the v1.4.1 LZ4 Frame format.
KafkaLZ4BlockInputStream(InputStream) - Constructor for class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
Create a new InputStream that will decompress data using the LZ4 algorithm.
KafkaLZ4BlockOutputStream - Class in org.apache.kafka.common.message
A partial implementation of the v1.4.1 LZ4 Frame format.
KafkaLZ4BlockOutputStream(OutputStream, int, boolean) - Constructor for class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
Create a new OutputStream that will compress data using the LZ4 algorithm.
KafkaLZ4BlockOutputStream(OutputStream, int) - Constructor for class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
Create a new OutputStream that will compress data using the LZ4 algorithm.
KafkaLZ4BlockOutputStream(OutputStream) - Constructor for class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
Create a new OutputStream that will compress data using the LZ4 algorithm.
KafkaLZ4BlockOutputStream.BD - Class in org.apache.kafka.common.message
 
KafkaLZ4BlockOutputStream.BD() - Constructor for class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.BD
 
KafkaLZ4BlockOutputStream.BD(int) - Constructor for class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.BD
 
KafkaLZ4BlockOutputStream.FLG - Class in org.apache.kafka.common.message
 
KafkaLZ4BlockOutputStream.FLG() - Constructor for class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.FLG
 
KafkaLZ4BlockOutputStream.FLG(boolean) - Constructor for class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.FLG
 
KafkaMetric - Class in org.apache.kafka.common.metrics
 
KafkaProducer - Class in org.apache.kafka.clients.producer
A Kafka client that publishes records to the Kafka cluster.
KafkaProducer(Map<String, Object>) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration.
KafkaProducer(Properties) - Constructor for class org.apache.kafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration.
KafkaThread - Class in org.apache.kafka.common.utils
A wrapper for Thread that sets things up nicely
KafkaThread(String, Runnable, boolean) - Constructor for class org.apache.kafka.common.utils.KafkaThread
 
key() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The key (or null if no key is specified)
key() - Method in class org.apache.kafka.clients.producer.ProducerRecord
The key (or null if no key is specified)
key() - Method in class org.apache.kafka.common.record.Record
A ByteBuffer containing the message key
KEY_OFFSET - Static variable in class org.apache.kafka.common.record.Record
 
KEY_SIZE_LENGTH - Static variable in class org.apache.kafka.common.record.Record
 
KEY_SIZE_OFFSET - Static variable in class org.apache.kafka.common.record.Record
 
keySet() - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
keySize() - Method in class org.apache.kafka.common.record.Record
The length of the key in bytes

L

lastAttemptMs - Variable in class org.apache.kafka.clients.producer.internals.RecordBatch
 
lastUpdate() - Method in class org.apache.kafka.clients.producer.internals.Metadata
The last time metadata was updated.
lastWindowMs - Variable in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
latestVersion(int) - Static method in class org.apache.kafka.common.protocol.ProtoUtils
 
leader() - Method in class org.apache.kafka.common.PartitionInfo
The node id of the node currently acting as a leader for this partition or -1 if there is no leader
leaderFor(TopicPartition) - Method in class org.apache.kafka.common.Cluster
Get the current leader for the given topic-partition
LeaderNotAvailableException - Exception in org.apache.kafka.common.errors
There is no currently available leader for the given partition (either because a leadership election is in progress or because all replicas are down).
LeaderNotAvailableException(String) - Constructor for exception org.apache.kafka.common.errors.LeaderNotAvailableException
 
leastLoadedNode(long) - Method in interface org.apache.kafka.clients.KafkaClient
Choose the node with the fewest outstanding requests.
leastLoadedNode(long) - Method in class org.apache.kafka.clients.NetworkClient
Choose the node with the fewest outstanding requests which is at least eligible for connection.
lessThan(double) - Static method in class org.apache.kafka.common.metrics.Quota
 
LINGER_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
linger.ms
LIST_OFFSET_REQUEST - Static variable in class org.apache.kafka.common.protocol.Protocol
 
LIST_OFFSET_REQUEST_PARTITION_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
LIST_OFFSET_REQUEST_TOPIC_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
LIST_OFFSET_REQUEST_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
LIST_OFFSET_RESPONSE - Static variable in class org.apache.kafka.common.protocol.Protocol
 
LIST_OFFSET_RESPONSE_PARTITION_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
LIST_OFFSET_RESPONSE_TOPIC_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
LIST_OFFSET_RESPONSE_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
ListOffsetRequest - Class in org.apache.kafka.common.requests
 
ListOffsetRequest(int, Map<TopicPartition, ListOffsetRequest.PartitionData>) - Constructor for class org.apache.kafka.common.requests.ListOffsetRequest
 
ListOffsetRequest(Struct) - Constructor for class org.apache.kafka.common.requests.ListOffsetRequest
 
ListOffsetRequest.PartitionData - Class in org.apache.kafka.common.requests
 
ListOffsetRequest.PartitionData(long, int) - Constructor for class org.apache.kafka.common.requests.ListOffsetRequest.PartitionData
 
ListOffsetResponse - Class in org.apache.kafka.common.requests
 
ListOffsetResponse(Map<TopicPartition, ListOffsetResponse.PartitionData>) - Constructor for class org.apache.kafka.common.requests.ListOffsetResponse
 
ListOffsetResponse(Struct) - Constructor for class org.apache.kafka.common.requests.ListOffsetResponse
 
ListOffsetResponse.PartitionData - Class in org.apache.kafka.common.requests
 
ListOffsetResponse.PartitionData(short, List<Long>) - Constructor for class org.apache.kafka.common.requests.ListOffsetResponse.PartitionData
 
LOG_OVERHEAD - Static variable in interface org.apache.kafka.common.record.Records
 
LogEntry - Class in org.apache.kafka.common.record
An offset and record pair
LogEntry(long, Record) - Constructor for class org.apache.kafka.common.record.LogEntry
 
logUnused() - Method in class org.apache.kafka.common.config.AbstractConfig
Log warnings for any unused configurations
LZ4_FRAME_INCOMPRESSIBLE_MASK - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
LZ4_MAX_HEADER_LENGTH - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 

M

MAGIC - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
magic() - Method in class org.apache.kafka.common.record.Record
The magic version of this record
MAGIC_LENGTH - Static variable in class org.apache.kafka.common.record.Record
 
MAGIC_OFFSET - Static variable in class org.apache.kafka.common.record.Record
 
main(String[]) - Static method in class org.apache.kafka.clients.producer.ProducerConfig
 
main(String[]) - Static method in class org.apache.kafka.clients.tools.ProducerPerformance
 
makeNext() - Method in class org.apache.kafka.common.record.MemoryRecords.RecordsIterator
 
makeNext() - Method in class org.apache.kafka.common.utils.AbstractIterator
 
mark(int) - Method in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
markSupported() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
Max - Class in org.apache.kafka.common.metrics.stats
A SampledStat that gives the max over its samples.
Max() - Constructor for class org.apache.kafka.common.metrics.stats.Max
 
MAX_API_KEY - Static variable in enum org.apache.kafka.common.protocol.ApiKeys
 
MAX_IN_FLIGHT_REQUESTS_PER_CONNECTION - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
max.in.flight.requests.per.connection
MAX_REQUEST_SIZE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
max.request.size
maxBytes - Variable in class org.apache.kafka.common.requests.FetchRequest.PartitionData
 
maxNumOffsets - Variable in class org.apache.kafka.common.requests.ListOffsetRequest.PartitionData
 
maxRecordSize - Variable in class org.apache.kafka.clients.producer.internals.RecordBatch
 
maxWait() - Method in class org.apache.kafka.common.requests.FetchRequest
 
maybeThrow() - Method in enum org.apache.kafka.common.protocol.Errors
Throw the exception corresponding to this error if there is one
Measurable - Interface in org.apache.kafka.common.metrics
A measurable quantity that can be registered as a metric
MeasurableStat - Interface in org.apache.kafka.common.metrics
A MeasurableStat is a Stat that is also Measurable (i.e.
measure(MetricConfig, long) - Method in interface org.apache.kafka.common.metrics.Measurable
Measure this quantity and return the result as a double
measure(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Rate
 
measure(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
measure(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.Total
 
MemoryRecords - Class in org.apache.kafka.common.record
A Records implementation backed by a ByteBuffer.
MemoryRecords.RecordsIterator - Class in org.apache.kafka.common.record
 
MemoryRecords.RecordsIterator(ByteBuffer, CompressionType, boolean) - Constructor for class org.apache.kafka.common.record.MemoryRecords.RecordsIterator
 
Metadata - Class in org.apache.kafka.clients.producer.internals
A class encapsulating some of the logic around metadata.
Metadata() - Constructor for class org.apache.kafka.clients.producer.internals.Metadata
Create a metadata instance with reasonable defaults
Metadata(long, long) - Constructor for class org.apache.kafka.clients.producer.internals.Metadata
Create a new Metadata instance
metadata - Variable in class org.apache.kafka.common.requests.OffsetCommitRequest.PartitionData
 
metadata - Variable in class org.apache.kafka.common.requests.OffsetFetchResponse.PartitionData
 
METADATA_FETCH_TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The maximum amount of time to block waiting to fetch metadata about a topic the first time a record is received from that topic.
METADATA_FETCH_TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metadata.fetch.timeout.ms
METADATA_MAX_AGE_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metadata.max.age.ms
METADATA_REQUEST - Static variable in class org.apache.kafka.common.protocol.Protocol
 
METADATA_REQUEST_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
METADATA_RESPONSE - Static variable in class org.apache.kafka.common.protocol.Protocol
 
METADATA_RESPONSE_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
MetadataRequest - Class in org.apache.kafka.common.requests
 
MetadataRequest(List<String>) - Constructor for class org.apache.kafka.common.requests.MetadataRequest
 
MetadataRequest(Struct) - Constructor for class org.apache.kafka.common.requests.MetadataRequest
 
MetadataResponse - Class in org.apache.kafka.common.requests
 
MetadataResponse(Cluster) - Constructor for class org.apache.kafka.common.requests.MetadataResponse
 
MetadataResponse(Struct) - Constructor for class org.apache.kafka.common.requests.MetadataResponse
 
Metric - Interface in org.apache.kafka.common
A numerical metric tracked for monitoring purposes
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metric.reporters
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metric.reporters
metricChange(KafkaMetric) - Method in class org.apache.kafka.common.metrics.JmxReporter
 
metricChange(KafkaMetric) - Method in interface org.apache.kafka.common.metrics.MetricsReporter
This is called whenever a metric is updated or added
MetricConfig - Class in org.apache.kafka.common.metrics
Configuration values for metrics
MetricConfig() - Constructor for class org.apache.kafka.common.metrics.MetricConfig
 
metrics() - Method in interface org.apache.kafka.clients.consumer.Consumer
Return a map of metrics maintained by the consumer
metrics() - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
 
metrics() - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
metrics() - Method in class org.apache.kafka.clients.producer.KafkaProducer
 
metrics() - Method in class org.apache.kafka.clients.producer.MockProducer
 
metrics() - Method in interface org.apache.kafka.clients.producer.Producer
Return a map of metrics maintained by the producer
Metrics - Class in org.apache.kafka.common.metrics
A registry of sensors and metrics.
Metrics() - Constructor for class org.apache.kafka.common.metrics.Metrics
Create a metrics repository with no metric reporters and default configuration.
Metrics(Time) - Constructor for class org.apache.kafka.common.metrics.Metrics
Create a metrics repository with no metric reporters and default configuration.
Metrics(MetricConfig) - Constructor for class org.apache.kafka.common.metrics.Metrics
Create a metrics repository with no reporters and the given default config.
Metrics(MetricConfig, List<MetricsReporter>, Time) - Constructor for class org.apache.kafka.common.metrics.Metrics
Create a metrics repository with a default config and the given metric reporters
metrics() - Method in class org.apache.kafka.common.metrics.Metrics
Get all the metrics currently maintained indexed by metric name
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metrics.num.samples
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metrics.num.samples
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
metrics.sample.window.ms
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
metrics.sample.window.ms
MetricsReporter - Interface in org.apache.kafka.common.metrics
A plugin interface to allow things to listen as new metrics are created so they can be reported.
milliseconds() - Method in class org.apache.kafka.common.utils.SystemTime
 
milliseconds() - Method in interface org.apache.kafka.common.utils.Time
The current time in milliseconds
Min - Class in org.apache.kafka.common.metrics.stats
A SampledStat that gives the min over its samples.
Min() - Constructor for class org.apache.kafka.common.metrics.stats.Min
 
minBytes() - Method in class org.apache.kafka.common.requests.FetchRequest
 
MockConsumer - Class in org.apache.kafka.clients.consumer
A mock of the Consumer interface you can use for testing code that uses Kafka.
MockConsumer() - Constructor for class org.apache.kafka.clients.consumer.MockConsumer
 
MockProducer - Class in org.apache.kafka.clients.producer
A mock of the producer interface you can use for testing code that uses Kafka.
MockProducer(Cluster, boolean) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a mock producer
MockProducer(boolean) - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a new mock producer with invented metadata the given autoComplete setting.
MockProducer() - Constructor for class org.apache.kafka.clients.producer.MockProducer
Create a new auto completing mock producer Equivalent to new MockProducer(true)
moreThan(double) - Static method in class org.apache.kafka.common.metrics.Quota
 
murmur2(byte[]) - Static method in class org.apache.kafka.common.utils.Utils
Generates 32 bit murmur2 hash from byte array

N

name() - Method in interface org.apache.kafka.common.Metric
A unique name for this metric
name() - Method in class org.apache.kafka.common.metrics.CompoundStat.NamedMeasurable
 
name() - Method in class org.apache.kafka.common.metrics.KafkaMetric
 
name() - Method in class org.apache.kafka.common.metrics.Sensor
The name this sensor is registered with.
name() - Method in class org.apache.kafka.common.metrics.stats.Percentile
 
name - Variable in enum org.apache.kafka.common.protocol.ApiKeys
an english description of the api--this is for debugging and can change
name - Variable in class org.apache.kafka.common.protocol.types.Field
 
name - Variable in enum org.apache.kafka.common.record.CompressionType
 
nanoseconds() - Method in class org.apache.kafka.common.utils.SystemTime
 
nanoseconds() - Method in interface org.apache.kafka.common.utils.Time
The current time in nanoseconds
NetworkClient - Class in org.apache.kafka.clients
A network client for asynchronous request/response network i/o.
NetworkClient(Selectable, Metadata, String, int, long, int, int) - Constructor for class org.apache.kafka.clients.NetworkClient
 
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
 
NetworkReceive - Class in org.apache.kafka.common.network
A size delimited Receive that consists of a 4 byte network-ordered size N followed by N bytes of content
NetworkReceive(int, ByteBuffer) - Constructor for class org.apache.kafka.common.network.NetworkReceive
 
NetworkReceive(int) - Constructor for class org.apache.kafka.common.network.NetworkReceive
 
NetworkSend - Class in org.apache.kafka.common.network
A size delimited Send that consists of a 4 byte network-ordered size N followed by N bytes of content
NetworkSend(int, ByteBuffer...) - Constructor for class org.apache.kafka.common.network.NetworkSend
 
newBatchCreated - Variable in class org.apache.kafka.clients.producer.internals.RecordAccumulator.RecordAppendResult
 
newInstance(Class<?>) - Static method in class org.apache.kafka.common.utils.Utils
Instantiate the class
newSample(long) - Method in class org.apache.kafka.common.metrics.stats.Percentiles
 
newSample(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
next() - Method in class org.apache.kafka.common.utils.AbstractIterator
 
nextReadyCheckDelayMs - Variable in class org.apache.kafka.clients.producer.internals.RecordAccumulator.ReadyCheckResult
 
nextRequestHeader(ApiKeys) - Method in interface org.apache.kafka.clients.KafkaClient
Generate a request header for the next request
nextRequestHeader(ApiKeys) - Method in class org.apache.kafka.clients.NetworkClient
Generate a request header for the given API key
NL - Static variable in class org.apache.kafka.common.utils.Utils
 
NO_COMPRESSION - Static variable in class org.apache.kafka.common.record.Record
Compression code for uncompressed records
NO_DEFAULT - Static variable in class org.apache.kafka.common.protocol.types.Field
 
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() - Method in class org.apache.kafka.common.requests.ConsumerMetadataResponse
 
nodes() - Method in class org.apache.kafka.common.Cluster
 
NOT_SUPPORTED - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
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() - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
 
NotEnoughReplicasAfterAppendException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
 
NotEnoughReplicasAfterAppendException(String) - Constructor for exception org.apache.kafka.common.errors.NotEnoughReplicasAfterAppendException
 
NotEnoughReplicasAfterAppendException(Throwable) - 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
This server is not the leader for the given partition
NotLeaderForPartitionException() - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(String) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.NotLeaderForPartitionException
 
notNull(T) - Static method in class org.apache.kafka.common.utils.Utils
Check that the parameter t is not null
numFields() - Method in class org.apache.kafka.common.protocol.types.Schema
The number of fields in this schema
numRecords - Variable in class org.apache.kafka.common.record.Compressor
 

O

offset() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The position of this record in the corresponding Kafka partition.
offset(TopicPartition) - Method in class org.apache.kafka.clients.consumer.OffsetMetadata
The offset of the record in the topic/partition.
offset() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The offset of the record in the topic/partition.
offset() - Method in class org.apache.kafka.common.record.LogEntry
 
offset - Variable in class org.apache.kafka.common.requests.FetchRequest.PartitionData
 
offset - Variable in class org.apache.kafka.common.requests.OffsetCommitRequest.PartitionData
 
offset - Variable in class org.apache.kafka.common.requests.OffsetFetchResponse.PartitionData
 
OFFSET_COMMIT_REQUEST - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_COMMIT_REQUEST_PARTITION_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_COMMIT_REQUEST_TOPIC_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_COMMIT_REQUEST_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_COMMIT_REQUEST_V1 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_COMMIT_RESPONSE - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_COMMIT_RESPONSE_PARTITION_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_COMMIT_RESPONSE_TOPIC_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_COMMIT_RESPONSE_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_FETCH_REQUEST - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_FETCH_REQUEST_PARTITION_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_FETCH_REQUEST_TOPIC_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_FETCH_REQUEST_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_FETCH_RESPONSE - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_FETCH_RESPONSE_PARTITION_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_FETCH_RESPONSE_TOPIC_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_FETCH_RESPONSE_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
OFFSET_LENGTH - Static variable in interface org.apache.kafka.common.record.Records
 
OffsetCommitRequest - Class in org.apache.kafka.common.requests
This wrapper supports both v0 and v1 of OffsetCommitRequest.
OffsetCommitRequest(String, Map<TopicPartition, OffsetCommitRequest.PartitionData>) - Constructor for class org.apache.kafka.common.requests.OffsetCommitRequest
Deprecated. 
OffsetCommitRequest(String, int, String, Map<TopicPartition, OffsetCommitRequest.PartitionData>) - Constructor for class org.apache.kafka.common.requests.OffsetCommitRequest
Constructor for version 1.
OffsetCommitRequest(Struct) - Constructor for class org.apache.kafka.common.requests.OffsetCommitRequest
 
OffsetCommitRequest.PartitionData - Class in org.apache.kafka.common.requests
 
OffsetCommitRequest.PartitionData(long, long, String) - Constructor for class org.apache.kafka.common.requests.OffsetCommitRequest.PartitionData
 
OffsetCommitResponse - Class in org.apache.kafka.common.requests
 
OffsetCommitResponse(Map<TopicPartition, Short>) - Constructor for class org.apache.kafka.common.requests.OffsetCommitResponse
 
OffsetCommitResponse(Struct) - Constructor for class org.apache.kafka.common.requests.OffsetCommitResponse
 
offsetData() - Method in class org.apache.kafka.common.requests.ListOffsetRequest
 
offsetData() - Method in class org.apache.kafka.common.requests.OffsetCommitRequest
 
OffsetFetchRequest - Class in org.apache.kafka.common.requests
This wrapper supports both v0 and v1 of OffsetFetchRequest.
OffsetFetchRequest(String, List<TopicPartition>) - Constructor for class org.apache.kafka.common.requests.OffsetFetchRequest
 
OffsetFetchRequest(Struct) - Constructor for class org.apache.kafka.common.requests.OffsetFetchRequest
 
OffsetFetchResponse - Class in org.apache.kafka.common.requests
 
OffsetFetchResponse(Map<TopicPartition, OffsetFetchResponse.PartitionData>) - Constructor for class org.apache.kafka.common.requests.OffsetFetchResponse
 
OffsetFetchResponse(Struct) - Constructor for class org.apache.kafka.common.requests.OffsetFetchResponse
 
OffsetFetchResponse.PartitionData - Class in org.apache.kafka.common.requests
 
OffsetFetchResponse.PartitionData(long, String, short) - Constructor for class org.apache.kafka.common.requests.OffsetFetchResponse.PartitionData
 
OffsetMetadata - Class in org.apache.kafka.clients.consumer
The metadata for an offset commit that has been acknowledged by the server
OffsetMetadata(Map<TopicPartition, Long>, Map<TopicPartition, RuntimeException>) - Constructor for class org.apache.kafka.clients.consumer.OffsetMetadata
 
OffsetMetadata(Map<TopicPartition, Long>) - Constructor for class org.apache.kafka.clients.consumer.OffsetMetadata
 
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
 
OffsetOutOfRangeException - Exception in org.apache.kafka.common.errors
This offset is either larger or smaller than the range of offsets the server has for the given partition.
OffsetOutOfRangeException() - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
OffsetOutOfRangeException(String) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
OffsetOutOfRangeException(Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
OffsetOutOfRangeException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.OffsetOutOfRangeException
 
offsets - Variable in class org.apache.kafka.common.requests.ListOffsetResponse.PartitionData
 
offsetsBeforeTime(long, Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
Fetches offsets before a certain timestamp
offsetsBeforeTime(long, Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Fetches offsets before a certain timestamp.
offsetsBeforeTime(long, Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
oldest(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
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.
onCompletion(RecordMetadata, Exception) - Method in class org.apache.kafka.clients.producer.internals.ErrorLoggingCallback
 
onPartitionsAssigned(Consumer, Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceCallback
A callback method the user can implement to provide handling of customized offsets on completion of a successful rebalance operation.
onPartitionsRevoked(Consumer, Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.ConsumerRebalanceCallback
A callback method the user can implement to provide handling of offset commits to a customized store on the start of a rebalance operation.
org.apache.kafka.clients - package org.apache.kafka.clients
 
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.clients.producer.internals - package org.apache.kafka.clients.producer.internals
 
org.apache.kafka.clients.tools - package org.apache.kafka.clients.tools
 
org.apache.kafka.common - package org.apache.kafka.common
 
org.apache.kafka.common.config - package org.apache.kafka.common.config
 
org.apache.kafka.common.errors - package org.apache.kafka.common.errors
 
org.apache.kafka.common.message - package org.apache.kafka.common.message
 
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.network - package org.apache.kafka.common.network
 
org.apache.kafka.common.protocol - package org.apache.kafka.common.protocol
 
org.apache.kafka.common.protocol.types - package org.apache.kafka.common.protocol.types
 
org.apache.kafka.common.record - package org.apache.kafka.common.record
 
org.apache.kafka.common.requests - package org.apache.kafka.common.requests
 
org.apache.kafka.common.utils - package org.apache.kafka.common.utils
 

P

parse(Map<?, ?>) - Method in class org.apache.kafka.common.config.ConfigDef
Parse and validate configs against this configuration definition.
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.ConsumerMetadataRequest
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.ConsumerMetadataResponse
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.FetchRequest
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.FetchResponse
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.HeartbeatRequest
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.HeartbeatResponse
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.JoinGroupRequest
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.JoinGroupResponse
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.ListOffsetRequest
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.ListOffsetResponse
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.MetadataRequest
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.MetadataResponse
 
parse(ByteBuffer, int) - Static method in class org.apache.kafka.common.requests.OffsetCommitRequest
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.OffsetCommitRequest
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.OffsetCommitResponse
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.OffsetFetchRequest
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.OffsetFetchResponse
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.ProduceRequest
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.ProduceResponse
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.RequestHeader
 
parse(ByteBuffer) - Static method in class org.apache.kafka.common.requests.ResponseHeader
 
parseAndValidateAddresses(List<String>) - Static method in class org.apache.kafka.common.utils.ClientUtils
 
parseRequest(int, int, ByteBuffer) - Static method in class org.apache.kafka.common.protocol.ProtoUtils
 
parseResponse(int, ByteBuffer) - Static method in class org.apache.kafka.common.protocol.ProtoUtils
 
partition() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The partition from which this record is received
partition(ProducerRecord, Cluster) - Method in class org.apache.kafka.clients.producer.internals.Partitioner
Compute the partition for the given record.
partition() - Method in class org.apache.kafka.clients.producer.ProducerRecord
The partition to which the record will be sent (or null if no partition was specified)
partition() - Method in class org.apache.kafka.clients.producer.RecordMetadata
The partition the record was sent to
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_ASSIGNMENT_STRATEGY - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The friendly name of the partition assignment strategy that the server will use to distribute partition ownership amongst consumer instances when group management is used
PARTITION_METADATA_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
Partitioner - Class in org.apache.kafka.clients.producer.internals
The default partitioning strategy: If a partition is specified in the record, use it If no partition is specified but a key is present choose a partition based on a hash of the key If no partition or key is present choose a partition in a round-robin fashion
Partitioner() - Constructor for class org.apache.kafka.clients.producer.internals.Partitioner
 
PartitionInfo - Class in org.apache.kafka.common
Information about a topic-partition.
PartitionInfo(String, int, Node, Node[], Node[]) - Constructor for class org.apache.kafka.common.PartitionInfo
 
partitionRecords() - Method in class org.apache.kafka.common.requests.ProduceRequest
 
partitions() - Method in class org.apache.kafka.common.requests.OffsetFetchRequest
 
partitionsFor(String) - Method in class org.apache.kafka.clients.producer.KafkaProducer
 
partitionsFor(String) - Method in class org.apache.kafka.clients.producer.MockProducer
 
partitionsFor(String) - Method in interface org.apache.kafka.clients.producer.Producer
Get a list of partitions for the given topic for custom partition assignment.
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
payload() - Method in class org.apache.kafka.common.network.NetworkReceive
 
peek() - Method in class org.apache.kafka.common.utils.AbstractIterator
 
Percentile - Class in org.apache.kafka.common.metrics.stats
 
Percentile(String, double) - Constructor for class org.apache.kafka.common.metrics.stats.Percentile
 
Percentile(String, String, 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
 
poll(long) - Method in interface org.apache.kafka.clients.consumer.Consumer
Fetches data for the subscribed list of topics and partitions
poll(long) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Fetches data for the topics or partitions specified using one of the subscribe APIs.
poll(long) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
poll(List<ClientRequest>, long, long) - Method in interface org.apache.kafka.clients.KafkaClient
Initiate the sending of the given requests and return any completed responses.
poll(List<ClientRequest>, long, long) - Method in class org.apache.kafka.clients.NetworkClient
Initiate the given requests and check for any new responses, waiting up to the specified time.
poll(long, List<NetworkSend>) - Method in interface org.apache.kafka.common.network.Selectable
Initiate any sends provided, and make progress on any other I/O operations in-flight (connections, disconnections, existing sends, and receives)
poll(long, List<NetworkSend>) - Method in class org.apache.kafka.common.network.Selector
Do whatever I/O can be done on each connection without blocking.
poolableSize() - Method in class org.apache.kafka.clients.producer.internals.BufferPool
The buffer size that will be retained in the free list after use
port() - Method in class org.apache.kafka.common.Node
The port for this node
position(Collection<TopicPartition>) - Method in interface org.apache.kafka.clients.consumer.Consumer
Returns the fetch position of the next message for the specified topic partition to be used on the next poll()
position(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Returns the fetch position of the next message for the specified topic partition to be used on the next poll()
position(Collection<TopicPartition>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
PREMATURE_EOS - Static variable in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
PRODUCE_REQUEST - Static variable in class org.apache.kafka.common.protocol.Protocol
 
PRODUCE_REQUEST_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
PRODUCE_RESPONSE - Static variable in class org.apache.kafka.common.protocol.Protocol
 
PRODUCE_RESPONSE_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
Producer - Interface in org.apache.kafka.clients.producer
The interface for the KafkaProducer
ProducerConfig - Class in org.apache.kafka.clients.producer
Configuration for the Kafka Producer.
ProduceRequest - Class in org.apache.kafka.common.requests
 
ProduceRequest(short, int, Map<TopicPartition, ByteBuffer>) - Constructor for class org.apache.kafka.common.requests.ProduceRequest
 
ProduceRequest(Struct) - Constructor for class org.apache.kafka.common.requests.ProduceRequest
 
ProduceRequestResult - Class in org.apache.kafka.clients.producer.internals
A class that models the future completion of a produce request for a single partition.
ProduceRequestResult() - Constructor for class org.apache.kafka.clients.producer.internals.ProduceRequestResult
 
ProduceResponse - Class in org.apache.kafka.common.requests
 
ProduceResponse(Map<TopicPartition, ProduceResponse.PartitionResponse>) - Constructor for class org.apache.kafka.common.requests.ProduceResponse
 
ProduceResponse(Struct) - Constructor for class org.apache.kafka.common.requests.ProduceResponse
 
ProduceResponse.PartitionResponse - Class in org.apache.kafka.common.requests
 
ProduceResponse.PartitionResponse(short, long) - Constructor for class org.apache.kafka.common.requests.ProduceResponse.PartitionResponse
 
ProducerPerformance - Class in org.apache.kafka.clients.tools
 
ProducerPerformance() - Constructor for class org.apache.kafka.clients.tools.ProducerPerformance
 
ProducerRecord - Class in org.apache.kafka.clients.producer
A key/value pair to be sent to Kafka.
ProducerRecord(String, Integer, byte[], byte[]) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Creates a record to be sent to a specified topic and partition
ProducerRecord(String, byte[], byte[]) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Create a record to be sent to Kafka
ProducerRecord(String, byte[]) - Constructor for class org.apache.kafka.clients.producer.ProducerRecord
Create a record with no key
Protocol - Class in org.apache.kafka.common.protocol
 
Protocol() - Constructor for class org.apache.kafka.common.protocol.Protocol
 
ProtoUtils - Class in org.apache.kafka.common.protocol
 
ProtoUtils() - Constructor for class org.apache.kafka.common.protocol.ProtoUtils
 
purgeObsoleteSamples(MetricConfig, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
put(ByteBuffer) - Method in class org.apache.kafka.common.record.Compressor
 
put(byte[], int, int) - Method in class org.apache.kafka.common.record.Compressor
 
put(K, V) - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
putByte(byte) - Method in class org.apache.kafka.common.record.Compressor
 
putIfAbsent(K, V) - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
putInt(int) - Method in class org.apache.kafka.common.record.Compressor
 
putLong(long) - Method in class org.apache.kafka.common.record.Compressor
 
putRecord(byte[], byte[], CompressionType, int, int) - Method in class org.apache.kafka.common.record.Compressor
 
putRecord(byte[], byte[]) - Method in class org.apache.kafka.common.record.Compressor
 

Q

queued() - Method in class org.apache.kafka.clients.producer.internals.BufferPool
The number of threads blocked waiting on memory
quota() - Method in class org.apache.kafka.common.metrics.MetricConfig
 
quota(Quota) - Method in class org.apache.kafka.common.metrics.MetricConfig
 
Quota - Class in org.apache.kafka.common.metrics
An upper or lower bound for metrics
Quota(double, boolean) - Constructor for class org.apache.kafka.common.metrics.Quota
 
QuotaViolationException - Exception in org.apache.kafka.common.metrics
Thrown when a sensor records a value that causes a metric to go outside the bounds configured as its quota
QuotaViolationException(String) - Constructor for exception org.apache.kafka.common.metrics.QuotaViolationException
 

R

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
 
rate - Variable in enum org.apache.kafka.common.record.CompressionType
 
Rate.SampledTotal - Class in org.apache.kafka.common.metrics.stats
 
Rate.SampledTotal() - Constructor for class org.apache.kafka.common.metrics.stats.Rate.SampledTotal
 
read() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
read(byte[], int, int) - Method in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
read(ByteBuffer) - Method in class org.apache.kafka.common.protocol.types.ArrayOf
 
read(ByteBuffer) - Method in class org.apache.kafka.common.protocol.types.Schema
Read a struct from the buffer
read(ByteBuffer) - Method in class org.apache.kafka.common.protocol.types.Type
 
read() - Method in class org.apache.kafka.common.record.ByteBufferInputStream
 
read(byte[], int, int) - Method in class org.apache.kafka.common.record.ByteBufferInputStream
 
readFrom(ScatteringByteChannel) - Method in class org.apache.kafka.common.network.ByteBufferReceive
 
readFrom(ScatteringByteChannel) - Method in class org.apache.kafka.common.network.NetworkReceive
 
readFrom(ScatteringByteChannel) - Method in interface org.apache.kafka.common.network.Receive
Read bytes into this receive from the given channel
readUnsignedInt(ByteBuffer) - Static method in class org.apache.kafka.common.utils.Utils
Read an unsigned integer from the current position in the buffer, incrementing the position by 4 bytes
readUnsignedInt(ByteBuffer, int) - Static method in class org.apache.kafka.common.utils.Utils
Read an unsigned integer from the given position without modifying the buffers position
readUnsignedIntLE(InputStream) - Static method in class org.apache.kafka.common.utils.Utils
Read an unsigned integer stored in little-endian format from the InputStream.
readUnsignedIntLE(byte[], int) - Static method in class org.apache.kafka.common.utils.Utils
Read an unsigned integer stored in little-endian format from a byte array at a given offset.
ready(Node, long) - Method in interface org.apache.kafka.clients.KafkaClient
Initiate a connection to the given node (if necessary), and return true if already connected.
ready(Node, long) - Method in class org.apache.kafka.clients.NetworkClient
Begin connecting to the given node, return true if we are already connected and ready to send to that node.
ready(Cluster, long) - Method in class org.apache.kafka.clients.producer.internals.RecordAccumulator
Get a list of nodes whose partitions are ready to be sent, and the time to when any partition will be ready if no partitions are ready yet; If the ready nodes list is non-empty, the timeout value will be 0.
readyNodes - Variable in class org.apache.kafka.clients.producer.internals.RecordAccumulator.ReadyCheckResult
 
Receive - Interface in org.apache.kafka.common.network
This interface models the in-progress reading of data from a channel to a source identified by an integer id
RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
receive.buffer.bytes
receivedTime() - Method in class org.apache.kafka.clients.ClientResponse
 
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The amount of time to wait before attempting to reconnect to a given host.
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(MetricConfig, double, long) - Method in interface org.apache.kafka.common.metrics.Stat
Record the given value
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.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.Total
 
record() - Method in class org.apache.kafka.common.record.LogEntry
 
Record - Class in org.apache.kafka.common.record
A record: a serialized key and value along with the associated CRC and other fields
Record(ByteBuffer) - Constructor for class org.apache.kafka.common.record.Record
 
Record(byte[], byte[], CompressionType, int, int) - Constructor for class org.apache.kafka.common.record.Record
A constructor to create a LogRecord.
Record(byte[], byte[], CompressionType) - Constructor for class org.apache.kafka.common.record.Record
 
Record(byte[], CompressionType) - Constructor for class org.apache.kafka.common.record.Record
 
Record(byte[], byte[]) - Constructor for class org.apache.kafka.common.record.Record
 
Record(byte[]) - Constructor for class org.apache.kafka.common.record.Record
 
RECORD_OVERHEAD - Static variable in class org.apache.kafka.common.record.Record
The amount of overhead bytes in a record
RecordAccumulator - Class in org.apache.kafka.clients.producer.internals
This class acts as a queue that accumulates records into MemoryRecords instances to be sent to the server.
RecordAccumulator(int, long, long, long, boolean, Metrics, Time) - Constructor for class org.apache.kafka.clients.producer.internals.RecordAccumulator
Create a new record accumulator
RecordAccumulator.ReadyCheckResult - Class in org.apache.kafka.clients.producer.internals
 
RecordAccumulator.ReadyCheckResult(Set<Node>, long, boolean) - Constructor for class org.apache.kafka.clients.producer.internals.RecordAccumulator.ReadyCheckResult
 
RecordAccumulator.RecordAppendResult - Class in org.apache.kafka.clients.producer.internals
 
RecordAccumulator.RecordAppendResult(FutureRecordMetadata, boolean, boolean) - Constructor for class org.apache.kafka.clients.producer.internals.RecordAccumulator.RecordAppendResult
 
RecordBatch - Class in org.apache.kafka.clients.producer.internals
A batch of records that is or will be sent.
RecordBatch(TopicPartition, MemoryRecords, long) - Constructor for class org.apache.kafka.clients.producer.internals.RecordBatch
 
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
 
recordCount - Variable in class org.apache.kafka.clients.producer.internals.RecordBatch
 
RecordMetadata - Class in org.apache.kafka.clients.producer
The metadata for a record that has been acknowledged by the server
RecordMetadata(TopicPartition, long, long) - Constructor for class org.apache.kafka.clients.producer.RecordMetadata
 
records(int...) - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
 
records - Variable in class org.apache.kafka.clients.producer.internals.RecordBatch
 
Records - Interface in org.apache.kafka.common.record
A binary format which consists of a 4 byte size, an 8 byte offset, and the record bytes.
recordSet - Variable in class org.apache.kafka.common.requests.FetchResponse.PartitionData
 
recordSize(byte[], byte[]) - Static method in class org.apache.kafka.common.record.Record
 
recordSize(int, int) - Static method in class org.apache.kafka.common.record.Record
 
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
 
recordWritten(int) - Method in class org.apache.kafka.common.record.Compressor
 
reenqueue(RecordBatch, long) - Method in class org.apache.kafka.clients.producer.internals.RecordAccumulator
Re-enqueue the given record batch in the accumulator to retry
refreshBackoff() - Method in class org.apache.kafka.clients.producer.internals.Metadata
The metadata refresh backoff in ms
reify() - Method in class org.apache.kafka.common.network.ByteBufferReceive
 
reify() - Method in class org.apache.kafka.common.network.ByteBufferSend
 
reify() - Method in class org.apache.kafka.common.network.NetworkReceive
 
reify() - Method in interface org.apache.kafka.common.network.Receive
Turn this receive into ByteBuffer instances, if possible (otherwise returns null).
reify() - Method in interface org.apache.kafka.common.network.Send
An optional method to turn this send into an array of ByteBuffers if possible (otherwise returns null)
relativeOffset() - Method in class org.apache.kafka.clients.producer.internals.FutureRecordMetadata
 
remaining() - Method in class org.apache.kafka.common.network.ByteBufferSend
 
remaining() - Method in interface org.apache.kafka.common.network.Send
The number of bytes remaining to send
remove() - Method in class org.apache.kafka.common.utils.AbstractIterator
 
remove(Object) - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
remove(Object, Object) - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
replace(K, V, V) - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
replace(K, V) - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
replicaId() - Method in class org.apache.kafka.common.requests.FetchRequest
 
replicaId() - Method in class org.apache.kafka.common.requests.ListOffsetRequest
 
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
request() - Method in class org.apache.kafka.clients.ClientRequest
 
request() - Method in class org.apache.kafka.clients.ClientResponse
 
REQUEST_HEADER - Static variable in class org.apache.kafka.common.protocol.Protocol
 
RequestHeader - Class in org.apache.kafka.common.requests
The header for a request in the Kafka protocol
RequestHeader(Struct) - Constructor for class org.apache.kafka.common.requests.RequestHeader
 
RequestHeader(short, String, int) - Constructor for class org.apache.kafka.common.requests.RequestHeader
 
RequestHeader(short, short, String, int) - Constructor for class org.apache.kafka.common.requests.RequestHeader
 
requestLatencyMs() - Method in class org.apache.kafka.clients.ClientResponse
 
REQUESTS - Static variable in class org.apache.kafka.common.protocol.Protocol
 
requestSchema(int, int) - Static method in class org.apache.kafka.common.protocol.ProtoUtils
 
RequestSend - Class in org.apache.kafka.common.requests
A send object for a kafka request
RequestSend(int, RequestHeader, Struct) - Constructor for class org.apache.kafka.common.requests.RequestSend
 
requestUpdate() - Method in class org.apache.kafka.clients.producer.internals.Metadata
Request an update of the current cluster metadata info, return the current version before the update
reset() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
reset(long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
reset() - Method in class org.apache.kafka.common.utils.Crc32
 
RESPONSE_HEADER - Static variable in class org.apache.kafka.common.protocol.Protocol
 
responseBody() - Method in class org.apache.kafka.clients.ClientResponse
 
responseData() - Method in class org.apache.kafka.common.requests.FetchResponse
 
responseData() - Method in class org.apache.kafka.common.requests.ListOffsetResponse
 
responseData() - Method in class org.apache.kafka.common.requests.OffsetCommitResponse
 
responseData() - Method in class org.apache.kafka.common.requests.OffsetFetchResponse
 
ResponseHeader - Class in org.apache.kafka.common.requests
A response header in the kafka protocol.
ResponseHeader(Struct) - Constructor for class org.apache.kafka.common.requests.ResponseHeader
 
ResponseHeader(int) - Constructor for class org.apache.kafka.common.requests.ResponseHeader
 
RESPONSES - Static variable in class org.apache.kafka.common.protocol.Protocol
 
responses() - Method in class org.apache.kafka.common.requests.ProduceResponse
 
responseSchema(int, int) - Static method in class org.apache.kafka.common.protocol.ProtoUtils
 
RetriableException - Exception in org.apache.kafka.common.errors
A retryable 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.producer.ProducerConfig
retries
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
retry.backoff.ms
run() - Method in class org.apache.kafka.clients.producer.internals.Sender
The main run loop for the sender thread
run(long) - Method in class org.apache.kafka.clients.producer.internals.Sender
Run a single iteration of sending

S

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
 
SampledStat.Sample(double, long) - Constructor for class org.apache.kafka.common.metrics.stats.SampledStat.Sample
 
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
 
Schema - Class in org.apache.kafka.common.protocol.types
The schema for a compound record definition
Schema(Field...) - Constructor for class org.apache.kafka.common.protocol.types.Schema
 
schema() - Method in class org.apache.kafka.common.protocol.types.Struct
The schema for this struct.
SchemaException - Exception in org.apache.kafka.common.protocol.types
 
SchemaException(String) - Constructor for exception org.apache.kafka.common.protocol.types.SchemaException
 
seek(Map<TopicPartition, Long>) - Method in interface org.apache.kafka.clients.consumer.Consumer
Overrides the fetch positions that the consumer will use on the next fetch request.
seek(Map<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(Map<TopicPartition, Long>) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
Selectable - Interface in org.apache.kafka.common.network
An interface for asynchronous, multi-channel network I/O
Selector - Class in org.apache.kafka.common.network
A selector interface for doing non-blocking multi-connection network I/O.
Selector(Metrics, Time) - Constructor for class org.apache.kafka.common.network.Selector
Create a new selector
send(ProducerRecord) - Method in class org.apache.kafka.clients.producer.KafkaProducer
Asynchronously send a record to a topic.
send(ProducerRecord, 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) - Method in class org.apache.kafka.clients.producer.MockProducer
Adds the record to the list of sent records.
send(ProducerRecord, Callback) - Method in class org.apache.kafka.clients.producer.MockProducer
Adds the record to the list of sent records.
send(ProducerRecord) - Method in interface org.apache.kafka.clients.producer.Producer
Send the given record asynchronously and return a future which will eventually contain the response information.
send(ProducerRecord, Callback) - Method in interface org.apache.kafka.clients.producer.Producer
Send a record and invoke the given callback when the record has been acknowledged by the server
Send - Interface in org.apache.kafka.common.network
This interface models the in-progress sending of data to a destination identified by an integer id.
SEND_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
send.buffer.bytes
Sender - Class in org.apache.kafka.clients.producer.internals
The background thread that handles the sending of produce requests to the Kafka cluster.
Sender(KafkaClient, Metadata, RecordAccumulator, int, short, int, int, Metrics, Time) - Constructor for class org.apache.kafka.clients.producer.internals.Sender
 
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...) - 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 - Class in org.apache.kafka.common.metrics
A sensor applies a continuous sequence of numerical values to a set of associated metrics.
SESSION_TIMEOUT_MS - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The timeout after which, if the poll(timeout) is not invoked, the consumer is marked dead and a rebalance operation is triggered for the group identified by ConsumerConfig.GROUP_ID_CONFIG.
sessionTimeout() - Method in class org.apache.kafka.common.requests.JoinGroupRequest
 
set(Field, Object) - Method in class org.apache.kafka.common.protocol.types.Struct
Set the given field to the specified value
set(String, Object) - Method in class org.apache.kafka.common.protocol.types.Struct
Set the field specified by the given name to the value
size() - Method in class org.apache.kafka.common.network.ByteBufferSend
 
size() - Method in class org.apache.kafka.common.record.Record
The complete serialized size of this record in bytes (including crc, header attributes, etc)
size() - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
SIZE_LENGTH - Static variable in interface org.apache.kafka.common.record.Records
 
sizeInBytes() - Method in class org.apache.kafka.common.record.MemoryRecords
The size of this record set
sizeInBytes() - Method in interface org.apache.kafka.common.record.Records
The size of these records in bytes
sizeOf(Object) - Method in class org.apache.kafka.common.protocol.types.ArrayOf
 
sizeOf(Object) - Method in class org.apache.kafka.common.protocol.types.Schema
The size of the given record
sizeOf() - Method in class org.apache.kafka.common.protocol.types.Struct
Get the serialized size of this object
sizeOf(Object) - Method in class org.apache.kafka.common.protocol.types.Type
 
sizeOf() - Method in class org.apache.kafka.common.requests.AbstractRequestResponse
Get the serialized size of this object
skip(long) - Method in class org.apache.kafka.common.message.KafkaLZ4BlockInputStream
 
sleep(long) - Method in class org.apache.kafka.common.utils.SystemTime
 
sleep(long) - Method in interface org.apache.kafka.common.utils.Time
Sleep for the given number of milliseconds
SOCKET_RECEIVE_BUFFER_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The size of the TCP send buffer to use when fetching data
source() - Method in class org.apache.kafka.common.network.ByteBufferReceive
 
source() - Method in class org.apache.kafka.common.network.NetworkReceive
 
source() - Method in interface org.apache.kafka.common.network.Receive
The numeric id of the source from which we are receiving data.
stat() - Method in class org.apache.kafka.common.metrics.CompoundStat.NamedMeasurable
 
Stat - Interface in org.apache.kafka.common.metrics
A Stat is a quanity such as average, max, etc that is computed off the stream of updates to a sensor
stats() - Method in interface org.apache.kafka.common.metrics.CompoundStat
 
stats() - Method in class org.apache.kafka.common.metrics.stats.Percentiles
 
strategy() - Method in class org.apache.kafka.common.requests.JoinGroupRequest
 
STRING - Static variable in class org.apache.kafka.common.protocol.types.Type
 
Struct - Class in org.apache.kafka.common.protocol.types
A record that can be serialized and deserialized according to a pre-defined schema
Struct(Schema) - Constructor for class org.apache.kafka.common.protocol.types.Struct
 
struct - Variable in class org.apache.kafka.common.requests.AbstractRequestResponse
 
subscribe(String...) - Method in interface org.apache.kafka.clients.consumer.Consumer
Incrementally subscribe to the given list of topics.
subscribe(TopicPartition...) - Method in interface org.apache.kafka.clients.consumer.Consumer
Incrementally subscribes to a specific topic and partition.
subscribe(String...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Incrementally subscribes to the given list of topics and uses the consumer's group management functionality
subscribe(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Incrementally subscribes to a specific topic partition and does not use the consumer's group management functionality.
subscribe(String...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
subscribe(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
SystemTime - Class in org.apache.kafka.common.utils
A time implementation that uses the system clock and sleep call
SystemTime() - Constructor for class org.apache.kafka.common.utils.SystemTime
 

T

Time - Interface in org.apache.kafka.common.utils
An interface abstracting the clock to use in unit testing classes that make use of clock time
timeout() - Method in class org.apache.kafka.common.requests.ProduceRequest
 
TIMEOUT_CONFIG - Static variable in class org.apache.kafka.clients.producer.ProducerConfig
timeout.ms
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
 
timestamp - Variable in class org.apache.kafka.common.requests.ListOffsetRequest.PartitionData
 
timestamp - Variable in class org.apache.kafka.common.requests.OffsetCommitRequest.PartitionData
 
timeToNextUpdate(long) - Method in class org.apache.kafka.clients.producer.internals.Metadata
The next time to update the cluster info is the maximum of the time the current info will expire and the time the current info can be updated (i.e.
timeUnit() - Method in class org.apache.kafka.common.metrics.MetricConfig
 
timeUnit(TimeUnit) - Method in class org.apache.kafka.common.metrics.MetricConfig
 
timeWindow(long, TimeUnit) - Method in class org.apache.kafka.common.metrics.MetricConfig
 
timeWindowMs() - Method in class org.apache.kafka.common.metrics.MetricConfig
 
toArray(ByteBuffer) - Static method in class org.apache.kafka.common.utils.Utils
Read the given byte buffer into a byte array
toArray(ByteBuffer, int, int) - Static method in class org.apache.kafka.common.utils.Utils
Read a byte array from the given offset and size in the buffer
toBin(double) - Method in interface org.apache.kafka.common.metrics.stats.Histogram.BinScheme
 
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
 
toByte() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.BD
 
toByte() - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream.FLG
 
toBytes() - Method in class org.apache.kafka.common.protocol.types.Struct
Create a byte buffer containing the serialized form of the values in this struct.
toHtmlTable() - Method in class org.apache.kafka.common.config.ConfigDef
 
topic() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The topic this record is received from
topic() - Method in class org.apache.kafka.clients.consumer.ConsumerRecords
 
topic() - Method in class org.apache.kafka.clients.producer.ProducerRecord
The topic this record is being sent to
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_METADATA_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
TOPIC_PRODUCE_DATA_V0 - Static variable in class org.apache.kafka.common.protocol.Protocol
 
topicAndPartition() - Method in class org.apache.kafka.clients.consumer.ConsumerRecord
The TopicPartition object containing the topic and partition
topicPartition() - Method in class org.apache.kafka.clients.producer.internals.ProduceRequestResult
The topic and partition to which the record was appended
topicPartition - Variable in class org.apache.kafka.clients.producer.internals.RecordBatch
 
TopicPartition - Class in org.apache.kafka.common
A topic name and partition number
TopicPartition(String, int) - Constructor for class org.apache.kafka.common.TopicPartition
 
topics() - Method in class org.apache.kafka.clients.producer.internals.Metadata
Get the list of topics we are currently maintaining metadata for
topics() - Method in class org.apache.kafka.common.Cluster
Get all topics.
topics() - Method in class org.apache.kafka.common.requests.JoinGroupRequest
 
topics() - Method in class org.apache.kafka.common.requests.MetadataRequest
 
toString() - Method in class org.apache.kafka.clients.ClientRequest
 
toString() - Method in class org.apache.kafka.clients.ClientResponse
 
toString() - Method in class org.apache.kafka.clients.producer.internals.RecordBatch
 
toString() - Method in class org.apache.kafka.clients.producer.ProducerRecord
 
toString() - Method in class org.apache.kafka.common.Cluster
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.Range
 
toString() - Method in class org.apache.kafka.common.config.ConfigDef.ValidString
 
toString() - Method in class org.apache.kafka.common.metrics.stats.Histogram
 
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.protocol.types.ArrayOf
 
toString() - Method in class org.apache.kafka.common.protocol.types.Schema
Display a string representation of the schema
toString() - Method in class org.apache.kafka.common.protocol.types.Struct
 
toString() - Method in class org.apache.kafka.common.record.LogEntry
 
toString() - Method in class org.apache.kafka.common.record.Record
 
toString() - Method in class org.apache.kafka.common.requests.AbstractRequestResponse
 
toString() - Method in class org.apache.kafka.common.requests.ProduceResponse.PartitionResponse
 
toString() - Method in class org.apache.kafka.common.requests.RequestSend
 
toString() - Method in class org.apache.kafka.common.TopicPartition
 
toStruct() - Method in class org.apache.kafka.common.requests.AbstractRequestResponse
 
Total - Class in org.apache.kafka.common.metrics.stats
An un-windowed cumulative total maintained over all time.
Total() - Constructor for class org.apache.kafka.common.metrics.stats.Total
 
Total(double) - Constructor for class org.apache.kafka.common.metrics.stats.Total
 
TOTAL_BUFFER_MEMORY_CONFIG - Static variable in class org.apache.kafka.clients.consumer.ConsumerConfig
The total memory used by the consumer to buffer records received from the server.
totalMemory() - Method in class org.apache.kafka.clients.producer.internals.BufferPool
The total memory managed by this pool
tryAppend(byte[], byte[], Callback) - Method in class org.apache.kafka.clients.producer.internals.RecordBatch
Append the record to the current record set and return the relative offset within that record set
type() - Method in class org.apache.kafka.common.protocol.types.ArrayOf
 
type - Variable in class org.apache.kafka.common.protocol.types.Field
 
type() - Method in class org.apache.kafka.common.protocol.types.Field
 
Type - Class in org.apache.kafka.common.protocol.types
A serializable type
Type() - Constructor for class org.apache.kafka.common.protocol.types.Type
 

U

unallocatedMemory() - Method in class org.apache.kafka.clients.producer.internals.BufferPool
Get the unallocated memory (not in the free list or in use)
unitName() - Method in class org.apache.kafka.common.metrics.stats.Rate
 
UNKNOWN_CONSUMER_ID - Static variable in class org.apache.kafka.common.requests.JoinGroupResponse
 
UNKNOWN_GENERATION_ID - Static variable in class org.apache.kafka.common.requests.JoinGroupResponse
 
unknownLeadersExist - Variable in class org.apache.kafka.clients.producer.internals.RecordAccumulator.ReadyCheckResult
 
UnknownServerException - Exception in org.apache.kafka.common.errors
An error occurred on the server for which the client doesn't have a corresponding error code.
UnknownServerException() - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownServerException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownServerException
 
UnknownTopicOrPartitionException - Exception in org.apache.kafka.common.errors
This topic/partition doesn't exist
UnknownTopicOrPartitionException() - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(String) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
UnknownTopicOrPartitionException(String, Throwable) - Constructor for exception org.apache.kafka.common.errors.UnknownTopicOrPartitionException
 
unsubscribe(String...) - Method in interface org.apache.kafka.clients.consumer.Consumer
Unsubscribe from the specific topics.
unsubscribe(TopicPartition...) - Method in interface org.apache.kafka.clients.consumer.Consumer
Unsubscribe from the specific topic partitions.
unsubscribe(String...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Unsubscribe from the specific topics.
unsubscribe(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.KafkaConsumer
Unsubscribe from the specific topic partitions.
unsubscribe(String...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
unsubscribe(TopicPartition...) - Method in class org.apache.kafka.clients.consumer.MockConsumer
 
unused() - Method in class org.apache.kafka.common.config.AbstractConfig
 
update(Cluster, long) - Method in class org.apache.kafka.clients.producer.internals.Metadata
Update the cluster metadata
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Avg
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Count
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Max
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Min
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Percentiles
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.Rate.SampledTotal
 
update(SampledStat.Sample, MetricConfig, double, long) - Method in class org.apache.kafka.common.metrics.stats.SampledStat
 
update(byte[], int, int) - Method in class org.apache.kafka.common.utils.Crc32
 
update(int) - Method in class org.apache.kafka.common.utils.Crc32
 
updateInt(int) - Method in class org.apache.kafka.common.utils.Crc32
Update the CRC32 given an integer
utf8(byte[]) - Static method in class org.apache.kafka.common.utils.Utils
Turn the given UTF8 byte array into a string
utf8(String) - Static method in class org.apache.kafka.common.utils.Utils
Turn a string into a utf8 byte[]
utf8Length(CharSequence) - Static method in class org.apache.kafka.common.utils.Utils
Get the length for UTF8-encoding a string without encoding it first
Utils - Class in org.apache.kafka.common.utils
 
Utils() - Constructor for class org.apache.kafka.common.utils.Utils
 

V

validate(Object) - Method in class org.apache.kafka.common.protocol.types.ArrayOf
 
validate(Object) - Method in class org.apache.kafka.common.protocol.types.Schema
 
validate() - Method in class org.apache.kafka.common.protocol.types.Struct
Validate the contents of this struct against its schema
validate(Object) - Method in class org.apache.kafka.common.protocol.types.Type
 
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 interface org.apache.kafka.common.Metric
The value of the metric
value() - Method in class org.apache.kafka.common.metrics.KafkaMetric
 
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() - Method in class org.apache.kafka.common.record.Record
A ByteBuffer containing the value of this record
VALUE_SIZE_LENGTH - Static variable in class org.apache.kafka.common.record.Record
 
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.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.protocol.ApiKeys
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.protocol.Errors
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.common.record.CompressionType
Returns the enum constant of this type with the specified name.
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.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.protocol.ApiKeys
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.protocol.Errors
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.record.CompressionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.kafka.common.utils.CopyOnWriteMap
 
valueSize() - Method in class org.apache.kafka.common.record.Record
The length of the value in bytes

W

wakeup() - Method in interface org.apache.kafka.clients.KafkaClient
Wake up the client if it is currently blocked waiting for I/O
wakeup() - Method in class org.apache.kafka.clients.NetworkClient
Interrupt the client if it is blocked waiting on I/O.
wakeup() - Method in class org.apache.kafka.clients.producer.internals.Sender
Wake up the selector associated with this send thread
wakeup() - Method in interface org.apache.kafka.common.network.Selectable
Wakeup this selector if it is blocked on I/O
wakeup() - Method in class org.apache.kafka.common.network.Selector
Interrupt the selector if it is blocked waiting to do I/O.
wasDisconnected() - Method in class org.apache.kafka.clients.ClientResponse
 
wrapForInput(ByteBufferInputStream, CompressionType) - Static method in class org.apache.kafka.common.record.Compressor
 
wrapForOutput(ByteBufferOutputStream, CompressionType, int) - Static method in class org.apache.kafka.common.record.Compressor
 
write(int) - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
write(byte[], int, int) - Method in class org.apache.kafka.common.message.KafkaLZ4BlockOutputStream
 
write(ByteBuffer, Object) - Method in class org.apache.kafka.common.protocol.types.ArrayOf
 
write(ByteBuffer, Object) - Method in class org.apache.kafka.common.protocol.types.Schema
Write a struct to the buffer
write(ByteBuffer, Object) - Method in class org.apache.kafka.common.protocol.types.Type
 
write(int) - Method in class org.apache.kafka.common.record.ByteBufferOutputStream
 
write(byte[], int, int) - Method in class org.apache.kafka.common.record.ByteBufferOutputStream
 
write(ByteBuffer, byte[], byte[], CompressionType, int, int) - Static method in class org.apache.kafka.common.record.Record
 
write(Compressor, long, byte, byte[], byte[], int, int) - Static method in class org.apache.kafka.common.record.Record
 
writeTo(GatheringByteChannel) - Method in class org.apache.kafka.common.network.ByteBufferSend
 
writeTo(GatheringByteChannel) - Method in interface org.apache.kafka.common.network.Send
Write some as-yet unwritten bytes from this send to the provided channel.
writeTo(ByteBuffer) - Method in class org.apache.kafka.common.protocol.types.Struct
Write this struct to a buffer
writeTo(GatheringByteChannel) - Method in class org.apache.kafka.common.record.MemoryRecords
Write the records in this set to the given channel
writeTo(GatheringByteChannel) - Method in interface org.apache.kafka.common.record.Records
Write these records to the given channel
writeTo(ByteBuffer) - Method in class org.apache.kafka.common.requests.AbstractRequestResponse
Write this object to a buffer
writetUnsignedInt(ByteBuffer, long) - Static method in class org.apache.kafka.common.utils.Utils
Write the given long value as a 4 byte unsigned integer.
writeUnsignedInt(ByteBuffer, int, long) - Static method in class org.apache.kafka.common.utils.Utils
Write the given long value as a 4 byte unsigned integer.
writeUnsignedIntLE(OutputStream, int) - Static method in class org.apache.kafka.common.utils.Utils
Write an unsigned integer in little-endian format to the OutputStream.
writeUnsignedIntLE(byte[], int, int) - Static method in class org.apache.kafka.common.utils.Utils
Write an unsigned integer in little-endian format to a byte array at a given offset.
writtenUncompressed - Variable in class org.apache.kafka.common.record.Compressor
 

A B C D E F G H I J K L M N O P Q R S T U V W