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

A

AbstractApiMessageSerde - Class in org.apache.kafka.server.common.serialization
This is an implementation of RecordSerde with ApiMessageAndVersion but implementors need to implement AbstractApiMessageSerde.apiMessageFor(short) to return a ApiMessage instance for the given apiKey.
AbstractApiMessageSerde() - Constructor for class org.apache.kafka.server.common.serialization.AbstractApiMessageSerde
 
add(long, DeferredEvent) - Method in class org.apache.kafka.deferred.DeferredEventQueue
Add a new deferred event to be completed by the provided offset.
add(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
add(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
add(E) - Method in class org.apache.kafka.server.mutable.BoundedList
 
add(int, E) - Method in class org.apache.kafka.server.mutable.BoundedList
 
add(TimerTask) - Method in class org.apache.kafka.server.util.timer.SystemTimer
 
add(TimerTask) - Method in interface org.apache.kafka.server.util.timer.Timer
Add a new task to this executor.
add(TimerTaskEntry) - Method in class org.apache.kafka.server.util.timer.TimingWheel
 
add(T) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
addAll(Collection<? extends E>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
addAll(Collection<? extends E>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
addAll(Collection<? extends E>) - Method in class org.apache.kafka.server.mutable.BoundedList
 
addAll(int, Collection<? extends E>) - Method in class org.apache.kafka.server.mutable.BoundedList
 
addAll(Collection<? extends T>) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
added(E) - Method in interface org.apache.kafka.server.immutable.ImmutableNavigableSet
 
added(E) - Method in interface org.apache.kafka.server.immutable.ImmutableSet
 
added(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
added(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
addReadinessFuture(String, CompletableFuture<?>) - Method in class org.apache.kafka.server.network.EndpointReadyFutures.Builder
Add a readiness future that will block all endpoints.
addReadinessFutures(String, Map<Endpoint, ? extends CompletionStage<?>>) - Method in class org.apache.kafka.server.network.EndpointReadyFutures.Builder
Add readiness futures for individual endpoints.
ADMIN_CLIENT_ID - Static variable in class org.apache.kafka.admin.AdminUtils
 
AdminCommandFailedException - Exception in org.apache.kafka.server.common
 
AdminCommandFailedException(String) - Constructor for exception org.apache.kafka.server.common.AdminCommandFailedException
 
AdminCommandFailedException(String, Throwable) - Constructor for exception org.apache.kafka.server.common.AdminCommandFailedException
 
AdminOperationException - Exception in org.apache.kafka.server.common
 
AdminOperationException(String) - Constructor for exception org.apache.kafka.server.common.AdminOperationException
 
AdminOperationException(Throwable) - Constructor for exception org.apache.kafka.server.common.AdminOperationException
 
AdminUtils - Class in org.apache.kafka.admin
 
AdminUtils() - Constructor for class org.apache.kafka.admin.AdminUtils
 
advanceClock(long) - Method in class org.apache.kafka.server.util.timer.SystemTimer
Advances the clock if there is an expired bucket.
advanceClock(long) - Method in interface org.apache.kafka.server.util.timer.Timer
Advance the internal clock, executing any tasks whose expiration has been reached within the duration of the passed timeout.
advanceClock(long) - Method in class org.apache.kafka.server.util.timer.TimingWheel
 
ALL_TOPIC_CONFIG_SYNONYMS - Static variable in class org.apache.kafka.server.config.ServerTopicConfigSynonyms
Maps topic configurations to their equivalent broker configurations.
ApiMessageAndVersion - Class in org.apache.kafka.server.common
An ApiMessage and an associated version.
ApiMessageAndVersion(ApiMessage, short) - Constructor for class org.apache.kafka.server.common.ApiMessageAndVersion
 
apiMessageFor(short) - Method in class org.apache.kafka.server.common.serialization.AbstractApiMessageSerde
Return ApiMessage instance for the given apiKey.
apiMessageFor(short) - Method in class org.apache.kafka.server.common.serialization.BytesApiMessageSerde
Return ApiMessage instance for the given apiKey.
append(EventQueue.Event) - Method in interface org.apache.kafka.queue.EventQueue
Add an element to the end of the queue.
appendWithDeadline(long, EventQueue.Event) - Method in interface org.apache.kafka.queue.EventQueue
Add an event to the end of the queue.
apply(OptionalLong) - Method in class org.apache.kafka.queue.EventQueue.DeadlineFunction
 
apply(OptionalLong) - Method in class org.apache.kafka.queue.EventQueue.EarliestDeadlineFunction
 
apply(OptionalLong) - Method in class org.apache.kafka.queue.EventQueue.NoDeadlineFunction
 
apply(String) - Method in class org.apache.kafka.server.util.json.JsonObject
 
apply(JsonNode) - Static method in interface org.apache.kafka.server.util.json.JsonValue
 
args - Variable in class org.apache.kafka.server.util.CommandDefaultOptions
 
asJsonArray() - Method in interface org.apache.kafka.server.util.json.JsonValue
If this is a JSON array, return an instance of JsonArray.
asJsonArrayOptional() - Method in interface org.apache.kafka.server.util.json.JsonValue
If this is a JSON array, return a JsonArray wrapped by a `Some`.
asJsonObject() - Method in interface org.apache.kafka.server.util.json.JsonValue
If this is a JSON object, return an instance of JsonObject.
asJsonObjectOptional() - Method in interface org.apache.kafka.server.util.json.JsonValue
If this is a JSON object, return a JsonObject wrapped by a `Some`.
assignedBrokerId() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
Get the ID of the broker that this block was assigned to.
assignReplicasToBrokers(Collection<BrokerMetadata>, int, int) - Static method in class org.apache.kafka.admin.AdminUtils
 
assignReplicasToBrokers(Collection<BrokerMetadata>, int, int, int, int) - Static method in class org.apache.kafka.admin.AdminUtils
There are 3 goals of replica assignment: Spread the replicas evenly among brokers. For partitions assigned to a particular broker, their other replicas are spread over the other brokers. If all brokers have rack information, assign the replicas for each partition to different racks if possible To achieve this goal for replica assignment without considering racks, we: Assign the first replica of each partition by round-robin, starting from a random position in the broker list. Assign the remaining replicas of each partition with an increasing shift. Here is an example of assigning broker-0broker-1broker-2broker-3broker-4  p0 p1 p2 p3 p4 (1st replica) p5 p6 p7 p8 p9 (1st replica) p4 p0 p1 p2 p3 (2nd replica) p8 p9 p5 p6 p7 (2nd replica) p3 p4 p0 p1 p2 (3nd replica) p7 p8 p9 p5 p6 (3nd replica)
awaitShutdown() - Method in class org.apache.kafka.server.util.ShutdownableThread
After calling initiateShutdown(), use this API to wait until the shutdown is complete.

B

beginShutdown(String) - Method in interface org.apache.kafka.queue.EventQueue
Asynchronously shut down the event queue.
beginShutdown(String) - Method in class org.apache.kafka.queue.KafkaEventQueue
 
BoundedList<E> - Class in org.apache.kafka.server.mutable
A list which cannot grow beyond a certain length.
BoundedList(int, List<E>) - Constructor for class org.apache.kafka.server.mutable.BoundedList
 
BoundedListTooLongException - Exception in org.apache.kafka.server.mutable
An exception that is thrown when the BoundedList cannot add any more elements.
BoundedListTooLongException(String) - Constructor for exception org.apache.kafka.server.mutable.BoundedListTooLongException
 
BoundedListTooLongException(String, Throwable) - Constructor for exception org.apache.kafka.server.mutable.BoundedListTooLongException
 
BrokerCompressionType - Enum in org.apache.kafka.server.record
 
brokerId() - Method in class org.apache.kafka.server.network.KafkaAuthorizerServerInfo
 
BrokerMetadata - Class in org.apache.kafka.admin
Broker metadata used by admin tools.
BrokerMetadata(int, Optional<String>) - Constructor for class org.apache.kafka.admin.BrokerMetadata
 
build() - Method in class org.apache.kafka.server.fault.ProcessTerminatingFaultHandler.Builder
 
build(Optional<Authorizer>, AuthorizerServerInfo) - Method in class org.apache.kafka.server.network.EndpointReadyFutures.Builder
Build the EndpointReadyFutures object.
Builder() - Constructor for class org.apache.kafka.server.fault.ProcessTerminatingFaultHandler.Builder
 
Builder() - Constructor for class org.apache.kafka.server.network.EndpointReadyFutures.Builder
 
BytesApiMessageSerde - Class in org.apache.kafka.server.common.serialization
This class provides conversion of ApiMessageAndVersion to bytes and vice versa..
BytesApiMessageSerde() - Constructor for class org.apache.kafka.server.common.serialization.BytesApiMessageSerde
 

C

cancel() - Method in class org.apache.kafka.server.util.timer.TimerTask
 
cancelDeferred(String) - Method in interface org.apache.kafka.queue.EventQueue
Cancel a deferred event.
cancelDeferred(String) - Method in class org.apache.kafka.queue.KafkaEventQueue
 
cancelled() - Method in class org.apache.kafka.server.util.timer.TimerTaskEntry
 
ceiling(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
chainFuture(CompletableFuture<? extends T>, CompletableFuture<T>) - Static method in class org.apache.kafka.server.util.FutureUtils
Complete a given destination future when a source future is completed.
checkIfMetadataChanged(MetadataVersion, MetadataVersion) - Static method in enum org.apache.kafka.server.common.MetadataVersion
 
checkInvalidArgs(OptionParser, OptionSet, OptionSpec<?>, OptionSpec<?>...) - Static method in class org.apache.kafka.server.util.CommandLineUtils
Check that none of the listed options are present.
checkInvalidArgs(OptionParser, OptionSet, OptionSpec<?>, Set<OptionSpec<?>>) - Static method in class org.apache.kafka.server.util.CommandLineUtils
Check that none of the listed options are present.
checkInvalidArgsSet(OptionParser, OptionSet, Set<OptionSpec<?>>, Set<OptionSpec<?>>, Optional<String>) - Static method in class org.apache.kafka.server.util.CommandLineUtils
Check that none of the listed options are present with the combination of used options.
CheckpointFile<T> - Class in org.apache.kafka.server.common
This class represents a utility to capture a checkpoint in a file.
CheckpointFile(File, int, CheckpointFile.EntryFormatter<T>) - Constructor for class org.apache.kafka.server.common.CheckpointFile
 
CheckpointFile.CheckpointReadBuffer<T> - Class in org.apache.kafka.server.common
 
CheckpointFile.CheckpointWriteBuffer<T> - Class in org.apache.kafka.server.common
 
CheckpointFile.EntryFormatter<T> - Interface in org.apache.kafka.server.common
This is used to convert the given entry of type T into a string and vice versa.
CheckpointReadBuffer(String, BufferedReader, int, CheckpointFile.EntryFormatter<T>) - Constructor for class org.apache.kafka.server.common.CheckpointFile.CheckpointReadBuffer
 
CheckpointWriteBuffer(BufferedWriter, int, CheckpointFile.EntryFormatter<T>) - Constructor for class org.apache.kafka.server.common.CheckpointFile.CheckpointWriteBuffer
 
checkRequiredArgs(OptionParser, OptionSet, OptionSpec<?>...) - Static method in class org.apache.kafka.server.util.CommandLineUtils
Check that all the listed options are present.
claimNextId() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
Claim the next available producer id from the block.
clear() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
clear() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
clear() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
clear() - Method in class org.apache.kafka.server.mutable.BoundedList
 
clear() - Method in class org.apache.kafka.timeline.TimelineHashMap
 
clear() - Method in class org.apache.kafka.timeline.TimelineHashSet
 
close() - Method in interface org.apache.kafka.queue.EventQueue
Synchronously close the event queue and wait for any threads to be joined.
close() - Method in class org.apache.kafka.queue.KafkaEventQueue
 
close() - Method in class org.apache.kafka.server.util.timer.SystemTimer
 
clusterResource() - Method in class org.apache.kafka.server.network.KafkaAuthorizerServerInfo
 
CommandDefaultOptions - Class in org.apache.kafka.server.util
 
CommandDefaultOptions(String[]) - Constructor for class org.apache.kafka.server.util.CommandDefaultOptions
 
CommandDefaultOptions(String[], boolean) - Constructor for class org.apache.kafka.server.util.CommandDefaultOptions
 
CommandLineUtils - Class in org.apache.kafka.server.util
Helper functions for dealing with command line utilities.
CommandLineUtils() - Constructor for class org.apache.kafka.server.util.CommandLineUtils
 
comparator() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
complete(Throwable) - Method in interface org.apache.kafka.deferred.DeferredEvent
Complete the event.
completeUpTo(long) - Method in class org.apache.kafka.deferred.DeferredEventQueue
Complete some purgatory entries.
CompositeTopicPartitionFilter(List<TopicPartitionFilter>) - Constructor for class org.apache.kafka.server.util.TopicPartitionFilter.CompositeTopicPartitionFilter
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
ConfigSynonym - Class in org.apache.kafka.server.config
Represents a synonym for a configuration plus a conversion function.
ConfigSynonym(String, Function<String, String>) - Constructor for class org.apache.kafka.server.config.ConfigSynonym
 
ConfigSynonym(String) - Constructor for class org.apache.kafka.server.config.ConfigSynonym
 
configure(Map<String, ?>) - Method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
contains(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
contains(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
contains(Object) - Method in class org.apache.kafka.server.mutable.BoundedList
 
contains(Object) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
contains(Object, long) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
containsAll(Collection<?>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
containsAll(Collection<?>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
containsAll(Collection<?>) - Method in class org.apache.kafka.server.mutable.BoundedList
 
containsAll(Collection<?>) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
containsKey(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
containsKey(Object) - Method in class org.apache.kafka.server.util.TranslatedValueMapView
 
containsKey(Object) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
containsKey(Object, long) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
containsValue(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
containsValue(Object) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
converter() - Method in class org.apache.kafka.server.config.ConfigSynonym
 
creationTimeMs - Variable in class org.apache.kafka.server.util.RequestAndCompletionHandler
 

D

Deadline - Class in org.apache.kafka.server.util
 
DeadlineFunction(long) - Constructor for class org.apache.kafka.queue.EventQueue.DeadlineFunction
 
decode(JsonNode) - Method in interface org.apache.kafka.server.util.json.DecodeJson
Decode the JSON node provided into an instance of `T`.
decode(JsonNode) - Method in class org.apache.kafka.server.util.json.DecodeJson.DecodeBoolean
 
decode(JsonNode) - Method in class org.apache.kafka.server.util.json.DecodeJson.DecodeDouble
 
decode(JsonNode) - Method in class org.apache.kafka.server.util.json.DecodeJson.DecodeInteger
 
decode(JsonNode) - Method in class org.apache.kafka.server.util.json.DecodeJson.DecodeLong
 
decode(JsonNode) - Method in class org.apache.kafka.server.util.json.DecodeJson.DecodeString
 
DecodeBoolean() - Constructor for class org.apache.kafka.server.util.json.DecodeJson.DecodeBoolean
 
DecodeDouble() - Constructor for class org.apache.kafka.server.util.json.DecodeJson.DecodeDouble
 
DecodeInteger() - Constructor for class org.apache.kafka.server.util.json.DecodeJson.DecodeInteger
 
DecodeJson<T> - Interface in org.apache.kafka.server.util.json
 
DecodeJson.DecodeBoolean - Class in org.apache.kafka.server.util.json
 
DecodeJson.DecodeDouble - Class in org.apache.kafka.server.util.json
 
DecodeJson.DecodeInteger - Class in org.apache.kafka.server.util.json
 
DecodeJson.DecodeLong - Class in org.apache.kafka.server.util.json
 
DecodeJson.DecodeString - Class in org.apache.kafka.server.util.json
 
decodeList(DecodeJson<E>) - Static method in interface org.apache.kafka.server.util.json.DecodeJson
 
DecodeLong() - Constructor for class org.apache.kafka.server.util.json.DecodeJson.DecodeLong
 
decodeMap(DecodeJson<V>) - Static method in interface org.apache.kafka.server.util.json.DecodeJson
 
decodeOptional(DecodeJson<E>) - Static method in interface org.apache.kafka.server.util.json.DecodeJson
 
DecodeString() - Constructor for class org.apache.kafka.server.util.json.DecodeJson.DecodeString
 
decrement() - Method in class org.apache.kafka.timeline.TimelineInteger
 
decrement() - Method in class org.apache.kafka.timeline.TimelineLong
 
defaultRegistry() - Static method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
convenience method to replace Metrics.defaultRegistry()
DeferredEvent - Interface in org.apache.kafka.deferred
Represents a deferred event in the {DeferredEventQueue}.
DeferredEventQueue - Class in org.apache.kafka.deferred
The queue which holds deferred events that have been started, but not yet completed.
DeferredEventQueue(LogContext) - Constructor for class org.apache.kafka.deferred.DeferredEventQueue
 
delayMs - Variable in class org.apache.kafka.server.util.timer.TimerTask
 
deleteSnapshot(long) - Method in class org.apache.kafka.timeline.SnapshotRegistry
Deletes the snapshot with the given epoch.
deleteSnapshot(Snapshot) - Method in class org.apache.kafka.timeline.SnapshotRegistry
Deletes the given snapshot.
deleteSnapshotsUpTo(long) - Method in class org.apache.kafka.timeline.SnapshotRegistry
Deletes all the snapshots up to the given epoch
descendingIterator() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
descendingSet() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
deserialize(byte[]) - Method in class org.apache.kafka.server.common.serialization.BytesApiMessageSerde
 
destination - Variable in class org.apache.kafka.server.util.RequestAndCompletionHandler
 
didMetadataChange() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
doWork() - Method in class org.apache.kafka.server.util.InterBrokerSendThread
 
doWork() - Method in class org.apache.kafka.server.util.ShutdownableThread
This method is repeatedly invoked until the thread shuts down or this method throws an exception

E

EarliestDeadlineFunction(long) - Constructor for class org.apache.kafka.queue.EventQueue.EarliestDeadlineFunction
 
earlyStartListeners() - Method in class org.apache.kafka.server.network.KafkaAuthorizerServerInfo
 
EMPTY - Static variable in class org.apache.kafka.server.common.ProducerIdsBlock
 
empty() - Static method in interface org.apache.kafka.server.immutable.ImmutableMap
 
empty() - Static method in interface org.apache.kafka.server.immutable.ImmutableNavigableSet
 
empty() - Static method in interface org.apache.kafka.server.immutable.ImmutableSet
 
empty() - Static method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
empty() - Static method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
empty() - Static method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
encodeAsBytes(Object) - Static method in class org.apache.kafka.server.util.Json
Encode an object into a JSON value in bytes.
encodeAsString(Object) - Static method in class org.apache.kafka.server.util.Json
Encode an object into a JSON string.
EndpointReadyFutures - Class in org.apache.kafka.server.network
Manages a set of per-endpoint futures.
EndpointReadyFutures.Builder - Class in org.apache.kafka.server.network
 
endpoints() - Method in class org.apache.kafka.server.network.KafkaAuthorizerServerInfo
 
enqueue(EventQueue.EventInsertionType, String, Function<OptionalLong, OptionalLong>, EventQueue.Event) - Method in interface org.apache.kafka.queue.EventQueue
Add an event to the queue.
enqueue(EventQueue.EventInsertionType, String, Function<OptionalLong, OptionalLong>, EventQueue.Event) - Method in class org.apache.kafka.queue.KafkaEventQueue
 
ensureValid(String, Object) - Method in class org.apache.kafka.server.common.MetadataVersionValidator
 
entrySet() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
entrySet() - Method in class org.apache.kafka.server.util.TranslatedValueMapView
 
entrySet() - Method in class org.apache.kafka.timeline.TimelineHashMap
 
entrySet(long) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
epochsList() - Method in class org.apache.kafka.timeline.SnapshotRegistry
Returns a sorted list of snapshot epochs.
equals(Object) - Method in class org.apache.kafka.admin.BrokerMetadata
 
equals(Object) - Method in class org.apache.kafka.server.common.ApiMessageAndVersion
 
equals(Object) - Method in class org.apache.kafka.server.common.Features
 
equals(Object) - Method in class org.apache.kafka.server.common.OffsetAndEpoch
 
equals(Object) - Method in class org.apache.kafka.server.common.ProducerIdsBlock
 
equals(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
equals(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
equals(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
equals(Object) - Method in class org.apache.kafka.server.mutable.BoundedList
 
equals(Object) - Method in class org.apache.kafka.server.network.KafkaAuthorizerServerInfo
 
equals(Object) - Method in class org.apache.kafka.server.util.Deadline
 
equals(Object) - Method in class org.apache.kafka.server.util.json.JsonArray
 
equals(Object) - Method in class org.apache.kafka.server.util.json.JsonObject
 
equals(Object) - Method in class org.apache.kafka.server.util.json.JsonValue.BasicJsonValue
 
equals(Object) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
equals(Object) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
equals(Object) - Method in class org.apache.kafka.timeline.TimelineInteger
 
equals(Object) - Method in class org.apache.kafka.timeline.TimelineLong
 
equals(Object) - Method in class org.apache.kafka.timeline.TimelineObject
 
EventQueue - Interface in org.apache.kafka.queue
 
EventQueue.DeadlineFunction - Class in org.apache.kafka.queue
 
EventQueue.EarliestDeadlineFunction - Class in org.apache.kafka.queue
 
EventQueue.Event - Interface in org.apache.kafka.queue
 
EventQueue.EventInsertionType - Enum in org.apache.kafka.queue
 
EventQueue.FailureLoggingEvent - Class in org.apache.kafka.queue
 
EventQueue.NoDeadlineFunction - Class in org.apache.kafka.queue
 
EventQueue.VoidEvent - Class in org.apache.kafka.queue
 
executeRevert(long, Delta) - Method in class org.apache.kafka.timeline.TimelineInteger
 
executeRevert(long, Delta) - Method in class org.apache.kafka.timeline.TimelineLong
 
executeRevert(long, Delta) - Method in class org.apache.kafka.timeline.TimelineObject
 
expirationMs - Variable in class org.apache.kafka.server.util.timer.TimerTaskEntry
 
explicitMetricName(String, String, String, Map<String, String>) - Static method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 

F

failAll(Exception) - Method in class org.apache.kafka.deferred.DeferredEventQueue
Fail all deferred events with the provided exception.
failedFuture(Throwable) - Static method in class org.apache.kafka.server.util.FutureUtils
Returns a new CompletableFuture that is already completed exceptionally with the given exception.
FailureLoggingEvent(Logger) - Constructor for class org.apache.kafka.queue.EventQueue.FailureLoggingEvent
 
FaultHandler - Interface in org.apache.kafka.server.fault
Handle a server fault.
FaultHandlerException - Exception in org.apache.kafka.server.fault
An exception thrown by a fault handler.
FaultHandlerException(String, Throwable) - Constructor for exception org.apache.kafka.server.fault.FaultHandlerException
 
FaultHandlerException(String) - Constructor for exception org.apache.kafka.server.fault.FaultHandlerException
 
FEATURE_NAME - Static variable in enum org.apache.kafka.server.common.MetadataVersion
 
featureLevel() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
FeatureLevelListener - Interface in org.apache.kafka.metadata
A callback for changes to feature levels.
Features - Class in org.apache.kafka.server.common
 
Features(MetadataVersion, Map<String, Short>, long, boolean) - Constructor for class org.apache.kafka.server.common.Features
 
fetchRequestVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
FilteringJmxReporter - Class in org.apache.kafka.server.metrics
 
FilteringJmxReporter(MetricsRegistry, Predicate<MetricName>) - Constructor for class org.apache.kafka.server.metrics.FilteringJmxReporter
 
finalizedFeatures() - Method in class org.apache.kafka.server.common.Features
 
finalizedFeaturesEpoch() - Method in class org.apache.kafka.server.common.Features
 
first() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
firstProducerId() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
Get the first ID (inclusive) to be assigned from this block.
floor(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
forEach(BiConsumer<? super K, ? super V>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
forEach(Consumer<? super E>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
forEach(Consumer<? super E>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
forName(String) - Static method in enum org.apache.kafka.server.record.BrokerCompressionType
 
fromDelay(Time, long, TimeUnit) - Static method in class org.apache.kafka.server.util.Deadline
 
fromFeatureLevel(short) - Static method in enum org.apache.kafka.server.common.MetadataVersion
 
fromKRaftVersion(MetadataVersion) - Static method in class org.apache.kafka.server.common.Features
 
fromMonotonicNanoseconds(long) - Static method in class org.apache.kafka.server.util.Deadline
 
fromString(String) - Method in interface org.apache.kafka.server.common.CheckpointFile.EntryFormatter
 
fromVersionString(String) - Static method in enum org.apache.kafka.server.common.MetadataVersion
Return an `MetadataVersion` instance for `versionString`, which can be in a variety of formats (e.g.
futures() - Method in class org.apache.kafka.server.network.EndpointReadyFutures
 
FutureUtils - Class in org.apache.kafka.server.util
 
FutureUtils() - Constructor for class org.apache.kafka.server.util.FutureUtils
 

G

generateRequests() - Method in class org.apache.kafka.server.util.InterBrokerSendThread
 
get(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
get(int) - Method in class org.apache.kafka.server.mutable.BoundedList
 
get(String) - Method in class org.apache.kafka.server.util.json.JsonObject
 
get(Object) - Method in class org.apache.kafka.server.util.TranslatedValueMapView
 
get(Object) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
get(Object, long) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
get() - Method in class org.apache.kafka.timeline.TimelineInteger
 
get(long) - Method in class org.apache.kafka.timeline.TimelineInteger
 
get() - Method in class org.apache.kafka.timeline.TimelineLong
 
get(long) - Method in class org.apache.kafka.timeline.TimelineLong
 
get() - Method in class org.apache.kafka.timeline.TimelineObject
 
get(long) - Method in class org.apache.kafka.timeline.TimelineObject
 
getMetricName(String, String, String) - Static method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
getMetricName(String, String, String, LinkedHashMap<String, String>) - Static method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
getOrCreateSnapshot(long) - Method in class org.apache.kafka.timeline.SnapshotRegistry
Creates a new snapshot at the given epoch.
getOrDefault(Object, V) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
getPattern() - Method in class org.apache.kafka.server.util.TopicFilter
 
getRackAlternatedBrokerList(Map<Integer, String>) - Static method in class org.apache.kafka.admin.AdminUtils
Given broker and rack information, returns a list of brokers alternated by the rack.
getSnapshot(long) - Method in class org.apache.kafka.timeline.SnapshotRegistry
Gets the snapshot for a specific epoch.
groupMetadataValueVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 

H

handle(String, short) - Method in interface org.apache.kafka.metadata.FeatureLevelListener
 
handleException(Throwable) - Method in interface org.apache.kafka.queue.EventQueue.Event
Handle an exception that was either generated by running the event, or by the event queue's inability to run the event.
handleException(Throwable) - Method in class org.apache.kafka.queue.EventQueue.FailureLoggingEvent
 
handleFault(String) - Method in interface org.apache.kafka.server.fault.FaultHandler
Handle a fault.
handleFault(String, Throwable) - Method in interface org.apache.kafka.server.fault.FaultHandler
Handle a fault.
handleFault(String, Throwable) - Method in class org.apache.kafka.server.fault.LoggingFaultHandler
 
handleFault(String, Throwable) - Method in class org.apache.kafka.server.fault.ProcessTerminatingFaultHandler
 
handler - Variable in class org.apache.kafka.server.util.RequestAndCompletionHandler
 
hashCode() - Method in class org.apache.kafka.admin.BrokerMetadata
 
hashCode() - Method in class org.apache.kafka.server.common.ApiMessageAndVersion
 
hashCode() - Method in class org.apache.kafka.server.common.Features
 
hashCode() - Method in class org.apache.kafka.server.common.OffsetAndEpoch
 
hashCode() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
 
hashCode() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
hashCode() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
hashCode() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
hashCode() - Method in class org.apache.kafka.server.mutable.BoundedList
 
hashCode() - Method in class org.apache.kafka.server.network.KafkaAuthorizerServerInfo
 
hashCode() - Method in class org.apache.kafka.server.util.Deadline
 
hashCode() - Method in class org.apache.kafka.server.util.json.JsonArray
 
hashCode() - Method in class org.apache.kafka.server.util.json.JsonObject
 
hashCode() - Method in class org.apache.kafka.server.util.json.JsonValue.BasicJsonValue
 
hashCode() - Method in class org.apache.kafka.timeline.TimelineHashMap
 
hashCode() - Method in class org.apache.kafka.timeline.TimelineHashSet
 
hashCode() - Method in class org.apache.kafka.timeline.TimelineInteger
 
hashCode() - Method in class org.apache.kafka.timeline.TimelineLong
 
hashCode() - Method in class org.apache.kafka.timeline.TimelineObject
 
hasSnapshot(long) - Method in class org.apache.kafka.timeline.SnapshotRegistry
 
hasUnsentRequests() - Method in class org.apache.kafka.server.util.InterBrokerSendThread
 
headSet(E, boolean) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
headSet(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
helpOpt - Variable in class org.apache.kafka.server.util.CommandDefaultOptions
 
higher(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
highestPendingOffset() - Method in class org.apache.kafka.deferred.DeferredEventQueue
Get the offset of the highest pending event, or empty if there are no pending events.
highestSupportedRecordVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
HOURS_TO_MILLISECONDS - Static variable in class org.apache.kafka.server.config.ConfigSynonym
 

I

id - Variable in class org.apache.kafka.admin.BrokerMetadata
 
ImmutableMap<K,V> - Interface in org.apache.kafka.server.immutable
A persistent Hash-based Map wrapper.
ImmutableNavigableSet<E> - Interface in org.apache.kafka.server.immutable
A persistent Tree-based NavigableSet wrapper java.util.Set methods that mutate in-place will throw UnsupportedOperationException
ImmutableSet<E> - Interface in org.apache.kafka.server.immutable
A persistent Hash-based Set wrapper java.util.Set methods that mutate in-place will throw UnsupportedOperationException
IncludeList(String) - Constructor for class org.apache.kafka.server.util.TopicFilter.IncludeList
 
increment() - Method in class org.apache.kafka.timeline.TimelineInteger
 
increment() - Method in class org.apache.kafka.timeline.TimelineLong
 
indexOf(Object) - Method in class org.apache.kafka.server.mutable.BoundedList
 
INIT - Static variable in class org.apache.kafka.timeline.TimelineInteger
 
INIT - Static variable in class org.apache.kafka.timeline.TimelineLong
 
initiateShutdown() - Method in class org.apache.kafka.server.util.ShutdownableThread
 
INSTANCE - Static variable in class org.apache.kafka.queue.EventQueue.NoDeadlineFunction
 
INSTANCE - Static variable in class org.apache.kafka.queue.EventQueue.VoidEvent
 
INSTANCE - Static variable in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
interBrokerEndpoint() - Method in class org.apache.kafka.server.network.KafkaAuthorizerServerInfo
 
InterBrokerSendThread - Class in org.apache.kafka.server.util
An inter-broker send thread that utilizes a non-blocking network client.
InterBrokerSendThread(String, KafkaClient, int, Time) - Constructor for class org.apache.kafka.server.util.InterBrokerSendThread
 
InterBrokerSendThread(String, KafkaClient, int, Time, boolean) - Constructor for class org.apache.kafka.server.util.InterBrokerSendThread
 
isAllocateProducerIdsSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isAlterPartitionSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isApiForwardingEnabled() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isAtLeast(MetadataVersion) - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isBrokerRegistrationChangeRecordSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isDelegationTokenSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isEmpty() - Method in interface org.apache.kafka.queue.EventQueue
 
isEmpty() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
isEmpty() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
isEmpty() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
isEmpty() - Method in class org.apache.kafka.server.mutable.BoundedList
 
isEmpty() - Method in class org.apache.kafka.server.util.TranslatedValueMapView
 
isEmpty() - Method in class org.apache.kafka.timeline.TimelineHashMap
 
isEmpty(long) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
isEmpty() - Method in class org.apache.kafka.timeline.TimelineHashSet
 
isEmpty(long) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
isFeatureVersioningSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isInControlledShutdownStateSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isKRaftSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isLeaderEpochBumpRequiredOnIsrShrink() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isLeaderRecoverySupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isLessThan(MetadataVersion) - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isMetadataTransactionSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isMigrationSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isNoOpRecordSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isOffsetForLeaderEpochSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isPartitionAllowed(int) - Method in interface org.apache.kafka.server.util.PartitionFilter
Used to filter partitions based on a certain criteria, for example, a set of partition ids.
isPartitionAllowed(int) - Method in class org.apache.kafka.server.util.PartitionFilter.PartitionRangeFilter
 
isPartitionAllowed(int) - Method in class org.apache.kafka.server.util.PartitionFilter.PartitionsSetFilter
 
isPartitionAllowed(int) - Method in class org.apache.kafka.server.util.PartitionFilter.UniquePartitionFilter
 
isPrintHelpNeeded(CommandDefaultOptions) - Static method in class org.apache.kafka.server.util.CommandLineUtils
Check if there are no options or `--help` option from command line.
isPrintVersionNeeded(CommandDefaultOptions) - Static method in class org.apache.kafka.server.util.CommandLineUtils
Check if there is `--version` option from command line.
isRunning() - Method in class org.apache.kafka.server.util.ShutdownableThread
 
isSaslInterBrokerHandshakeRequestEnabled() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isScramSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isShutdownComplete() - Method in class org.apache.kafka.server.util.ShutdownableThread
 
isShutdownInitiated() - Method in class org.apache.kafka.server.util.ShutdownableThread
 
isStarted() - Method in class org.apache.kafka.server.util.KafkaScheduler
 
isThreadFailed() - Method in class org.apache.kafka.server.util.ShutdownableThread
 
isTopicAllowed(String, boolean) - Method in class org.apache.kafka.server.util.TopicFilter.IncludeList
 
isTopicAllowed(String, boolean) - Method in class org.apache.kafka.server.util.TopicFilter
 
isTopicAllowed(String) - Method in class org.apache.kafka.server.util.TopicPartitionFilter.CompositeTopicPartitionFilter
 
isTopicAllowed(String) - Method in interface org.apache.kafka.server.util.TopicPartitionFilter
Used to filter topics based on a certain criteria, for example, a set of topic names or a regular expression.
isTopicAllowed(String) - Method in class org.apache.kafka.server.util.TopicPartitionFilter.TopicFilterAndPartitionFilter
 
isTopicIdsSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isTopicPartitionAllowed(TopicPartition) - Method in class org.apache.kafka.server.util.TopicPartitionFilter.CompositeTopicPartitionFilter
 
isTopicPartitionAllowed(TopicPartition) - Method in interface org.apache.kafka.server.util.TopicPartitionFilter
Used to filter topic-partitions based on a certain criteria, for example, a topic pattern and a set of partition ids.
isTopicPartitionAllowed(TopicPartition) - Method in class org.apache.kafka.server.util.TopicPartitionFilter.TopicFilterAndPartitionFilter
 
isTruncationOnFetchSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
iterator() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
iterator() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
iterator() - Method in class org.apache.kafka.server.mutable.BoundedList
 
iterator() - Method in class org.apache.kafka.server.util.json.JsonArray
 
iterator() - Method in class org.apache.kafka.server.util.json.JsonObject
 
iterator() - Method in class org.apache.kafka.timeline.SnapshotRegistry
Returns a snapshot iterator that iterates from the snapshots with the lowest epoch to those with the highest.
iterator(long) - Method in class org.apache.kafka.timeline.SnapshotRegistry
Returns a snapshot iterator that iterates from the snapshots with the lowest epoch to those with the highest, starting at the snapshot with the given epoch.
iterator(Snapshot) - Method in class org.apache.kafka.timeline.SnapshotRegistry
Returns a snapshot iterator that iterates from the snapshots with the lowest epoch to those with the highest, starting at the given snapshot.
iterator() - Method in class org.apache.kafka.timeline.TimelineHashSet
 
iterator(long) - Method in class org.apache.kafka.timeline.TimelineHashSet
 

J

Json - Class in org.apache.kafka.server.util
Provides methods for parsing JSON with Jackson and encoding to JSON with a simple and naive custom implementation.
Json() - Constructor for class org.apache.kafka.server.util.Json
 
JsonArray - Class in org.apache.kafka.server.util.json
 
JsonObject - Class in org.apache.kafka.server.util.json
 
JsonValue - Interface in org.apache.kafka.server.util.json
A simple wrapper over Jackson's JsonNode that enables type safe parsing via the `DecodeJson` type class.
JsonValue.BasicJsonValue - Class in org.apache.kafka.server.util.json
 

K

KafkaAuthorizerServerInfo - Class in org.apache.kafka.server.network
Runtime broker configuration metadata provided to authorizers during start up.
KafkaAuthorizerServerInfo(ClusterResource, int, Collection<Endpoint>, Endpoint, Collection<String>) - Constructor for class org.apache.kafka.server.network.KafkaAuthorizerServerInfo
 
KafkaEventQueue - Class in org.apache.kafka.queue
 
KafkaEventQueue(Time, LogContext, String) - Constructor for class org.apache.kafka.queue.KafkaEventQueue
 
KafkaEventQueue(Time, LogContext, String, EventQueue.Event) - Constructor for class org.apache.kafka.queue.KafkaEventQueue
 
KafkaMetricsGroup - Class in org.apache.kafka.server.metrics
 
KafkaMetricsGroup(Class<?>) - Constructor for class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
KafkaScheduler - Class in org.apache.kafka.server.util
A scheduler based on java.util.concurrent.ScheduledThreadPoolExecutor It has a pool of kafka-scheduler- threads that do the actual work.
KafkaScheduler(int) - Constructor for class org.apache.kafka.server.util.KafkaScheduler
 
KafkaScheduler(int, boolean) - Constructor for class org.apache.kafka.server.util.KafkaScheduler
 
KafkaScheduler(int, boolean, String) - Constructor for class org.apache.kafka.server.util.KafkaScheduler
 
KafkaYammerMetrics - Class in org.apache.kafka.server.metrics
This class encapsulates the default yammer metrics registry for Kafka server, and configures the set of exported JMX metrics for Yammer metrics.
keySet() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
keySet() - Method in class org.apache.kafka.timeline.TimelineHashMap
 
keySet(long) - Method in class org.apache.kafka.timeline.TimelineHashMap
 

L

last() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
lastIndexOf(Object) - Method in class org.apache.kafka.server.mutable.BoundedList
 
lastProducerId() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
Get the last ID (inclusive) to be assigned from this block.
latest() - Static method in enum org.apache.kafka.server.common.MetadataVersion
 
LATEST_EPOCH - Static variable in class org.apache.kafka.timeline.SnapshotRegistry
 
latestEpoch() - Method in class org.apache.kafka.timeline.SnapshotRegistry
Return the latest epoch.
leaderEpoch() - Method in class org.apache.kafka.server.common.OffsetAndEpoch
 
listIterator() - Method in class org.apache.kafka.server.mutable.BoundedList
 
listIterator(int) - Method in class org.apache.kafka.server.mutable.BoundedList
 
listOffsetRequestVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
LoggingFaultHandler - Class in org.apache.kafka.server.fault
A fault handler which logs an error message and executes a runnable.
LoggingFaultHandler(String, Runnable) - Constructor for class org.apache.kafka.server.fault.LoggingFaultHandler
 
logPrefix - Variable in class org.apache.kafka.server.util.ShutdownableThread
 
lower(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 

M

maybeMergeOptions(Properties, String, OptionSet, OptionSpec<T>) - Static method in class org.apache.kafka.server.util.CommandLineUtils
Merge the options into props for key key, with the following precedence, from high to low: 1) if spec is specified on options explicitly, use the value; 2) if props already has key set, keep it; 3) otherwise, use the default value of spec.
maybePrintHelpOrVersion(CommandDefaultOptions, String) - Static method in class org.apache.kafka.server.util.CommandLineUtils
Check and print help message if there is no options or `--help` option from command line, if `--version` is specified on the command line print version information and exit.
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
message() - Method in class org.apache.kafka.server.common.ApiMessageAndVersion
 
MetadataParseException - Exception in org.apache.kafka.server.common.serialization
An exception indicating that we failed to parse a metadata entry.
MetadataParseException(String) - Constructor for exception org.apache.kafka.server.common.serialization.MetadataParseException
 
MetadataParseException(Throwable) - Constructor for exception org.apache.kafka.server.common.serialization.MetadataParseException
 
MetadataParseException(String, Throwable) - Constructor for exception org.apache.kafka.server.common.serialization.MetadataParseException
 
metadataVersion() - Method in class org.apache.kafka.server.common.Features
 
MetadataVersion - Enum in org.apache.kafka.server.common
This class contains the different Kafka versions.
MetadataVersionValidator - Class in org.apache.kafka.server.common
 
MetadataVersionValidator() - Constructor for class org.apache.kafka.server.common.MetadataVersionValidator
 
metricName(String, Map<String, String>) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
Creates a new MetricName object for gauges, meters, etc.
MINIMUM_BOOTSTRAP_VERSION - Static variable in enum org.apache.kafka.server.common.MetadataVersion
The first version we currently support in the bootstrap metadata.
MINIMUM_KRAFT_VERSION - Static variable in enum org.apache.kafka.server.common.MetadataVersion
The first version we currently support in KRaft.
minSupportedFor(RecordVersion) - Static method in enum org.apache.kafka.server.common.MetadataVersion
Return the minimum `MetadataVersion` that supports `RecordVersion`.
MINUTES_TO_MILLISECONDS - Static variable in class org.apache.kafka.server.config.ConfigSynonym
 

N

name() - Method in class org.apache.kafka.server.config.ConfigSynonym
 
name - Variable in enum org.apache.kafka.server.record.BrokerCompressionType
 
names() - Static method in enum org.apache.kafka.server.record.BrokerCompressionType
 
nanoseconds() - Method in class org.apache.kafka.server.util.Deadline
 
newArrayBacked(int) - Static method in class org.apache.kafka.server.mutable.BoundedList
 
newArrayBacked(int, int) - Static method in class org.apache.kafka.server.mutable.BoundedList
 
newGauge(String, Gauge<T>, Map<String, String>) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
newGauge(String, Gauge<T>) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
newHistogram(String, boolean, Map<String, String>) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
newHistogram(String) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
newMeter(String, String, TimeUnit, Map<String, String>) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
newMeter(String, String, TimeUnit) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
newMeter(MetricName, String, TimeUnit) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
newTimer(String, TimeUnit, TimeUnit, Map<String, String>) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
newTimer(String, TimeUnit, TimeUnit) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
nextBlockFirstId() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
Get the first ID of the next block following this one.
node() - Method in class org.apache.kafka.server.util.json.JsonArray
 
node() - Method in class org.apache.kafka.server.util.json.JsonObject
 
node() - Method in class org.apache.kafka.server.util.json.JsonValue.BasicJsonValue
 
node() - Method in interface org.apache.kafka.server.util.json.JsonValue
 
NoDeadlineFunction() - Constructor for class org.apache.kafka.queue.EventQueue.NoDeadlineFunction
 

O

offset() - Method in class org.apache.kafka.server.common.OffsetAndEpoch
 
OffsetAndEpoch - Class in org.apache.kafka.server.common
 
OffsetAndEpoch(long, int) - Constructor for class org.apache.kafka.server.common.OffsetAndEpoch
 
offsetCommitValueVersion(boolean) - Method in enum org.apache.kafka.server.common.MetadataVersion
 
offsetForLeaderEpochRequestVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
onMetricAdded(MetricName, Metric) - Method in class org.apache.kafka.server.metrics.FilteringJmxReporter
 
options - Variable in class org.apache.kafka.server.util.CommandDefaultOptions
 
org.apache.kafka.admin - package org.apache.kafka.admin
 
org.apache.kafka.deferred - package org.apache.kafka.deferred
 
org.apache.kafka.metadata - package org.apache.kafka.metadata
 
org.apache.kafka.queue - package org.apache.kafka.queue
 
org.apache.kafka.server.common - package org.apache.kafka.server.common
 
org.apache.kafka.server.common.serialization - package org.apache.kafka.server.common.serialization
 
org.apache.kafka.server.config - package org.apache.kafka.server.config
 
org.apache.kafka.server.fault - package org.apache.kafka.server.fault
 
org.apache.kafka.server.immutable - package org.apache.kafka.server.immutable
 
org.apache.kafka.server.immutable.pcollections - package org.apache.kafka.server.immutable.pcollections
 
org.apache.kafka.server.metrics - package org.apache.kafka.server.metrics
 
org.apache.kafka.server.mutable - package org.apache.kafka.server.mutable
 
org.apache.kafka.server.network - package org.apache.kafka.server.network
 
org.apache.kafka.server.record - package org.apache.kafka.server.record
 
org.apache.kafka.server.util - package org.apache.kafka.server.util
 
org.apache.kafka.server.util.json - package org.apache.kafka.server.util.json
 
org.apache.kafka.server.util.timer - package org.apache.kafka.server.util.timer
 
org.apache.kafka.timeline - package org.apache.kafka.timeline
 

P

parallelStream() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
parallelStream() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
parseBytes(byte[]) - Static method in class org.apache.kafka.server.util.Json
Parse a JSON byte array into a JsonValue if possible.
parseBytesAs(byte[], Class<T>) - Static method in class org.apache.kafka.server.util.Json
Parse a JSON byte array into a generic type T, or throws a JsonProcessingException in the case of exception.
parseFull(String) - Static method in class org.apache.kafka.server.util.Json
Parse a JSON string into a JsonValue if possible.
parseKeyValueArgs(List<String>) - Static method in class org.apache.kafka.server.util.CommandLineUtils
Parse key-value pairs in the form key=value.
parseKeyValueArgs(List<String>, boolean) - Static method in class org.apache.kafka.server.util.CommandLineUtils
Parse key-value pairs in the form key=value.
parser - Variable in class org.apache.kafka.server.util.CommandDefaultOptions
 
parseStringAs(String, Class<T>) - Static method in class org.apache.kafka.server.util.Json
Parse a JSON string into a generic type T, or throw JsonProcessingException in the case of exception.
PartitionFilter - Interface in org.apache.kafka.server.util
 
PartitionFilter.PartitionRangeFilter - Class in org.apache.kafka.server.util
 
PartitionFilter.PartitionsSetFilter - Class in org.apache.kafka.server.util
 
PartitionFilter.UniquePartitionFilter - Class in org.apache.kafka.server.util
 
PartitionRangeFilter(int, int) - Constructor for class org.apache.kafka.server.util.PartitionFilter.PartitionRangeFilter
 
PartitionsSetFilter(Set<Integer>) - Constructor for class org.apache.kafka.server.util.PartitionFilter.PartitionsSetFilter
 
pause(long, TimeUnit) - Method in class org.apache.kafka.server.util.ShutdownableThread
Causes the current thread to wait until the shutdown is initiated, or the specified waiting time elapses.
PCollectionsImmutableMap<K,V> - Class in org.apache.kafka.server.immutable.pcollections
 
PCollectionsImmutableMap(HashPMap<K, V>) - Constructor for class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
PCollectionsImmutableNavigableSet<E> - Class in org.apache.kafka.server.immutable.pcollections
 
PCollectionsImmutableNavigableSet(TreePSet<E>) - Constructor for class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
PCollectionsImmutableSet<E> - Class in org.apache.kafka.server.immutable.pcollections
 
PCollectionsImmutableSet(MapPSet<E>) - Constructor for class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
pollFirst() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
pollLast() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
prepend(EventQueue.Event) - Method in interface org.apache.kafka.queue.EventQueue
Add an element to the front of the queue.
printUsageAndExit(OptionParser, String) - Static method in class org.apache.kafka.server.util.CommandLineUtils
 
printVersionAndExit() - Static method in class org.apache.kafka.server.util.CommandLineUtils
 
ProcessTerminatingFaultHandler - Class in org.apache.kafka.server.fault
This is a fault handler which terminates the JVM process.
ProcessTerminatingFaultHandler.Builder - Class in org.apache.kafka.server.fault
 
PRODUCER_ID_BLOCK_SIZE - Static variable in class org.apache.kafka.server.common.ProducerIdsBlock
 
ProducerIdsBlock - Class in org.apache.kafka.server.common
Holds a range of Producer IDs used for Transactional and EOS producers.
ProducerIdsBlock(int, long, int) - Constructor for class org.apache.kafka.server.common.ProducerIdsBlock
 
put(K, V) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
put(K, V) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
putIfAbsent(K, V) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 

R

rack - Variable in class org.apache.kafka.admin.BrokerMetadata
 
read() - Method in class org.apache.kafka.server.common.CheckpointFile.CheckpointReadBuffer
 
read() - Method in class org.apache.kafka.server.common.CheckpointFile
 
read(Readable, int) - Method in class org.apache.kafka.server.common.serialization.AbstractApiMessageSerde
 
read(Readable, int) - Method in interface org.apache.kafka.server.common.serialization.RecordSerde
Read a record from a Readable input.
reconfigurableConfigs() - Method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
reconfigure(Map<String, ?>) - Method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
RecordSerde<T> - Interface in org.apache.kafka.server.common.serialization
Serde interface for records written to a metadata log.
recordSize(ApiMessageAndVersion, ObjectSerializationCache) - Method in class org.apache.kafka.server.common.serialization.AbstractApiMessageSerde
 
recordSize(T, ObjectSerializationCache) - Method in interface org.apache.kafka.server.common.serialization.RecordSerde
Get the size of a record.
register(Revertable) - Method in class org.apache.kafka.timeline.SnapshotRegistry
Associate a revertable with this registry.
registerBrokerRecordVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
remove(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
remove(Object, Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
remove(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
remove(Object) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
remove(Object) - Method in class org.apache.kafka.server.mutable.BoundedList
 
remove(int) - Method in class org.apache.kafka.server.mutable.BoundedList
 
remove() - Method in class org.apache.kafka.server.util.timer.TimerTaskEntry
 
remove(Object) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
remove(Object) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
removeAll(Collection<?>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
removeAll(Collection<?>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
removeAll(Collection<?>) - Method in class org.apache.kafka.server.mutable.BoundedList
 
removeAll(Collection<?>) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
removed(K) - Method in interface org.apache.kafka.server.immutable.ImmutableMap
 
removed(E) - Method in interface org.apache.kafka.server.immutable.ImmutableNavigableSet
 
removed(E) - Method in interface org.apache.kafka.server.immutable.ImmutableSet
 
removed(K) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
removed(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
removed(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
removeIf(Predicate<? super E>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
removeIf(Predicate<? super E>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
removeMetric(String, Map<String, String>) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
removeMetric(String) - Method in class org.apache.kafka.server.metrics.KafkaMetricsGroup
 
replace(K, V, V) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
replace(K, V) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
request - Variable in class org.apache.kafka.server.util.RequestAndCompletionHandler
 
RequestAndCompletionHandler - Class in org.apache.kafka.server.util
 
RequestAndCompletionHandler(long, Node, AbstractRequest.Builder<? extends AbstractRequest>, RequestCompletionHandler) - Constructor for class org.apache.kafka.server.util.RequestAndCompletionHandler
 
reset() - Method in class org.apache.kafka.timeline.SnapshotRegistry
Delete all snapshots and resets all of the Revertable object registered.
reset() - Method in class org.apache.kafka.timeline.TimelineInteger
 
reset() - Method in class org.apache.kafka.timeline.TimelineLong
 
reset() - Method in class org.apache.kafka.timeline.TimelineObject
 
resizeThreadPool(int) - Method in class org.apache.kafka.server.util.KafkaScheduler
 
resizeThreadPool(int) - Method in interface org.apache.kafka.server.util.Scheduler
 
retainAll(Collection<?>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
retainAll(Collection<?>) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
retainAll(Collection<?>) - Method in class org.apache.kafka.server.mutable.BoundedList
 
retainAll(Collection<?>) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
reverseIterator() - Method in class org.apache.kafka.timeline.SnapshotRegistry
Returns a reverse snapshot iterator that iterates from the snapshots with the highest epoch to those with the lowest.
revertToSnapshot(long) - Method in class org.apache.kafka.timeline.SnapshotRegistry
Reverts the state of all data structures to the state at the given epoch.
run() - Method in interface org.apache.kafka.queue.EventQueue.Event
Run the event.
run() - Method in class org.apache.kafka.queue.EventQueue.VoidEvent
 
run() - Method in class org.apache.kafka.server.util.ShutdownableThread
 

S

schedule(String, Runnable, long, long) - Method in class org.apache.kafka.server.util.KafkaScheduler
 
schedule(String, Runnable, long, long) - Method in interface org.apache.kafka.server.util.Scheduler
Schedule a task.
scheduleDeferred(String, Function<OptionalLong, OptionalLong>, EventQueue.Event) - Method in interface org.apache.kafka.queue.EventQueue
Schedule an event to be run at a specific time.
scheduleOnce(String, Runnable) - Method in interface org.apache.kafka.server.util.Scheduler
 
scheduleOnce(String, Runnable, long) - Method in interface org.apache.kafka.server.util.Scheduler
 
Scheduler - Interface in org.apache.kafka.server.util
A scheduler for running jobs This interface controls a job scheduler that allows scheduling either repeating background jobs that execute periodically or delayed one-time actions that are scheduled in the future.
serialize(ApiMessageAndVersion) - Method in class org.apache.kafka.server.common.serialization.BytesApiMessageSerde
 
serverSynonym(String) - Static method in class org.apache.kafka.server.config.ServerTopicConfigSynonyms
Return the server config with the highest priority for `topicConfigName` if it exists.
ServerTopicConfigSynonyms - Class in org.apache.kafka.server.config
 
ServerTopicConfigSynonyms() - Constructor for class org.apache.kafka.server.config.ServerTopicConfigSynonyms
 
set(int, E) - Method in class org.apache.kafka.server.mutable.BoundedList
 
set(int) - Method in class org.apache.kafka.timeline.TimelineInteger
 
set(long) - Method in class org.apache.kafka.timeline.TimelineLong
 
set(T) - Method in class org.apache.kafka.timeline.TimelineObject
 
setAction(Runnable) - Method in class org.apache.kafka.server.fault.ProcessTerminatingFaultHandler.Builder
Set the Runnable to run when handling a fault.
setShouldHalt(boolean) - Method in class org.apache.kafka.server.fault.ProcessTerminatingFaultHandler.Builder
Set if halt or exit should be used.
shortVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
shouldThrottle(long, long) - Method in class org.apache.kafka.server.util.ThroughputThrottler
 
shutdown() - Method in class org.apache.kafka.server.util.InterBrokerSendThread
 
shutdown() - Method in class org.apache.kafka.server.util.KafkaScheduler
 
shutdown() - Method in interface org.apache.kafka.server.util.Scheduler
Shutdown this scheduler.
shutdown() - Method in class org.apache.kafka.server.util.ShutdownableThread
 
ShutdownableThread - Class in org.apache.kafka.server.util
 
ShutdownableThread(String) - Constructor for class org.apache.kafka.server.util.ShutdownableThread
 
ShutdownableThread(String, boolean) - Constructor for class org.apache.kafka.server.util.ShutdownableThread
 
ShutdownableThread(String, boolean, String) - Constructor for class org.apache.kafka.server.util.ShutdownableThread
 
singleton(K, V) - Static method in interface org.apache.kafka.server.immutable.ImmutableMap
 
singleton(E) - Static method in interface org.apache.kafka.server.immutable.ImmutableNavigableSet
 
singleton(E) - Static method in interface org.apache.kafka.server.immutable.ImmutableSet
 
singleton(K, V) - Static method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
singleton(E) - Static method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
singleton(E) - Static method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
size() - Method in interface org.apache.kafka.queue.EventQueue
 
size() - Method in class org.apache.kafka.queue.KafkaEventQueue
 
size() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
Get the number of IDs contained in this block.
size() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
size() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
size() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
size() - Method in class org.apache.kafka.server.mutable.BoundedList
 
size() - Method in class org.apache.kafka.server.util.timer.SystemTimer
 
size() - Method in interface org.apache.kafka.server.util.timer.Timer
Get the number of tasks pending execution
size() - Method in class org.apache.kafka.timeline.TimelineHashMap
 
size(long) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
size() - Method in class org.apache.kafka.timeline.TimelineHashSet
 
size(long) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
SnapshotRegistry - Class in org.apache.kafka.timeline
A registry containing snapshots of timeline data structures.
SnapshotRegistry(LogContext) - Constructor for class org.apache.kafka.timeline.SnapshotRegistry
 
spliterator() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
spliterator() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
startup() - Method in class org.apache.kafka.server.util.KafkaScheduler
 
startup() - Method in interface org.apache.kafka.server.util.Scheduler
Initialize this scheduler so it is ready to accept scheduling of tasks
stream() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
stream() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
subList(int, int) - Method in class org.apache.kafka.server.mutable.BoundedList
 
subSet(E, boolean, E, boolean) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
subSet(E, E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
SystemTimer - Class in org.apache.kafka.server.util.timer
 
SystemTimer(String) - Constructor for class org.apache.kafka.server.util.timer.SystemTimer
 
SystemTimer(String, long, int, long) - Constructor for class org.apache.kafka.server.util.timer.SystemTimer
 

T

tailSet(E, boolean) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
tailSet(E) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
targetCompressionType(CompressionType) - Method in enum org.apache.kafka.server.record.BrokerCompressionType
 
taskRunning(ScheduledFuture<?>) - Method in class org.apache.kafka.server.util.KafkaScheduler
 
threadNamePrefix() - Method in class org.apache.kafka.server.util.KafkaScheduler
 
throttle() - Method in class org.apache.kafka.server.util.ThroughputThrottler
Occasionally blocks for small amounts of time to achieve targetThroughput.
ThroughputThrottler - Class in org.apache.kafka.server.util
This class helps producers throttle throughput.
ThroughputThrottler(long, long) - Constructor for class org.apache.kafka.server.util.ThroughputThrottler
 
throwJsonMappingException(String, JsonNode) - Static method in interface org.apache.kafka.server.util.json.DecodeJson
 
time() - Method in class org.apache.kafka.queue.KafkaEventQueue
 
TimelineHashMap<K,V> - Class in org.apache.kafka.timeline
This is a hash map which can be snapshotted.
TimelineHashMap(SnapshotRegistry, int) - Constructor for class org.apache.kafka.timeline.TimelineHashMap
 
TimelineHashSet<T> - Class in org.apache.kafka.timeline
This is a hash set which can be snapshotted.
TimelineHashSet(SnapshotRegistry, int) - Constructor for class org.apache.kafka.timeline.TimelineHashSet
 
TimelineInteger - Class in org.apache.kafka.timeline
This is a mutable integer which can be snapshotted.
TimelineInteger(SnapshotRegistry) - Constructor for class org.apache.kafka.timeline.TimelineInteger
 
TimelineLong - Class in org.apache.kafka.timeline
This is a mutable long which can be snapshotted.
TimelineLong(SnapshotRegistry) - Constructor for class org.apache.kafka.timeline.TimelineLong
 
TimelineObject<T> - Class in org.apache.kafka.timeline
This is a mutable reference to an immutable object.
TimelineObject(SnapshotRegistry, T) - Constructor for class org.apache.kafka.timeline.TimelineObject
 
Timer - Interface in org.apache.kafka.server.util.timer
 
TimerTask - Class in org.apache.kafka.server.util.timer
 
TimerTask(long) - Constructor for class org.apache.kafka.server.util.timer.TimerTask
 
timerTask - Variable in class org.apache.kafka.server.util.timer.TimerTaskEntry
 
TimerTaskEntry - Class in org.apache.kafka.server.util.timer
 
TimerTaskEntry(TimerTask, long) - Constructor for class org.apache.kafka.server.util.timer.TimerTaskEntry
 
TimingWheel - Class in org.apache.kafka.server.util.timer
Hierarchical Timing Wheels A simple timing wheel is a circular list of buckets of timer tasks.
to(DecodeJson<T>) - Method in interface org.apache.kafka.server.util.json.JsonValue
 
toArray() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
toArray(T[]) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
toArray() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
toArray(T[]) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
toArray() - Method in class org.apache.kafka.server.mutable.BoundedList
 
toArray(T[]) - Method in class org.apache.kafka.server.mutable.BoundedList
 
toArray() - Method in class org.apache.kafka.timeline.TimelineHashSet
 
toArray(R[]) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
TOPIC_CONFIG_SYNONYMS - Static variable in class org.apache.kafka.server.config.ServerTopicConfigSynonyms
Map topic config to the server config with the highest priority.
TopicFilter - Class in org.apache.kafka.server.util
 
TopicFilter(String) - Constructor for class org.apache.kafka.server.util.TopicFilter
 
TopicFilter.IncludeList - Class in org.apache.kafka.server.util
 
TopicFilterAndPartitionFilter(TopicFilter.IncludeList, PartitionFilter) - Constructor for class org.apache.kafka.server.util.TopicPartitionFilter.TopicFilterAndPartitionFilter
 
TopicPartitionFilter - Interface in org.apache.kafka.server.util
 
TopicPartitionFilter.CompositeTopicPartitionFilter - Class in org.apache.kafka.server.util
 
TopicPartitionFilter.TopicFilterAndPartitionFilter - Class in org.apache.kafka.server.util
 
toString() - Method in class org.apache.kafka.queue.EventQueue.FailureLoggingEvent
 
toString() - Method in class org.apache.kafka.server.common.ApiMessageAndVersion
 
toString(T) - Method in interface org.apache.kafka.server.common.CheckpointFile.EntryFormatter
 
toString() - Method in class org.apache.kafka.server.common.Features
 
toString() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
toString() - Method in class org.apache.kafka.server.common.MetadataVersionValidator
 
toString() - Method in class org.apache.kafka.server.common.OffsetAndEpoch
 
toString() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
 
toString() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
toString() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableNavigableSet
 
toString() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableSet
 
toString() - Method in class org.apache.kafka.server.mutable.BoundedList
 
toString() - Method in class org.apache.kafka.server.network.KafkaAuthorizerServerInfo
 
toString() - Method in class org.apache.kafka.server.util.json.JsonArray
 
toString() - Method in class org.apache.kafka.server.util.json.JsonObject
 
toString() - Method in class org.apache.kafka.server.util.json.JsonValue.BasicJsonValue
 
toString() - Method in class org.apache.kafka.server.util.RequestAndCompletionHandler
 
toString() - Method in class org.apache.kafka.server.util.TopicFilter
 
toString() - Method in class org.apache.kafka.timeline.TimelineInteger
 
toString() - Method in class org.apache.kafka.timeline.TimelineLong
 
toString() - Method in class org.apache.kafka.timeline.TimelineObject
 
TranslatedValueMapView<K,V,B> - Class in org.apache.kafka.server.util
A map which presents a lightweight view of another "underlying" map.
TranslatedValueMapView(Map<K, B>, Function<B, V>) - Constructor for class org.apache.kafka.server.util.TranslatedValueMapView
 
tryParseBytes(byte[]) - Static method in class org.apache.kafka.server.util.Json
 
tryParseFull(String) - Static method in class org.apache.kafka.server.util.Json
Parse a JSON string into a JsonValue if possible.

U

UniquePartitionFilter(int) - Constructor for class org.apache.kafka.server.util.PartitionFilter.UniquePartitionFilter
 
updated(K, V) - Method in interface org.apache.kafka.server.immutable.ImmutableMap
 
updated(K, V) - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
updatePredicate(Predicate<MetricName>) - Method in class org.apache.kafka.server.metrics.FilteringJmxReporter
 

V

validateReconfiguration(Map<String, ?>) - Method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
valueOf(String) - Static method in enum org.apache.kafka.queue.EventQueue.EventInsertionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.server.common.MetadataVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.kafka.server.record.BrokerCompressionType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.kafka.queue.EventQueue.EventInsertionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.kafka.server.common.MetadataVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.kafka.server.immutable.pcollections.PCollectionsImmutableMap
 
values() - Static method in enum org.apache.kafka.server.record.BrokerCompressionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.kafka.timeline.TimelineHashMap
 
values(long) - Method in class org.apache.kafka.timeline.TimelineHashMap
 
version() - Method in class org.apache.kafka.server.common.ApiMessageAndVersion
 
version() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
versionOpt - Variable in class org.apache.kafka.server.util.CommandDefaultOptions
 
VERSIONS - Static variable in enum org.apache.kafka.server.common.MetadataVersion
 
VoidEvent() - Constructor for class org.apache.kafka.queue.EventQueue.VoidEvent
 

W

waitWithLogging(Logger, String, String, CompletableFuture<T>, Deadline, Time) - Static method in class org.apache.kafka.server.util.FutureUtils
Wait for a future until a specific time in the future, with copious logging.
wakeup() - Method in interface org.apache.kafka.queue.EventQueue
This method is used during unit tests where MockTime is in use.
wakeup() - Method in class org.apache.kafka.queue.KafkaEventQueue
 
wakeup() - Method in class org.apache.kafka.server.util.InterBrokerSendThread
 
wakeup() - Method in class org.apache.kafka.server.util.ThroughputThrottler
Wakeup the throttler if its sleeping.
write(Collection<T>) - Method in class org.apache.kafka.server.common.CheckpointFile.CheckpointWriteBuffer
 
write(Collection<T>) - Method in class org.apache.kafka.server.common.CheckpointFile
 
write(ApiMessageAndVersion, ObjectSerializationCache, Writable) - Method in class org.apache.kafka.server.common.serialization.AbstractApiMessageSerde
 
write(T, ObjectSerializationCache, Writable) - Method in interface org.apache.kafka.server.common.serialization.RecordSerde
Write the record to the output stream.
A B C D E F G H I J K L M N O P R S T U V W