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

A

abortTransaction() - Method in class com.opendxl.databus.producer.Producer
Aborts the ongoing transaction.
ACKS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
acks
adapt(S) - Method in interface com.opendxl.databus.common.internal.adapter.Adapter
 
adapt(ConsumerRecord<String, DatabusMessage>) - Method in class com.opendxl.databus.common.internal.adapter.ConsumerRecordAdapter
Adapter pattern implementation for ConsumerRecord.
adapt(ConsumerRecords<String, DatabusMessage>) - Method in class com.opendxl.databus.common.internal.adapter.ConsumerRecordsAdapter
Adapter pattern implementation for ConsumerRecords instance.
adapt(DatabusMessage) - Method in class com.opendxl.databus.common.internal.adapter.DatabusMessageAdapter
Adapter pattern implementation for MessagePayload instance.
adapt(ProducerRecord) - Method in class com.opendxl.databus.common.internal.adapter.DatabusProducerRecordAdapter
Adapter pattern implementation for DatabusProducerRecord instance.
adapt(Object) - Method in class com.opendxl.databus.common.internal.adapter.HeadersAvroDeserializedAdapter
Gets a Headers based on a Object that represents a map deserialized with Avro.
adapt(MessagePayload<P>) - Method in class com.opendxl.databus.common.internal.adapter.MessagePayloadAdapter
Adapter pattern implementation for DatabusMessage instance.
adapt(Map<MetricName, ? extends Metric>) - Method in class com.opendxl.databus.common.internal.adapter.MetricNameMapAdapter
Adapter pattern implementation for a Map<MetricName, Metric> instance.
adapt(Node) - Method in class com.opendxl.databus.common.internal.adapter.NodeAdapter
Adapter pattern implementation for Node instance.
adapt(Node[]) - Method in class com.opendxl.databus.common.internal.adapter.NodeArrayAdapter
Adapter pattern implementation for Node[] array instance.
adapt(PartitionInfo) - Method in class com.opendxl.databus.common.internal.adapter.PartitionInfoAdapter
Adapter pattern implementation for PartitionInfo instance.
adapt(List<PartitionInfo>) - Method in class com.opendxl.databus.common.internal.adapter.PartitionInfoListAdapter
Adapter pattern implementation for PartitionInfo List instance.
adapt(Object) - Method in class com.opendxl.databus.common.internal.adapter.PayloadHeadersAvroDeserializedAdapter
Creates a byte[] that represents a binary payload based on a Object that represents a deserialized Avro payload.
adapt(TopicPartition) - Method in class com.opendxl.databus.common.internal.adapter.TopicPartitionAdapter
Gets a TopicPartition instance.
adapt(Map<String, List<PartitionInfo>>) - Method in class com.opendxl.databus.common.internal.adapter.TopicPartitionInfoListAdapter
Adapter pattern implementation for Map<String, List<PartitionInfo>> instance.
Adapter<S,T> - Interface in com.opendxl.databus.common.internal.adapter
It becomes a getInstance of type S (source) in getInstance of type T (target)
addDeserializerToConfig(Map<String, Object>, Deserializer<?>, Deserializer<?>) - Static method in class com.opendxl.databus.consumer.ConsumerConfiguration
Adds a serializer object to the config map
addDeserializerToConfig(Properties, Deserializer<?>, Deserializer<?>) - Static method in class com.opendxl.databus.consumer.ConsumerConfiguration
Adds a serializer object to the Properties map
addSerializerToConfig(Map<String, Object>, Serializer<?>, Serializer<?>) - Static method in class com.opendxl.databus.producer.ProducerConfig
Adds a serializer object to the config map
addSerializerToConfig(Properties, Serializer<?>, Serializer<?>) - Static method in class com.opendxl.databus.producer.ProducerConfig
Adds a serializer object to the Properties map
assign(List<TopicPartition>) - Method in class com.opendxl.databus.consumer.Consumer
Manually assign a list of partition to this consumer.
assignment() - Method in class com.opendxl.databus.consumer.Consumer
Get the set of topicPartitions currently assigned to this consumer.
AUTO_COMMIT_INTERVAL_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
auto.commit.interval.ms
AUTO_OFFSET_RESET_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
auto.offset.reset
AUTO_OFFSET_RESET_DOC - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
 
AVRO_1_VERSION_NUMBER - Static variable in class com.opendxl.databus.serialization.internal.MessageStructureConstant
The Avro version number.
AvroMessageDeserializer - Class in com.opendxl.databus.serialization.internal
Avro Message Deserializer It used internally by Consumer.poll(long) } after reading a ConsumerRecord
AvroMessageDeserializer(Schema) - Constructor for class com.opendxl.databus.serialization.internal.AvroMessageDeserializer
Constructor
AvroMessageSerializer - Class in com.opendxl.databus.serialization.internal
AvroMessageSerializer(Schema) - Constructor for class com.opendxl.databus.serialization.internal.AvroMessageSerializer
Constructor
AvroV1MessageSchema - Class in com.opendxl.databus.serialization.internal
Avro Schema Registry Avro Schema V1 { "namespace": "com.intel.databus.client", "type": "record", "name": "DatabusMessage", "fields": [{ "name": "headers", "type": { "type": "map" "values": "string" } }, { "name": "payload" "type": "bytes" }] }

B

BATCH_SIZE_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
batch.size
beginningOffsets(List<TopicPartition>) - Method in class com.opendxl.databus.consumer.Consumer
Get the first offset for the given topicPartitions.
beginTransaction() - Method in class com.opendxl.databus.producer.Producer
Should be called before the start of each new transaction.
BOOTSTRAP_SERVERS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
bootstrap.servers
BOOTSTRAP_SERVERS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
bootstrap.servers
BUFFER_MEMORY_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
buffer.memory
buildClientIdMetric(Map<MetricName, ? extends Metric>, String, String) - Static method in class com.opendxl.databus.producer.metric.ProducerMetricBuilder
This method builds an instance of a ProducerMetric which gives a result value related to metric associated to the clientId.
buildClientIdTopicMetric(Map<MetricName, ? extends Metric>, String, String, TopicPartition) - Static method in class com.opendxl.databus.producer.metric.ProducerMetricBuilder
This method builds an instance of a ProducerMetric which gives a result value related to metric associated to an specific topic provided as a parameter associated to the clientId.
buildClientMetric(Map<MetricName, ? extends Metric>, String, String) - Static method in class com.opendxl.databus.consumer.metric.ConsumerMetricsBuilder
This method builds an instance of a ConsumerMetricPerClientId which gives a result value related to metric associated to the clientId.
buildClientTopicMetric(Map<MetricName, ? extends Metric>, String, String, List<TopicPartition>) - Static method in class com.opendxl.databus.consumer.metric.ConsumerMetricsBuilder
This method builds an instance of a ConsumerMetricPerClientIdAndTopics which gives a resultvalue related to metric associated to an specific topic provided as a parameter associated to the clientId.
buildClientTopicPartitionMetric(Map<MetricName, ? extends Metric>, String, String, List<TopicPartition>) - Static method in class com.opendxl.databus.consumer.metric.ConsumerMetricsBuilder
This method builds an instance of a ConsumerMetricPerClientIdAndTopicPartitions which gives a result value related to metric associated to an specific topic-partition provided as a parameter associated to the clientId.
ByteArrayDeserializer - Class in com.opendxl.databus.serialization
Byte Array Deserializer.
ByteArrayDeserializer() - Constructor for class com.opendxl.databus.serialization.ByteArrayDeserializer
 
ByteArraySerializer - Class in com.opendxl.databus.serialization
Byte Array Serializer.
ByteArraySerializer() - Constructor for class com.opendxl.databus.serialization.ByteArraySerializer
 
bytesFetchRequestSizeAvgMetric() - Method in class com.opendxl.databus.consumer.Consumer
Average bytes per fetch request for each consumer and its topics.
bytesPerSecondAvgMetric() - Method in class com.opendxl.databus.consumer.Consumer
Average bytes consumed per second for each consumer and its topics.
bytesTotalMetric() - Method in class com.opendxl.databus.consumer.Consumer
Total bytes consumed per consumer and its topics.

C

Callback - Interface in com.opendxl.databus.producer
A callback class which can be implemented to provide asynchronous handling of request completion.
cancel(boolean) - Method in class com.opendxl.databus.consumer.DatabusPushConsumerFuture
 
CHECK_CRCS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
check.crcs
CLIENT_ID_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
client.id
CLIENT_ID_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
client.id
CliUtils - Class in com.opendxl.databus.cli
Facilities for command line options
clone() - Method in class com.opendxl.databus.entities.Headers
A clone object of Headers instance
close() - Method in class com.opendxl.databus.consumer.Consumer
Close the consumer, waiting for up to the default timeout of 30 seconds for any needed cleanup.
close(Duration) - Method in class com.opendxl.databus.consumer.Consumer
Tries to close the consumer cleanly within the specified timeout.
close() - Method in class com.opendxl.databus.consumer.DatabusPushConsumer
Close the consumer, waiting for up to the default timeout of 30 seconds for any needed cleanup.
close() - Method in class com.opendxl.databus.producer.Producer
Close this producer.
close(long, TimeUnit) - Method in class com.opendxl.databus.producer.Producer
This method waits up to timeout for the producer to complete the sending of all incomplete requests.
close() - Method in class com.opendxl.databus.serialization.internal.DatabusKeyDeserializer
Close this deserializer.
close() - Method in class com.opendxl.databus.serialization.internal.DatabusKeySerializer
Close this deserializer.
close() - Method in class com.opendxl.databus.serialization.internal.MessageDeserializer
Not implemented.
close() - Method in class com.opendxl.databus.serialization.internal.MessageSerializer
Not implemented.
close() - Method in class com.opendxl.databus.serialization.SerdeDatabus
Not implemented.
com.opendxl.databus.cli - package com.opendxl.databus.cli
 
com.opendxl.databus.cli.entity - package com.opendxl.databus.cli.entity
 
com.opendxl.databus.cli.operation - package com.opendxl.databus.cli.operation
 
com.opendxl.databus.common - package com.opendxl.databus.common
 
com.opendxl.databus.common.internal.adapter - package com.opendxl.databus.common.internal.adapter
 
com.opendxl.databus.common.internal.builder - package com.opendxl.databus.common.internal.builder
 
com.opendxl.databus.common.internal.util - package com.opendxl.databus.common.internal.util
 
com.opendxl.databus.consumer - package com.opendxl.databus.consumer
 
com.opendxl.databus.consumer.metric - package com.opendxl.databus.consumer.metric
 
com.opendxl.databus.credential - package com.opendxl.databus.credential
 
com.opendxl.databus.entities - package com.opendxl.databus.entities
 
com.opendxl.databus.entities.internal - package com.opendxl.databus.entities.internal
 
com.opendxl.databus.exception - package com.opendxl.databus.exception
 
com.opendxl.databus.producer - package com.opendxl.databus.producer
 
com.opendxl.databus.producer.internal - package com.opendxl.databus.producer.internal
 
com.opendxl.databus.producer.metric - package com.opendxl.databus.producer.metric
 
com.opendxl.databus.serialization - package com.opendxl.databus.serialization
 
com.opendxl.databus.serialization.internal - package com.opendxl.databus.serialization.internal
 
CommandLineInterface - Class in com.opendxl.databus.cli
Main class for the Databus client CLI.
CommandLineInterface(String[]) - Constructor for class com.opendxl.databus.cli.CommandLineInterface
Constructor
CommandLineOperation - Interface in com.opendxl.databus.cli.operation
Interface for all --operation arguments
commitAsync() - Method in class com.opendxl.databus.consumer.Consumer
Commit offsets returned on the last poll() for all the subscribed list of topics and partition.
commitAsync(OffsetCommitCallback) - Method in class com.opendxl.databus.consumer.Consumer
Commit offsets returned on the last poll() for the subscribed list of topics and topicPartitions.
commitAsync(Map<TopicPartition, OffsetAndMetadata>, OffsetCommitCallback) - Method in class com.opendxl.databus.consumer.Consumer
Commit the specified offsets for the specified list of topics and topicPartitions to Kafka.
commitSync() - Method in class com.opendxl.databus.consumer.Consumer
Commit offsets returned on the last poll() for all the subscribed list of topics and topicPartitions.
commitSync(Map<TopicPartition, OffsetAndMetadata>) - Method in class com.opendxl.databus.consumer.Consumer
Commit the specified offsets for the specified list of topics and topicPartitions.
committed(TopicPartition) - Method in class com.opendxl.databus.consumer.Consumer
Get the last committed offset for the given partition (whether the commit happened by this process or another).
commitTransaction() - Method in class com.opendxl.databus.producer.Producer
Commits the ongoing transaction.
COMPRESSION_TYPE_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
compression.type
configNames() - Static method in class com.opendxl.databus.consumer.ConsumerConfiguration
Gets the config names
configNames() - Static method in class com.opendxl.databus.producer.ProducerConfig
Gets the config names
configure(Map<String, ?>, boolean) - Method in class com.opendxl.databus.serialization.internal.DatabusKeyDeserializer
Add configuration.
configure(Map<String, ?>, boolean) - Method in class com.opendxl.databus.serialization.internal.DatabusKeySerializer
Add configuration.
configure(Map<String, ?>, boolean) - Method in class com.opendxl.databus.serialization.internal.MessageDeserializer
Not implemented.
configure(Map<String, ?>, boolean) - Method in class com.opendxl.databus.serialization.internal.MessageSerializer
Not implemented.
configure(Map<String, ?>, boolean) - Method in class com.opendxl.databus.serialization.SerdeDatabus
Not implemented.
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
connections.max.idle.ms
CONNECTIONS_MAX_IDLE_MS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
connections.max.idle.ms
ConsumeOperation - Class in com.opendxl.databus.cli.operation
It represents a --consume operation command line
ConsumeOperation(Map<Options, ArgumentAcceptingOptionSpec>, OptionSet) - Constructor for class com.opendxl.databus.cli.operation.ConsumeOperation
Constructor
Consumer<P> - Class in com.opendxl.databus.consumer
A abstract consumer, responsible for handling Databus incoming messages.
Consumer() - Constructor for class com.opendxl.databus.consumer.Consumer
 
ConsumerConfiguration - Class in com.opendxl.databus.consumer
 
ConsumerConfiguration(Properties) - Constructor for class com.opendxl.databus.consumer.ConsumerConfiguration
ConsumerConfiguration constructor
ConsumerConfiguration(Map<String, Object>) - Constructor for class com.opendxl.databus.consumer.ConsumerConfiguration
ConsumerConfiguration constructor
ConsumerMetric - Class in com.opendxl.databus.consumer.metric
ConsumerMetric.
ConsumerMetricPerClientId - Class in com.opendxl.databus.consumer.metric
 
ConsumerMetricPerClientId(String, ConsumerMetric) - Constructor for class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientId
ConsumerMetricPerClientId constructor.
ConsumerMetricPerClientIdAndTopicPartitions - Class in com.opendxl.databus.consumer.metric
 
ConsumerMetricPerClientIdAndTopicPartitions(String, Map<TopicPartition, ConsumerMetric>) - Constructor for class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopicPartitions
ConsumerMetricPerClientIdAndTopicPartitions constructor.
ConsumerMetricPerClientIdAndTopics - Class in com.opendxl.databus.consumer.metric
 
ConsumerMetricPerClientIdAndTopics(String, ConsumerMetric, Map<TopicPartition, ConsumerMetric>) - Constructor for class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopics
ConsumerMetricPerClientIdAndTopicPartitions constructor.
ConsumerMetricsBuilder - Class in com.opendxl.databus.consumer.metric
ConsumerMetricsBuilder.
ConsumerRebalanceListener - Interface in com.opendxl.databus.consumer
A callback interface that the user can implement to trigger custom actions when the set of partitions assigned to the consumer changes.
ConsumerRecord<P> - Class in com.opendxl.databus.consumer
It represents a consumer record created by a DatabusConsumer when a new incoming message comes up.
ConsumerRecord(String, Headers, MessagePayload<P>, String, String, Integer, long, long) - Constructor for class com.opendxl.databus.consumer.ConsumerRecord
Construct a record received from a specified topic and partition
ConsumerRecordAdapter<P> - Class in com.opendxl.databus.common.internal.adapter
Adapter for ConsumerRecord.
ConsumerRecordAdapter(Deserializer<P>) - Constructor for class com.opendxl.databus.common.internal.adapter.ConsumerRecordAdapter
Constructor
ConsumerRecordResult - Class in com.opendxl.databus.cli.entity
Helper class use to deserialize the Consumer instance
ConsumerRecordResult(String, String, String, String, String, Map<String, String>, long, int, long) - Constructor for class com.opendxl.databus.cli.entity.ConsumerRecordResult
Constructor with all parameters
ConsumerRecords<P> - Class in com.opendxl.databus.consumer
This class contains a set of ConsumerRecord.
ConsumerRecords(Map<TopicPartition, List<ConsumerRecord<P>>>) - Constructor for class com.opendxl.databus.consumer.ConsumerRecords
Constructor for the consumer record Map.
ConsumerRecordsAdapter<P> - Class in com.opendxl.databus.common.internal.adapter
Adapter for ConsumerRecords
ConsumerRecordsAdapter(Deserializer<P>) - Constructor for class com.opendxl.databus.common.internal.adapter.ConsumerRecordsAdapter
Constructor
count() - Method in class com.opendxl.databus.consumer.ConsumerRecords
Gets total of records contained in the records object instance.
Credential - Interface in com.opendxl.databus.credential
 

D

DatabusClientRuntimeException - Exception in com.opendxl.databus.exception
A RuntimeException exception that wrap the original exception
DatabusClientRuntimeException(String, Throwable, Class) - Constructor for exception com.opendxl.databus.exception.DatabusClientRuntimeException
Constructor with all parameters
DatabusClientRuntimeException(String, Class) - Constructor for exception com.opendxl.databus.exception.DatabusClientRuntimeException
Constructor with message and causedByClass parameters
DatabusConsumer<P> - Class in com.opendxl.databus.consumer
It consumes records listening to a set of topics that were published for a DatabusProducer
DatabusConsumer(Map<String, Object>, Deserializer<P>) - Constructor for class com.opendxl.databus.consumer.DatabusConsumer
A consumer is instantiated by providing a set of key-value pairs as configuration.
DatabusConsumer(Map<String, Object>, Deserializer<P>, Credential) - Constructor for class com.opendxl.databus.consumer.DatabusConsumer
A consumer is instantiated by providing a set of key-value pairs as configuration.
DatabusConsumer(Properties, Deserializer<P>) - Constructor for class com.opendxl.databus.consumer.DatabusConsumer
A consumer is instantiated by providing a Properties object as configuration.
DatabusConsumer(Properties, Deserializer<P>, Credential) - Constructor for class com.opendxl.databus.consumer.DatabusConsumer
A consumer is instantiated by providing a Properties object as configuration.
DatabusKeyDeserializer - Class in com.opendxl.databus.serialization.internal
Deserializer for Databus key
DatabusKeyDeserializer() - Constructor for class com.opendxl.databus.serialization.internal.DatabusKeyDeserializer
 
DatabusKeySerializer - Class in com.opendxl.databus.serialization.internal
Serializer for Databus key
DatabusKeySerializer() - Constructor for class com.opendxl.databus.serialization.internal.DatabusKeySerializer
 
DatabusMessage - Class in com.opendxl.databus.entities.internal
It represents the message sent thru Databus.
DatabusMessage(Headers, byte[]) - Constructor for class com.opendxl.databus.entities.internal.DatabusMessage
A DatabusMessage is created by providing a Headers and a payload as byte[].
DatabusMessageAdapter<P> - Class in com.opendxl.databus.common.internal.adapter
A Adapter for Databus Message
DatabusMessageAdapter(Deserializer<P>) - Constructor for class com.opendxl.databus.common.internal.adapter.DatabusMessageAdapter
Constructor
DatabusProducer<P> - Class in com.opendxl.databus.producer
Publishes records to Databus.
DatabusProducer(Map<String, Object>, Serializer<P>) - Constructor for class com.opendxl.databus.producer.DatabusProducer
A DatabusProducer is instantiated by providing a set of key-value as configuration.
DatabusProducer(Map<String, Object>, Serializer<P>, Credential) - Constructor for class com.opendxl.databus.producer.DatabusProducer
A DatabusProducer is instantiated by providing a set of key-value as configuration.
DatabusProducer(Properties, Serializer<P>) - Constructor for class com.opendxl.databus.producer.DatabusProducer
A producer is instantiated by providing a set of key-value as configuration.
DatabusProducer(Properties, Serializer<P>, Credential) - Constructor for class com.opendxl.databus.producer.DatabusProducer
A producer is instantiated by providing a set of key-value as configuration.
DatabusProducerRecordAdapter<P> - Class in com.opendxl.databus.common.internal.adapter
Adapter for Databus Producer Record
DatabusProducerRecordAdapter(Serializer<P>) - Constructor for class com.opendxl.databus.common.internal.adapter.DatabusProducerRecordAdapter
Constructor
DatabusPushConsumer<P> - Class in com.opendxl.databus.consumer
Extends a DatabusConsumer to replace poll model for push message model.
DatabusPushConsumer(Map<String, Object>, Deserializer<P>, DatabusPushConsumerListener) - Constructor for class com.opendxl.databus.consumer.DatabusPushConsumer
Constructor
DatabusPushConsumer(Map<String, Object>, Deserializer<P>, DatabusPushConsumerListener, Credential) - Constructor for class com.opendxl.databus.consumer.DatabusPushConsumer
 
DatabusPushConsumer(Properties, Deserializer<P>, DatabusPushConsumerListener) - Constructor for class com.opendxl.databus.consumer.DatabusPushConsumer
 
DatabusPushConsumer(Properties, Deserializer<P>, DatabusPushConsumerListener, Credential) - Constructor for class com.opendxl.databus.consumer.DatabusPushConsumer
 
DatabusPushConsumerFuture - Class in com.opendxl.databus.consumer
This class allows SDK Databus client to know the status of a DatabusPushConsumer instance
DatabusPushConsumerFuture(DatabusPushConsumerStatus, CountDownLatch) - Constructor for class com.opendxl.databus.consumer.DatabusPushConsumerFuture
Constructor
DatabusPushConsumerListener<P> - Interface in com.opendxl.databus.consumer
This is the interface that SDK Databus client has to implement to receive and process records when consume them by using a DatabusPushConsumer instance.
DatabusPushConsumerListenerResponse - Enum in com.opendxl.databus.consumer
 
DatabusPushConsumerStatus - Class in com.opendxl.databus.consumer
This class tracks DatabusPushConsumer internal status DatabusPushConsumerStatus.Status and let the user knows how is going on the internal message listener processor DatabusPushConsumerListenerResponse
DatabusPushConsumerStatus.Status - Enum in com.opendxl.databus.consumer
DatabusPushConsumer Status
DEFAULT_EXCLUDE_INTERNAL_TOPICS - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
 
DEFAULT_FETCH_MAX_BYTES - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
 
DEFAULT_ISOLATION_LEVEL - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
 
DEFAULT_MAX_PARTITION_FETCH_BYTES - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
 
description() - Method in class com.opendxl.databus.common.MetricName
 
deserialize(byte[]) - Method in class com.opendxl.databus.serialization.ByteArrayDeserializer
Deserialize a message.
deserialize(byte[]) - Method in interface com.opendxl.databus.serialization.Deserializer
Deserialize a message.
deserialize(String, byte[]) - Method in class com.opendxl.databus.serialization.internal.AvroMessageDeserializer
Deserialize a message
deserialize(String, byte[]) - Method in class com.opendxl.databus.serialization.internal.DatabusKeyDeserializer
Deserialize a record value from a byte array into a value or object.
deserialize(String, byte[]) - Method in interface com.opendxl.databus.serialization.internal.InternalDeserializer
Deserialize data.
deserialize(String, byte[]) - Method in class com.opendxl.databus.serialization.internal.LegacyMessageDeserializer
Deserialize data to a DatabusMessage.
deserialize(String, byte[]) - Method in class com.opendxl.databus.serialization.internal.MessageDeserializer
Deserialize a message to a DatabusMessage
deserialize(String, byte[]) - Method in class com.opendxl.databus.serialization.internal.RawMessageDeserializer
It takes binary data from Databus and create a DatabusMessage with this binary data and empty headers.
Deserializer<P> - Interface in com.opendxl.databus.serialization
Deserializer SDK's users have to implement this, in order to be able to consume a Databus message.
deserializer() - Method in class com.opendxl.databus.serialization.SerdeDatabus
Creates the deserializer.
DeserializerRegistry - Class in com.opendxl.databus.serialization.internal
Contains a key-value Collection of message version and Deserializer.

E

EMPTY - Static variable in class com.opendxl.databus.consumer.ConsumerRecords
The consumer record instance.
empty() - Static method in class com.opendxl.databus.consumer.ConsumerRecords
Gets an empty set of the consumer records map.
ENABLE_AUTO_COMMIT_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
enable.auto.commit
ENABLE_IDEMPOTENCE_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
enable.idempotence
ENABLE_IDEMPOTENCE_DOC - Static variable in class com.opendxl.databus.producer.ProducerConfig
 
endOffsets(List<TopicPartition>) - Method in class com.opendxl.databus.consumer.Consumer
Get the end offsets for the given topicPartitions.
equals(Object) - Method in class com.opendxl.databus.common.MetricName
 
equals(Object) - Method in class com.opendxl.databus.common.Node
 
equals(Object) - Method in class com.opendxl.databus.common.OffsetAndTimestamp
 
equals(Object) - Method in class com.opendxl.databus.common.TopicPartition
 
equals(Object) - Method in class com.opendxl.databus.consumer.OffsetAndMetadata
Overriding equals method
equals(Object) - Method in class com.opendxl.databus.entities.internal.DatabusMessage
Overrides equals method for DatabusMessage
EXCLUDE_INTERNAL_TOPICS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
exclude.internal.topics
execute() - Method in class com.opendxl.databus.cli.CommandLineInterface
Execute an operation
execute() - Method in interface com.opendxl.databus.cli.operation.CommandLineOperation
Execute the operation
execute() - Method in class com.opendxl.databus.cli.operation.ConsumeOperation
Execute the operation
execute() - Method in class com.opendxl.databus.cli.operation.ProduceOperation
Execute the operation
ExecutionResult - Class in com.opendxl.databus.cli.entity
Represent the result of a operation command line
ExecutionResult(String, Object, Map<OptionSpec<?>, List<?>>) - Constructor for class com.opendxl.databus.cli.entity.ExecutionResult
Result of a command line operation.

F

FETCH_MAX_BYTES_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
fetch.max.bytes
FETCH_MAX_WAIT_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
fetch.max.wait.ms
FETCH_MIN_BYTES_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
fetch.min.bytes
fetchRequestAvgMetric() - Method in class com.opendxl.databus.consumer.Consumer
The number of fetch requests per second.
flush() - Method in class com.opendxl.databus.producer.Producer
Invoking this method makes all buffered records immediately available to send (even if linger.ms is greater than 0) and blocks on the completion of the requests associated with these records.
fromString(String) - Static method in enum com.opendxl.databus.cli.operation.OperationArguments
Return a OperationArgument enumerated based on a string

G

get() - Method in class com.opendxl.databus.consumer.DatabusPushConsumerFuture
 
get(long, TimeUnit) - Method in class com.opendxl.databus.consumer.DatabusPushConsumerFuture
 
get(String) - Method in class com.opendxl.databus.entities.Headers
Gets an specific header in the headers map
get(String) - Static method in class com.opendxl.databus.producer.internal.ProducerDefaultConfiguration
 
getAll() - Method in class com.opendxl.databus.entities.Headers
Gets the headers maps
getAll() - Static method in class com.opendxl.databus.producer.internal.ProducerDefaultConfiguration
 
getCausedByClass() - Method in exception com.opendxl.databus.exception.DatabusClientRuntimeException
Gets the class name of the thew exception
getClientId() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientId
Gets the clientId of the metric.
getClientId() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopicPartitions
Returns the client id.
getClientId() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopics
Gets the client id.
getClientId() - Method in class com.opendxl.databus.producer.metric.ProducerMetric
Get the metric clientId.
getCode() - Method in class com.opendxl.databus.cli.entity.ExecutionResult
Gets the result code of an Execution result
getComposedTopic() - Method in class com.opendxl.databus.consumer.ConsumerRecord
The Composed Topic name
getConfiguration() - Method in class com.opendxl.databus.producer.Producer
Gets the configuration to a producer instance
getCredentialConfig() - Method in interface com.opendxl.databus.credential.Credential
Gets the credential configuration as a Map<String,Object>.
getCredentialConfig() - Method in class com.opendxl.databus.credential.SSLCredential
Gets config map.
getCredentialConfig() - Method in class com.opendxl.databus.credential.SSLSaslPlainCredential
Gets config map.
getCredentialConfig() - Method in class com.opendxl.databus.credential.SSLSaslScramSHA512Credential
Gets config map.
getDeserializer(Integer) - Static method in class com.opendxl.databus.serialization.internal.DeserializerRegistry
Gets the Internal deserializer.
getError() - Method in enum com.opendxl.databus.producer.metric.ProducerMetricEnum
Gets the error message for the ProducerMetricEnum instance
getException() - Method in class com.opendxl.databus.consumer.DatabusPushConsumerStatus
 
getHeaders() - Method in class com.opendxl.databus.consumer.ConsumerRecord
The Headers
getHeaders() - Method in class com.opendxl.databus.entities.internal.DatabusMessage
Gets the headers of a DatabusMessage instance
getHeaders() - Method in class com.opendxl.databus.producer.ProducerRecord
A Map with additional information.
getKey() - Method in class com.opendxl.databus.consumer.ConsumerRecord
The Key
getListenerResult() - Method in class com.opendxl.databus.consumer.DatabusPushConsumerStatus
 
getMagicByte() - Method in class com.opendxl.databus.serialization.internal.LegacyMessageStructure
Gets the magic byte.
getMagicByte() - Method in interface com.opendxl.databus.serialization.internal.MessageStructure
Gets the magic byte.
getMagicByte() - Method in class com.opendxl.databus.serialization.internal.RawMessageStructure
Gets the magic byte.
getMagicByte() - Method in class com.opendxl.databus.serialization.internal.RegularMessageStructure
Gets the magic byte.
getMandatoryOptions() - Method in interface com.opendxl.databus.cli.operation.CommandLineOperation
Gets the mandatory options map
getMandatoryOptions() - Method in class com.opendxl.databus.cli.operation.ConsumeOperation
Gets the mandatory options map
getMandatoryOptions() - Method in class com.opendxl.databus.cli.operation.ProduceOperation
Gets the mandatory options map
getMessage() - Method in class com.opendxl.databus.serialization.internal.LegacyMessageStructure
Gets the message.
getMessage() - Method in interface com.opendxl.databus.serialization.internal.MessageStructure
Gets the message.
getMessage() - Method in class com.opendxl.databus.serialization.internal.RawMessageStructure
Gets the message.
getMessage() - Method in class com.opendxl.databus.serialization.internal.RegularMessageStructure
Gets the message.
getMessagePayload() - Method in class com.opendxl.databus.consumer.ConsumerRecord
The message payload
getMetricDescription() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetric
Get the metric description.
getMetricDescription() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientId
Gets the description of the metric.
getMetricDescription() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopics
Gets the metric description.
getMetricDescription() - Method in class com.opendxl.databus.producer.metric.ProducerMetric
Get the metric description.
getMetricGroup() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetric
Get the metric group.
getMetricGroup() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientId
Gets the metric group of the metric.
getMetricGroup() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopics
Gets the metric group.
getMetricGroup() - Method in class com.opendxl.databus.producer.metric.ProducerMetric
Get the metric group.
getMetricName() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetric
Get the value of the metric.
getMetricName() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientId
Gets the name of the metric.
getMetricName() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopics
Gets the metric name.
getMetricName() - Method in class com.opendxl.databus.producer.metric.ProducerMetric
Get the metric name.
getMetricTags() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetric
Get the metric tags.
getMetricTags() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientId
Gets the tags of the metric.
getMetricTags() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopics
Gets the metric tag.
getMetricTags() - Method in class com.opendxl.databus.producer.metric.ProducerMetric
Get the metric tags.
getName() - Method in enum com.opendxl.databus.producer.metric.ProducerMetricEnum
Gets the error message for the ProducerMetricEnum instance
getOffset() - Method in class com.opendxl.databus.consumer.ConsumerRecord
The Offset number
getOperation(ArgumentAcceptingOptionSpec<String>) - Method in class com.opendxl.databus.cli.operation.OperationFactory
Gets a specific operation for the command line instance
getOperationName() - Method in interface com.opendxl.databus.cli.operation.CommandLineOperation
Gets the operation name
getOperationName() - Method in class com.opendxl.databus.cli.operation.ConsumeOperation
Gets the operation name
getOperationName() - Method in class com.opendxl.databus.cli.operation.ProduceOperation
Gets the operation name
getOptionName() - Method in enum com.opendxl.databus.cli.Options
Gets and specific option name
getOptions() - Method in class com.opendxl.databus.cli.entity.ExecutionResult
Gets the option list for the operation
getPartition() - Method in class com.opendxl.databus.consumer.ConsumerRecord
The Partition number
getPartition() - Method in class com.opendxl.databus.entities.RoutingData
Gets the partition number
getPayload() - Method in class com.opendxl.databus.entities.internal.DatabusMessage
Gets the payload data
getPayload() - Method in class com.opendxl.databus.entities.MessagePayload
Gets the payload Message Instance
getPayload() - Method in class com.opendxl.databus.serialization.internal.LegacyMessageStructure
Gets the full payload
getPayload() - Method in interface com.opendxl.databus.serialization.internal.MessageStructure
Gets the payload.
getPayload() - Method in class com.opendxl.databus.serialization.internal.RawMessageStructure
Gets the payload.
getPayload() - Method in class com.opendxl.databus.serialization.internal.RegularMessageStructure
Gets the payload.
getResult() - Method in class com.opendxl.databus.cli.entity.ExecutionResult
Gets the result of an Execution result
getRoutingData() - Method in class com.opendxl.databus.producer.ProducerRecord
The address where the record must to be sent.
getSchema() - Static method in class com.opendxl.databus.serialization.internal.AvroV1MessageSchema
Gets Avro version 1 Schema
getShardingKey() - Method in class com.opendxl.databus.entities.RoutingData
Gets the sharding key
getStatus() - Method in class com.opendxl.databus.consumer.DatabusPushConsumerStatus
 
getStructure(byte[]) - Static method in class com.opendxl.databus.serialization.internal.MessageStructureFactory
Gets a MessageStructure instance based on the first byte (magic byte).
getTenantGroup() - Method in class com.opendxl.databus.consumer.ConsumerRecord
The Tenant Group
getTenantGroup() - Method in class com.opendxl.databus.entities.RoutingData
Gets the tenant group
getTenantGroupTopicFromComposedTopicName(String) - Static method in class com.opendxl.databus.common.internal.builder.TopicNameBuilder
Gets the tenant group.
getTimestamp() - Method in class com.opendxl.databus.consumer.ConsumerRecord
The Timestamp as Long
getTopic() - Method in class com.opendxl.databus.consumer.ConsumerRecord
The Topic name
getTopic() - Method in class com.opendxl.databus.entities.RoutingData
Gets the topic name
getTopicFromComposedTopicName(String) - Static method in class com.opendxl.databus.common.internal.builder.TopicNameBuilder
Gets topic name and tenant group composed by topicname-tenantgroup.
getTopicMetrics() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopics
Gets a map with the topic name and the associated metric value.
getTopicName(String, String) - Static method in class com.opendxl.databus.common.internal.builder.TopicNameBuilder
Compose a Kafka topic name based on group and topic.
getTopicPartitionsMetrics() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopicPartitions
Returns the map of topic partitions with an associated consumer metric value.
getValue() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetric
Get the value of the metric.
getValue() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientId
Gets the value of the metric.
getValue() - Method in class com.opendxl.databus.consumer.metric.ConsumerMetricPerClientIdAndTopics
Gets the metric value.
getValue() - Method in class com.opendxl.databus.producer.metric.ProducerMetric
Get the value of the metric.
getVersion() - Method in class com.opendxl.databus.serialization.internal.LegacyMessageStructure
Gets the message structure version.
getVersion() - Method in interface com.opendxl.databus.serialization.internal.MessageStructure
Gets the version.
getVersion() - Method in class com.opendxl.databus.serialization.internal.RawMessageStructure
Gets the version.
getVersion() - Method in class com.opendxl.databus.serialization.internal.RegularMessageStructure
Gets the version.
GlobalConstants - Class in com.opendxl.databus.common.internal.util
Databus SDK Global Constants
group() - Method in class com.opendxl.databus.common.MetricName
 
GROUP_ID_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
group.id

H

hashCode() - Method in class com.opendxl.databus.common.MetricName
 
hashCode() - Method in class com.opendxl.databus.common.Node
 
hashCode() - Method in class com.opendxl.databus.common.OffsetAndTimestamp
 
hashCode() - Method in class com.opendxl.databus.common.TopicPartition
 
hashCode() - Method in class com.opendxl.databus.consumer.OffsetAndMetadata
Get the hashcode of the OffsetAndMetadata object
hashCode() - Method in class com.opendxl.databus.entities.internal.DatabusMessage
Overrides equals method for DatabusMessage
HeaderInternalField - Class in com.opendxl.databus.common.internal.util
Internal Headers Key All Header field valus must start and finish with "_"
Headers - Class in com.opendxl.databus.entities
It represents a key-value pair map where the user can put elements for the consumer's interest Some out-of-the-box elements names are located at HeadersField
Headers(Map<String, String>) - Constructor for class com.opendxl.databus.entities.Headers
Headers constructor with a map of headers as a parameter
Headers() - Constructor for class com.opendxl.databus.entities.Headers
Headers default constructor with and empty map of headers
HeadersAvroDeserializedAdapter - Class in com.opendxl.databus.common.internal.adapter
Adapter for a Headers deserialized with Avro
HeadersAvroDeserializedAdapter() - Constructor for class com.opendxl.databus.common.internal.adapter.HeadersAvroDeserializedAdapter
 
HeadersField - Class in com.opendxl.databus.common
 
HEARTBEAT_INTERVAL_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
heartbeat.interval.ms
host() - Method in class com.opendxl.databus.common.Node
 

I

id() - Method in class com.opendxl.databus.common.Node
 
idString() - Method in class com.opendxl.databus.common.Node
 
initTransactions() - Method in class com.opendxl.databus.producer.Producer
Needs to be called before any other methods when the transactional.id is set in the configuration.
inSyncReplicas() - Method in class com.opendxl.databus.common.PartitionInfo
 
INTERCEPTOR_CLASSES_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
interceptor.classes
INTERCEPTOR_CLASSES_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
interceptor.classes
INTERCEPTOR_CLASSES_DOC - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
 
INTERCEPTOR_CLASSES_DOC - Static variable in class com.opendxl.databus.producer.ProducerConfig
 
INTERNAL_HEADER_IDENTIFIER - Static variable in class com.opendxl.databus.common.internal.util.HeaderInternalField
The internal header identifier.
InternalDeserializer<P> - Interface in com.opendxl.databus.serialization.internal
Internal Deserializer Used by SDK to deserialize an object of P type,
InternalSerializer<P> - Interface in com.opendxl.databus.serialization.internal
A Internal Message Serializer Interface, Used by SDK to serialize an object ot type P
isCancelled() - Method in class com.opendxl.databus.consumer.DatabusPushConsumerFuture
 
isDone() - Method in class com.opendxl.databus.consumer.DatabusPushConsumerFuture
 
isEmpty() - Method in class com.opendxl.databus.consumer.ConsumerRecords
Gets a boolean value that checks if the records map if empty.
ISOLATION_LEVEL_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
isolation.level
ISOLATION_LEVEL_DOC - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
 
isValidPartitionNumber(String) - Static method in class com.opendxl.databus.cli.CliUtils
This method returns if a partition provided by the command line is valid
iterator() - Method in class com.opendxl.databus.consumer.ConsumerRecords
 

K

KEY_DESERIALIZER_CLASS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
key.deserializer
KEY_DESERIALIZER_CLASS_DOC - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
 
KEY_SERIALIZER_CLASS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
key.serializer
KEY_SERIALIZER_CLASS_DOC - Static variable in class com.opendxl.databus.producer.ProducerConfig
 

L

leader() - Method in class com.opendxl.databus.common.PartitionInfo
 
leaderEpoch() - Method in class com.opendxl.databus.common.OffsetAndTimestamp
Get the leader epoch corresponding to the offset that was found (if one exists).
LEGACY_STRUCTURE_MAGIC_BYTE - Static variable in class com.opendxl.databus.serialization.internal.MessageStructureConstant
The legacy structure of the magic byte.
LEGACY_VERSION_NUMBER - Static variable in class com.opendxl.databus.serialization.internal.MessageStructureConstant
The legacy version number.
LegacyMessageDeserializer - Class in com.opendxl.databus.serialization.internal
Deserilize Legacy JSON messages
LegacyMessageDeserializer() - Constructor for class com.opendxl.databus.serialization.internal.LegacyMessageDeserializer
 
LegacyMessageStructure - Class in com.opendxl.databus.serialization.internal
Represent a Legacy Message Structura based on JSON
LegacyMessageStructure(byte[]) - Constructor for class com.opendxl.databus.serialization.internal.LegacyMessageStructure
Constructor.
LINGER_MS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
linger.ms
listTopics() - Method in class com.opendxl.databus.consumer.Consumer
Get metadata about topicPartitions for all topics that the user is authorized to view.

M

main(String[]) - Static method in class com.opendxl.databus.cli.CommandLineInterface
Entry point
main(String[]) - Static method in class com.opendxl.databus.consumer.ConsumerConfiguration
 
main(String[]) - Static method in class com.opendxl.databus.producer.ProducerConfig
 
MAX_BLOCK_MS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
max.block.ms
MAX_BLOCK_MS_CONFIG_DEFAULT_VALUE - Static variable in class com.opendxl.databus.producer.internal.ProducerDefaultConfiguration
The max time in ms that controls how long the producer will block when calling send() method
MAX_BLOCK_MS_CONFIG_KEY - Static variable in class com.opendxl.databus.producer.internal.ProducerDefaultConfiguration
The key name of the max block ms configuration parameter
MAX_IN_FLIGHT_REQUESTS_PER_CONNECTION - Static variable in class com.opendxl.databus.producer.ProducerConfig
max.in.flight.requests.per.connection
MAX_PARTITION_FETCH_BYTES_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
max.partition.fetch.bytes
MAX_POLL_INTERVAL_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
max.poll.interval.ms
MAX_POLL_RECORDS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
max.poll.records
MAX_REQUEST_SIZE_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
max.request.size
MessageDeserializer - Class in com.opendxl.databus.serialization.internal
Deserialize a message based on MessageStructure getInstance
MessageDeserializer() - Constructor for class com.opendxl.databus.serialization.internal.MessageDeserializer
 
MessagePayload<P> - Class in com.opendxl.databus.entities
Represent a Payload to be sent thru databus
MessagePayload(P) - Constructor for class com.opendxl.databus.entities.MessagePayload
The message payload constructor
MessagePayloadAdapter<P> - Class in com.opendxl.databus.common.internal.adapter
Adapter for Message Payload
MessagePayloadAdapter(Serializer<P>, Headers) - Constructor for class com.opendxl.databus.common.internal.adapter.MessagePayloadAdapter
Constructor
MessageSerializer - Class in com.opendxl.databus.serialization.internal
Serializer message based on MessageStructure getInstance
MessageSerializer() - Constructor for class com.opendxl.databus.serialization.internal.MessageSerializer
Constructor
MessageStructure - Interface in com.opendxl.databus.serialization.internal
A common interface for the message structure.
MessageStructureConstant - Class in com.opendxl.databus.serialization.internal
Contains a set of constants for Message Structure
MessageStructureFactory - Class in com.opendxl.databus.serialization.internal
Factory for MessageStructure getInstance
metadata() - Method in class com.opendxl.databus.consumer.OffsetAndMetadata
Returns the metadata value as String
METADATA_MAX_AGE_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
metadata.max.age.ms
METADATA_MAX_AGE_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
metadata.max.age.ms
Metric - Interface in com.opendxl.databus.common
A Databus Metric
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
metric.reporters
METRIC_REPORTER_CLASSES_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
metric.reporters
metricName() - Method in interface com.opendxl.databus.common.Metric
 
MetricName - Class in com.opendxl.databus.common
A Metric name
MetricName(String, String, String, Map<String, String>) - Constructor for class com.opendxl.databus.common.MetricName
Create MetricName
MetricNameMapAdapter - Class in com.opendxl.databus.common.internal.adapter
Adapter for a Metric Name Map
MetricNameMapAdapter() - Constructor for class com.opendxl.databus.common.internal.adapter.MetricNameMapAdapter
 
metrics() - Method in class com.opendxl.databus.consumer.Consumer
Get the metrics kept by the consumer.
metrics() - Method in class com.opendxl.databus.producer.Producer
Get the full set of internal metrics maintained by the producer.
METRICS_NUM_SAMPLES_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
metrics.num.samples
METRICS_NUM_SAMPLES_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
metrics.num.samples
METRICS_RECORDING_LEVEL_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
metrics.log.level
METRICS_RECORDING_LEVEL_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
metrics.log.level
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
metrics.sample.window.ms
METRICS_SAMPLE_WINDOW_MS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
metrics.sample.window.ms

N

name() - Method in class com.opendxl.databus.common.MetricName
 
Node - Class in com.opendxl.databus.common
Information about a Databus node
Node(int, String, int) - Constructor for class com.opendxl.databus.common.Node
 
NodeAdapter - Class in com.opendxl.databus.common.internal.adapter
A Adapter for Node
NodeAdapter() - Constructor for class com.opendxl.databus.common.internal.adapter.NodeAdapter
 
NodeArrayAdapter - Class in com.opendxl.databus.common.internal.adapter
A Adapter For List of Node
NodeArrayAdapter() - Constructor for class com.opendxl.databus.common.internal.adapter.NodeArrayAdapter
 
noNode() - Static method in class com.opendxl.databus.common.Node
 
NoOpConsumerRebalanceListener - Class in com.opendxl.databus.consumer
A non-functional implementation of ConsumerRebalanceListener
NoOpConsumerRebalanceListener() - Constructor for class com.opendxl.databus.consumer.NoOpConsumerRebalanceListener
 
notNull(T) - Static method in class com.opendxl.databus.common.internal.util.Validator
Null validator
NUMBER_OF_TOPIC_COMPONENTS - Static variable in class com.opendxl.databus.common.internal.util.GlobalConstants
The number of components for topic and tenant group.

O

offset() - Method in class com.opendxl.databus.common.OffsetAndTimestamp
 
offset() - Method in class com.opendxl.databus.common.RecordMetadata
 
offset() - Method in class com.opendxl.databus.consumer.OffsetAndMetadata
Returns the offset value number
OffsetAndMetadata - Class in com.opendxl.databus.consumer
The Kafka offset commit API allows users to provide additional metadata (in the form of a string) when an offset is committed.
OffsetAndMetadata(long, String) - Constructor for class com.opendxl.databus.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through Consumer.
OffsetAndMetadata(long) - Constructor for class com.opendxl.databus.consumer.OffsetAndMetadata
Construct a new OffsetAndMetadata object for committing through Consumer.
OffsetAndTimestamp - Class in com.opendxl.databus.common
A container class for offset and timestamp.
OffsetAndTimestamp(long, long) - Constructor for class com.opendxl.databus.common.OffsetAndTimestamp
 
OffsetAndTimestamp(long, long, Optional<Integer>) - Constructor for class com.opendxl.databus.common.OffsetAndTimestamp
 
OffsetCommitCallback - Interface in com.opendxl.databus.consumer
A callback interface that the user can implement to trigger custom actions when a commit request completes.
offsetsForTimes(Map<TopicPartition, Long>) - Method in class com.opendxl.databus.consumer.Consumer
Look up the offsets for the given topicPartitions by timestamp.
onComplete(Map<TopicPartition, OffsetAndMetadata>, Exception) - Method in interface com.opendxl.databus.consumer.OffsetCommitCallback
A callback method the user can implement to provide asynchronous handling of commit request completion.
onCompletion(RecordMetadata, Exception) - Method in interface com.opendxl.databus.producer.Callback
A callback method which the user can implement to provide asynchronous handling of request completion.
onConsume(ConsumerRecords<P>) - Method in interface com.opendxl.databus.consumer.DatabusPushConsumerListener
It is called by DatabusPushConsumer main loop in a separated thread.
onPartitionsAssigned(Collection<TopicPartition>) - Method in interface com.opendxl.databus.consumer.ConsumerRebalanceListener
A callback method the user can implement to provide handling of customized offsets on completion of a successful partition re-assignment.
onPartitionsAssigned(Collection<TopicPartition>) - Method in class com.opendxl.databus.consumer.NoOpConsumerRebalanceListener
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in interface com.opendxl.databus.consumer.ConsumerRebalanceListener
A callback method the user can implement to provide handling of offset commits to a customized store on the start of a rebalance operation.
onPartitionsRevoked(Collection<TopicPartition>) - Method in class com.opendxl.databus.consumer.NoOpConsumerRebalanceListener
 
OperationArguments - Enum in com.opendxl.databus.cli.operation
Arguments of --operation command line option
OperationFactory - Class in com.opendxl.databus.cli.operation
This factory class creates instances of --operations arguments .
OperationFactory(Map<Options, ArgumentAcceptingOptionSpec>, OptionSet) - Constructor for class com.opendxl.databus.cli.operation.OperationFactory
The Operation Factory constructor
Options - Enum in com.opendxl.databus.cli
Each enumerated represents a command line option.

P

parser - Static variable in class com.opendxl.databus.cli.CommandLineInterface
Parses command line arguments
partition() - Method in class com.opendxl.databus.common.PartitionInfo
 
partition() - Method in class com.opendxl.databus.common.RecordMetadata
 
partition() - Method in class com.opendxl.databus.common.TopicPartition
 
PARTITION_ASSIGNMENT_STRATEGY_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
partition.assignment.strategy
PARTITIONER_CLASS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
partitioner.class
PartitionInfo - Class in com.opendxl.databus.common
Information about a topic-partition.
PartitionInfo(String, int, Node, Node[], Node[]) - Constructor for class com.opendxl.databus.common.PartitionInfo
 
PartitionInfoAdapter - Class in com.opendxl.databus.common.internal.adapter
Adapter for PartitionInfo.
PartitionInfoAdapter() - Constructor for class com.opendxl.databus.common.internal.adapter.PartitionInfoAdapter
 
PartitionInfoListAdapter - Class in com.opendxl.databus.common.internal.adapter
Adapter a List of PartitionInfo.
PartitionInfoListAdapter() - Constructor for class com.opendxl.databus.common.internal.adapter.PartitionInfoListAdapter
 
partitions() - Method in class com.opendxl.databus.consumer.ConsumerRecords
Gets the topic partition Set object for the records Map.
partitionsFor(String) - Method in class com.opendxl.databus.consumer.Consumer
Get metadata about the topicPartitions for a given topic.
partitionsFor(String) - Method in class com.opendxl.databus.producer.Producer
Get the partition metadata for the give topic.
pause(Collection<TopicPartition>) - Method in class com.opendxl.databus.consumer.Consumer
Suspend fetching from the requested topicPartitions.
paused() - Method in class com.opendxl.databus.consumer.Consumer
Get the set of topicPartitions that were previously paused by a call to Consumer.pause(Collection).
payload() - Method in class com.opendxl.databus.producer.ProducerRecord
The message which will be sent
PayloadHeadersAvroDeserializedAdapter - Class in com.opendxl.databus.common.internal.adapter
Adapter for a Headers deserialized with Avro.
PayloadHeadersAvroDeserializedAdapter() - Constructor for class com.opendxl.databus.common.internal.adapter.PayloadHeadersAvroDeserializedAdapter
 
poll(long) - Method in class com.opendxl.databus.consumer.Consumer
Fetch data for the topics or topicPartitions specified using one of the subscribe/assign APIs.
poll(Duration) - Method in class com.opendxl.databus.consumer.Consumer
Fetch data for the topics or partitions specified using one of the subscribe/assign APIs.
poll(Duration) - Method in class com.opendxl.databus.consumer.DatabusPushConsumer
Fetch data for the topics or partitions specified using one of the subscribe/assign APIs.
poll(long) - Method in class com.opendxl.databus.consumer.DatabusPushConsumer
Fetch data for the topics or topicPartitions specified using one of the subscribe/assign APIs.
port() - Method in class com.opendxl.databus.common.Node
 
position(TopicPartition) - Method in class com.opendxl.databus.consumer.Consumer
Get the offset of the next record that will be fetched (if a record with that offset exists).
printUsageAndFinish(String) - Static method in class com.opendxl.databus.cli.CliUtils
Prints usage and exits without system error
printUsageAndFinish(OptionParser, String) - Static method in class com.opendxl.databus.cli.CliUtils
This method is invoked when the command line made up by options and argument are ill formed or do not meet options spec.
printUsageAndFinish(OptionParser, String, Exception) - Static method in class com.opendxl.databus.cli.CliUtils
This method is invoked when the command line made up by options and argument are ill formed or do not meet options spec.
ProduceOperation - Class in com.opendxl.databus.cli.operation
It represents a --consume operation command line
ProduceOperation(Map<Options, ArgumentAcceptingOptionSpec>, OptionSet) - Constructor for class com.opendxl.databus.cli.operation.ProduceOperation
Constructor
Producer<P> - Class in com.opendxl.databus.producer
A abstract producer, responsible for handling Databus outgoing messages.
Producer() - Constructor for class com.opendxl.databus.producer.Producer
 
ProducerConfig - Class in com.opendxl.databus.producer
This class contains a set of names to configure a DatabusProducer
ProducerConfig(Properties) - Constructor for class com.opendxl.databus.producer.ProducerConfig
ProducerConfig constructor
ProducerConfig(Map<String, Object>) - Constructor for class com.opendxl.databus.producer.ProducerConfig
ProducerConfig constructor
ProducerDefaultConfiguration - Class in com.opendxl.databus.producer.internal
This class contains a set of config properties values that will be added to DatabusProducer unless they are provided by the SDK user
ProducerMetric - Class in com.opendxl.databus.producer.metric
ProducerMetric.
ProducerMetricBuilder - Class in com.opendxl.databus.producer.metric
ProducerMetricBuilder.
ProducerMetricEnum - Enum in com.opendxl.databus.producer.metric
ProducerMetricEnum.
ProducerRecord<P> - Class in com.opendxl.databus.producer
Represents a record that DatabusProducer sends to DatabusConsumer
ProducerRecord(RoutingData, Headers, MessagePayload<P>) - Constructor for class com.opendxl.databus.producer.ProducerRecord
Parameters cannot be null.
pushAsync(Duration) - Method in class com.opendxl.databus.consumer.DatabusPushConsumer
Reads messages from Databus and push them to DatabusPushConsumerListener instance which was passed in the constructor
pushAsync() - Method in class com.opendxl.databus.consumer.DatabusPushConsumer
Reads messages from Databus and push them to DatabusPushConsumerListener instance which was passed in the constructor
put(String, String) - Method in class com.opendxl.databus.entities.Headers
Puts an specific header in the headers map

R

RAW_MAGIC_BYTE - Static variable in class com.opendxl.databus.serialization.internal.MessageStructureConstant
The raw magic byte.
RAW_VERSION_NUMBER - Static variable in class com.opendxl.databus.serialization.internal.MessageStructureConstant
The raw version number.
RawMessageDeserializer - Class in com.opendxl.databus.serialization.internal
Deserialize messages produced by Kafka Client.
RawMessageDeserializer() - Constructor for class com.opendxl.databus.serialization.internal.RawMessageDeserializer
 
RawMessageStructure - Class in com.opendxl.databus.serialization.internal
Represents a message produced with a non-SDK producer, for getInstance Kafka SDK.
RawMessageStructure(byte[]) - Constructor for class com.opendxl.databus.serialization.internal.RawMessageStructure
The Constructor.
RECEIVE_BUFFER_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
receive.buffer.bytes
RECEIVE_BUFFER_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
receive.buffer.bytes
RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
reconnect.backoff.max.ms
RECONNECT_BACKOFF_MAX_MS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
reconnect.backoff.max.ms
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
reconnect.backoff.ms
RECONNECT_BACKOFF_MS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
reconnect.backoff.ms
recordBatchSizeAvgMetric() - Method in class com.opendxl.databus.producer.Producer
The maximum size of the batches processed by the connector per clientId.
recordBatchSizeMaxMetric() - Method in class com.opendxl.databus.producer.Producer
The maximum size of the batches processed by the connector per clientId.
recordByteRatePerTopicMetric(String) - Method in class com.opendxl.databus.producer.Producer
The average number of bytes sent per second for a topic.
recordByteTotalPerTopicMetric(String) - Method in class com.opendxl.databus.producer.Producer
The total number of bytes sent for a topic.
recordErrorRateMetric() - Method in class com.opendxl.databus.producer.Producer
The average per-second number of record sends that resulted in errors per clientId.
recordErrorRatePerTopicMetric(String) - Method in class com.opendxl.databus.producer.Producer
The average per-second number of record sends that resulted in errors for a topic.
recordErrorTotalMetric() - Method in class com.opendxl.databus.producer.Producer
The total number of record sends that resulted in errors per clientId.
recordErrorTotalPerTopicMetric(String) - Method in class com.opendxl.databus.producer.Producer
The total number of record sends that resulted in errors for a topic.
RecordMetadata - Class in com.opendxl.databus.common
The metadata for a record that has been acknowledged by the server An object of this class is built only for Databus as a result of a #send( com.opendxl.streaming.nativeclient.producer.ProducerRecord, com.opendxl.streaming.nativeclient.producer.Callback) method
RecordMetadata(RecordMetadata) - Constructor for class com.opendxl.databus.common.RecordMetadata
 
records(TopicPartition) - Method in class com.opendxl.databus.consumer.ConsumerRecords
Gets the consumer ConsumerRecord list.
records(String) - Method in class com.opendxl.databus.consumer.ConsumerRecords
Gets an Iterable instance of ConsumerRecord list.
recordSendRateMetric() - Method in class com.opendxl.databus.producer.Producer
The average number of records sent per second per clientId.
recordSendRatePerTopicMetric(String) - Method in class com.opendxl.databus.producer.Producer
The average number of records sent per second for a topic.
recordSendTotalMetric() - Method in class com.opendxl.databus.producer.Producer
The total number of records sent per clientId.
recordSendTotalPerTopicMetric(String) - Method in class com.opendxl.databus.producer.Producer
The total number of records sent for a topic.
recordSizeAvgMetric() - Method in class com.opendxl.databus.producer.Producer
The average record size per clientId.
recordSizeMaxMetric() - Method in class com.opendxl.databus.producer.Producer
The maximum record size per clientId.
recordsLagAvgPerTopicPartition() - Method in class com.opendxl.databus.consumer.Consumer
The average lag of the partition.
recordsLagMaxMetric() - Method in class com.opendxl.databus.consumer.Consumer
The maximum lag in terms of number of records for any partition in this window.
recordsLagMaxPerTopicPartition() - Method in class com.opendxl.databus.consumer.Consumer
The max lag of the partition.
recordsLagPerTopicPartition() - Method in class com.opendxl.databus.consumer.Consumer
The latest lag of the partition.
recordsPerRequestAvgMetric() - Method in class com.opendxl.databus.consumer.Consumer
Average number of records gotten per fetch request for each consumer and its topics.
recordsPerSecondAvgMetric() - Method in class com.opendxl.databus.consumer.Consumer
Average number of records consumed per seconds for each consumer and its topics.
recordsTotalMetric() - Method in class com.opendxl.databus.consumer.Consumer
Total number of records consumed per consumer and its topics.
REGULAR_STRUCTURE_MAGIC_BYTE - Static variable in class com.opendxl.databus.serialization.internal.MessageStructureConstant
The structure of the magic byte.
RegularMessageStructure - Class in com.opendxl.databus.serialization.internal
Represents a DatabusMessage structure.
RegularMessageStructure(byte[]) - Constructor for class com.opendxl.databus.serialization.internal.RegularMessageStructure
Constructor.
RegularMessageStructure(byte, int, byte[]) - Constructor for class com.opendxl.databus.serialization.internal.RegularMessageStructure
Constructor.
removeHeader(String) - Method in class com.opendxl.databus.entities.internal.DatabusMessage
Delete an specific header passing a header name as a parameter
replicas() - Method in class com.opendxl.databus.common.PartitionInfo
 
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
request.timeout.ms
REQUEST_TIMEOUT_MS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
request.timeout.ms
resume(Collection<TopicPartition>) - Method in class com.opendxl.databus.consumer.Consumer
Resume specified topicPartitions which have been paused with Consumer.pause(Collection).
RETRIES_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
retries
RETRY_BACKOFF_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
retry.backoff.ms
RETRY_BACKOFF_MS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
retry.backoff.ms
RoutingData - Class in com.opendxl.databus.entities
Represent a address where a message must be sent.
RoutingData(String) - Constructor for class com.opendxl.databus.entities.RoutingData
RoutingData constructor with only topic name parameter
RoutingData(String, String, String) - Constructor for class com.opendxl.databus.entities.RoutingData
RoutingData constructor with topic name sharding key and tenant group parameters
RoutingData(String, String, String, Integer) - Constructor for class com.opendxl.databus.entities.RoutingData
RoutingData constructor with all parameters

S

seek(TopicPartition, long) - Method in class com.opendxl.databus.consumer.Consumer
Overrides the fetch offsets that the consumer will use on the next poll(timeout).
seekToBeginning(TopicPartition...) - Method in class com.opendxl.databus.consumer.Consumer
Seek to the first offset for each of the given topicPartitions.
seekToEnd(TopicPartition...) - Method in class com.opendxl.databus.consumer.Consumer
Seek to the last offset for each of the given topicPartitions.
send(ProducerRecord) - Method in class com.opendxl.databus.producer.Producer
Asynchronously send a record to a topic.
send(ProducerRecord<P>, Callback) - Method in class com.opendxl.databus.producer.Producer
Asynchronously send a record to a topic and invoke the provided callback when the send has been acknowledged.
SEND_BUFFER_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
send.buffer.bytes
SEND_BUFFER_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
send.buffer.bytes
sendOffsetsToTransaction(Map<TopicPartition, OffsetAndMetadata>, String) - Method in class com.opendxl.databus.producer.Producer
Sends a list of specified offsets to the consumer group coordinator, also marks those offsets as part of the current transaction.
SerdeDatabus - Class in com.opendxl.databus.serialization
Serializer / Deserializer for Databus messages
SerdeDatabus() - Constructor for class com.opendxl.databus.serialization.SerdeDatabus
 
serialize(byte[]) - Method in class com.opendxl.databus.serialization.ByteArraySerializer
Serialize a message.
serialize(DatabusMessage) - Method in class com.opendxl.databus.serialization.internal.AvroMessageSerializer
Serialize a message
serialize(String, String) - Method in class com.opendxl.databus.serialization.internal.DatabusKeySerializer
Convert data into a byte array.
serialize(P) - Method in interface com.opendxl.databus.serialization.internal.InternalSerializer
Serialize data.
serialize(String, DatabusMessage) - Method in class com.opendxl.databus.serialization.internal.MessageSerializer
Serialize a message, input data to serialize is a DatabusMessage.
serialize(P) - Method in interface com.opendxl.databus.serialization.Serializer
Serialize a message.
serializer() - Method in class com.opendxl.databus.serialization.SerdeDatabus
Creates the serializer.
Serializer<P> - Interface in com.opendxl.databus.serialization
A Message Serializer Interface, SDK's users have to implement this in order to be able to produce a Databus message.
SESSION_TIMEOUT_MS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
session.timeout.ms
setConfiguration(Map<String, Object>) - Method in class com.opendxl.databus.producer.Producer
Set configuration to a producer instance
setDatabusPushConsumerListenerStatus(DatabusPushConsumerStatus) - Method in class com.opendxl.databus.consumer.DatabusPushConsumerFuture
Set the listener status
SOURCE_ID - Static variable in class com.opendxl.databus.common.HeadersField
 
SSLCredential - Class in com.opendxl.databus.credential
SSL Credential.
SSLCredential(String, String, String, String, String) - Constructor for class com.opendxl.databus.credential.SSLCredential
Constructor
SSLSaslPlainCredential - Class in com.opendxl.databus.credential
SSL SASL PLAIN Credential.
SSLSaslPlainCredential(String, String, String, String) - Constructor for class com.opendxl.databus.credential.SSLSaslPlainCredential
Constructor
SSLSaslScramSHA512Credential - Class in com.opendxl.databus.credential
SSL SASL PLAIN Credential.
SSLSaslScramSHA512Credential(String, String, String, String) - Constructor for class com.opendxl.databus.credential.SSLSaslScramSHA512Credential
Constructor
stringToMap(String) - Static method in class com.opendxl.databus.cli.CliUtils
Get properties from comma-separated config String
subscribe(Map<String, List<String>>) - Method in class com.opendxl.databus.consumer.Consumer
Subscribe to the given list of tenantGroups and topics to get dynamically assigned topicPartitions.
subscribe(Map<String, List<String>>, ConsumerRebalanceListener) - Method in class com.opendxl.databus.consumer.Consumer
Subscribe to the given list of tenantGroups and topics to get dynamically assigned topicPartitions.
subscribe(List<String>, ConsumerRebalanceListener) - Method in class com.opendxl.databus.consumer.Consumer
Subscribe to the given list of topics to get dynamically assigned topicPartitions.
subscribe(List<String>) - Method in class com.opendxl.databus.consumer.Consumer
Subscribe to the given list of topics to get dynamically assigned topicPartitions.
subscribe(Pattern, ConsumerRebalanceListener) - Method in class com.opendxl.databus.consumer.Consumer
Subscribe to all topics matching specified pattern to get dynamically assigned topicPartitions.
subscription() - Method in class com.opendxl.databus.consumer.Consumer
Get the current subscription.

T

tags() - Method in class com.opendxl.databus.common.MetricName
 
TENANT_GROUP_NAME_KEY - Static variable in class com.opendxl.databus.common.internal.util.HeaderInternalField
The tenant group key name.
TENANT_GROUP_POSITION - Static variable in class com.opendxl.databus.common.internal.util.GlobalConstants
The tenant group position to get tenant group.
TENANT_ID - Static variable in class com.opendxl.databus.common.HeadersField
 
timestamp() - Method in class com.opendxl.databus.common.OffsetAndTimestamp
 
topic() - Method in class com.opendxl.databus.common.PartitionInfo
 
topic() - Method in class com.opendxl.databus.common.RecordMetadata
 
topic() - Method in class com.opendxl.databus.common.TopicPartition
 
TOPIC_NAME_KEY - Static variable in class com.opendxl.databus.common.internal.util.HeaderInternalField
The topic name key name.
TOPIC_POSITION - Static variable in class com.opendxl.databus.common.internal.util.GlobalConstants
The topic position to get the topic.
TOPIC_SEPARATOR - Static variable in class com.opendxl.databus.common.internal.util.GlobalConstants
The topic separator.
TopicNameBuilder - Class in com.opendxl.databus.common.internal.builder
It is a helper class to compose topic names.
TopicPartition - Class in com.opendxl.databus.common
A topic name and partition number
TopicPartition(String, int) - Constructor for class com.opendxl.databus.common.TopicPartition
 
TopicPartition(String) - Constructor for class com.opendxl.databus.common.TopicPartition
 
TopicPartitionAdapter - Class in com.opendxl.databus.common.internal.adapter
Adapter for TopicPartition
TopicPartitionAdapter() - Constructor for class com.opendxl.databus.common.internal.adapter.TopicPartitionAdapter
 
TopicPartitionInfoListAdapter - Class in com.opendxl.databus.common.internal.adapter
Adapter for a Map of Topic and Partition Info.
TopicPartitionInfoListAdapter() - Constructor for class com.opendxl.databus.common.internal.adapter.TopicPartitionInfoListAdapter
 
toString() - Method in class com.opendxl.databus.common.MetricName
 
toString() - Method in class com.opendxl.databus.common.Node
 
toString() - Method in class com.opendxl.databus.common.OffsetAndTimestamp
 
toString() - Method in class com.opendxl.databus.common.PartitionInfo
 
toString() - Method in class com.opendxl.databus.common.TopicPartition
 
toString() - Method in class com.opendxl.databus.consumer.OffsetAndMetadata
Get the toString method of the OffsetAndMetadata object
totalFetchRequestMetric() - Method in class com.opendxl.databus.consumer.Consumer
Total number of fetch request for each consumer.
TRANSACTION_TIMEOUT_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
transaction.timeout.ms
TRANSACTION_TIMEOUT_DOC - Static variable in class com.opendxl.databus.producer.ProducerConfig
 
TRANSACTIONAL_ID_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
transactional.id
TRANSACTIONAL_ID_DOC - Static variable in class com.opendxl.databus.producer.ProducerConfig
 

U

unsubscribe() - Method in class com.opendxl.databus.consumer.Consumer
Unsubscribe from topics currently subscribed with Consumer.subscribe(List).

V

validateMandatoryOperationArgs(CommandLineOperation, OptionParser, OptionSet) - Static method in class com.opendxl.databus.cli.CliUtils
This method validate the mandatory arguments for a specific operation
Validator - Class in com.opendxl.databus.common.internal.util
Validator
value() - Method in interface com.opendxl.databus.common.Metric
 
VALUE_DESERIALIZER_CLASS_CONFIG - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
value.deserializer
VALUE_DESERIALIZER_CLASS_DOC - Static variable in class com.opendxl.databus.consumer.ConsumerConfiguration
 
VALUE_SERIALIZER_CLASS_CONFIG - Static variable in class com.opendxl.databus.producer.ProducerConfig
value.serializer
VALUE_SERIALIZER_CLASS_DOC - Static variable in class com.opendxl.databus.producer.ProducerConfig
 
valueOf(String) - Static method in enum com.opendxl.databus.cli.operation.OperationArguments
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.opendxl.databus.cli.Options
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.opendxl.databus.consumer.DatabusPushConsumerListenerResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.opendxl.databus.consumer.DatabusPushConsumerStatus.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.opendxl.databus.producer.metric.ProducerMetricEnum
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.opendxl.databus.cli.operation.OperationArguments
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.opendxl.databus.cli.Options
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.opendxl.databus.consumer.DatabusPushConsumerListenerResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.opendxl.databus.consumer.DatabusPushConsumerStatus.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.opendxl.databus.producer.metric.ProducerMetricEnum
Returns an array containing the constants of this enum type, in the order they are declared.

W

wakeup() - Method in class com.opendxl.databus.consumer.Consumer
Wakeup the consumer.
A B C D E F G H I K L M N O P R S T U V W 
Skip navigation links