Skip navigation links
A B C D E F G H I 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(T) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
addAll(Collection<? extends T>) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
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
 
assignedBrokerId() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
Get the ID of the broker that this block was assigned to.

B

beginShutdown(String) - Method in interface org.apache.kafka.queue.EventQueue
Asynchronously shut down the event queue with no unnecessary delay.
beginShutdown(String, EventQueue.Event) - Method in interface org.apache.kafka.queue.EventQueue
Asynchronously shut down the event queue with no unnecessary delay.
beginShutdown(String, EventQueue.Event, long, TimeUnit) - Method in interface org.apache.kafka.queue.EventQueue
Asynchronously shut down the event queue.
beginShutdown(String, EventQueue.Event, long, TimeUnit) - Method in class org.apache.kafka.queue.KafkaEventQueue
 
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

cancelDeferred(String) - Method in interface org.apache.kafka.queue.EventQueue
Cancel a deferred event.
cancelDeferred(String) - Method in class org.apache.kafka.queue.KafkaEventQueue
 
checkIfMetadataChanged(MetadataVersion, MetadataVersion) - Static method in enum org.apache.kafka.server.common.MetadataVersion
 
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.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.
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
 
configure(Map<String, ?>) - Method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
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.timeline.TimelineHashSet
 
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.timeline.TimelineHashMap
 

D

DeadlineFunction(long) - Constructor for class org.apache.kafka.queue.EventQueue.DeadlineFunction
 
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()
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
deserialize(byte[]) - Method in class org.apache.kafka.server.common.serialization.BytesApiMessageSerde
 
didMetadataChange() - Method in enum org.apache.kafka.server.common.MetadataVersion
 

E

EarliestDeadlineFunction(long) - Constructor for class org.apache.kafka.queue.EventQueue.EarliestDeadlineFunction
 
EMPTY - Static variable in class org.apache.kafka.server.common.ProducerIdsBlock
 
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.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.server.common.ApiMessageAndVersion
 
equals(Object) - Method in class org.apache.kafka.server.common.ProducerIdsBlock
 
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
 

F

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.
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
 
firstProducerId() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
Get the first ID (inclusive) to be assigned from this block.
fromFeatureLevel(short) - Static method in enum org.apache.kafka.server.common.MetadataVersion
 
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.

G

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.
getSnapshot(long) - Method in class org.apache.kafka.timeline.SnapshotRegistry
Gets the snapshot for a specific epoch.

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.ProcessExitingFaultHandler
 
hashCode() - Method in class org.apache.kafka.server.common.ApiMessageAndVersion
 
hashCode() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
 
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
 
highestSupportedRecordVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 

I

increment() - Method in class org.apache.kafka.timeline.TimelineInteger
 
increment() - Method in class org.apache.kafka.timeline.TimelineLong
 
INIT - Static variable in class org.apache.kafka.timeline.TimelineInteger
 
INIT - Static variable in class org.apache.kafka.timeline.TimelineLong
 
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
 
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
 
isEmpty() - Method in interface org.apache.kafka.queue.EventQueue
 
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
 
isLeaderRecoverySupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isLessThan(MetadataVersion) - 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
 
isSaslInterBrokerHandshakeRequestEnabled() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isTopicIdsSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isTruncationOnFetchSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
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
 

K

KafkaEventQueue - Class in org.apache.kafka.queue
 
KafkaEventQueue(Time, LogContext, String) - Constructor for class org.apache.kafka.queue.KafkaEventQueue
 
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.timeline.TimelineHashMap
 
keySet(long) - Method in class org.apache.kafka.timeline.TimelineHashMap
 

L

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.
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
 

M

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 - 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
 
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`.

N

nextBlockFirstId() - Method in class org.apache.kafka.server.common.ProducerIdsBlock
Get the first ID of the next block following this one.
NoDeadlineFunction() - Constructor for class org.apache.kafka.queue.EventQueue.NoDeadlineFunction
 

O

offsetForLeaderEpochRequestVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
onMetricAdded(MetricName, Metric) - Method in class org.apache.kafka.server.metrics.FilteringJmxReporter
 
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.fault - package org.apache.kafka.server.fault
 
org.apache.kafka.server.metrics - package org.apache.kafka.server.metrics
 
org.apache.kafka.server.util - package org.apache.kafka.server.util
 
org.apache.kafka.timeline - package org.apache.kafka.timeline
 

P

prepend(EventQueue.Event) - Method in interface org.apache.kafka.queue.EventQueue
Add an element to the front of the queue.
prettyPrintTable(List<String>, List<List<String>>, PrintStream) - Static method in class org.apache.kafka.server.util.ToolsUtils
 
printMetrics(Map<MetricName, ? extends Metric>) - Static method in class org.apache.kafka.server.util.ToolsUtils
print out the metrics in alphabetical order
ProcessExitingFaultHandler - Class in org.apache.kafka.server.fault
This is a fault handler which exits the Java process.
ProcessExitingFaultHandler() - Constructor for class org.apache.kafka.server.fault.ProcessExitingFaultHandler
 
ProcessExitingFaultHandler(Runnable) - Constructor for class org.apache.kafka.server.fault.ProcessExitingFaultHandler
 
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.timeline.TimelineHashMap
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.kafka.timeline.TimelineHashMap
 

R

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.timeline.TimelineHashMap
 
remove(Object) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
removeAll(Collection<?>) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
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
 
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
 

S

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.
serialize(ApiMessageAndVersion) - Method in class org.apache.kafka.server.common.serialization.BytesApiMessageSerde
 
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
 
shortVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
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.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
 

T

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
 
toArray() - Method in class org.apache.kafka.timeline.TimelineHashSet
 
toArray(R[]) - Method in class org.apache.kafka.timeline.TimelineHashSet
 
ToolsUtils - Class in org.apache.kafka.server.util
 
ToolsUtils() - Constructor for class org.apache.kafka.server.util.ToolsUtils
 
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 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.ProducerIdsBlock
 
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
 

U

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.
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.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
 
VERSIONS - Static variable in enum org.apache.kafka.server.common.MetadataVersion
 
VoidEvent() - Constructor for class org.apache.kafka.queue.EventQueue.VoidEvent
 

W

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
 
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 K L M N O P R S T U V W 
Skip navigation links