Skip navigation links
Oracle® Database Transactional Event Queues Java API Reference
21c

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

A

abortTransaction() - Method in class org.oracle.okafka.clients.producer.KafkaProducer
This api is not yet supported
abortTransaction() - Method in interface org.oracle.okafka.clients.producer.Producer
AbstractConfig - Class in org.oracle.okafka.common.config
A convenient base class for configurations to extend.
AbstractConfig(ConfigDef, Map<?, ?>, boolean) - Constructor for class org.oracle.okafka.common.config.AbstractConfig
 
AbstractConfig(ConfigDef, Map<?, ?>) - Constructor for class org.oracle.okafka.common.config.AbstractConfig
 
AbstractOptions<T extends AbstractOptions> - Class in org.oracle.okafka.clients.admin
 
AbstractOptions() - Constructor for class org.oracle.okafka.clients.admin.AbstractOptions
 
accept(A, B) - Method in interface org.oracle.okafka.common.KafkaFuture.BiConsumer
 
ACKS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
acks
addClientSslSupport(ConfigDef) - Static method in class org.oracle.okafka.common.config.SslConfigs
 
addDeserializerToConfig(Map<String, Object>, Deserializer<?>, Deserializer<?>) - Static method in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
addDeserializerToConfig(Properties, Deserializer<?>, Deserializer<?>) - Static method in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
addErrorMessage(String) - Method in class org.oracle.okafka.common.config.ConfigValue
 
addSerializerToConfig(Map<String, Object>, Serializer<?>, Serializer<?>) - Static method in class org.oracle.okafka.clients.producer.ProducerConfig
 
addSerializerToConfig(Properties, Serializer<?>, Serializer<?>) - Static method in class org.oracle.okafka.clients.producer.ProducerConfig
 
addWaiter(KafkaFuture.BiConsumer<? super T, ? super Throwable>) - Method in class org.oracle.okafka.common.KafkaFuture
 
AdminClient - Class in org.oracle.okafka.clients.admin
The administrative client for Transactional Event Queues(TEQ), which supports managing and inspecting topics.
AdminClient() - Constructor for class org.oracle.okafka.clients.admin.AdminClient
 
AdminClientConfig - Class in org.oracle.okafka.clients.admin
The AdminClient configuration class, which also contains constants for configuration entry names.
AdminClientConfig(Map<?, ?>) - Constructor for class org.oracle.okafka.clients.admin.AdminClientConfig
 
all() - Method in class org.oracle.okafka.clients.admin.CreatePartitionsResult
Return a future which succeeds if all the partition creations succeed.
all() - Method in class org.oracle.okafka.clients.admin.CreateTopicsResult
Return a future which succeeds if all the topic creations succeed.
all() - Method in class org.oracle.okafka.clients.admin.DeleteConsumerGroupsResult
Return a future which succeeds only if all the consumer group deletions succeed.
all() - Method in class org.oracle.okafka.clients.admin.DeleteRecordsResult
Return a future which succeeds only if all the records deletions succeed.
all() - Method in class org.oracle.okafka.clients.admin.DeleteTopicsResult
Return a future which succeeds only if all the topic deletions succeed.
allOf(KafkaFuture<?>...) - Static method in class org.oracle.okafka.common.KafkaFuture
Returns a new KafkaFuture that is completed when all the given futures have completed.
alterConfigs(Map<ConfigResource, Config>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
alterConfigs(Map<ConfigResource, Config>, AlterConfigsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
AlterConfigsOptions - Class in org.oracle.okafka.clients.admin
AlterConfigsOptions() - Constructor for class org.oracle.okafka.clients.admin.AlterConfigsOptions
 
AlterConfigsResult - Class in org.oracle.okafka.clients.admin
The result of the AdminClient.alterConfigs(Map) call.
AlterConfigsResult() - Constructor for class org.oracle.okafka.clients.admin.AlterConfigsResult
 
alterReplicaLogDirs(Map<TopicPartitionReplica, String>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
alterReplicaLogDirs(Map<TopicPartitionReplica, String>, AlterReplicaLogDirsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
AlterReplicaLogDirsOptions - Class in org.oracle.okafka.clients.admin
AlterReplicaLogDirsOptions() - Constructor for class org.oracle.okafka.clients.admin.AlterReplicaLogDirsOptions
 
AlterReplicaLogDirsResult - Class in org.oracle.okafka.clients.admin
AlterReplicaLogDirsResult() - Constructor for class org.oracle.okafka.clients.admin.AlterReplicaLogDirsResult
 
ApiException - Exception in org.oracle.okafka.common.errors
Any API exception that is part of the public protocol and should be a subclass of this class and be part of this package.
ApiException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.ApiException
 
ApiException(String) - Constructor for exception org.oracle.okafka.common.errors.ApiException
 
ApiException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.ApiException
 
ApiException() - Constructor for exception org.oracle.okafka.common.errors.ApiException
 
apply(A) - Method in interface org.oracle.okafka.common.KafkaFuture.BaseFunction
 
AQException - Exception in org.oracle.okafka.common
Base class of all other TEQ exceptions.
AQException(String, Throwable) - Constructor for exception org.oracle.okafka.common.AQException
 
AQException(String) - Constructor for exception org.oracle.okafka.common.AQException
 
AQException(Throwable) - Constructor for exception org.oracle.okafka.common.AQException
 
AQException() - Constructor for exception org.oracle.okafka.common.AQException
 
assign(Collection<TopicPartition>) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
assign(Collection<TopicPartition>) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
assignment() - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
assignment() - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
assignments() - Method in class org.oracle.okafka.clients.admin.NewPartitions
The replica assignments for the new partitions, or null if the assignment will be done by the controller.
atLeast(Number) - Static method in class org.oracle.okafka.common.config.ConfigDef.Range
A numeric range that checks only the lower bound
AuthenticationException - Exception in org.oracle.okafka.common.errors
This exception indicates that authentication has failed.
AuthenticationException(String) - Constructor for exception org.oracle.okafka.common.errors.AuthenticationException
 
AuthenticationException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.AuthenticationException
 
AuthorizationException - Exception in org.oracle.okafka.common.errors
 
AuthorizationException(String) - Constructor for exception org.oracle.okafka.common.errors.AuthorizationException
 
AuthorizationException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.AuthorizationException
 
AUTO_COMMIT_INTERVAL_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
auto.commit.interval.ms
AUTO_OFFSET_RESET_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
auto.offset.reset
AUTO_OFFSET_RESET_DOC - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
availablePartitionsForTopic(String) - Method in class org.oracle.okafka.common.Cluster
Get the list of available partitions for this topic

B

BATCH_SIZE_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
batch.size
beforeOffset(long) - Static method in class org.oracle.okafka.clients.admin.RecordsToDelete
Delete all the records before the given offset
beforeOffset() - Method in class org.oracle.okafka.clients.admin.RecordsToDelete
The offset before which all records will be deleted
beginningOffsets(Collection<TopicPartition>) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
beginningOffsets(Collection<TopicPartition>, Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
beginningOffsets(Collection<TopicPartition>) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
beginningOffsets(Collection<TopicPartition>, Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
beginTransaction() - Method in class org.oracle.okafka.clients.producer.KafkaProducer
This api is not yet supported
beginTransaction() - Method in interface org.oracle.okafka.clients.producer.Producer
between(Number, Number) - Static method in class org.oracle.okafka.common.config.ConfigDef.Range
A numeric range that checks both the upper and lower bound
bootstrap(List<InetSocketAddress>, AbstractConfig, String, String) - Static method in class org.oracle.okafka.common.Cluster
Create a "bootstrap" cluster using the given list of host/ports
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
bootstrap.servers
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
bootstrap.servers
BOOTSTRAP_SERVERS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
bootstrap.servers
brokerId() - Method in class org.oracle.okafka.common.TopicPartitionReplica
 
BUFFER_MEMORY_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
buffer.memory
BufferExhaustedException - Exception in org.oracle.okafka.clients.producer
This exception is thrown if the producer is in non-blocking mode and the rate of data production exceeds the rate at which data can be sent for long enough for the allocated buffer to be exhausted.
BufferExhaustedException(String) - Constructor for exception org.oracle.okafka.clients.producer.BufferExhaustedException
 
ByteArrayDeserializer - Class in org.oracle.okafka.common.serialization
 
ByteArrayDeserializer() - Constructor for class org.oracle.okafka.common.serialization.ByteArrayDeserializer
 
ByteArraySerializer - Class in org.oracle.okafka.common.serialization
 
ByteArraySerializer() - Constructor for class org.oracle.okafka.common.serialization.ByteArraySerializer
 
ByteBufferDeserializer - Class in org.oracle.okafka.common.serialization
 
ByteBufferDeserializer() - Constructor for class org.oracle.okafka.common.serialization.ByteBufferDeserializer
 
ByteBufferSerializer - Class in org.oracle.okafka.common.serialization
 
ByteBufferSerializer() - Constructor for class org.oracle.okafka.common.serialization.ByteBufferSerializer
 
BytesDeserializer - Class in org.oracle.okafka.common.serialization
 
BytesDeserializer() - Constructor for class org.oracle.okafka.common.serialization.BytesDeserializer
 
BytesSerializer - Class in org.oracle.okafka.common.serialization
 
BytesSerializer() - Constructor for class org.oracle.okafka.common.serialization.BytesSerializer
 

C

Callback - Interface in org.oracle.okafka.clients.producer
A callback interface that the user can implement to allow code to execute when the request is complete.
cancel(boolean) - Method in class org.oracle.okafka.common.KafkaFuture
If not already completed, completes this future with a CancellationException.
CHECK_CRCS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
check.crcs
checksum() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
Deprecated.
checksum() - Method in class org.oracle.okafka.clients.producer.RecordMetadata
Deprecated.
CLIENT_ID_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
CLIENT_ID_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
client.id
CLIENT_ID_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
client.id
close() - Method in class org.oracle.okafka.clients.admin.AdminClient
Close the AdminClient and release all associated resources.
close(long, TimeUnit) - Method in class org.oracle.okafka.clients.admin.AdminClient
Close the AdminClient and release all associated resources.
close(long, TimeUnit) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
close() - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
close(long, TimeUnit) - Method in interface org.oracle.okafka.clients.consumer.Consumer
Deprecated.
close(Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
close() - Method in interface org.oracle.okafka.clients.consumer.ConsumerInterceptor
This is called when interceptor is closed
close() - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Tries to close the consumer cleanly.
close(long, TimeUnit) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Deprecated.
close(Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Tries to close the consumer cleanly.
close() - Method in class org.oracle.okafka.clients.producer.KafkaProducer
Close this producer.
close(long, TimeUnit) - Method in class org.oracle.okafka.clients.producer.KafkaProducer
This method waits up to timeout for the producer to complete the sending of all incomplete requests.
close() - Method in interface org.oracle.okafka.clients.producer.Partitioner
This is called when partitioner is closed.
close() - Method in interface org.oracle.okafka.clients.producer.Producer
close(long, TimeUnit) - Method in interface org.oracle.okafka.clients.producer.Producer
close() - Method in interface org.oracle.okafka.clients.producer.ProducerInterceptor
This is called when interceptor is closed
close() - Method in class org.oracle.okafka.common.serialization.ByteArrayDeserializer
 
close() - Method in class org.oracle.okafka.common.serialization.ByteArraySerializer
 
close() - Method in class org.oracle.okafka.common.serialization.ByteBufferDeserializer
 
close() - Method in class org.oracle.okafka.common.serialization.ByteBufferSerializer
 
close() - Method in class org.oracle.okafka.common.serialization.BytesDeserializer
 
close() - Method in class org.oracle.okafka.common.serialization.BytesSerializer
 
close() - Method in interface org.oracle.okafka.common.serialization.Deserializer
 
close() - Method in class org.oracle.okafka.common.serialization.DoubleDeserializer
 
close() - Method in class org.oracle.okafka.common.serialization.DoubleSerializer
 
close() - Method in class org.oracle.okafka.common.serialization.ExtendedDeserializer.Wrapper
 
close() - Method in class org.oracle.okafka.common.serialization.ExtendedSerializer.Wrapper
 
close() - Method in class org.oracle.okafka.common.serialization.FloatDeserializer
 
close() - Method in class org.oracle.okafka.common.serialization.FloatSerializer
 
close() - Method in class org.oracle.okafka.common.serialization.IntegerDeserializer
 
close() - Method in class org.oracle.okafka.common.serialization.IntegerSerializer
 
close() - Method in class org.oracle.okafka.common.serialization.LongDeserializer
 
close() - Method in class org.oracle.okafka.common.serialization.LongSerializer
 
close() - Method in interface org.oracle.okafka.common.serialization.Serializer
Close this serializer.
close() - Method in class org.oracle.okafka.common.serialization.ShortDeserializer
 
close() - Method in class org.oracle.okafka.common.serialization.ShortSerializer
 
close() - Method in class org.oracle.okafka.common.serialization.StringDeserializer
 
close() - Method in class org.oracle.okafka.common.serialization.StringSerializer
 
Cluster - Class in org.oracle.okafka.common
 
Cluster(String, Collection<Node>, Collection<PartitionInfo>, Set<String>, Set<String>, AbstractConfig) - Constructor for class org.oracle.okafka.common.Cluster
 
Cluster(String, Collection<Node>, Collection<PartitionInfo>, Set<String>, Set<String>, Node, AbstractConfig) - Constructor for class org.oracle.okafka.common.Cluster
 
Cluster(String, boolean, Collection<Node>, Collection<PartitionInfo>, Set<String>, Set<String>, Node, AbstractConfig) - Constructor for class org.oracle.okafka.common.Cluster
 
clusterId() - Method in class org.oracle.okafka.clients.admin.DescribeClusterResult
Returns a future which yields the current cluster id.
clusterId() - Method in class org.oracle.okafka.common.ClusterResource
 
clusterResource() - Method in class org.oracle.okafka.common.Cluster
 
ClusterResource - Class in org.oracle.okafka.common
The ClusterResource class encapsulates metadata for a TEQ/oracle db cluster.
ClusterResource(String) - Constructor for class org.oracle.okafka.common.ClusterResource
 
ClusterResourceListener - Interface in org.oracle.okafka.common
This feature is not yet supported.
commitAsync() - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
commitAsync(OffsetCommitCallback) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
commitAsync() - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Commit mesages consumed using KafkaConsumer.poll(Duration) for the subscribed topic and assigned partition in this session since last commit.
commitAsync(OffsetCommitCallback) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Commits messages(offsets) consumed using ) since last commit in this session.
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
commitSync() - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
commitSync(Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
commitSync() - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Commits messages(offsets) consumed using poll() since last commit in this session.
commitSync(Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Commits messages(offsets) consumed using poll() since last commit in this session.
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method not yet supported.
commitSync(Map<TopicPartition, OffsetAndMetadata>, Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method not yet supported.
committed(TopicPartition) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
committed(TopicPartition, Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
committed(TopicPartition) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
committed(TopicPartition, Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
commitTransaction() - Method in class org.oracle.okafka.clients.producer.KafkaProducer
This api is not yet supported
commitTransaction() - Method in interface org.oracle.okafka.clients.producer.Producer
complete(T) - Method in class org.oracle.okafka.common.KafkaFuture
If not already completed, sets the value returned by get() and related methods to the given value.
completedFuture(U) - Static method in class org.oracle.okafka.common.KafkaFuture
Returns a new KafkaFuture that is already completed with the given value.
completeExceptionally(Throwable) - Method in class org.oracle.okafka.common.KafkaFuture
If not already completed, causes invocations of get() and related methods to throw the given exception.
COMPRESSION_TYPE_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
compression.type (This property is not yet supported)
Config - Class in org.oracle.okafka.clients.admin
A configuration object containing the configuration entries for a resource.
Config(Collection<ConfigEntry>) - Constructor for class org.oracle.okafka.clients.admin.Config
Create a configuration instance with the provided entries.
ConfigDef - Class in org.oracle.okafka.common.config
This class is used for specifying the set of expected configurations.
ConfigDef() - Constructor for class org.oracle.okafka.common.config.ConfigDef
 
ConfigDef(ConfigDef) - Constructor for class org.oracle.okafka.common.config.ConfigDef
 
ConfigDef.CompositeValidator - Class in org.oracle.okafka.common.config
 
ConfigDef.ConfigKey - Class in org.oracle.okafka.common.config
 
ConfigDef.Importance - Enum in org.oracle.okafka.common.config
The importance level for a configuration
ConfigDef.NonEmptyString - Class in org.oracle.okafka.common.config
 
ConfigDef.NonEmptyStringWithoutControlChars - Class in org.oracle.okafka.common.config
 
ConfigDef.NonNullValidator - Class in org.oracle.okafka.common.config
 
ConfigDef.Range - Class in org.oracle.okafka.common.config
Validation logic for numeric ranges
ConfigDef.Recommender - Interface in org.oracle.okafka.common.config
This is used by the ConfigDef.validate(Map) to get valid values for a configuration given the current configuration values in order to perform full configuration validation and visibility modification.
ConfigDef.Type - Enum in org.oracle.okafka.common.config
The config types
ConfigDef.Validator - Interface in org.oracle.okafka.common.config
Validation logic the user may provide to perform single configuration validation.
ConfigDef.ValidList - Class in org.oracle.okafka.common.config
 
ConfigDef.ValidString - Class in org.oracle.okafka.common.config
 
ConfigDef.Width - Enum in org.oracle.okafka.common.config
The width of a configuration value
ConfigEntry - Class in org.oracle.okafka.clients.admin
A class representing a configuration entry containing name, value and additional metadata.
ConfigEntry(String, String) - Constructor for class org.oracle.okafka.clients.admin.ConfigEntry
Create a configuration entry with the provided values.
ConfigEntry(String, String, boolean, boolean, boolean) - Constructor for class org.oracle.okafka.clients.admin.ConfigEntry
Deprecated.
since 1.1.0. This constructor will be removed in a future release.
ConfigEntry.ConfigSource - Enum in org.oracle.okafka.clients.admin
Source of configuration entries.
ConfigEntry.ConfigSynonym - Class in org.oracle.okafka.clients.admin
Class representing a configuration synonym of a ConfigEntry.
ConfigException - Exception in org.oracle.okafka.common.config
Thrown if the user supplies an invalid configuration
ConfigException(String) - Constructor for exception org.oracle.okafka.common.config.ConfigException
 
ConfigException(String, Object) - Constructor for exception org.oracle.okafka.common.config.ConfigException
 
ConfigException(String, Object, String) - Constructor for exception org.oracle.okafka.common.config.ConfigException
 
ConfigKey(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender, boolean) - Constructor for class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
configKeys() - Method in class org.oracle.okafka.common.config.ConfigDef
Get the configuration keys
configNames() - Static method in class org.oracle.okafka.clients.admin.AdminClientConfig
 
configNames() - Static method in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
configNames() - Static method in class org.oracle.okafka.clients.producer.ProducerConfig
 
ConfigResource - Class in org.oracle.okafka.common.config
A class representing resources that have configs.
ConfigResource(ConfigResource.Type, String) - Constructor for class org.oracle.okafka.common.config.ConfigResource
Create an instance of this class with the provided parameters.
ConfigResource.Type - Enum in org.oracle.okafka.common.config
Type of resource.
configs(Map<String, String>) - Method in class org.oracle.okafka.clients.admin.NewTopic
Set the configuration to use on the new topic.
configs() - Method in class org.oracle.okafka.clients.admin.NewTopic
The configuration for the new topic or null if no configs ever specified.
Configurable - Interface in org.oracle.okafka.common
A Mix-in style interface for classes that are instantiated by reflection and need to take configuration parameters
configure(Map<String, ?>) - Method in interface org.oracle.okafka.common.Configurable
Configure this class with the given key-value pairs
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.ByteArrayDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.ByteArraySerializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.ByteBufferDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.ByteBufferSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.BytesDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.BytesSerializer
 
configure(Map<String, ?>, boolean) - Method in interface org.oracle.okafka.common.serialization.Deserializer
Configure this class.
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.DoubleDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.DoubleSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.ExtendedDeserializer.Wrapper
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.ExtendedSerializer.Wrapper
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.FloatDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.FloatSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.IntegerDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.IntegerSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.LongDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.LongSerializer
 
configure(Map<String, ?>, boolean) - Method in interface org.oracle.okafka.common.serialization.Serializer
Configure this class.
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.ShortDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.ShortSerializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.StringDeserializer
 
configure(Map<String, ?>, boolean) - Method in class org.oracle.okafka.common.serialization.StringSerializer
 
ConfigValue - Class in org.oracle.okafka.common.config
 
ConfigValue(String) - Constructor for class org.oracle.okafka.common.config.ConfigValue
 
ConfigValue(String, Object, List<Object>, List<String>) - Constructor for class org.oracle.okafka.common.config.ConfigValue
 
ConnectionException - Exception in org.oracle.okafka.common.errors
 
ConnectionException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.ConnectionException
 
ConnectionException(String) - Constructor for exception org.oracle.okafka.common.errors.ConnectionException
 
ConnectionException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.ConnectionException
 
ConnectionException() - Constructor for exception org.oracle.okafka.common.errors.ConnectionException
 
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
connections.max.idle.ms
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
connections.max.idle.ms
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
connections.max.idle.ms (This property is not yet supported)
Consumer<K,V> - Interface in org.oracle.okafka.clients.consumer
 
ConsumerConfig - Class in org.oracle.okafka.clients.consumer
The consumer configuration keys
ConsumerConfig(Properties) - Constructor for class org.oracle.okafka.clients.consumer.ConsumerConfig
 
ConsumerConfig(Map<String, Object>) - Constructor for class org.oracle.okafka.clients.consumer.ConsumerConfig
 
ConsumerInterceptor<K,V> - Interface in org.oracle.okafka.clients.consumer
A plugin interface that allows you to intercept (and possibly mutate) records received by the consumer.
ConsumerRebalanceListener - Interface in org.oracle.okafka.clients.consumer
This feature is not yet supported.
ConsumerRecord<K,V> - Class in org.oracle.okafka.clients.consumer
A key/value pair to be received from TEQ.
ConsumerRecord(String, int, long, K, V) - Constructor for class org.oracle.okafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition (
ConsumerRecord(String, int, long, long, TimestampType, long, int, int, K, V) - Constructor for class org.oracle.okafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition
ConsumerRecord(String, int, long, long, TimestampType, Long, int, int, K, V, Headers) - Constructor for class org.oracle.okafka.clients.consumer.ConsumerRecord
Creates a record to be received from a specified topic and partition
ConsumerRecords<K,V> - Class in org.oracle.okafka.clients.consumer
A container that holds the list ConsumerRecord per partition for a particular topic.
ConsumerRecords(Map<TopicPartition, List<ConsumerRecord<K, V>>>) - Constructor for class org.oracle.okafka.clients.consumer.ConsumerRecords
 
controller() - Method in class org.oracle.okafka.clients.admin.DescribeClusterResult
Returns a future which yields the current controller id.
controller() - Method in class org.oracle.okafka.common.Cluster
 
convertToString(Object, ConfigDef.Type) - Static method in class org.oracle.okafka.common.config.ConfigDef
 
convertToStringMapWithPasswordValues(Map<String, ?>) - Static method in class org.oracle.okafka.common.config.ConfigDef
Converts a map of config (key, value) pairs to a map of strings where each value is converted to a string.
CorruptRecordException - Exception in org.oracle.okafka.common.errors
This exception indicates a record has failed its internal CRC check, this generally indicates network or disk corruption.
CorruptRecordException() - Constructor for exception org.oracle.okafka.common.errors.CorruptRecordException
 
CorruptRecordException(String) - Constructor for exception org.oracle.okafka.common.errors.CorruptRecordException
 
CorruptRecordException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.CorruptRecordException
 
CorruptRecordException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.CorruptRecordException
 
count() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecords
The number of records for all topics
create(Properties) - Static method in class org.oracle.okafka.clients.admin.AdminClient
Create a new AdminClient with the given configuration.
create(Map<String, Object>) - Static method in class org.oracle.okafka.clients.admin.AdminClient
Create a new AdminClient with the given configuration.
createAcls(Collection<AclBinding>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
createAcls(Collection<AclBinding>, CreateAclsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
createAcls(Collection<AclBinding>, CreateAclsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
CreateAclsOptions - Class in org.oracle.okafka.clients.admin
CreateAclsOptions() - Constructor for class org.oracle.okafka.clients.admin.CreateAclsOptions
 
CreateAclsResult - Class in org.oracle.okafka.clients.admin
The result of the AdminClient.createAcls(Collection) call.
CreateAclsResult() - Constructor for class org.oracle.okafka.clients.admin.CreateAclsResult
 
createDelegationToken() - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
createDelegationToken(CreateDelegationTokenOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
createDelegationToken(CreateDelegationTokenOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
CreateDelegationTokenOptions - Class in org.oracle.okafka.clients.admin
CreateDelegationTokenOptions() - Constructor for class org.oracle.okafka.clients.admin.CreateDelegationTokenOptions
 
CreateDelegationTokenResult - Class in org.oracle.okafka.clients.admin
CreateDelegationTokenResult() - Constructor for class org.oracle.okafka.clients.admin.CreateDelegationTokenResult
 
createPartitions(Map<String, NewPartitions>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
createPartitions(Map<String, NewPartitions>, CreatePartitionsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
CreatePartitionsOptions - Class in org.oracle.okafka.clients.admin
CreatePartitionsOptions() - Constructor for class org.oracle.okafka.clients.admin.CreatePartitionsOptions
 
CreatePartitionsResult - Class in org.oracle.okafka.clients.admin
The result of the AdminClient.createPartitions(Map) call.
createTopics(Collection<NewTopic>) - Method in class org.oracle.okafka.clients.admin.AdminClient
Create a batch of new topics .This call doen't consider options for topic creation.
createTopics(Collection<NewTopic>, CreateTopicsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
Create a batch of new topics.
createTopics(Collection<NewTopic>, CreateTopicsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
CreateTopicsOptions - Class in org.oracle.okafka.clients.admin
This feature is not yet supported.
CreateTopicsOptions() - Constructor for class org.oracle.okafka.clients.admin.CreateTopicsOptions
 
CreateTopicsResult - Class in org.oracle.okafka.clients.admin

D

DEFAULT_API_TIMEOUT_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
default.api.timeout.ms
DEFAULT_API_TIMEOUT_MS_DOC - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
DEFAULT_EXCLUDE_INTERNAL_TOPICS - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
DEFAULT_FETCH_MAX_BYTES - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
DEFAULT_ISOLATION_LEVEL - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
DEFAULT_MAX_PARTITION_FETCH_BYTES - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
DEFAULT_SECURITY_PROTOCOL - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
defaultValue - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
defaultValues() - Method in class org.oracle.okafka.common.config.ConfigDef
 
define(ConfigDef.ConfigKey) - Method in class org.oracle.okafka.common.config.ConfigDef
 
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no dependents
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no special validation logic
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no special validation logic and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no special validation logic and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no special validation logic, not dependents and no custom recommender
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>, ConfigDef.Recommender) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no default value and no special validation logic
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, List<String>) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic and no custom recommender
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String, ConfigDef.Recommender) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic and no custom recommender
define(String, ConfigDef.Type, ConfigDef.Importance, String, String, int, ConfigDef.Width, String) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no default value, no special validation logic, no dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Validator, ConfigDef.Importance, String) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no group, no order in group, no width, no display name, no dependents and no custom recommender
define(String, ConfigDef.Type, Object, ConfigDef.Importance, String) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no special validation logic
define(String, ConfigDef.Type, ConfigDef.Importance, String) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new configuration with no default value and no special validation logic
defineInternal(String, ConfigDef.Type, Object, ConfigDef.Importance) - Method in class org.oracle.okafka.common.config.ConfigDef
Define a new internal configuration.
deleteAcls(Collection<AclBindingFilter>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
deleteAcls(Collection<AclBindingFilter>, DeleteAclsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
deleteAcls(Collection<AclBindingFilter>, DeleteAclsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DeleteAclsOptions - Class in org.oracle.okafka.clients.admin
DeleteAclsOptions() - Constructor for class org.oracle.okafka.clients.admin.DeleteAclsOptions
 
DeleteAclsResult - Class in org.oracle.okafka.clients.admin
The result of the AdminClient.deleteAcls(Collection) call.
DeleteAclsResult() - Constructor for class org.oracle.okafka.clients.admin.DeleteAclsResult
 
deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
deleteConsumerGroups(Collection<String>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
deleteConsumerGroups(Collection<String>, DeleteConsumerGroupsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DeleteConsumerGroupsOptions - Class in org.oracle.okafka.clients.admin
DeleteConsumerGroupsOptions() - Constructor for class org.oracle.okafka.clients.admin.DeleteConsumerGroupsOptions
 
DeleteConsumerGroupsResult - Class in org.oracle.okafka.clients.admin
deletedGroups() - Method in class org.oracle.okafka.clients.admin.DeleteConsumerGroupsResult
Return a map from group id to futures which can be used to check the status of individual deletions.
DeletedRecords - Class in org.oracle.okafka.clients.admin
Represents information about deleted records The API for this class is still evolving and we may break compatibility in minor releases, if necessary.
DeletedRecords(long) - Constructor for class org.oracle.okafka.clients.admin.DeletedRecords
Create an instance of this class with the provided parameters.
deleteRecords(Map<TopicPartition, RecordsToDelete>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
deleteRecords(Map<TopicPartition, RecordsToDelete>, DeleteRecordsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DeleteRecordsOptions - Class in org.oracle.okafka.clients.admin
DeleteRecordsOptions() - Constructor for class org.oracle.okafka.clients.admin.DeleteRecordsOptions
 
DeleteRecordsResult - Class in org.oracle.okafka.clients.admin
The result of the AdminClient.deleteRecords(Map) call.
DeleteRecordsResult(Map<TopicPartition, KafkaFuture<DeletedRecords>>) - Constructor for class org.oracle.okafka.clients.admin.DeleteRecordsResult
 
deleteTopics(Collection<String>) - Method in class org.oracle.okafka.clients.admin.AdminClient
Delete a batch of topics.
deleteTopics(Collection<String>, DeleteTopicsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
Delete a batch of topics.
deleteTopics(Collection<String>, DeleteTopicsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DeleteTopicsOptions - Class in org.oracle.okafka.clients.admin
This feature is not yet supported.
DeleteTopicsOptions() - Constructor for class org.oracle.okafka.clients.admin.DeleteTopicsOptions
 
DeleteTopicsResult - Class in org.oracle.okafka.clients.admin
The result of the AdminClient.deleteTopics(Collection) call.
dependents - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
describeAcls(AclBindingFilter) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeAcls(AclBindingFilter, DescribeAclsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeAcls(AclBindingFilter, DescribeAclsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DescribeAclsOptions - Class in org.oracle.okafka.clients.admin
DescribeAclsOptions() - Constructor for class org.oracle.okafka.clients.admin.DescribeAclsOptions
 
DescribeAclsResult - Class in org.oracle.okafka.clients.admin
DescribeAclsResult() - Constructor for class org.oracle.okafka.clients.admin.DescribeAclsResult
 
describeCluster() - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeCluster(DescribeClusterOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeCluster(DescribeClusterOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DescribeClusterOptions - Class in org.oracle.okafka.clients.admin
DescribeClusterOptions() - Constructor for class org.oracle.okafka.clients.admin.DescribeClusterOptions
 
DescribeClusterResult - Class in org.oracle.okafka.clients.admin
The result of the AdminClient.describeCluster() call.
describeConfigs(Collection<ConfigResource>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeConfigs(Collection<ConfigResource>, DescribeConfigsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeConfigs(Collection<ConfigResource>, DescribeConfigsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DescribeConfigsOptions - Class in org.oracle.okafka.clients.admin
DescribeConfigsOptions() - Constructor for class org.oracle.okafka.clients.admin.DescribeConfigsOptions
 
DescribeConfigsResult - Class in org.oracle.okafka.clients.admin
DescribeConfigsResult() - Constructor for class org.oracle.okafka.clients.admin.DescribeConfigsResult
 
describeConsumerGroups(Collection<String>, DescribeConsumerGroupsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
DThis method is not yet supported.
describeConsumerGroups(Collection<String>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeConsumerGroups(Collection<String>, DescribeConsumerGroupsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DescribeConsumerGroupsOptions - Class in org.oracle.okafka.clients.admin
DescribeConsumerGroupsOptions() - Constructor for class org.oracle.okafka.clients.admin.DescribeConsumerGroupsOptions
 
DescribeConsumerGroupsResult - Class in org.oracle.okafka.clients.admin
DescribeConsumerGroupsResult() - Constructor for class org.oracle.okafka.clients.admin.DescribeConsumerGroupsResult
 
describeDelegationToken() - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeDelegationToken(DescribeDelegationTokenOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeDelegationToken(DescribeDelegationTokenOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DescribeDelegationTokenOptions - Class in org.oracle.okafka.clients.admin
DescribeDelegationTokenOptions() - Constructor for class org.oracle.okafka.clients.admin.DescribeDelegationTokenOptions
 
DescribeDelegationTokenResult - Class in org.oracle.okafka.clients.admin
DescribeDelegationTokenResult() - Constructor for class org.oracle.okafka.clients.admin.DescribeDelegationTokenResult
 
describeLogDirs(Collection<Integer>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeLogDirs(Collection<Integer>, DescribeLogDirsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DescribeLogDirsOptions - Class in org.oracle.okafka.clients.admin
Options for AdminClient.describeLogDirs(Collection) The API of this class is evolving, see AdminClient for details.
DescribeLogDirsOptions() - Constructor for class org.oracle.okafka.clients.admin.DescribeLogDirsOptions
 
DescribeLogDirsResult - Class in org.oracle.okafka.clients.admin
DescribeLogDirsResult() - Constructor for class org.oracle.okafka.clients.admin.DescribeLogDirsResult
 
describeReplicaLogDirs(Collection<TopicPartitionReplica>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeReplicaLogDirs(Collection<TopicPartitionReplica>, DescribeReplicaLogDirsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeReplicaLogDirs(Collection<TopicPartitionReplica>, DescribeReplicaLogDirsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DescribeReplicaLogDirsOptions - Class in org.oracle.okafka.clients.admin
DescribeReplicaLogDirsOptions() - Constructor for class org.oracle.okafka.clients.admin.DescribeReplicaLogDirsOptions
 
DescribeReplicaLogDirsResult - Class in org.oracle.okafka.clients.admin
DescribeReplicaLogDirsResult() - Constructor for class org.oracle.okafka.clients.admin.DescribeReplicaLogDirsResult
 
describeTopics(Collection<String>) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeTopics(Collection<String>, DescribeTopicsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
describeTopics(Collection<String>, DescribeTopicsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
DescribeTopicsOptions - Class in org.oracle.okafka.clients.admin
DescribeTopicsOptions() - Constructor for class org.oracle.okafka.clients.admin.DescribeTopicsOptions
 
DescribeTopicsResult - Class in org.oracle.okafka.clients.admin
DescribeTopicsResult() - Constructor for class org.oracle.okafka.clients.admin.DescribeTopicsResult
 
description() - Method in class org.oracle.okafka.common.MetricName
 
description() - Method in class org.oracle.okafka.common.MetricNameTemplate
 
deserialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.ByteArrayDeserializer
 
deserialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.ByteBufferDeserializer
 
deserialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.BytesDeserializer
 
deserialize(String, byte[]) - Method in interface org.oracle.okafka.common.serialization.Deserializer
Deserialize a record value from a byte array into a value or object.
deserialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.DoubleDeserializer
 
deserialize(String, Headers, byte[]) - Method in interface org.oracle.okafka.common.serialization.ExtendedDeserializer
Deserialize a record value from a byte array into a value or object.
deserialize(String, Headers, byte[]) - Method in class org.oracle.okafka.common.serialization.ExtendedDeserializer.Wrapper
 
deserialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.ExtendedDeserializer.Wrapper
 
deserialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.FloatDeserializer
 
deserialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.IntegerDeserializer
 
deserialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.LongDeserializer
 
deserialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.ShortDeserializer
 
deserialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.StringDeserializer
 
Deserializer<T> - Interface in org.oracle.okafka.common.serialization
An interface for converting bytes to objects.
displayName - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
documentation - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
DoubleDeserializer - Class in org.oracle.okafka.common.serialization
 
DoubleDeserializer() - Constructor for class org.oracle.okafka.common.serialization.DoubleDeserializer
 
DoubleSerializer - Class in org.oracle.okafka.common.serialization
 
DoubleSerializer() - Constructor for class org.oracle.okafka.common.serialization.DoubleSerializer
 

E

embed(String, String, int, ConfigDef) - Method in class org.oracle.okafka.common.config.ConfigDef
 
EMPTY - Static variable in class org.oracle.okafka.clients.consumer.ConsumerRecords
 
empty() - Static method in class org.oracle.okafka.clients.consumer.ConsumerRecords
 
empty() - Static method in class org.oracle.okafka.common.Cluster
Create an empty cluster node with no Nodes and no topic-partitions.
ENABLE_AUTO_COMMIT_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
enable.auto.commit
ENABLE_IDEMPOTENCE_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
enable.idempotence (This property is not yet supported)
ENABLE_IDEMPOTENCE_DOC - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
 
endOffsets(Collection<TopicPartition>) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
endOffsets(Collection<TopicPartition>, Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
endOffsets(Collection<TopicPartition>) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
endOffsets(Collection<TopicPartition>, Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
ensureExtended(Deserializer<T>) - Static method in class org.oracle.okafka.common.serialization.ExtendedDeserializer.Wrapper
 
ensureExtended(Serializer<T>) - Static method in class org.oracle.okafka.common.serialization.ExtendedSerializer.Wrapper
 
ensureValid(String, Object) - Method in class org.oracle.okafka.common.config.ConfigDef.CompositeValidator
 
ensureValid(String, Object) - Method in class org.oracle.okafka.common.config.ConfigDef.NonEmptyString
 
ensureValid(String, Object) - Method in class org.oracle.okafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
 
ensureValid(String, Object) - Method in class org.oracle.okafka.common.config.ConfigDef.NonNullValidator
 
ensureValid(String, Object) - Method in class org.oracle.okafka.common.config.ConfigDef.Range
 
ensureValid(String, Object) - Method in interface org.oracle.okafka.common.config.ConfigDef.Validator
Perform single configuration validation.
ensureValid(String, Object) - Method in class org.oracle.okafka.common.config.ConfigDef.ValidList
 
ensureValid(String, Object) - Method in class org.oracle.okafka.common.config.ConfigDef.ValidString
 
entries() - Method in class org.oracle.okafka.clients.admin.Config
Configuration entries for a resource.
equals(Object) - Method in class org.oracle.okafka.clients.admin.Config
 
equals(Object) - Method in class org.oracle.okafka.clients.admin.ConfigEntry.ConfigSynonym
 
equals(Object) - Method in class org.oracle.okafka.clients.admin.ConfigEntry
 
equals(Object) - Method in class org.oracle.okafka.clients.admin.RecordsToDelete
 
equals(Object) - Method in class org.oracle.okafka.clients.consumer.OffsetAndMetadata
 
equals(Object) - Method in class org.oracle.okafka.clients.consumer.OffsetAndTimestamp
 
equals(Object) - Method in class org.oracle.okafka.clients.producer.ProducerRecord
 
equals(Object) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
equals(Object) - Method in class org.oracle.okafka.common.config.ConfigResource
 
equals(Object) - Method in class org.oracle.okafka.common.config.ConfigValue
 
equals(Object) - Method in class org.oracle.okafka.common.MetricName
 
equals(Object) - Method in class org.oracle.okafka.common.MetricNameTemplate
 
equals(Object) - Method in class org.oracle.okafka.common.Node
 
equals(Object) - Method in class org.oracle.okafka.common.TopicPartition
 
equals(Object) - Method in class org.oracle.okafka.common.TopicPartitionReplica
 
errorMessages() - Method in class org.oracle.okafka.common.config.ConfigValue
 
EXCLUDE_INTERNAL_TOPICS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
exclude.internal.topics
expireDelegationToken(byte[]) - Method in class org.oracle.okafka.clients.admin.AdminClient
<This method is not yet supported.
expireDelegationToken(byte[], ExpireDelegationTokenOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
expireDelegationToken(byte[], ExpireDelegationTokenOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
ExpireDelegationTokenOptions - Class in org.oracle.okafka.clients.admin
ExpireDelegationTokenOptions() - Constructor for class org.oracle.okafka.clients.admin.ExpireDelegationTokenOptions
 
ExpireDelegationTokenResult - Class in org.oracle.okafka.clients.admin
expiryTimePeriodMs(long) - Method in class org.oracle.okafka.clients.admin.ExpireDelegationTokenOptions
 
expiryTimePeriodMs() - Method in class org.oracle.okafka.clients.admin.ExpireDelegationTokenOptions
 
expiryTimestamp() - Method in class org.oracle.okafka.clients.admin.ExpireDelegationTokenResult
Returns a future which yields expiry timestamp
expiryTimestamp() - Method in class org.oracle.okafka.clients.admin.RenewDelegationTokenResult
Returns a future which yields expiry timestamp
ExtendedDeserializer<T> - Interface in org.oracle.okafka.common.serialization
A Deserializer that has access to the headers associated with the record.
ExtendedDeserializer.Wrapper<T> - Class in org.oracle.okafka.common.serialization
 
ExtendedSerializer<T> - Interface in org.oracle.okafka.common.serialization
A Serializer that has access to the headers associated with the record.
ExtendedSerializer.Wrapper<T> - Class in org.oracle.okafka.common.serialization
 

F

FeatureNotSupportedException - Exception in org.oracle.okafka.common.errors
If a method/api is not supported then this exception is thrown.
FeatureNotSupportedException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.FeatureNotSupportedException
 
FeatureNotSupportedException(String) - Constructor for exception org.oracle.okafka.common.errors.FeatureNotSupportedException
 
FeatureNotSupportedException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.FeatureNotSupportedException
 
FeatureNotSupportedException() - Constructor for exception org.oracle.okafka.common.errors.FeatureNotSupportedException
 
FETCH_MAX_BYTES_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
fetch.max.bytes
FETCH_MAX_WAIT_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
fetch.max.wait.ms
FETCH_MIN_BYTES_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
fetch.min.bytes
fillInStackTrace() - Method in exception org.oracle.okafka.common.errors.ApiException
 
fillInStackTrace() - Method in exception org.oracle.okafka.common.errors.SerializationException
 
FloatDeserializer - Class in org.oracle.okafka.common.serialization
 
FloatDeserializer() - Constructor for class org.oracle.okafka.common.serialization.FloatDeserializer
 
FloatSerializer - Class in org.oracle.okafka.common.serialization
 
FloatSerializer() - Constructor for class org.oracle.okafka.common.serialization.FloatSerializer
 
flush() - Method in class org.oracle.okafka.clients.producer.KafkaProducer
This api is not yet supported
flush() - Method in interface org.oracle.okafka.clients.producer.Producer
forId(byte) - Static method in enum org.oracle.okafka.common.config.ConfigResource.Type
 
Function() - Constructor for class org.oracle.okafka.common.KafkaFuture.Function
 

G

get(String) - Method in class org.oracle.okafka.clients.admin.Config
Get the configuration entry with the provided name or null if there isn't one.
get(String) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
get() - Method in class org.oracle.okafka.common.KafkaFuture
Waits if necessary for this future to complete, and then returns its result.
get(long, TimeUnit) - Method in class org.oracle.okafka.common.KafkaFuture
Waits if necessary for at most the given time for this future to complete, and then returns its result, if available.
getBoolean(String) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
getClass(String) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
getConfigs() - Method in class org.oracle.okafka.common.Cluster
 
getConfiguredInstance(String, Class<T>) - Method in class org.oracle.okafka.common.config.AbstractConfig
Get a configured instance of the give class specified by the given configuration key.
getConfiguredInstances(String, Class<T>) - Method in class org.oracle.okafka.common.config.AbstractConfig
Get a list of configured instances of the given class specified by the given configuration key.
getConfiguredInstances(String, Class<T>, Map<String, Object>) - Method in class org.oracle.okafka.common.config.AbstractConfig
Get a list of configured instances of the given class specified by the given configuration key.
getConfiguredInstances(List<String>, Class<T>, Map<String, Object>) - Method in class org.oracle.okafka.common.config.AbstractConfig
Get a list of configured instances of the given class specified by the given configuration key.
getConfigValue(ConfigDef.ConfigKey, String) - Method in class org.oracle.okafka.common.config.ConfigDef
 
getInt(String) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
getList(String) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
getLong(String) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
getNow(T) - Method in class org.oracle.okafka.common.KafkaFuture
Returns the result value (or throws any encountered exception) if completed, else returns the given valueIfAbsent.
getShort(String) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
getString(String) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
group - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
group() - Method in class org.oracle.okafka.common.MetricName
 
group() - Method in class org.oracle.okafka.common.MetricNameTemplate
 
GROUP_ID_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
group.id
groups() - Method in class org.oracle.okafka.common.config.ConfigDef
Get the groups for the configuration

H

hasDefault() - Method in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
hashCode() - Method in class org.oracle.okafka.clients.admin.Config
 
hashCode() - Method in class org.oracle.okafka.clients.admin.ConfigEntry.ConfigSynonym
 
hashCode() - Method in class org.oracle.okafka.clients.admin.ConfigEntry
 
hashCode() - Method in class org.oracle.okafka.clients.admin.RecordsToDelete
 
hashCode() - Method in class org.oracle.okafka.clients.consumer.OffsetAndMetadata
 
hashCode() - Method in class org.oracle.okafka.clients.consumer.OffsetAndTimestamp
 
hashCode() - Method in class org.oracle.okafka.clients.producer.ProducerRecord
 
hashCode() - Method in class org.oracle.okafka.common.config.AbstractConfig
 
hashCode() - Method in class org.oracle.okafka.common.config.ConfigResource
 
hashCode() - Method in class org.oracle.okafka.common.config.ConfigValue
 
hashCode() - Method in class org.oracle.okafka.common.MetricName
 
hashCode() - Method in class org.oracle.okafka.common.MetricNameTemplate
 
hashCode() - Method in class org.oracle.okafka.common.Node
 
hashCode() - Method in class org.oracle.okafka.common.TopicPartition
 
hashCode() - Method in class org.oracle.okafka.common.TopicPartitionReplica
 
hasOffset() - Method in class org.oracle.okafka.clients.producer.RecordMetadata
Indicates whether the record metadata includes the offset.
hasTimestamp() - Method in class org.oracle.okafka.clients.producer.RecordMetadata
Indicates whether the record metadata includes the timestamp.
headers() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
The headers
headers() - Method in class org.oracle.okafka.clients.producer.ProducerRecord
This method is not yet supported
headers() - Method in class org.oracle.okafka.common.config.ConfigDef
 
HEARTBEAT_INTERVAL_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
heartbeat.interval.ms
host() - Method in class org.oracle.okafka.common.Node
The host name for this Node

I

id() - Method in enum org.oracle.okafka.common.config.ConfigResource.Type
 
id() - Method in class org.oracle.okafka.common.Node
The Node id of this Node
idString() - Method in class org.oracle.okafka.common.Node
 
ignore(String) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
importance - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
in(String...) - Static method in class org.oracle.okafka.common.config.ConfigDef.ValidList
 
in(String...) - Static method in class org.oracle.okafka.common.config.ConfigDef.ValidString
 
includeSynonyms() - Method in class org.oracle.okafka.clients.admin.DescribeConfigsOptions
Return true if synonym configs should be returned in the response.
includeSynonyms(boolean) - Method in class org.oracle.okafka.clients.admin.DescribeConfigsOptions
Set to true if synonym configs should be returned in the response.
increaseTo(int) - Static method in class org.oracle.okafka.clients.admin.NewPartitions
Increase the partition count for a topic to the given totalCount.
increaseTo(int, List<List<Integer>>) - Static method in class org.oracle.okafka.clients.admin.NewPartitions
Increase the partition count for a topic to the given totalCount assigning the new partitions according to the given newAssignments.
initTransactions() - Method in class org.oracle.okafka.clients.producer.KafkaProducer
This api is not yet supported
initTransactions() - Method in interface org.oracle.okafka.clients.producer.Producer
instanceName() - Method in class org.oracle.okafka.common.Node
Name of this instance
inSyncReplicas() - Method in class org.oracle.okafka.common.PartitionInfo
All oracle db instances run on same disk, so there is no need of replicating data among instances.
IntegerDeserializer - Class in org.oracle.okafka.common.serialization
 
IntegerDeserializer() - Constructor for class org.oracle.okafka.common.serialization.IntegerDeserializer
 
IntegerSerializer - Class in org.oracle.okafka.common.serialization
 
IntegerSerializer() - Constructor for class org.oracle.okafka.common.serialization.IntegerSerializer
 
INTERCEPTOR_CLASSES_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
interceptor.classes
INTERCEPTOR_CLASSES_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
interceptor.classes
INTERCEPTOR_CLASSES_DOC - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
INTERCEPTOR_CLASSES_DOC - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
 
InterfaceStability - Class in org.oracle.okafka.common.annotation
Annotation to inform users of how much to rely on a particular package, class or method not changing over time.
InterfaceStability() - Constructor for class org.oracle.okafka.common.annotation.InterfaceStability
 
InterfaceStability.Evolving - Annotation Type in org.oracle.okafka.common.annotation
Compatibility may be broken at minor release (i.e.
InterfaceStability.Stable - Annotation Type in org.oracle.okafka.common.annotation
Compatibility is maintained in major, minor and patch releases with one exception: compatibility may be broken in a major release (i.e.
InterfaceStability.Unstable - Annotation Type in org.oracle.okafka.common.annotation
No guarantee is provided as to reliability or stability across any level of release granularity.
internalConfig - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
internalTopics() - Method in class org.oracle.okafka.common.Cluster
 
InterruptException - Exception in org.oracle.okafka.common.errors
An unchecked wrapper for InterruptedException
InterruptException(InterruptedException) - Constructor for exception org.oracle.okafka.common.errors.InterruptException
 
InterruptException(String, InterruptedException) - Constructor for exception org.oracle.okafka.common.errors.InterruptException
 
InterruptException(String) - Constructor for exception org.oracle.okafka.common.errors.InterruptException
 
INVALID_OFFSET - Static variable in class org.oracle.okafka.clients.consumer.OffsetAndMetadata
 
InvalidConfigurationException - Exception in org.oracle.okafka.common.errors
 
InvalidConfigurationException(String) - Constructor for exception org.oracle.okafka.common.errors.InvalidConfigurationException
 
InvalidConfigurationException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.InvalidConfigurationException
 
InvalidLoginCredentialsException - Exception in org.oracle.okafka.common.errors
This exception indicates that user provided invalid login details.
InvalidLoginCredentialsException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.InvalidLoginCredentialsException
 
InvalidLoginCredentialsException(String) - Constructor for exception org.oracle.okafka.common.errors.InvalidLoginCredentialsException
 
InvalidLoginCredentialsException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.InvalidLoginCredentialsException
 
InvalidLoginCredentialsException() - Constructor for exception org.oracle.okafka.common.errors.InvalidLoginCredentialsException
 
InvalidMessageIdException - Exception in org.oracle.okafka.common.errors
This exception indicates that client has received invalid message id from server.
InvalidMessageIdException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.InvalidMessageIdException
 
InvalidMessageIdException(String) - Constructor for exception org.oracle.okafka.common.errors.InvalidMessageIdException
 
InvalidMessageIdException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.InvalidMessageIdException
 
InvalidMessageIdException() - Constructor for exception org.oracle.okafka.common.errors.InvalidMessageIdException
 
InvalidMetadataException - Exception in org.oracle.okafka.common.errors
An exception that may indicate the client's metadata is out of date
InvalidMetadataException() - Constructor for exception org.oracle.okafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(String) - Constructor for exception org.oracle.okafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.InvalidMetadataException
 
InvalidMetadataException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.InvalidMetadataException
 
InvalidTopicException - Exception in org.oracle.okafka.common.errors
The client has attempted to perform an operation on an invalid topic.
InvalidTopicException() - Constructor for exception org.oracle.okafka.common.errors.InvalidTopicException
 
InvalidTopicException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.InvalidTopicException
 
InvalidTopicException(String) - Constructor for exception org.oracle.okafka.common.errors.InvalidTopicException
 
InvalidTopicException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.InvalidTopicException
 
isBootstrapConfigured() - Method in class org.oracle.okafka.common.Cluster
 
isCancelled() - Method in class org.oracle.okafka.common.KafkaFuture
Returns true if this CompletableFuture was cancelled before it completed normally.
isCompletedExceptionally() - Method in class org.oracle.okafka.common.KafkaFuture
Returns true if this CompletableFuture completed exceptionally, in any way.
isDefault() - Method in class org.oracle.okafka.clients.admin.ConfigEntry
Return whether the config value is the default or if it's been explicitly set.
isDefault() - Method in class org.oracle.okafka.common.config.ConfigResource
Returns true if this is the default resource of a resource type.
isDone() - Method in class org.oracle.okafka.common.KafkaFuture
Returns true if completed in any fashion: normally, exceptionally, or via cancellation.
isEmpty() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecords
 
isEmpty() - Method in class org.oracle.okafka.common.Node
 
ISOLATION_LEVEL_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
isolation.level
ISOLATION_LEVEL_DOC - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
isReadOnly() - Method in class org.oracle.okafka.clients.admin.ConfigEntry
Return whether the config is read-only and cannot be updated.
isSensitive() - Method in class org.oracle.okafka.clients.admin.ConfigEntry
Return whether the config value is sensitive.
iterator() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecords
 

K

KafkaAdminClient - Class in org.oracle.okafka.clients.admin
The default implementation of AdminClient.
KafkaConsumer<K,V> - Class in org.oracle.okafka.clients.consumer
Note: Topic name has to be in uppercase wherever used.
KafkaConsumer(Map<String, Object>) - Constructor for class org.oracle.okafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a set of key-value pairs as configuration.
KafkaConsumer(Map<String, Object>, Deserializer<K>, Deserializer<V>) - Constructor for class org.oracle.okafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a set of key-value pairs as configuration, and a key and a value Deserializer.
KafkaConsumer(Properties) - Constructor for class org.oracle.okafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a Properties object as configuration.
KafkaConsumer(Properties, Deserializer<K>, Deserializer<V>) - Constructor for class org.oracle.okafka.clients.consumer.KafkaConsumer
A consumer is instantiated by providing a Properties object as configuration, and a key and a value Deserializer.
KafkaException - Exception in org.oracle.okafka.common
The base class of all other Kafka exceptions
KafkaException(String, Throwable) - Constructor for exception org.oracle.okafka.common.KafkaException
 
KafkaException(String) - Constructor for exception org.oracle.okafka.common.KafkaException
 
KafkaException(Throwable) - Constructor for exception org.oracle.okafka.common.KafkaException
 
KafkaException() - Constructor for exception org.oracle.okafka.common.KafkaException
 
KafkaFuture<T> - Class in org.oracle.okafka.common
A flexible future which supports call chaining and other asynchronous programming patterns.
KafkaFuture() - Constructor for class org.oracle.okafka.common.KafkaFuture
 
KafkaFuture.BaseFunction<A,B> - Interface in org.oracle.okafka.common
A function which takes objects of type A and returns objects of type B.
KafkaFuture.BiConsumer<A,B> - Interface in org.oracle.okafka.common
A consumer of two different types of object.
KafkaFuture.Function<A,B> - Class in org.oracle.okafka.common
A function which takes objects of type A and returns objects of type B.
KafkaProducer<K,V> - Class in org.oracle.okafka.clients.producer
Note: Topic name has to be in uppercase wherever used.
KafkaProducer(Map<String, Object>) - Constructor for class org.oracle.okafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration.
KafkaProducer(Map<String, Object>, Serializer<K>, Serializer<V>) - Constructor for class org.oracle.okafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration, a key and a value Serializer.
KafkaProducer(Properties) - Constructor for class org.oracle.okafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration.
KafkaProducer(Properties, Serializer<K>, Serializer<V>) - Constructor for class org.oracle.okafka.clients.producer.KafkaProducer
A producer is instantiated by providing a set of key-value pairs as configuration, a key and a value Serializer.
key() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
The key (or null if no key is specified)
key() - Method in class org.oracle.okafka.clients.producer.ProducerRecord
 
KEY_DESERIALIZER_CLASS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
key.deserializer
KEY_DESERIALIZER_CLASS_DOC - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
KEY_SERIALIZER_CLASS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
key.serializer
KEY_SERIALIZER_CLASS_DOC - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
 

L

leader() - Method in class org.oracle.okafka.common.Cluster
 
leader() - Method in class org.oracle.okafka.common.PartitionInfo
The Node currently acting as a leader for this partition or null if there is no leader
leaderFor(TopicPartition) - Method in class org.oracle.okafka.common.Cluster
Get the current leader for the given topic-partition
LINGER_MS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
linger.ms
listConsumerGroupOffsets(String, ListConsumerGroupOffsetsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
listConsumerGroupOffsets(String) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
listConsumerGroupOffsets(String, ListConsumerGroupOffsetsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
ListConsumerGroupOffsetsOptions - Class in org.oracle.okafka.clients.admin
ListConsumerGroupOffsetsOptions() - Constructor for class org.oracle.okafka.clients.admin.ListConsumerGroupOffsetsOptions
 
ListConsumerGroupOffsetsResult - Class in org.oracle.okafka.clients.admin
listConsumerGroups(ListConsumerGroupsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
listConsumerGroups() - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
listConsumerGroups(ListConsumerGroupsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
ListConsumerGroupsOptions - Class in org.oracle.okafka.clients.admin
ListConsumerGroupsOptions() - Constructor for class org.oracle.okafka.clients.admin.ListConsumerGroupsOptions
 
ListConsumerGroupsResult - Class in org.oracle.okafka.clients.admin
The result of the AdminClient.listConsumerGroups() call.
ListConsumerGroupsResult() - Constructor for class org.oracle.okafka.clients.admin.ListConsumerGroupsResult
 
listInternal(boolean) - Method in class org.oracle.okafka.clients.admin.ListTopicsOptions
Set whether we should list internal topics.
listTopics() - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
listTopics(ListTopicsOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
listTopics(ListTopicsOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
listTopics() - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
listTopics(Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
listTopics() - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
listTopics(Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
ListTopicsOptions - Class in org.oracle.okafka.clients.admin
ListTopicsOptions() - Constructor for class org.oracle.okafka.clients.admin.ListTopicsOptions
 
ListTopicsResult - Class in org.oracle.okafka.clients.admin
The result of the AdminClient.listTopics() call.
ListTopicsResult() - Constructor for class org.oracle.okafka.clients.admin.ListTopicsResult
 
logUnused() - Method in class org.oracle.okafka.common.config.AbstractConfig
Log warnings for any unused configurations
LongDeserializer - Class in org.oracle.okafka.common.serialization
 
LongDeserializer() - Constructor for class org.oracle.okafka.common.serialization.LongDeserializer
 
LongSerializer - Class in org.oracle.okafka.common.serialization
 
LongSerializer() - Constructor for class org.oracle.okafka.common.serialization.LongSerializer
 
lowWatermark() - Method in class org.oracle.okafka.clients.admin.DeletedRecords
Return the "low watermark" for the topic partition on which the deletion was executed
lowWatermarks() - Method in class org.oracle.okafka.clients.admin.DeleteRecordsResult
Return a map from topic partition to futures which can be used to check the status of individual deletions.

M

main(String[]) - Static method in class org.oracle.okafka.clients.admin.AdminClientConfig
 
main(String[]) - Static method in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
main(String[]) - Static method in class org.oracle.okafka.clients.producer.ProducerConfig
 
MAX_BLOCK_MS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
max.block.ms
MAX_IN_FLIGHT_REQUESTS_PER_CONNECTION - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
max.in.flight.requests.per.connection (This property is not yet supported)
MAX_PARTITION_FETCH_BYTES_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
max.partition.fetch.bytes
MAX_POLL_INTERVAL_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
max.poll.interval.ms
MAX_POLL_RECORDS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
max.poll.records
MAX_REQUEST_SIZE_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
max.request.size
metadata() - Method in class org.oracle.okafka.clients.consumer.OffsetAndMetadata
 
METADATA_MAX_AGE_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
METADATA_MAX_AGE_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
metadata.max.age.ms
METADATA_MAX_AGE_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
metadata.max.age.ms
Metric - Interface in org.oracle.okafka.common
A metric tracked for monitoring purposes.
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
metric.reporters
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
metric.reporters (This property is not yet supported)
metricName() - Method in interface org.oracle.okafka.common.Metric
A name for this metric
MetricName - Class in org.oracle.okafka.common
Metrics feature is not yet supported.
MetricName(String, String, String, Map<String, String>) - Constructor for class org.oracle.okafka.common.MetricName
 
MetricNameTemplate - Class in org.oracle.okafka.common
Metrics Feature is not yet supported.
MetricNameTemplate(String, String, String, Set<String>) - Constructor for class org.oracle.okafka.common.MetricNameTemplate
 
MetricNameTemplate(String, String, String, String...) - Constructor for class org.oracle.okafka.common.MetricNameTemplate
 
metrics() - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
metrics() - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
metrics() - Method in class org.oracle.okafka.clients.producer.KafkaProducer
This api is not yet supported
metrics() - Method in interface org.oracle.okafka.clients.producer.Producer
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
metrics.num.samples
METRICS_NUM_SAMPLES_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
metrics.num.samples (This property is not yet supported)
METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
metrics.log.level
METRICS_RECORDING_LEVEL_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
metrics.log.level (This property is not yet supported)
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
metrics.sample.window.ms
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
metrics.sample.window.ms (This property is not yet supported)
metricValue() - Method in interface org.oracle.okafka.common.Metric
The value of the metric, which may be measurable or a non-measurable gauge

N

name() - Method in class org.oracle.okafka.clients.admin.ConfigEntry.ConfigSynonym
Returns the name of this configuration.
name() - Method in class org.oracle.okafka.clients.admin.ConfigEntry
Return the config name.
name() - Method in class org.oracle.okafka.clients.admin.NewTopic
The name of the topic to be created.
name - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
name() - Method in class org.oracle.okafka.common.config.ConfigResource
Return the resource name.
name() - Method in class org.oracle.okafka.common.config.ConfigValue
 
name() - Method in class org.oracle.okafka.common.MetricName
 
name() - Method in class org.oracle.okafka.common.MetricNameTemplate
 
names() - Method in class org.oracle.okafka.common.config.ConfigDef
Returns unmodifiable set of properties names defined in this ConfigDef
NETWORK_THREAD_PREFIX - Static variable in class org.oracle.okafka.clients.producer.KafkaProducer
 
NewPartitions - Class in org.oracle.okafka.clients.admin
Describes new partitions for a particular topic in a call to AdminClient.createPartitions(Map).
NewTopic - Class in org.oracle.okafka.clients.admin
A new topic to be created via AdminClient.createTopics(Collection).
NewTopic(String, int, short) - Constructor for class org.oracle.okafka.clients.admin.NewTopic
A new topic with the specified replication factor and number of partitions.
NewTopic(String, Map<Integer, List<Integer>>) - Constructor for class org.oracle.okafka.clients.admin.NewTopic
A new topic with the specified replica assignment configuration.
NO_DEFAULT_VALUE - Static variable in class org.oracle.okafka.common.config.ConfigDef
A unique Java object which represents the lack of a default value.
NO_METADATA - Static variable in class org.oracle.okafka.clients.consumer.OffsetAndMetadata
 
NO_TIMESTAMP - Static variable in class org.oracle.okafka.clients.consumer.ConsumerRecord
 
Node - Class in org.oracle.okafka.common
 
Node(String, int, String) - Constructor for class org.oracle.okafka.common.Node
 
Node(int, String, int, String) - Constructor for class org.oracle.okafka.common.Node
 
Node(int, String, int, String, String) - Constructor for class org.oracle.okafka.common.Node
 
nodeById(int) - Method in class org.oracle.okafka.common.Cluster
Get the node by the node id (or null if no such node exists)
nodes() - Method in class org.oracle.okafka.clients.admin.DescribeClusterResult
Returns a future which yields a collection of nodes.
nodes() - Method in class org.oracle.okafka.common.Cluster
 
NonEmptyString() - Constructor for class org.oracle.okafka.common.config.ConfigDef.NonEmptyString
 
NonEmptyStringWithoutControlChars() - Constructor for class org.oracle.okafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
 
nonEmptyStringWithoutControlChars() - Static method in class org.oracle.okafka.common.config.ConfigDef.NonEmptyStringWithoutControlChars
 
NonNullValidator() - Constructor for class org.oracle.okafka.common.config.ConfigDef.NonNullValidator
 
noNode() - Static method in class org.oracle.okafka.common.Node
 
NotLeaderForPartitionException - Exception in org.oracle.okafka.common.errors
This server is not the leader for the given partition
NotLeaderForPartitionException() - Constructor for exception org.oracle.okafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(String) - Constructor for exception org.oracle.okafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.NotLeaderForPartitionException
 
NotLeaderForPartitionException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.NotLeaderForPartitionException
 
NULL_CHECKSUM - Static variable in class org.oracle.okafka.clients.consumer.ConsumerRecord
 
NULL_SIZE - Static variable in class org.oracle.okafka.clients.consumer.ConsumerRecord
 
numPartitions() - Method in class org.oracle.okafka.clients.admin.NewTopic
The number of partitions for the new topic or -1 if a replica assignment has been specified.

O

of(ConfigDef.Validator...) - Static method in class org.oracle.okafka.common.config.ConfigDef.CompositeValidator
 
offlineReplicas() - Method in class org.oracle.okafka.common.PartitionInfo
All oracle db instances run on same disk, so there is no need of replicating data among instances.
offset() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
The position of this record in the corresponding TEQ partition.
offset() - Method in class org.oracle.okafka.clients.consumer.OffsetAndMetadata
 
offset() - Method in class org.oracle.okafka.clients.consumer.OffsetAndTimestamp
 
offset() - Method in class org.oracle.okafka.clients.producer.RecordMetadata
The offset of the record in the topic/partition.
OffsetAndMetadata - Class in org.oracle.okafka.clients.consumer
This feature is not yet supported.
OffsetAndMetadata(long, String) - Constructor for class org.oracle.okafka.clients.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through KafkaConsumer.
OffsetAndMetadata(long) - Constructor for class org.oracle.okafka.clients.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through KafkaConsumer.
OffsetAndTimestamp - Class in org.oracle.okafka.clients.consumer
A container class for offset and timestamp.
OffsetAndTimestamp(long, long) - Constructor for class org.oracle.okafka.clients.consumer.OffsetAndTimestamp
 
OffsetCommitCallback - Interface in org.oracle.okafka.clients.consumer
A callback interface that the user can implement to trigger custom actions when a commit request completes.
OffsetResetStrategy - Enum in org.oracle.okafka.clients.consumer
This feature is not yet supported
offsetsForTimes(Map<TopicPartition, Long>) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
offsetsForTimes(Map<TopicPartition, Long>) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
offsetsForTimes(Map<TopicPartition, Long>, Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
onAcknowledgement(RecordMetadata, Exception) - Method in interface org.oracle.okafka.clients.producer.ProducerInterceptor
This method is called when the record sent to the server has been acknowledged, or when sending the record fails before it gets sent to the server.
onCommit(Map<TopicPartition, OffsetAndMetadata>) - Method in interface org.oracle.okafka.clients.consumer.ConsumerInterceptor
This is called when offsets get committed.
onComplete(Map<TopicPartition, OffsetAndMetadata>, Exception) - Method in interface org.oracle.okafka.clients.consumer.OffsetCommitCallback
A callback method the user can implement to provide asynchronous handling of commit request completion.
onCompletion(RecordMetadata, Exception) - Method in interface org.oracle.okafka.clients.producer.Callback
A callback method the user can implement to provide synchronous handling of request completion.
onConsume(ConsumerRecords<K, V>) - Method in interface org.oracle.okafka.clients.consumer.ConsumerInterceptor
This is called just before the records are returned by KafkaConsumer.poll(java.time.Duration)
onPartitionsAssigned(Collection<TopicPartition>) - Method in interface org.oracle.okafka.clients.consumer.ConsumerRebalanceListener
This method is not yet supported.
onPartitionsRevoked(Collection<TopicPartition>) - Method in interface org.oracle.okafka.clients.consumer.ConsumerRebalanceListener
This method is not yet supported.
onSend(ProducerRecord<K, V>) - Method in interface org.oracle.okafka.clients.producer.ProducerInterceptor
This is called from KafkaProducer.send(ProducerRecord) and KafkaProducer.send(ProducerRecord, Callback) methods, before key and value get serialized and partition is assigned (if partition is not specified in ProducerRecord).
onUpdate(ClusterResource) - Method in interface org.oracle.okafka.common.ClusterResourceListener
A callback method that a user can implement to get updates for ClusterResource.
ORACLE_INSTANCE_NAME - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
ORACLE_INSTANCE_NAME - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
ORACLE_INSTANCE_NAME - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
oracle.instance.name
ORACLE_NET_TNS_ADMIN - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
oracle.net.tns_admin
ORACLE_NET_TNS_ADMIN - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
oracle.net.tns_admin
ORACLE_NET_TNS_ADMIN - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
oracle.net.tns_admin
ORACLE_SERVICE_NAME - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
ORACLE_SERVICE_NAME - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
ORACLE_SERVICE_NAME - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
oracle.service.name
orderInGroup - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
org.oracle.okafka.clients.admin - package org.oracle.okafka.clients.admin
This package contains APIs for creating and managing Oracle Transactional Event Queues.
org.oracle.okafka.clients.consumer - package org.oracle.okafka.clients.consumer
This package contains APIs for consuming streams of data from Oracle Transactional Event Queues.
org.oracle.okafka.clients.producer - package org.oracle.okafka.clients.producer
This package contains APIs for sending streams of data to Oracle Transactional Event Queues.
org.oracle.okafka.common - package org.oracle.okafka.common
This package contains Classes, Interfaces common for Producer, Consumer and Admin.
org.oracle.okafka.common.annotation - package org.oracle.okafka.common.annotation
 
org.oracle.okafka.common.config - package org.oracle.okafka.common.config
 
org.oracle.okafka.common.errors - package org.oracle.okafka.common.errors
This package defines all the exceptions thrown by Producer, Consumer and Admin.
org.oracle.okafka.common.serialization - package org.oracle.okafka.common.serialization
This package contains APIs for serializing and deserializing data.
originals() - Method in class org.oracle.okafka.common.config.AbstractConfig
 

P

parse(Map<?, ?>) - Method in class org.oracle.okafka.common.config.ConfigDef
Parse and validate configs against this configuration definition.
parseType(String, Object, ConfigDef.Type) - Static method in class org.oracle.okafka.common.config.ConfigDef
Parse a value according to its expected type.
partition() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
The partition from which this record is received
partition(String, Object, byte[], Object, byte[], Cluster) - Method in interface org.oracle.okafka.clients.producer.Partitioner
Compute the partition for the given record.
partition() - Method in class org.oracle.okafka.clients.producer.ProducerRecord
 
partition() - Method in class org.oracle.okafka.clients.producer.RecordMetadata
The partition the record was sent to
partition(TopicPartition) - Method in class org.oracle.okafka.common.Cluster
Get the metadata for the specified partition
partition() - Method in class org.oracle.okafka.common.PartitionInfo
The partition id
partition() - Method in class org.oracle.okafka.common.TopicPartition
 
partition() - Method in class org.oracle.okafka.common.TopicPartitionReplica
 
PARTITION_ASSIGNMENT_STRATEGY_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
partition.assignment.strategy
partitionCountForTopic(String) - Method in class org.oracle.okafka.common.Cluster
Get the number of partitions for the given topic
Partitioner - Interface in org.oracle.okafka.clients.producer
Partitioner Interface
PARTITIONER_CLASS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
partitioner.class
PartitionInfo - Class in org.oracle.okafka.common
This is used to describe per-partition state in the MetadataResponse.
PartitionInfo(String, int, Node, Node[], Node[]) - Constructor for class org.oracle.okafka.common.PartitionInfo
 
PartitionInfo(String, int, Node, Node[], Node[], Node[]) - Constructor for class org.oracle.okafka.common.PartitionInfo
 
partitions() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecords
Get the partitions which have records contained in this record set.
partitionsFor(String) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
partitionsFor(String, Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
partitionsFor(String) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
partitionsFor(String, Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
partitionsFor(String) - Method in class org.oracle.okafka.clients.producer.KafkaProducer
Get the partition metadata for the given topic.
partitionsFor(String) - Method in interface org.oracle.okafka.clients.producer.Producer
partitionsForNode(Node) - Method in class org.oracle.okafka.common.Cluster
Get the list of partitions whose leader is this Node
partitionsForTopic(String) - Method in class org.oracle.okafka.common.Cluster
Get the list of partitions for this topic
partitionsToOffsetAndMetadata() - Method in class org.oracle.okafka.clients.admin.ListConsumerGroupOffsetsResult
Return a future which yields a map of topic partitions to OffsetAndMetadata objects.
pause(Collection<TopicPartition>) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
pause(Collection<TopicPartition>) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
paused() - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
paused() - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
poll(long) - Method in interface org.oracle.okafka.clients.consumer.Consumer
Deprecated.
poll(Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
poll(long) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Deprecated.
poll(Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Fetch data for the topic specified using KafkaConsumer.subscribe(Collection) APIs.
port() - Method in class org.oracle.okafka.common.Node
The port for this Node
position(TopicPartition) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
position(TopicPartition, Duration) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
position(TopicPartition) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
position(TopicPartition, Duration) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
postProcessParsedConfig(Map<String, Object>) - Method in class org.oracle.okafka.clients.admin.AdminClientConfig
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
postProcessParsedConfig(Map<String, Object>) - Method in class org.oracle.okafka.common.config.AbstractConfig
 
Producer<K,V> - Interface in org.oracle.okafka.clients.producer
The interface for the KafkaProducer
ProducerConfig - Class in org.oracle.okafka.clients.producer
 
ProducerConfig(Properties) - Constructor for class org.oracle.okafka.clients.producer.ProducerConfig
 
ProducerConfig(Map<String, Object>) - Constructor for class org.oracle.okafka.clients.producer.ProducerConfig
 
ProducerFencedException - Exception in org.oracle.okafka.common.errors
This fatal exception indicates that another producer with the same transactional.id has been started.
ProducerFencedException(String) - Constructor for exception org.oracle.okafka.common.errors.ProducerFencedException
 
ProducerInterceptor<K,V> - Interface in org.oracle.okafka.clients.producer
A plugin interface that allows you to intercept (and possibly mutate) the records received by the producer before they are published to the Transactional Event Queues.
ProducerRecord<K,V> - Class in org.oracle.okafka.clients.producer
A key/value pair to be sent to TEQ.
ProducerRecord(String, Integer, Long, K, V, Iterable<Header>) - Constructor for class org.oracle.okafka.clients.producer.ProducerRecord
Creates a record with a specified timestamp to be sent to a specified topic and partition
ProducerRecord(String, Integer, Long, K, V) - Constructor for class org.oracle.okafka.clients.producer.ProducerRecord
Creates a record with a specified timestamp to be sent to a specified topic and partition
ProducerRecord(String, Integer, K, V, Iterable<Header>) - Constructor for class org.oracle.okafka.clients.producer.ProducerRecord
Creates a record to be sent to a specified topic and partition
ProducerRecord(String, Integer, K, V) - Constructor for class org.oracle.okafka.clients.producer.ProducerRecord
Creates a record to be sent to a specified topic and partition
ProducerRecord(String, K, V) - Constructor for class org.oracle.okafka.clients.producer.ProducerRecord
Create a record to be sent to Kafka
ProducerRecord(String, V) - Constructor for class org.oracle.okafka.clients.producer.ProducerRecord
Create a record with no key

R

RECEIVE_BUFFER_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
RECEIVE_BUFFER_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
receive.buffer.bytes
RECEIVE_BUFFER_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
receive.buffer.bytes (This property is not yet supported)
recommendedValues() - Method in class org.oracle.okafka.common.config.ConfigValue
 
recommendedValues(List<Object>) - Method in class org.oracle.okafka.common.config.ConfigValue
 
recommender - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
reconnect.backoff.max.ms
RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
reconnect.backoff.max.ms
RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
reconnect.backoff.max.ms
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
reconnect.backoff.ms
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
reconnect.backoff.ms
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
reconnect.backoff.ms
RecordBatchTooLargeException - Exception in org.oracle.okafka.common.errors
This record batch is larger than the maximum allowable size
RecordBatchTooLargeException() - Constructor for exception org.oracle.okafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(String) - Constructor for exception org.oracle.okafka.common.errors.RecordBatchTooLargeException
 
RecordBatchTooLargeException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.RecordBatchTooLargeException
 
RecordMetadata - Class in org.oracle.okafka.clients.producer
The metadata for a record that has been acknowledged by the server
RecordMetadata(TopicPartition, long, long, long, Long, int, int) - Constructor for class org.oracle.okafka.clients.producer.RecordMetadata
 
records(TopicPartition) - Method in class org.oracle.okafka.clients.consumer.ConsumerRecords
Get just the records for the given partition
records(String) - Method in class org.oracle.okafka.clients.consumer.ConsumerRecords
Get just the records for the given topic
RecordsToDelete - Class in org.oracle.okafka.clients.admin
Describe records to delete in a call to AdminClient.deleteRecords(Map) The API of this class is evolving, see AdminClient for details.
RecordTooLargeException - Exception in org.oracle.okafka.common.errors
This record is larger than the maximum allowable size
RecordTooLargeException() - Constructor for exception org.oracle.okafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String) - Constructor for exception org.oracle.okafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.RecordTooLargeException
 
RecordTooLargeException(String, Map<TopicPartition, Long>) - Constructor for exception org.oracle.okafka.common.errors.RecordTooLargeException
 
recordTooLargePartitions() - Method in exception org.oracle.okafka.common.errors.RecordTooLargeException
 
renewDelegationToken(byte[]) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
renewDelegationToken(byte[], RenewDelegationTokenOptions) - Method in class org.oracle.okafka.clients.admin.AdminClient
This method is not yet supported.
renewDelegationToken(byte[], RenewDelegationTokenOptions) - Method in class org.oracle.okafka.clients.admin.KafkaAdminClient
 
RenewDelegationTokenOptions - Class in org.oracle.okafka.clients.admin
RenewDelegationTokenOptions() - Constructor for class org.oracle.okafka.clients.admin.RenewDelegationTokenOptions
 
RenewDelegationTokenResult - Class in org.oracle.okafka.clients.admin
renewTimePeriodMs(long) - Method in class org.oracle.okafka.clients.admin.RenewDelegationTokenOptions
 
renewTimePeriodMs() - Method in class org.oracle.okafka.clients.admin.RenewDelegationTokenOptions
 
replicas() - Method in class org.oracle.okafka.common.PartitionInfo
All oracle db instances run on same disk, so there is no need of replicating data among instances.
replicasAssignments() - Method in class org.oracle.okafka.clients.admin.NewTopic
A map from partition id to replica ids (i.e.
replicationFactor() - Method in class org.oracle.okafka.clients.admin.NewTopic
The replication factor for the new topic or -1 if a replica assignment has been specified.
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
request.timeout.ms
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
request.timeout.ms
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
request.timeout.ms (This property is not yet supported)
resume(Collection<TopicPartition>) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
resume(Collection<TopicPartition>) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
RetriableException - Exception in org.oracle.okafka.common.errors
A retriable exception is a transient exception that if retried may succeed.
RetriableException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.RetriableException
 
RetriableException(String) - Constructor for exception org.oracle.okafka.common.errors.RetriableException
 
RetriableException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.RetriableException
 
RetriableException() - Constructor for exception org.oracle.okafka.common.errors.RetriableException
 
RETRIES_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
RETRIES_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
retries
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
retry.backoff.ms
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
retry.backoff.ms
RETRY_BACKOFF_MS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
retry.backoff.ms

S

SECURITY_PROTOCOL_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
seek(TopicPartition, long) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
seek(TopicPartition, long) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Overrides the fetch offset that the consumer will use on the next poll(timeout).
seekToBeginning(Collection<TopicPartition>) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
seekToBeginning(Collection<TopicPartition>) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Seek to the first available offset for each of the given partitions.
seekToEnd(Collection<TopicPartition>) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
seekToEnd(Collection<TopicPartition>) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Seek to the last offset for each of the given partitions.
send(ProducerRecord<K, V>) - Method in class org.oracle.okafka.clients.producer.KafkaProducer
Asynchronously send a record to a topic.
send(ProducerRecord<K, V>, Callback) - Method in class org.oracle.okafka.clients.producer.KafkaProducer
Asynchronously send a record to a topic and invoke the provided callback when the send has been acknowledged.
send(ProducerRecord<K, V>) - Method in interface org.oracle.okafka.clients.producer.Producer
send(ProducerRecord<K, V>, Callback) - Method in interface org.oracle.okafka.clients.producer.Producer
SEND_BUFFER_CONFIG - Static variable in class org.oracle.okafka.clients.admin.AdminClientConfig
 
SEND_BUFFER_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
send.buffer.bytes
SEND_BUFFER_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
send.buffer.bytes (This property is not yet supported)
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class org.oracle.okafka.clients.producer.KafkaProducer
This api is not yet supported
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in interface org.oracle.okafka.clients.producer.Producer
SerializationException - Exception in org.oracle.okafka.common.errors
Any exception during serialization in the producer
SerializationException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.SerializationException
 
SerializationException(String) - Constructor for exception org.oracle.okafka.common.errors.SerializationException
 
SerializationException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.SerializationException
 
SerializationException() - Constructor for exception org.oracle.okafka.common.errors.SerializationException
 
serialize(String, byte[]) - Method in class org.oracle.okafka.common.serialization.ByteArraySerializer
 
serialize(String, ByteBuffer) - Method in class org.oracle.okafka.common.serialization.ByteBufferSerializer
 
serialize(String, Bytes) - Method in class org.oracle.okafka.common.serialization.BytesSerializer
 
serialize(String, Double) - Method in class org.oracle.okafka.common.serialization.DoubleSerializer
 
serialize(String, Headers, T) - Method in interface org.oracle.okafka.common.serialization.ExtendedSerializer
Convert data into a byte array.
serialize(String, Headers, T) - Method in class org.oracle.okafka.common.serialization.ExtendedSerializer.Wrapper
 
serialize(String, T) - Method in class org.oracle.okafka.common.serialization.ExtendedSerializer.Wrapper
 
serialize(String, Float) - Method in class org.oracle.okafka.common.serialization.FloatSerializer
 
serialize(String, Integer) - Method in class org.oracle.okafka.common.serialization.IntegerSerializer
 
serialize(String, Long) - Method in class org.oracle.okafka.common.serialization.LongSerializer
 
serialize(String, T) - Method in interface org.oracle.okafka.common.serialization.Serializer
Convert data into a byte array.
serialize(String, Short) - Method in class org.oracle.okafka.common.serialization.ShortSerializer
 
serialize(String, String) - Method in class org.oracle.okafka.common.serialization.StringSerializer
 
serializedKeySize() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
The size of the serialized, uncompressed key in bytes.
serializedKeySize() - Method in class org.oracle.okafka.clients.producer.RecordMetadata
The size of the serialized, uncompressed key in bytes.
serializedValueSize() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
The size of the serialized, uncompressed value in bytes.
serializedValueSize() - Method in class org.oracle.okafka.clients.producer.RecordMetadata
The size of the serialized, uncompressed value in bytes.
Serializer<T> - Interface in org.oracle.okafka.common.serialization
An interface for converting objects to bytes.
serviceName() - Method in class org.oracle.okafka.common.Node
Name of the service running on this node/instance
SESSION_TIMEOUT_MS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
session.timeout.ms
ShortDeserializer - Class in org.oracle.okafka.common.serialization
 
ShortDeserializer() - Constructor for class org.oracle.okafka.common.serialization.ShortDeserializer
 
ShortSerializer - Class in org.oracle.okafka.common.serialization
 
ShortSerializer() - Constructor for class org.oracle.okafka.common.serialization.ShortSerializer
 
shouldListInternal() - Method in class org.oracle.okafka.clients.admin.ListTopicsOptions
Return true if we should list internal topics.
shouldValidateOnly() - Method in class org.oracle.okafka.clients.admin.AlterConfigsOptions
Return true if the request should be validated without altering the configs.
shouldValidateOnly() - Method in class org.oracle.okafka.clients.admin.CreateTopicsOptions
Return true if the request should be validated without creating the topic.
source() - Method in class org.oracle.okafka.clients.admin.ConfigEntry.ConfigSynonym
Returns the source of this configuration.
source() - Method in class org.oracle.okafka.clients.admin.ConfigEntry
Return the source of this configuration entry.
SslConfigs - Class in org.oracle.okafka.common.config
 
SslConfigs() - Constructor for class org.oracle.okafka.common.config.SslConfigs
 
StringDeserializer - Class in org.oracle.okafka.common.serialization
String encoding defaults to UTF8 and can be customized by setting the property key.deserializer.encoding, value.deserializer.encoding or deserializer.encoding.
StringDeserializer() - Constructor for class org.oracle.okafka.common.serialization.StringDeserializer
 
StringSerializer - Class in org.oracle.okafka.common.serialization
String encoding defaults to UTF8 and can be customized by setting the property key.serializer.encoding, value.serializer.encoding or serializer.encoding.
StringSerializer() - Constructor for class org.oracle.okafka.common.serialization.StringSerializer
 
subscribe(Collection<String>) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
subscribe(Pattern, ConsumerRebalanceListener) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
subscribe(Pattern) - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
subscribe(Collection<String>, ConsumerRebalanceListener) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(Collection<String>) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Subscribe to the given list of topics to get dynamically assigned partitions.
subscribe(Pattern, ConsumerRebalanceListener) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
subscribe(Pattern) - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
subscription() - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
subscription() - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
synonyms() - Method in class org.oracle.okafka.clients.admin.ConfigEntry
Returns all config values that may be used as the value of this config along with their source, in the order of precedence.

T

tags() - Method in class org.oracle.okafka.common.MetricName
 
tags() - Method in class org.oracle.okafka.common.MetricNameTemplate
 
thenApply(KafkaFuture.BaseFunction<T, R>) - Method in class org.oracle.okafka.common.KafkaFuture
Returns a new KafkaFuture that, when this future completes normally, is executed with this futures's result as the argument to the supplied function.
thenApply(KafkaFuture.Function<T, R>) - Method in class org.oracle.okafka.common.KafkaFuture
 
TimeoutException - Exception in org.oracle.okafka.common.errors
Indicates that a request timed out.
TimeoutException() - Constructor for exception org.oracle.okafka.common.errors.TimeoutException
 
TimeoutException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.TimeoutException
 
TimeoutException(String) - Constructor for exception org.oracle.okafka.common.errors.TimeoutException
 
TimeoutException(Throwable) - Constructor for exception org.oracle.okafka.common.errors.TimeoutException
 
timeoutMs - Variable in class org.oracle.okafka.clients.admin.AbstractOptions
 
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.AbstractOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs() - Method in class org.oracle.okafka.clients.admin.AbstractOptions
The request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.AlterConfigsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.CreateAclsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.CreateTopicsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.DeleteAclsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.DeleteTopicsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.DescribeAclsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.DescribeClusterOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.DescribeConfigsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.DescribeTopicsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timeoutMs(Integer) - Method in class org.oracle.okafka.clients.admin.ListTopicsOptions
Set the request timeout in milliseconds for this operation or null if the default request timeout for the AdminClient should be used.
timestamp() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
The timestamp of this record
timestamp() - Method in class org.oracle.okafka.clients.consumer.OffsetAndTimestamp
 
timestamp() - Method in class org.oracle.okafka.clients.producer.ProducerRecord
 
timestamp() - Method in class org.oracle.okafka.clients.producer.RecordMetadata
The timestamp of the record in the topic/partition.
timestampType() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
The timestamp type of this record
TNS_ALIAS - Static variable in class org.oracle.okafka.common.config.SslConfigs
 
TNS_ALIAS_DOC - Static variable in class org.oracle.okafka.common.config.SslConfigs
 
toEnrichedRst() - Method in class org.oracle.okafka.common.config.ConfigDef
Configs with new metadata (group, orderInGroup, dependents) formatted with reStructuredText, suitable for embedding in Sphinx documentation.
toHtmlTable() - Method in class org.oracle.okafka.common.config.ConfigDef
 
toHtmlTable(Map<String, String>) - Method in class org.oracle.okafka.common.config.ConfigDef
Converts this config into an HTML table that can be embedded into docs.
topic() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
The topic this record is received from
topic() - Method in class org.oracle.okafka.clients.producer.ProducerRecord
 
topic() - Method in class org.oracle.okafka.clients.producer.RecordMetadata
The topic the record was appended to
topic() - Method in class org.oracle.okafka.common.PartitionInfo
The topic name
topic() - Method in class org.oracle.okafka.common.TopicPartition
 
topic() - Method in class org.oracle.okafka.common.TopicPartitionReplica
 
TopicExistsException - Exception in org.oracle.okafka.common.errors
 
TopicExistsException(String) - Constructor for exception org.oracle.okafka.common.errors.TopicExistsException
 
TopicExistsException(String, Throwable) - Constructor for exception org.oracle.okafka.common.errors.TopicExistsException
 
TopicPartition - Class in org.oracle.okafka.common
A topic name and partition number
TopicPartition(String, int) - Constructor for class org.oracle.okafka.common.TopicPartition
 
TopicPartitionReplica - Class in org.oracle.okafka.common
The topic name, partition number and the brokerId of the replica.
TopicPartitionReplica(String, int, int) - Constructor for class org.oracle.okafka.common.TopicPartitionReplica
 
topicPartitions(List<TopicPartition>) - Method in class org.oracle.okafka.clients.admin.ListConsumerGroupOffsetsOptions
Set the topic partitions to list as part of the result.
topicPartitions() - Method in class org.oracle.okafka.clients.admin.ListConsumerGroupOffsetsOptions
Returns a list of topic partitions to add as part of the result.
topics() - Method in class org.oracle.okafka.common.Cluster
Get all topics.
toRst() - Method in class org.oracle.okafka.common.config.ConfigDef
Get the configs formatted with reStructuredText, suitable for embedding in Sphinx documentation.
toString() - Method in class org.oracle.okafka.clients.admin.Config
 
toString() - Method in class org.oracle.okafka.clients.admin.ConfigEntry.ConfigSynonym
 
toString() - Method in class org.oracle.okafka.clients.admin.ConfigEntry
 
toString() - Method in class org.oracle.okafka.clients.admin.NewPartitions
 
toString() - Method in class org.oracle.okafka.clients.admin.NewTopic
 
toString() - Method in class org.oracle.okafka.clients.admin.RecordsToDelete
 
toString() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
 
toString() - Method in class org.oracle.okafka.clients.consumer.OffsetAndMetadata
 
toString() - Method in class org.oracle.okafka.clients.consumer.OffsetAndTimestamp
 
toString() - Method in class org.oracle.okafka.clients.producer.ProducerRecord
 
toString() - Method in class org.oracle.okafka.clients.producer.RecordMetadata
 
toString() - Method in class org.oracle.okafka.common.Cluster
 
toString() - Method in class org.oracle.okafka.common.ClusterResource
 
toString() - Method in class org.oracle.okafka.common.config.ConfigDef.NonEmptyString
 
toString() - Method in class org.oracle.okafka.common.config.ConfigDef.Range
 
toString() - Method in class org.oracle.okafka.common.config.ConfigDef.ValidList
 
toString() - Method in class org.oracle.okafka.common.config.ConfigDef.ValidString
 
toString() - Method in class org.oracle.okafka.common.config.ConfigResource
 
toString() - Method in class org.oracle.okafka.common.config.ConfigValue
 
toString() - Method in class org.oracle.okafka.common.MetricName
 
toString() - Method in class org.oracle.okafka.common.MetricNameTemplate
 
toString() - Method in class org.oracle.okafka.common.Node
 
toString() - Method in class org.oracle.okafka.common.PartitionInfo
 
toString() - Method in class org.oracle.okafka.common.TopicPartition
 
toString() - Method in class org.oracle.okafka.common.TopicPartitionReplica
 
totalCount() - Method in class org.oracle.okafka.clients.admin.NewPartitions
The total number of partitions after the operation succeeds.
TRANSACTION_TIMEOUT_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
transaction.timeout.ms (This property is not yet supported)
TRANSACTION_TIMEOUT_DOC - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
 
TRANSACTIONAL_ID_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
transactional.id (This property is not yet supported)
TRANSACTIONAL_ID_DOC - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
 
type - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
type() - Method in class org.oracle.okafka.common.config.ConfigResource
Return the resource type.

U

unauthorizedTopics() - Method in class org.oracle.okafka.common.Cluster
 
UNKNOWN_PARTITION - Static variable in class org.oracle.okafka.clients.producer.RecordMetadata
Partition value for record without partition assigned
unsubscribe() - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
unsubscribe() - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
Unsubscribe from topic currently subscribed with KafkaConsumer.subscribe(Collection).
unused() - Method in class org.oracle.okafka.common.config.AbstractConfig
 

V

validate(Map<String, String>) - Method in class org.oracle.okafka.common.config.ConfigDef
Validate the current configuration values with the configuration definition.
validateAll(Map<String, String>) - Method in class org.oracle.okafka.common.config.ConfigDef
 
validateOnly(boolean) - Method in class org.oracle.okafka.clients.admin.AlterConfigsOptions
Set to true if the request should be validated without altering the configs.
validateOnly() - Method in class org.oracle.okafka.clients.admin.CreatePartitionsOptions
Return true if the request should be validated without creating new partitions.
validateOnly(boolean) - Method in class org.oracle.okafka.clients.admin.CreatePartitionsOptions
Set to true if the request should be validated without creating new partitions.
validateOnly(boolean) - Method in class org.oracle.okafka.clients.admin.CreateTopicsOptions
Set to true if the request should be validated without creating the topic.
validator - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
validValues(String, Map<String, Object>) - Method in interface org.oracle.okafka.common.config.ConfigDef.Recommender
The valid values for the configuration given the current configuration values.
value() - Method in class org.oracle.okafka.clients.admin.ConfigEntry.ConfigSynonym
Returns the value of this configuration, which may be null if the configuration is sensitive.
value() - Method in class org.oracle.okafka.clients.admin.ConfigEntry
Return the value or null.
value() - Method in class org.oracle.okafka.clients.consumer.ConsumerRecord
The value
value() - Method in class org.oracle.okafka.clients.producer.ProducerRecord
 
value() - Method in class org.oracle.okafka.common.config.ConfigValue
 
value(Object) - Method in class org.oracle.okafka.common.config.ConfigValue
 
value() - Method in interface org.oracle.okafka.common.Metric
Deprecated.
As of kafka 1.0.0, use Metric.metricValue() instead. This will be removed in a future major release.
VALUE_DESERIALIZER_CLASS_CONFIG - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
value.deserializer
VALUE_DESERIALIZER_CLASS_DOC - Static variable in class org.oracle.okafka.clients.consumer.ConsumerConfig
 
VALUE_SERIALIZER_CLASS_CONFIG - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
value.serializer
VALUE_SERIALIZER_CLASS_DOC - Static variable in class org.oracle.okafka.clients.producer.ProducerConfig
 
valueOf(String) - Static method in enum org.oracle.okafka.clients.admin.ConfigEntry.ConfigSource
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.oracle.okafka.clients.consumer.OffsetResetStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.oracle.okafka.common.config.ConfigDef.Importance
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.oracle.okafka.common.config.ConfigDef.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.oracle.okafka.common.config.ConfigDef.Width
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.oracle.okafka.common.config.ConfigResource.Type
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.oracle.okafka.clients.admin.ConfigEntry.ConfigSource
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.oracle.okafka.clients.admin.CreatePartitionsResult
Return a map from topic names to futures, which can be used to check the status of individual partition creations.
values() - Method in class org.oracle.okafka.clients.admin.CreateTopicsResult
Return a map from topic names to futures, which can be used to check the status of individual topic creations.
values() - Method in class org.oracle.okafka.clients.admin.DeleteTopicsResult
Return a map from topic names to futures which can be used to check the status of individual deletions.
values() - Static method in enum org.oracle.okafka.clients.consumer.OffsetResetStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.oracle.okafka.common.config.ConfigDef.Importance
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.oracle.okafka.common.config.ConfigDef.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.oracle.okafka.common.config.ConfigDef.Width
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.oracle.okafka.common.config.ConfigResource.Type
Returns an array containing the constants of this enum type, in the order they are declared.
visible(String, Map<String, Object>) - Method in interface org.oracle.okafka.common.config.ConfigDef.Recommender
Set the visibility of the configuration given the current configuration values.
visible() - Method in class org.oracle.okafka.common.config.ConfigValue
 
visible(boolean) - Method in class org.oracle.okafka.common.config.ConfigValue
 

W

wakeup() - Method in interface org.oracle.okafka.clients.consumer.Consumer
 
wakeup() - Method in class org.oracle.okafka.clients.consumer.KafkaConsumer
This method is not yet supported.
whenComplete(KafkaFuture.BiConsumer<? super T, ? super Throwable>) - Method in class org.oracle.okafka.common.KafkaFuture
Returns a new KafkaFuture with the same result or exception as this future, that executes the given action when this future completes.
width - Variable in class org.oracle.okafka.common.config.ConfigDef.ConfigKey
 
withClientSaslSupport() - Method in class org.oracle.okafka.common.config.ConfigDef
Add standard SASL client configuration options.
withClientSslSupport() - Method in class org.oracle.okafka.common.config.ConfigDef
Add standard SSL client configuration options.
withPartitions(Map<TopicPartition, PartitionInfo>) - Method in class org.oracle.okafka.common.Cluster
Return a copy of this cluster combined with `partitions`.
Wrapper(Deserializer<T>) - Constructor for class org.oracle.okafka.common.serialization.ExtendedDeserializer.Wrapper
 
Wrapper(Serializer<T>) - Constructor for class org.oracle.okafka.common.serialization.ExtendedSerializer.Wrapper
 
A B C D E F G H I K L M N O P R S T U V W 
Skip navigation links
Oracle® Database Transactional Event Queues Java API Reference
21c

F32110-01

Copyright © 2001, 2020, Oracle and/or its affiliates. All rights reserved.