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

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
 
addPath(String) - Method in class io.confluent.security.authorizer.Scope.Builder
 
AlterReplicaExclusionOp - Class in org.apache.kafka.server.common
A single operation to alter the exclusion on the given broker
AlterReplicaExclusionOp(int, String, ExclusionOp.OpType) - Constructor for class org.apache.kafka.server.common.AlterReplicaExclusionOp
A single operation to alter the exclusion on the given brokerId
AlterReplicaExclusionsReply - Class in org.apache.kafka.server.common
 
AlterReplicaExclusionsReply(boolean, boolean, Set<BrokerReplicaExclusionResult>) - Constructor for class org.apache.kafka.server.common.AlterReplicaExclusionsReply
 
ancestorWithBindingScope(String) - Method in class io.confluent.security.authorizer.Scope
Starts at this scope and works up through its chain of parent scopes, returning the first scope it finds that has a bindingScope that matches the specified bindingScope.
APACHE_FEATURE_NAME - Static variable in enum org.apache.kafka.server.common.MetadataVersion
 
apacheFeatureLevel() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
apacheRelease() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
apiErrorOptional() - Method in class org.apache.kafka.server.common.BrokerReplicaExclusionResult
 
apiKeyAuthenticated(boolean) - Method in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
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.
AUTH_CREDENTIAL_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
AUTH_METHOD_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 

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
 
bindingScope() - Method in class io.confluent.security.authorizer.Scope
 
BROKER_COUNT - Static variable in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
brokerId() - Method in class org.apache.kafka.server.common.AlterReplicaExclusionOp
 
brokerId() - Method in class org.apache.kafka.server.common.BrokerReplicaExclusionResult
 
BrokerReplicaExclusionModificationResult - Class in org.apache.kafka.server.common
The in-memory result of a modification of replica exclusions.
BrokerReplicaExclusionModificationResult(AlterReplicaExclusionsReply, Map<Integer, String>) - Constructor for class org.apache.kafka.server.common.BrokerReplicaExclusionModificationResult
 
BrokerReplicaExclusionResult - Class in org.apache.kafka.server.common
The result of a single broker replica exclusion operation.
BrokerReplicaExclusionResult(int, Optional<ApiError>, ExclusionOp.OpType, String) - Constructor for class org.apache.kafka.server.common.BrokerReplicaExclusionResult
 
BrokerReplicaExclusionUtils - Class in org.apache.kafka.server.util
 
BrokerReplicaExclusionUtils() - Constructor for class org.apache.kafka.server.util.BrokerReplicaExclusionUtils
 
build() - Method in class io.confluent.kafka.multitenant.IdentityMetadata.Builder
 
build() - Method in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
build() - Method in class io.confluent.security.authorizer.Scope.Builder
 
build() - Method in class org.apache.kafka.server.fault.ProcessTerminatingFaultHandler.Builder
 
Builder() - Constructor for class io.confluent.kafka.multitenant.IdentityMetadata.Builder
 
Builder(String, String) - Constructor for class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
Builder(String...) - Constructor for class io.confluent.security.authorizer.Scope.Builder
 
Builder(List<String>) - Constructor for class io.confluent.security.authorizer.Scope.Builder
 
Builder() - Constructor for class org.apache.kafka.server.fault.ProcessTerminatingFaultHandler.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

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.CheckpointReadBuffer<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
 
clear() - Method in class org.apache.kafka.timeline.TimelineHashMap
 
clear() - Method in class org.apache.kafka.timeline.TimelineHashSet
 
CLIENT_ID_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
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
 
CLUSTER_BINDING_SCOPE - Static variable in class io.confluent.security.authorizer.Scope
 
clusterId - Variable in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
clusterId - Variable in class io.confluent.kafka.multitenant.TenantMetadata
 
ClusterLinkConfig - Class in io.confluent.kafka.link
 
ClusterLinkConfig() - Constructor for class io.confluent.kafka.link.ClusterLinkConfig
 
ClusterLinkConfig.LinkMode - Enum in io.confluent.kafka.link
 
clusterLinkRecordVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
ClusterLinkUtils - Class in io.confluent.kafka.link
Cluster link utility methods that are needed by both the broker and controller.
ClusterLinkUtils() - Constructor for class io.confluent.kafka.link.ClusterLinkUtils
 
clusters() - Method in class io.confluent.security.authorizer.Scope
 
configure(Map<String, ?>) - Method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
CONFLUENT_FEATURE_NAME - Static variable in enum org.apache.kafka.server.common.MetadataVersion
 
CONFLUENT_RELEASE_PREFIX - Static variable in enum org.apache.kafka.server.common.MetadataVersion
 
confluentFeatureLevel() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
confluentRelease() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
CONSUMER_GROUP_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
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
 
containsScope(Scope) - Method in class io.confluent.security.authorizer.Scope
 
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
DELIMITER - Static variable in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
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
 
environmentId - Variable in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
environmentId(String) - Method in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
environmentId - Variable in class io.confluent.kafka.multitenant.TenantMetadata
 
epochsList() - Method in class org.apache.kafka.timeline.SnapshotRegistry
Returns a sorted list of snapshot epochs.
equals(Object) - Method in class io.confluent.kafka.multitenant.IdentityMetadata
 
equals(Object) - Method in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
equals(Object) - Method in class io.confluent.kafka.multitenant.TenantMetadata
 
equals(Object) - Method in class io.confluent.security.authorizer.Scope
 
equals(Object) - Method in class org.apache.kafka.server.common.AlterReplicaExclusionOp
 
equals(Object) - Method in class org.apache.kafka.server.common.ApiMessageAndVersion
 
equals(Object) - Method in class org.apache.kafka.server.common.BrokerReplicaExclusionResult
 
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
 
exclusionExists(Map<Integer, String>, int, String) - Static method in class org.apache.kafka.server.util.BrokerReplicaExclusionUtils
Given a map of existing broker replica exclusions, determine whether the given broker replica exclusion exists in the map.
exclusionExists(Map<Integer, String>, int) - Static method in class org.apache.kafka.server.util.BrokerReplicaExclusionUtils
Given a map of existing broker replica exclusions, determine whether the given broker replica exclusion exists in the map.
exclusionResults() - Method in class org.apache.kafka.server.common.AlterReplicaExclusionsReply
 
exclusionsMatchCurrentState(Map<Integer, String>, Set<AlterReplicaExclusionOp>) - Static method in class org.apache.kafka.server.util.BrokerReplicaExclusionUtils
Return a boolean indicating whether the user-requested AlterReplicaExclusionOp operations match the currently-active replica exclusions (e.g as in the case of duplicate requests)
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
 
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.
fromApacheFeatureLevel(short) - Static method in enum org.apache.kafka.server.common.MetadataVersion
 
fromConfluentFeatureLevel(short) - Static method in enum org.apache.kafka.server.common.MetadataVersion
 
fromString(String) - Static method in enum io.confluent.kafka.link.ClusterLinkConfig.LinkMode
 
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.
getValidBrokerRackSet(String) - Static method in class io.confluent.kafka.multitenant.ZoneUtils
 
GROUP - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
GROUP_INSTANCE_ID_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 

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
 
hashCode() - Method in class io.confluent.kafka.multitenant.IdentityMetadata
 
hashCode() - Method in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
hashCode() - Method in class io.confluent.kafka.multitenant.TenantMetadata
 
hashCode() - Method in class io.confluent.security.authorizer.Scope
 
hashCode() - Method in class org.apache.kafka.server.common.AlterReplicaExclusionOp
 
hashCode() - Method in class org.apache.kafka.server.common.ApiMessageAndVersion
 
hashCode() - Method in class org.apache.kafka.server.common.BrokerReplicaExclusionResult
 
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
 
healthcheckTenant(boolean) - Method in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
highestSupportedRecordVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 

I

identity(String) - Method in class io.confluent.kafka.multitenant.IdentityMetadata.Builder
 
identity() - Method in class io.confluent.kafka.multitenant.IdentityMetadata
 
IdentityMetadata - Class in io.confluent.kafka.multitenant
 
IdentityMetadata(String, String, String) - Constructor for class io.confluent.kafka.multitenant.IdentityMetadata
 
IdentityMetadata.Builder - Class in io.confluent.kafka.multitenant
 
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
 
intermediateScope(String...) - Static method in class io.confluent.security.authorizer.Scope
 
InvalidScopeException - Exception in io.confluent.security.authorizer.provider
 
InvalidScopeException(String) - Constructor for exception io.confluent.security.authorizer.provider.InvalidScopeException
 
io.confluent.kafka.link - package io.confluent.kafka.link
 
io.confluent.kafka.multitenant - package io.confluent.kafka.multitenant
 
io.confluent.security.authorizer - package io.confluent.security.authorizer
 
io.confluent.security.authorizer.provider - package io.confluent.security.authorizer.provider
 
IP_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
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
 
isApiKeyAuthenticated - Variable in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
isApiKeyAuthenticated - Variable in class io.confluent.kafka.multitenant.TenantMetadata
 
isAtLeast(MetadataVersion) - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isBrokerRegistrationChangeRecordSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isClusterLinkModeSupported() - 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
 
isFetchFromFollowerEnabled(String, String, Set<String>) - Static method in class io.confluent.kafka.multitenant.ZoneUtils
 
isHealthcheckTenant - Variable in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
isHealthcheckTenant - Variable in class io.confluent.kafka.multitenant.TenantMetadata
 
isInControlledShutdownStateSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isInternalUser() - Method in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
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
 
isLinkCoordinatorEnabled() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isMigrationSupported() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
isMinTierFeatureSupported() - 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
 
isServiceAccount - Variable in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
isServiceAccount - Variable in class io.confluent.kafka.multitenant.TenantMetadata
 
isSuperUser(boolean, boolean) - Method in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
isTenantPrincipal(KafkaPrincipal) - Static method in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
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

KAFKA_CLUSTER_TYPE - Static variable in class io.confluent.security.authorizer.Scope
 
kafkaClusterScope(String) - Static method in class io.confluent.security.authorizer.Scope
 
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
 
KafkaProducerWrapperWithTime<K,V> - Class in org.apache.kafka.clients.producer
 
KafkaProducerWrapperWithTime(Properties, Time) - Constructor for class org.apache.kafka.clients.producer.KafkaProducerWrapperWithTime
 
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
 
KSQL_CLUSTER_TYPE - Static variable in class io.confluent.security.authorizer.Scope
 

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.
linkModeProp - Static variable in class io.confluent.kafka.link.ClusterLinkConfig
 
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

maybeGetIdentity() - Method in class io.confluent.kafka.multitenant.IdentityMetadata
 
maybeGetIdentityMetadata() - Method in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
maybeGetPoolId() - Method in class io.confluent.kafka.multitenant.IdentityMetadata
 
maybeGetProviderId() - Method in class io.confluent.kafka.multitenant.IdentityMetadata
 
MEMBER_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
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`.
modifiedExclusions() - Method in class org.apache.kafka.server.common.BrokerReplicaExclusionModificationResult
 
MultiTenantPrincipal - Class in io.confluent.kafka.multitenant
 
MultiTenantPrincipal(String, TenantMetadata) - Constructor for class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
MultiTenantPrincipal(String, String, TenantMetadata) - Constructor for class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
MultiTenantPrincipal(String, TenantMetadata, IdentityMetadata) - Constructor for class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
MultiTenantPrincipal(String, String, TenantMetadata, IdentityMetadata) - Constructor for class io.confluent.kafka.multitenant.MultiTenantPrincipal
 

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
 
opType() - Method in class org.apache.kafka.server.common.AlterReplicaExclusionOp
 
opType() - Method in class org.apache.kafka.server.common.BrokerReplicaExclusionResult
 
org.apache.kafka.clients.producer - package org.apache.kafka.clients.producer
 
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
 
organizationId - Variable in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
organizationId(String) - Method in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
organizationId - Variable in class io.confluent.kafka.multitenant.TenantMetadata
 

P

parent() - Method in class io.confluent.security.authorizer.Scope
 
PARTITION_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
path() - Method in class io.confluent.security.authorizer.Scope
 
poolId(String) - Method in class io.confluent.kafka.multitenant.IdentityMetadata.Builder
 
poolId() - Method in class io.confluent.kafka.multitenant.IdentityMetadata
 
prepareReplicaExclusions(Map<Integer, String>, Set<AlterReplicaExclusionOp>) - Static method in class org.apache.kafka.server.util.BrokerReplicaExclusionUtils
Processes, validates and conditionally applies the requested replica exclusions to the current active set of replica exclusions.
prepend(EventQueue.Event) - Method in interface org.apache.kafka.queue.EventQueue
Add an element to the front of the queue.
prettyPrintTable(String[], List<String[]>, PrintStream) - Static method in class org.apache.kafka.server.util.ToolsUtils
 
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
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
 
providerId(String) - Method in class io.confluent.kafka.multitenant.IdentityMetadata.Builder
 
providerId() - Method in class io.confluent.kafka.multitenant.IdentityMetadata
 
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.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.
reason() - Method in class org.apache.kafka.server.common.AlterReplicaExclusionOp
 
reason() - Method in class org.apache.kafka.server.common.BrokerReplicaExclusionResult
 
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.
registerBroker() - Static method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
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
 
reply() - Method in class org.apache.kafka.server.common.BrokerReplicaExclusionModificationResult
 
REQUEST_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
RESERVED_BINDING_SCOPES - Static variable in class io.confluent.security.authorizer.Scope
 
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.
ROOT_BINDING_SCOPE - Static variable in class io.confluent.security.authorizer.Scope
 
ROOT_SCOPE - Static variable in class io.confluent.security.authorizer.Scope
 
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.
SCHEMA_REGISTRY_CLUSTER_TYPE - Static variable in class io.confluent.security.authorizer.Scope
 
scope() - Method in class io.confluent.kafka.multitenant.TenantMetadata
 
Scope - Class in io.confluent.security.authorizer
Hierarchical scopes for role bindings.
Scope(List<String>, Map<String, String>) - Constructor for class io.confluent.security.authorizer.Scope
 
Scope.Builder - Class in io.confluent.security.authorizer
 
SCOPE_TYPE_PATTERN - Static variable in class io.confluent.security.authorizer.Scope
 
serialize(ApiMessageAndVersion) - Method in class org.apache.kafka.server.common.serialization.BytesApiMessageSerde
 
serviceAccount(boolean) - Method in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
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.
shortConfluentRelease() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
shortVersion() - Method in enum org.apache.kafka.server.common.MetadataVersion
 
shouldApply() - Method in class org.apache.kafka.server.common.BrokerReplicaExclusionModificationResult
 
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

TENANT_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
TENANT_USER_TYPE - Static variable in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
TENANT_USERV2_TYPE - Static variable in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
TENANT_WILDCARD_USER_TYPE - Static variable in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
TENANT_WILDCARD_USERV2_TYPE - Static variable in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
tenantMetadata() - Method in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
TenantMetadata - Class in io.confluent.kafka.multitenant
 
TenantMetadata(String, String) - Constructor for class io.confluent.kafka.multitenant.TenantMetadata
 
TenantMetadata.Builder - Class in io.confluent.kafka.multitenant
 
tenantName - Variable in class io.confluent.kafka.multitenant.TenantMetadata.Builder
 
tenantName - Variable in class io.confluent.kafka.multitenant.TenantMetadata
 
tenantPrefix() - Method in class io.confluent.kafka.multitenant.TenantMetadata
 
TenantUtils - Class in io.confluent.kafka.multitenant
 
TenantUtils() - Constructor for class io.confluent.kafka.multitenant.TenantUtils
 
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
 
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
 
TOPIC_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
toResponseData() - Method in class org.apache.kafka.server.common.AlterReplicaExclusionsReply
Converts the given alter broker replica exclusions reply to a response data object
toString() - Method in class io.confluent.kafka.multitenant.IdentityMetadata
 
toString() - Method in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
toString() - Method in class io.confluent.kafka.multitenant.TenantMetadata
 
toString() - Method in class io.confluent.security.authorizer.Scope
 
toString() - Method in class org.apache.kafka.queue.EventQueue.FailureLoggingEvent
 
toString() - Method in class org.apache.kafka.server.common.AlterReplicaExclusionOp
 
toString() - Method in class org.apache.kafka.server.common.ApiMessageAndVersion
 
toString() - Method in class org.apache.kafka.server.common.BrokerReplicaExclusionResult
 
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

unregisterBroker() - Static method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
updateOrgProperties(String, String) - Method in class io.confluent.kafka.multitenant.TenantMetadata
 
updatePredicate(Predicate<MetricName>) - Method in class org.apache.kafka.server.metrics.FilteringJmxReporter
 
user() - Method in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
USER_RESOURCE_ID_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
USER_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
userResourceId - Variable in class io.confluent.kafka.multitenant.TenantMetadata
 
USERV2 - Static variable in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 

V

validate() - Method in class io.confluent.security.authorizer.Scope
 
validateLinkNameOrThrow(String) - Static method in class io.confluent.kafka.link.ClusterLinkUtils
Validates the provided cluster link name, ensuring it's non-empty and contains only legal characters.
validateReconfiguration(Map<String, ?>) - Method in class org.apache.kafka.server.metrics.KafkaYammerMetrics
 
validateZoneAlignment(Set<String>, String, String) - Static method in class io.confluent.kafka.multitenant.ZoneUtils
 
valueOf(String) - Static method in enum io.confluent.kafka.link.ClusterLinkConfig.LinkMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.confluent.kafka.multitenant.ZoneAlignment
Returns the enum constant of this type with the specified name.
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 io.confluent.kafka.link.ClusterLinkConfig.LinkMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.confluent.kafka.multitenant.ZoneAlignment
Returns an array containing the constants of this enum type, in the order they are declared.
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
 
wasSuccessful() - Method in class org.apache.kafka.server.common.AlterReplicaExclusionsReply
 
wasSuccessfulNoOp() - Method in class org.apache.kafka.server.common.AlterReplicaExclusionsReply
 
WILDCARD_USERV2_PRINCIPAL - Static variable in class io.confluent.kafka.multitenant.MultiTenantPrincipal
 
withCluster(String, String) - Method in class io.confluent.security.authorizer.Scope.Builder
 
withKafkaCluster(String) - Method in class io.confluent.security.authorizer.Scope.Builder
 
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.
writeToByteArray(Collection<T>) - Method in class org.apache.kafka.server.common.CheckpointFile
 
writeToWriter(Collection<T>, BufferedWriter) - Method in class org.apache.kafka.server.common.CheckpointFile
 

Z

ZONE_ALIGNMENT_TAG - Static variable in class io.confluent.kafka.multitenant.TenantUtils
 
ZoneAlignment - Enum in io.confluent.kafka.multitenant
 
ZoneUtils - Class in io.confluent.kafka.multitenant
 
ZoneUtils() - Constructor for class io.confluent.kafka.multitenant.ZoneUtils
 
A B C D E F G H I K L M N O P R S T U V W Z 
Skip navigation links