Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abortTransaction() - Method in interface org.apache.kafka.connect.source.TransactionContext
-
Requests a transaction abort after the next batch of records from
SourceTask.poll()
. - abortTransaction(SourceRecord) - Method in interface org.apache.kafka.connect.source.TransactionContext
-
Requests a transaction abort after a source record is processed.
- AbstractState - Class in org.apache.kafka.connect.health
-
Provides the current status for a connector or a task, along with an identifier for its Connect worker
- AbstractState(String, String, String) - Constructor for class org.apache.kafka.connect.health.AbstractState
-
Construct a state for a connector or task.
- add(String, Object, Schema) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- add(String, Object, Schema) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - add(String, SchemaAndValue) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- add(String, SchemaAndValue) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - add(Header) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- add(Header) - Method in interface org.apache.kafka.connect.header.Headers
-
Add the given
Header
to this collection. - addBoolean(String, boolean) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addBoolean(String, boolean) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addByte(String, byte) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addByte(String, byte) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addBytes(String, byte[]) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addBytes(String, byte[]) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addDate(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addDate(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
- addDecimal(String, BigDecimal) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addDecimal(String, BigDecimal) - Method in interface org.apache.kafka.connect.header.Headers
- addDouble(String, double) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addDouble(String, double) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addFloat(String, float) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addFloat(String, float) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addInt(String, int) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addInt(String, int) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addList(String, List<?>, Schema) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addList(String, List<?>, Schema) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addLong(String, long) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addLong(String, long) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addMap(String, Map<?, ?>, Schema) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addMap(String, Map<?, ?>, Schema) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addShort(String, short) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addShort(String, short) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addString(String, String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addString(String, String) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addStruct(String, Struct) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addStruct(String, Struct) - Method in interface org.apache.kafka.connect.header.Headers
-
Add to this collection a
Header
with the given key and value. - addTime(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addTime(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
- addTimestamp(String, Date) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- addTimestamp(String, Date) - Method in interface org.apache.kafka.connect.header.Headers
- ADMIN - Enum constant in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- allWithName(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- allWithName(String) - Method in interface org.apache.kafka.connect.header.Headers
- AlreadyExistsException - Exception Class in org.apache.kafka.connect.errors
-
Indicates the operation tried to create an entity that already exists.
- AlreadyExistsException(String) - Constructor for exception class org.apache.kafka.connect.errors.AlreadyExistsException
- AlreadyExistsException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.AlreadyExistsException
- AlreadyExistsException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.AlreadyExistsException
- alterOffsets(Map<String, String>, Map<Map<String, ?>, Map<String, ?>>) - Method in class org.apache.kafka.connect.source.SourceConnector
-
Invoked when users request to manually alter/reset the offsets for this connector via the Connect worker's REST API.
- alterOffsets(Map<String, String>, Map<TopicPartition, Long>) - Method in class org.apache.kafka.connect.sink.SinkConnector
-
Invoked when users request to manually alter/reset the offsets for this connector via the Connect worker's REST API.
- apply(String, Headers.HeaderTransform) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- apply(String, Headers.HeaderTransform) - Method in interface org.apache.kafka.connect.header.Headers
-
Get all
Header
s with the given key, apply the transform to each and store the result in place of the original. - apply(Header) - Method in interface org.apache.kafka.connect.header.Headers.HeaderTransform
- apply(Headers.HeaderTransform) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- apply(Headers.HeaderTransform) - Method in interface org.apache.kafka.connect.header.Headers
-
Get all
Header
s, apply the transform to each and store the result in place of the original. - apply(R) - Method in interface org.apache.kafka.connect.transforms.Transformation
-
Apply transformation to the
record
and return another record object (which may berecord
itself) ornull
, corresponding to a map or filter operation respectively. - array(Schema) - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- ARRAY - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
An ordered sequence of elements, each of which shares the same type.
- assignment() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Get the current set of assigned TopicPartitions for this task.
B
- bool() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- BOOLEAN - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
Boolean value (true or false)
- BOOLEAN_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- build() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Build the Schema using the current settings
- builder() - Static method in class org.apache.kafka.connect.data.Date
-
Returns a SchemaBuilder for a Date.
- builder() - Static method in class org.apache.kafka.connect.data.Time
-
Returns a SchemaBuilder for a Time.
- builder() - Static method in class org.apache.kafka.connect.data.Timestamp
-
Returns a SchemaBuilder for a Timestamp.
- builder(int) - Static method in class org.apache.kafka.connect.data.Decimal
-
Returns a SchemaBuilder for a Decimal with the given scale factor.
- bytes() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- BYTES - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
Sequence of unsigned 8-bit bytes
- BYTES_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
C
- canDefineTransactionBoundaries(Map<String, String>) - Method in class org.apache.kafka.connect.source.SourceConnector
-
Signals whether the connector implementation is capable of defining the transaction boundaries for a connector with the given configuration.
- clear() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- clear() - Method in interface org.apache.kafka.connect.header.Headers
-
Removes all headers from this object.
- clientProps() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
Provides configs with prefix "
producer.override.
" forsource connectors
and alsosink connectors
that are configured with a DLQ topic. - clientType() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
- close() - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- close() - Method in class org.apache.kafka.connect.storage.StringConverter
- close() - Method in interface org.apache.kafka.connect.transforms.predicates.Predicate
- close() - Method in interface org.apache.kafka.connect.transforms.Transformation
-
Signal that this transformation instance will no longer will be used.
- close(Collection<TopicPartition>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
The SinkTask uses this method to close writers for partitions that are no longer assigned to the SinkTask.
- clusterDetails() - Method in interface org.apache.kafka.connect.health.ConnectClusterState
-
Get details about the setup of the Connect cluster.
- clusterState() - Method in interface org.apache.kafka.connect.rest.ConnectRestExtensionContext
-
Provides the cluster state and health information about the connectors and tasks.
- commit() - Method in class org.apache.kafka.connect.source.SourceTask
-
This method is invoked periodically when offsets are committed for this source task.
- commitRecord(SourceRecord, RecordMetadata) - Method in class org.apache.kafka.connect.source.SourceTask
-
Commit an individual
SourceRecord
when the callback from the producer client is received. - commitTransaction() - Method in interface org.apache.kafka.connect.source.TransactionContext
-
Request a transaction commit after the next batch of records from
SourceTask.poll()
is processed. - commitTransaction(SourceRecord) - Method in interface org.apache.kafka.connect.source.TransactionContext
-
Request a transaction commit after a source record is processed.
- config() - Method in class org.apache.kafka.connect.connector.Connector
-
Define the configuration for the connector.
- config() - Method in interface org.apache.kafka.connect.storage.Converter
-
Configuration specification for this converter.
- config() - Method in interface org.apache.kafka.connect.storage.HeaderConverter
-
Configuration specification for this set of header converters.
- config() - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- config() - Method in class org.apache.kafka.connect.storage.StringConverter
- config() - Method in interface org.apache.kafka.connect.transforms.predicates.Predicate
-
Configuration specification for this predicate.
- config() - Method in interface org.apache.kafka.connect.transforms.Transformation
-
Configuration specification for this transformation.
- configDef() - Static method in class org.apache.kafka.connect.storage.StringConverterConfig
- configs() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Get the Task configuration.
- configs() - Method in interface org.apache.kafka.connect.source.SourceTaskContext
-
Get the Task configuration.
- configurable() - Method in interface org.apache.kafka.connect.rest.ConnectRestExtensionContext
-
Provides an implementation of
Configurable
that can be used to register JAX-RS resources. - configure(Map<String, ?>) - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- configure(Map<String, ?>) - Method in class org.apache.kafka.connect.storage.StringConverter
- configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.connect.storage.Converter
-
Configure this class.
- configure(Map<String, ?>, boolean) - Method in class org.apache.kafka.connect.storage.StringConverter
- ConnectClusterDetails - Interface in org.apache.kafka.connect.health
-
Provides immutable Connect cluster information, such as the ID of the backing Kafka cluster.
- ConnectClusterState - Interface in org.apache.kafka.connect.health
-
Provides the ability to lookup connector metadata, including status and configurations, as well as immutable cluster information such as Kafka cluster ID.
- ConnectException - Exception Class in org.apache.kafka.connect.errors
-
ConnectException is the top-level exception type generated by Kafka Connect and connector implementations.
- ConnectException(String) - Constructor for exception class org.apache.kafka.connect.errors.ConnectException
- ConnectException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.ConnectException
- ConnectException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.ConnectException
- ConnectHeaders - Class in org.apache.kafka.connect.header
-
A basic
Headers
implementation. - ConnectHeaders() - Constructor for class org.apache.kafka.connect.header.ConnectHeaders
- ConnectHeaders(Iterable<Header>) - Constructor for class org.apache.kafka.connect.header.ConnectHeaders
- Connector - Class in org.apache.kafka.connect.connector
-
Connectors manage integration of Kafka Connect with another system, either as an input that ingests data into Kafka or an output that passes data to an external system.
- Connector() - Constructor for class org.apache.kafka.connect.connector.Connector
- CONNECTOR - Enum constant in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
-
Transactions will be defined by the connector itself, via a
TransactionContext
. - connectorClass() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
The class of the Connector.
- ConnectorClientConfigOverridePolicy - Interface in org.apache.kafka.connect.connector.policy
-
An interface for enforcing a policy on overriding of Kafka client configs via the connector configs.
- ConnectorClientConfigRequest - Class in org.apache.kafka.connect.connector.policy
- ConnectorClientConfigRequest(String, ConnectorType, Class<? extends Connector>, Map<String, Object>, ConnectorClientConfigRequest.ClientType) - Constructor for class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
- ConnectorClientConfigRequest.ClientType - Enum Class in org.apache.kafka.connect.connector.policy
- connectorConfig(String) - Method in interface org.apache.kafka.connect.health.ConnectClusterState
-
Lookup the current configuration of a connector.
- ConnectorContext - Interface in org.apache.kafka.connect.connector
-
ConnectorContext allows
Connector
s to proactively interact with the Kafka Connect runtime. - connectorHealth(String) - Method in interface org.apache.kafka.connect.health.ConnectClusterState
-
Lookup the current health of a connector and its tasks.
- ConnectorHealth - Class in org.apache.kafka.connect.health
-
Provides basic health information about the connector and its tasks.
- ConnectorHealth(String, ConnectorState, Map<Integer, TaskState>, ConnectorType) - Constructor for class org.apache.kafka.connect.health.ConnectorHealth
- connectorName() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
Name of the connector specified in the connector config.
- connectors() - Method in interface org.apache.kafka.connect.health.ConnectClusterState
-
Get the names of the connectors currently deployed in this cluster.
- connectorState() - Method in class org.apache.kafka.connect.health.ConnectorHealth
-
Provides the current state of the connector.
- ConnectorState - Class in org.apache.kafka.connect.health
-
Describes the status, worker ID, and any errors associated with a connector.
- ConnectorState(String, String, String) - Constructor for class org.apache.kafka.connect.health.ConnectorState
-
Provides an instance of the ConnectorState.
- ConnectorTransactionBoundaries - Enum Class in org.apache.kafka.connect.source
-
An enum to represent the level of support for connector-defined transaction boundaries.
- connectorType() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
-
Type of the Connector.
- ConnectorType - Enum Class in org.apache.kafka.connect.health
-
Enum definition that identifies the type of the connector.
- ConnectorUtils - Class in org.apache.kafka.connect.util
-
Utilities that connector implementations might find useful.
- ConnectorUtils() - Constructor for class org.apache.kafka.connect.util.ConnectorUtils
- ConnectRecord<R> - Class in org.apache.kafka.connect.connector
-
Base class for records containing data to be copied to/from Kafka.
- ConnectRecord(String, Integer, Schema, Object, Schema, Object, Long) - Constructor for class org.apache.kafka.connect.connector.ConnectRecord
- ConnectRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Constructor for class org.apache.kafka.connect.connector.ConnectRecord
- ConnectRestExtension - Interface in org.apache.kafka.connect.rest
-
A plugin interface to allow registration of new JAX-RS resources like Filters, REST endpoints, providers, etc.
- ConnectRestExtensionContext - Interface in org.apache.kafka.connect.rest
-
The interface provides the ability for
ConnectRestExtension
implementations to access the JAX-RSConfigurable
and cluster stateConnectClusterState
. - ConnectSchema - Class in org.apache.kafka.connect.data
- ConnectSchema(Schema.Type) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
-
Construct a default schema for a primitive type.
- ConnectSchema(Schema.Type, boolean, Object, String, Integer, String) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
-
Construct a Schema for a primitive type, setting schema parameters, struct fields, and key and value schemas to null.
- ConnectSchema(Schema.Type, boolean, Object, String, Integer, String, Map<String, String>, List<Field>, Schema, Schema) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
-
Construct a Schema.
- CONSUMER - Enum constant in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- Converter - Interface in org.apache.kafka.connect.storage
-
The Converter interface provides support for translating between Kafka Connect's runtime data format and byte[].
- ConverterConfig - Class in org.apache.kafka.connect.storage
-
Abstract class that defines the configuration options for
Converter
andHeaderConverter
instances. - ConverterType - Enum Class in org.apache.kafka.connect.storage
-
The type of
Converter
andHeaderConverter
. - convertToBoolean(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to a
Schema.Type.BOOLEAN
value. - convertToByte(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to an
Schema.Type.INT8
byte value. - convertToDate(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to a
date
value. - convertToDecimal(Schema, Object, int) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to a
decimal
value. - convertToDouble(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to a
Schema.Type.FLOAT64
double value. - convertToFloat(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to a
Schema.Type.FLOAT32
float value. - convertToInteger(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to an
Schema.Type.INT32
int value. - convertToList(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to an
Schema.Type.ARRAY
value. - convertToLong(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to an
Schema.Type.INT64
long value. - convertToMap(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to a
Schema.Type.MAP
value. - convertToShort(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to an
Schema.Type.INT16
short value. - convertToString(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to a
Schema.Type.STRING
value. - convertToStruct(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to a
Schema.Type.STRUCT
value. - convertToTime(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to a
time
value. - convertToTimestamp(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
-
Convert the specified value to a
timestamp
value.
D
- DataException - Exception Class in org.apache.kafka.connect.errors
-
Base class for all Kafka Connect data API exceptions.
- DataException(String) - Constructor for exception class org.apache.kafka.connect.errors.DataException
- DataException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.DataException
- DataException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.DataException
- Date - Class in org.apache.kafka.connect.data
-
A date representing a calendar day with no time of day or timezone.
- Date() - Constructor for class org.apache.kafka.connect.data.Date
- dateFormatFor(Date) - Static method in class org.apache.kafka.connect.data.Values
- Decimal - Class in org.apache.kafka.connect.data
-
An arbitrary-precision signed decimal number.
- Decimal() - Constructor for class org.apache.kafka.connect.data.Decimal
- DEFAULT - Static variable in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
-
The default transaction boundary style that will be used for source connectors when no style is explicitly configured.
- defaultValue() - Method in class org.apache.kafka.connect.data.ConnectSchema
- defaultValue() - Method in interface org.apache.kafka.connect.data.Schema
- defaultValue() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- defaultValue(Object) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set the default value for this schema.
- doc() - Method in class org.apache.kafka.connect.data.ConnectSchema
- doc() - Method in interface org.apache.kafka.connect.data.Schema
- doc() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- doc(String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set the documentation for this schema.
- duplicate() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- duplicate() - Method in interface org.apache.kafka.connect.header.Headers
-
Create a copy of this
Headers
object.
E
- encoding() - Method in class org.apache.kafka.connect.storage.StringConverterConfig
-
Get the string encoding.
- ENCODING_CONFIG - Static variable in class org.apache.kafka.connect.storage.StringConverterConfig
- ENCODING_DEFAULT - Static variable in class org.apache.kafka.connect.storage.StringConverterConfig
- equals(Object) - Method in class org.apache.kafka.connect.connector.ConnectRecord
- equals(Object) - Method in class org.apache.kafka.connect.data.ConnectSchema
- equals(Object) - Method in class org.apache.kafka.connect.data.Field
- equals(Object) - Method in class org.apache.kafka.connect.data.SchemaAndValue
- equals(Object) - Method in class org.apache.kafka.connect.data.Struct
- equals(Object) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- equals(Object) - Method in class org.apache.kafka.connect.health.AbstractState
- equals(Object) - Method in class org.apache.kafka.connect.health.ConnectorHealth
- equals(Object) - Method in class org.apache.kafka.connect.health.TaskState
- equals(Object) - Method in class org.apache.kafka.connect.sink.SinkRecord
- equals(Object) - Method in class org.apache.kafka.connect.source.SourceRecord
- errantRecordReporter() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Get the reporter to which the sink task can report problematic or failed
records
passed to theSinkTask.put(java.util.Collection)
method. - ErrantRecordReporter - Interface in org.apache.kafka.connect.sink
-
Component that a
SinkTask
can use to report problematic records (and their corresponding problems) as it writes them throughSinkTask.put(java.util.Collection)
. - exactlyOnceSupport(Map<String, String>) - Method in class org.apache.kafka.connect.source.SourceConnector
-
Signals whether the connector supports exactly-once semantics with a proposed configuration.
- ExactlyOnceSupport - Enum Class in org.apache.kafka.connect.source
-
An enum to represent the level of support for exactly-once semantics from a source connector.
F
- field(String) - Method in class org.apache.kafka.connect.data.ConnectSchema
- field(String) - Method in interface org.apache.kafka.connect.data.Schema
-
Get a
Field
for this Schema by name. - field(String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
- field(String, Schema) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Add a field to this
Schema.Type.STRUCT
schema. - Field - Class in org.apache.kafka.connect.data
- Field(String, int, Schema) - Constructor for class org.apache.kafka.connect.data.Field
- fields() - Method in class org.apache.kafka.connect.data.ConnectSchema
- fields() - Method in interface org.apache.kafka.connect.data.Schema
-
Get the list of Fields for this Schema.
- fields() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Get the list of fields for this Schema.
- float32() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- FLOAT32 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
32-bit IEEE 754 floating point number
- FLOAT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- float64() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- FLOAT64 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
64-bit IEEE 754 floating point number
- FLOAT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- flush(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
Flush all records that have been
SinkTask.put(Collection)
for the specified topic-partitions. - fromConnectData(String, Headers, Schema, Object) - Method in interface org.apache.kafka.connect.storage.Converter
-
Convert a Kafka Connect data object to a native object for serialization, potentially using the supplied topic and headers in the record as necessary.
- fromConnectData(String, Schema, Object) - Method in interface org.apache.kafka.connect.storage.Converter
-
Convert a Kafka Connect data object to a native object for serialization.
- fromConnectData(String, Schema, Object) - Method in class org.apache.kafka.connect.storage.StringConverter
- fromConnectHeader(String, String, Schema, Object) - Method in interface org.apache.kafka.connect.storage.HeaderConverter
- fromConnectHeader(String, String, Schema, Object) - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- fromConnectHeader(String, String, Schema, Object) - Method in class org.apache.kafka.connect.storage.StringConverter
- fromLogical(Schema, BigDecimal) - Static method in class org.apache.kafka.connect.data.Decimal
-
Convert a value from its logical format (
BigDecimal
) to its encoded format (byte[]). - fromLogical(Schema, Date) - Static method in class org.apache.kafka.connect.data.Date
-
Convert a value from its logical format (
Date
) to its encoded format (int). - fromLogical(Schema, Date) - Static method in class org.apache.kafka.connect.data.Time
-
Convert a value from its logical format (
Date
) to its encoded format (int). - fromLogical(Schema, Date) - Static method in class org.apache.kafka.connect.data.Timestamp
-
Convert a value from its logical format (
Date
) to its encoded format (long). - fromProperty(String) - Static method in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
-
Parse a
SourceTask.TransactionBoundary
from the given string.
G
- get(String) - Method in class org.apache.kafka.connect.data.Struct
-
Get the value of a field, returning the default value if no value has been set yet and a default value is specified in the field's schema.
- get(Field) - Method in class org.apache.kafka.connect.data.Struct
-
Get the value of a field, returning the default value if no value has been set yet and a default value is specified in the field's schema.
- getArray(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a List. - getBoolean(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a Boolean. - getBytes(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a byte[]. - getFloat32(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a Float. - getFloat64(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a Double. - getInt16(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a Short. - getInt32(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to an Integer. - getInt64(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a Long. - getInt8(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a Byte. - getMap(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a Map. - getName() - Method in enum class org.apache.kafka.connect.data.Schema.Type
- getName() - Method in enum class org.apache.kafka.connect.storage.ConverterType
- getString(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a String. - getStruct(String) - Method in class org.apache.kafka.connect.data.Struct
-
Equivalent to calling
Struct.get(String)
and casting the result to a Struct. - getWithoutDefault(String) - Method in class org.apache.kafka.connect.data.Struct
-
Get the underlying raw value for the field without accounting for default values.
- groupPartitions(List<T>, int) - Static method in class org.apache.kafka.connect.util.ConnectorUtils
-
Given a list of elements and a target number of groups, generates list of groups of elements to match the target number of groups, spreading them evenly among the groups.
H
- hashCode() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- hashCode() - Method in class org.apache.kafka.connect.data.ConnectSchema
- hashCode() - Method in class org.apache.kafka.connect.data.Field
- hashCode() - Method in class org.apache.kafka.connect.data.SchemaAndValue
- hashCode() - Method in class org.apache.kafka.connect.data.Struct
- hashCode() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- hashCode() - Method in class org.apache.kafka.connect.health.AbstractState
- hashCode() - Method in class org.apache.kafka.connect.health.ConnectorHealth
- hashCode() - Method in class org.apache.kafka.connect.health.TaskState
- hashCode() - Method in class org.apache.kafka.connect.sink.SinkRecord
- hashCode() - Method in class org.apache.kafka.connect.source.SourceRecord
- Header - Interface in org.apache.kafka.connect.header
-
A
Header
is a key-value pair, and multiple headers can be included with the key, value, and timestamp in each Kafka message. - HEADER - Enum constant in enum class org.apache.kafka.connect.storage.ConverterType
- HeaderConverter - Interface in org.apache.kafka.connect.storage
-
The HeaderConverter interface provides support for translating between Kafka Connect's runtime data format and byte[].
- headers() - Method in class org.apache.kafka.connect.connector.ConnectRecord
-
Get the headers for this record.
- Headers - Interface in org.apache.kafka.connect.header
-
A mutable ordered collection of
Header
objects. - Headers.HeaderTransform - Interface in org.apache.kafka.connect.header
-
A function to transform the supplied
Header
.
I
- IllegalWorkerStateException - Exception Class in org.apache.kafka.connect.errors
-
Indicates that a method has been invoked illegally or at an invalid time by a connector or task.
- IllegalWorkerStateException(String) - Constructor for exception class org.apache.kafka.connect.errors.IllegalWorkerStateException
- IllegalWorkerStateException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.IllegalWorkerStateException
- IllegalWorkerStateException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.IllegalWorkerStateException
- index() - Method in class org.apache.kafka.connect.data.Field
-
Get the index of this field within the struct.
- inferSchema(Object) - Static method in class org.apache.kafka.connect.data.Values
-
If possible infer a schema for the given value.
- initialize(ConnectorContext) - Method in class org.apache.kafka.connect.connector.Connector
-
Initialize this connector, using the provided ConnectorContext to notify the runtime of input configuration changes.
- initialize(ConnectorContext, List<Map<String, String>>) - Method in class org.apache.kafka.connect.connector.Connector
-
Initialize this connector, using the provided ConnectorContext to notify the runtime of input configuration changes and using the provided set of Task configurations.
- initialize(SinkTaskContext) - Method in class org.apache.kafka.connect.sink.SinkTask
-
Initialize the context of this task.
- initialize(SourceTaskContext) - Method in class org.apache.kafka.connect.source.SourceTask
-
Initialize this SourceTask with the specified context object.
- int16() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- INT16 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
16-bit signed integer
- INT16_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- int32() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- INT32 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
32-bit signed integer
- INT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- int64() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- INT64 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
64-bit signed integer
- INT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- int8() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- INT8 - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
8-bit signed integer
- INT8_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- INTERVAL - Enum constant in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
-
Transactions will be started and committed on a user-defined time interval.
- isEmpty() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- isEmpty() - Method in interface org.apache.kafka.connect.header.Headers
-
Determine whether this object has no headers.
- isOptional() - Method in class org.apache.kafka.connect.data.ConnectSchema
- isOptional() - Method in interface org.apache.kafka.connect.data.Schema
- isOptional() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- isPrimitive() - Method in enum class org.apache.kafka.connect.data.Schema.Type
- iterator() - Method in class org.apache.kafka.connect.header.ConnectHeaders
K
- kafkaClusterId() - Method in interface org.apache.kafka.connect.health.ConnectClusterDetails
-
Get the cluster ID of the Kafka cluster backing this Connect cluster.
- kafkaOffset() - Method in class org.apache.kafka.connect.sink.SinkRecord
- kafkaPartition() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- key() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- key() - Method in interface org.apache.kafka.connect.header.Header
-
The header's key, which is not necessarily unique within the set of headers on a Kafka message.
- KEY - Enum constant in enum class org.apache.kafka.connect.storage.ConverterType
- keySchema() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- keySchema() - Method in class org.apache.kafka.connect.data.ConnectSchema
- keySchema() - Method in interface org.apache.kafka.connect.data.Schema
-
Get the key schema for this map schema.
- keySchema() - Method in class org.apache.kafka.connect.data.SchemaBuilder
L
- lastWithName(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- lastWithName(String) - Method in interface org.apache.kafka.connect.header.Headers
-
Return the last
Header
with the specified key. - LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Date
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Decimal
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Time
- LOGICAL_NAME - Static variable in class org.apache.kafka.connect.data.Timestamp
M
- map(Schema, Schema) - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- MAP - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
A mapping from keys to values.
N
- name() - Method in class org.apache.kafka.connect.data.ConnectSchema
- name() - Method in class org.apache.kafka.connect.data.Field
-
Get the name of this field.
- name() - Method in interface org.apache.kafka.connect.data.Schema
- name() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- name() - Method in class org.apache.kafka.connect.health.ConnectorHealth
-
Provides the name of the connector.
- name(String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set the name of this schema.
- newConfigDef() - Static method in class org.apache.kafka.connect.storage.ConverterConfig
-
Create a new
ConfigDef
instance containing the configurations defined by ConverterConfig. - newRecord(String, Integer, Schema, Object, Schema, Object, Long) - Method in class org.apache.kafka.connect.connector.ConnectRecord
-
Create a new record of the same type as itself, with the specified parameter values.
- newRecord(String, Integer, Schema, Object, Schema, Object, Long) - Method in class org.apache.kafka.connect.sink.SinkRecord
- newRecord(String, Integer, Schema, Object, Schema, Object, Long) - Method in class org.apache.kafka.connect.source.SourceRecord
- newRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Method in class org.apache.kafka.connect.connector.ConnectRecord
-
Create a new record of the same type as itself, with the specified parameter values.
- newRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Method in class org.apache.kafka.connect.sink.SinkRecord
- newRecord(String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Method in class org.apache.kafka.connect.source.SourceRecord
- NotFoundException - Exception Class in org.apache.kafka.connect.errors
-
Indicates that an operation attempted to modify or delete a connector or task that is not present on the worker.
- NotFoundException(String) - Constructor for exception class org.apache.kafka.connect.errors.NotFoundException
- NotFoundException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.NotFoundException
- NotFoundException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.NotFoundException
- NULL - Static variable in class org.apache.kafka.connect.data.SchemaAndValue
O
- offset(Map<String, T>) - Method in interface org.apache.kafka.connect.storage.OffsetStorageReader
-
Get the offset for the specified partition.
- offset(Map<TopicPartition, Long>) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Reset the consumer offsets for the given topic partitions.
- offset(TopicPartition, long) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Reset the consumer offsets for the given topic partition.
- offsets(Collection<Map<String, T>>) - Method in interface org.apache.kafka.connect.storage.OffsetStorageReader
-
Get a set of offsets for the specified partition identifiers.
- offsetStorageReader() - Method in interface org.apache.kafka.connect.source.SourceConnectorContext
-
Returns the
OffsetStorageReader
for this SourceConnectorContext. - offsetStorageReader() - Method in interface org.apache.kafka.connect.source.SourceTaskContext
-
Get the OffsetStorageReader for this SourceTask.
- OffsetStorageReader - Interface in org.apache.kafka.connect.storage
-
OffsetStorageReader provides access to the offset storage used by sources.
- open(Collection<TopicPartition>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
The SinkTask uses this method to create writers for newly assigned partitions in case of partition rebalance.
- optional() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set this schema as optional.
- OPTIONAL_BOOLEAN_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_BYTES_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_FLOAT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_FLOAT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_INT16_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_INT32_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_INT64_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_INT8_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- OPTIONAL_STRING_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- org.apache.kafka.connect.components - package org.apache.kafka.connect.components
-
Provides common interfaces used to describe pluggable components.
- org.apache.kafka.connect.connector - package org.apache.kafka.connect.connector
-
Provides interfaces for Connector and Task implementations.
- org.apache.kafka.connect.connector.policy - package org.apache.kafka.connect.connector.policy
-
Provides pluggable interfaces for policies controlling how users can configure connectors.
- org.apache.kafka.connect.data - package org.apache.kafka.connect.data
-
Provides classes for representing data and schemas handled by Connect.
- org.apache.kafka.connect.errors - package org.apache.kafka.connect.errors
-
Provides common exception classes for Connect, used by the framework and plugins to communicate failures.
- org.apache.kafka.connect.header - package org.apache.kafka.connect.header
-
Provides an API for application-defined metadata attached to Connect records.
- org.apache.kafka.connect.health - package org.apache.kafka.connect.health
-
Provides an API for describing the state of a running Connect cluster to
ConnectRestExtension
instances. - org.apache.kafka.connect.rest - package org.apache.kafka.connect.rest
-
Provides a pluggable interface for altering the behavior of the Connect REST API.
- org.apache.kafka.connect.sink - package org.apache.kafka.connect.sink
-
Provides an API for implementing sink connectors which write Kafka records to external applications.
- org.apache.kafka.connect.source - package org.apache.kafka.connect.source
-
Provides an API for implementing source connectors which read data from external applications into Kafka.
- org.apache.kafka.connect.storage - package org.apache.kafka.connect.storage
-
Provides pluggable interfaces and some implementations for (de)serializing data to and from Kafka
- org.apache.kafka.connect.transforms - package org.apache.kafka.connect.transforms
-
Provides a pluggable interface for altering data which is being moved by Connect.
- org.apache.kafka.connect.transforms.predicates - package org.apache.kafka.connect.transforms.predicates
-
Provides a pluggable interface for describing when a
Transformation
should be applied to a record. - org.apache.kafka.connect.util - package org.apache.kafka.connect.util
-
Provides common utilities that can be used in component implementations.
- originalKafkaOffset() - Method in class org.apache.kafka.connect.sink.SinkRecord
-
Get the original offset for this sink record, before any
transformations
were applied. - originalKafkaPartition() - Method in class org.apache.kafka.connect.sink.SinkRecord
-
Get the original topic partition for this sink record, before any
transformations
were applied. - originalTopic() - Method in class org.apache.kafka.connect.sink.SinkRecord
-
Get the original topic for this sink record, before any
transformations
were applied.
P
- parameter(String, String) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set a schema parameter.
- parameters() - Method in class org.apache.kafka.connect.data.ConnectSchema
- parameters() - Method in interface org.apache.kafka.connect.data.Schema
-
Get a map of schema parameters.
- parameters() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- parameters(Map<String, String>) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set schema parameters.
- parseString(String) - Static method in class org.apache.kafka.connect.data.Values
-
Parse the specified string representation of a value into its schema and value.
- pause(TopicPartition...) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Pause consumption of messages from the specified TopicPartitions.
- poll() - Method in class org.apache.kafka.connect.source.SourceTask
-
Poll this source task for new records.
- POLL - Enum constant in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
-
A new transaction will be started and committed for every batch of records returned by
SourceTask.poll()
. - preCommit(Map<TopicPartition, OffsetAndMetadata>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
Pre-commit hook invoked prior to an offset commit.
- Predicate<R> - Interface in org.apache.kafka.connect.transforms.predicates
-
A predicate on records.
- PRODUCER - Enum constant in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- project(Schema, Object, Schema) - Static method in class org.apache.kafka.connect.data.SchemaProjector
-
This method projects a value between compatible schemas and throws exceptions when non-compatible schemas are provided
- put(String, Object) - Method in class org.apache.kafka.connect.data.Struct
-
Set the value of a field.
- put(Collection<SinkRecord>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
Put the records in the sink.
- put(Field, Object) - Method in class org.apache.kafka.connect.data.Struct
-
Set the value of a field.
R
- raiseError(Exception) - Method in interface org.apache.kafka.connect.connector.ConnectorContext
-
Raise an unrecoverable exception to the Connect framework.
- reconfigure(Map<String, String>) - Method in class org.apache.kafka.connect.connector.Connector
-
Reconfigure this Connector.
- register(ConnectRestExtensionContext) - Method in interface org.apache.kafka.connect.rest.ConnectRestExtension
-
ConnectRestExtension implementations can register custom JAX-RS resources via this method.
- remove(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- remove(String) - Method in interface org.apache.kafka.connect.header.Headers
- rename(String) - Method in interface org.apache.kafka.connect.header.Header
-
Return a new
Header
object that has the same schema and value but with the supplied key. - report(SinkRecord, Throwable) - Method in interface org.apache.kafka.connect.sink.ErrantRecordReporter
-
Report a problematic record and the corresponding error to be written to the sink connector's dead letter queue (DLQ).
- requestCommit() - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Request an offset commit.
- requestTaskReconfiguration() - Method in interface org.apache.kafka.connect.connector.ConnectorContext
-
Requests that the runtime reconfigure the Tasks for this source.
- required() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set this schema as required.
- resume(TopicPartition...) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Resume consumption of messages from previously paused TopicPartitions.
- retainLatest() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- retainLatest() - Method in interface org.apache.kafka.connect.header.Headers
-
Removes all but the last
Header
object with each key. - retainLatest(String) - Method in class org.apache.kafka.connect.header.ConnectHeaders
- retainLatest(String) - Method in interface org.apache.kafka.connect.header.Headers
- RetriableException - Exception Class in org.apache.kafka.connect.errors
-
An exception that indicates the operation can be reattempted.
- RetriableException(String) - Constructor for exception class org.apache.kafka.connect.errors.RetriableException
- RetriableException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.RetriableException
- RetriableException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.RetriableException
S
- SCALE_FIELD - Static variable in class org.apache.kafka.connect.data.Decimal
- schema() - Method in class org.apache.kafka.connect.data.ConnectSchema
- schema() - Method in class org.apache.kafka.connect.data.Field
-
Get the schema of this field
- schema() - Method in interface org.apache.kafka.connect.data.Schema
-
Return a concrete instance of the
Schema
- schema() - Method in class org.apache.kafka.connect.data.SchemaAndValue
- schema() - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Return a concrete instance of the
Schema
specified by this builder - schema() - Method in class org.apache.kafka.connect.data.Struct
-
Get the schema for this Struct.
- schema() - Method in interface org.apache.kafka.connect.header.Header
-
Return the
Schema
associated with this header, if there is one. - schema(int) - Static method in class org.apache.kafka.connect.data.Decimal
- Schema - Interface in org.apache.kafka.connect.data
-
Definition of an abstract data type.
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Date
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Time
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Timestamp
- Schema.Type - Enum Class in org.apache.kafka.connect.data
-
The type of a schema.
- SchemaAndValue - Class in org.apache.kafka.connect.data
-
A composite containing a
Schema
and associated value - SchemaAndValue(Schema, Object) - Constructor for class org.apache.kafka.connect.data.SchemaAndValue
- SchemaBuilder - Class in org.apache.kafka.connect.data
-
SchemaBuilder provides a fluent API for constructing
Schema
objects. - SchemaBuilder(Schema.Type) - Constructor for class org.apache.kafka.connect.data.SchemaBuilder
- SchemaBuilderException - Exception Class in org.apache.kafka.connect.errors
-
Indicates an error while building a schema via
SchemaBuilder
- SchemaBuilderException(String) - Constructor for exception class org.apache.kafka.connect.errors.SchemaBuilderException
- SchemaBuilderException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.SchemaBuilderException
- SchemaBuilderException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.SchemaBuilderException
- SchemaProjector - Class in org.apache.kafka.connect.data
-
SchemaProjector is a utility to project a value between compatible schemas and throw exceptions when non compatible schemas are provided.
- SchemaProjector() - Constructor for class org.apache.kafka.connect.data.SchemaProjector
- SchemaProjectorException - Exception Class in org.apache.kafka.connect.errors
-
Indicates an error while projecting a schema via
SchemaProjector
- SchemaProjectorException(String) - Constructor for exception class org.apache.kafka.connect.errors.SchemaProjectorException
- SchemaProjectorException(String, Throwable) - Constructor for exception class org.apache.kafka.connect.errors.SchemaProjectorException
- SchemaProjectorException(Throwable) - Constructor for exception class org.apache.kafka.connect.errors.SchemaProjectorException
- schemaType(Class<?>) - Static method in class org.apache.kafka.connect.data.ConnectSchema
-
Get the
Schema.Type
associated with the given class. - SimpleHeaderConverter - Class in org.apache.kafka.connect.storage
-
A
HeaderConverter
that serializes header values as strings and that deserializes header values to the most appropriate numeric, boolean, array, or map representation. - SimpleHeaderConverter() - Constructor for class org.apache.kafka.connect.storage.SimpleHeaderConverter
- SINK - Enum constant in enum class org.apache.kafka.connect.health.ConnectorType
-
Identifies a sink connector
- SinkConnector - Class in org.apache.kafka.connect.sink
-
SinkConnectors implement the Connector interface to send Kafka data to another system.
- SinkConnector() - Constructor for class org.apache.kafka.connect.sink.SinkConnector
- SinkConnectorContext - Interface in org.apache.kafka.connect.sink
-
A context to allow a
SinkConnector
to interact with the Kafka Connect runtime. - SinkRecord - Class in org.apache.kafka.connect.sink
-
SinkRecord is a
ConnectRecord
that has been read from Kafka and includes the original Kafka record's topic, partition and offset (before anytransformations
have been applied) in addition to the standard fields. - SinkRecord(String, int, Schema, Object, Schema, Object, long) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
- SinkRecord(String, int, Schema, Object, Schema, Object, long, Long, TimestampType) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
- SinkRecord(String, int, Schema, Object, Schema, Object, long, Long, TimestampType, Iterable<Header>) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
- SinkRecord(String, int, Schema, Object, Schema, Object, long, Long, TimestampType, Iterable<Header>, String, Integer, long) - Constructor for class org.apache.kafka.connect.sink.SinkRecord
-
This constructor is intended for use by the Connect runtime only and plugins (sink connectors or transformations) should not use this directly outside testing code.
- SinkTask - Class in org.apache.kafka.connect.sink
-
SinkTask is a Task that takes records loaded from Kafka and sends them to another system.
- SinkTask() - Constructor for class org.apache.kafka.connect.sink.SinkTask
- SinkTaskContext - Interface in org.apache.kafka.connect.sink
-
Context passed to
SinkTask
s, allowing them to access utilities in the Kafka Connect runtime. - size() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- size() - Method in interface org.apache.kafka.connect.header.Headers
-
Get the number of headers in this object.
- SOURCE - Enum constant in enum class org.apache.kafka.connect.health.ConnectorType
-
Identifies a source connector
- SourceConnector - Class in org.apache.kafka.connect.source
-
SourceConnectors implement the connector interface to pull data from another system and send it to Kafka.
- SourceConnector() - Constructor for class org.apache.kafka.connect.source.SourceConnector
- SourceConnectorContext - Interface in org.apache.kafka.connect.source
-
A context to allow a
SourceConnector
to interact with the Kafka Connect runtime. - sourceOffset() - Method in class org.apache.kafka.connect.source.SourceRecord
- sourcePartition() - Method in class org.apache.kafka.connect.source.SourceRecord
- SourceRecord - Class in org.apache.kafka.connect.source
-
SourceRecords are generated by
SourceTask
s and passed to Kafka Connect for storage in Kafka. - SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object, Schema, Object, Long) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Integer, Schema, Object, Schema, Object, Long, Iterable<Header>) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceRecord(Map<String, ?>, Map<String, ?>, String, Schema, Object, Schema, Object) - Constructor for class org.apache.kafka.connect.source.SourceRecord
- SourceTask - Class in org.apache.kafka.connect.source
-
SourceTask is a Task that pulls records from another system for storage in Kafka.
- SourceTask() - Constructor for class org.apache.kafka.connect.source.SourceTask
- SourceTask.TransactionBoundary - Enum Class in org.apache.kafka.connect.source
-
Represents the permitted values for the
SourceTask.TRANSACTION_BOUNDARY_CONFIG
property. - SourceTaskContext - Interface in org.apache.kafka.connect.source
-
SourceTaskContext is provided to SourceTasks to allow them to interact with the underlying runtime.
- start(Map<String, String>) - Method in class org.apache.kafka.connect.connector.Connector
-
Start this Connector.
- start(Map<String, String>) - Method in interface org.apache.kafka.connect.connector.Task
-
Start the Task
- start(Map<String, String>) - Method in class org.apache.kafka.connect.sink.SinkTask
-
Start the Task.
- start(Map<String, String>) - Method in class org.apache.kafka.connect.source.SourceTask
-
Start the Task.
- state() - Method in class org.apache.kafka.connect.health.AbstractState
-
Provides the current state of the connector or task.
- stop() - Method in class org.apache.kafka.connect.connector.Connector
-
Stop this connector.
- stop() - Method in interface org.apache.kafka.connect.connector.Task
-
Stop this task.
- stop() - Method in class org.apache.kafka.connect.sink.SinkTask
-
Perform any cleanup to stop this task.
- stop() - Method in class org.apache.kafka.connect.source.SourceTask
-
Signal this SourceTask to stop.
- string() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- STRING - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
Character string that supports all Unicode characters.
- STRING_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
- StringConverter - Class in org.apache.kafka.connect.storage
-
Converter
andHeaderConverter
implementation that only supports serializing to strings. - StringConverter() - Constructor for class org.apache.kafka.connect.storage.StringConverter
- StringConverterConfig - Class in org.apache.kafka.connect.storage
-
Configuration options for
StringConverter
instances. - StringConverterConfig(Map<String, ?>) - Constructor for class org.apache.kafka.connect.storage.StringConverterConfig
- struct() - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- Struct - Class in org.apache.kafka.connect.data
-
A structured record containing a set of named fields with values, each field using an independent
Schema
. - Struct(Schema) - Constructor for class org.apache.kafka.connect.data.Struct
-
Create a new Struct for this
Schema
- STRUCT - Enum constant in enum class org.apache.kafka.connect.data.Schema.Type
-
A structured record containing a set of named fields, each field using a fixed, independent
Schema
. - SUPPORTED - Enum constant in enum class org.apache.kafka.connect.source.ConnectorTransactionBoundaries
-
Signals that a connector can define its own transaction boundaries.
- SUPPORTED - Enum constant in enum class org.apache.kafka.connect.source.ExactlyOnceSupport
-
Signals that a connector supports exactly-once semantics.
T
- Task - Interface in org.apache.kafka.connect.connector
-
Tasks contain the code that actually copies data to/from another system.
- taskClass() - Method in class org.apache.kafka.connect.connector.Connector
-
Returns the
Task
implementation for this Connector. - taskConfigs(int) - Method in class org.apache.kafka.connect.connector.Connector
-
Returns a set of configurations for Tasks based on the current configuration, producing at most
maxTasks
configurations. - taskId() - Method in class org.apache.kafka.connect.health.TaskState
-
Provides the ID of the task.
- tasksState() - Method in class org.apache.kafka.connect.health.ConnectorHealth
-
Provides the current state of the connector tasks.
- TaskState - Class in org.apache.kafka.connect.health
-
Describes the state, IDs, and any errors of a connector task.
- TaskState(int, String, String, String) - Constructor for class org.apache.kafka.connect.health.TaskState
-
Provides an instance of
TaskState
. - test(R) - Method in interface org.apache.kafka.connect.transforms.predicates.Predicate
-
Returns whether the given record satisfies this predicate.
- Time - Class in org.apache.kafka.connect.data
-
A time representing a specific point in a day, not tied to any specific date.
- Time() - Constructor for class org.apache.kafka.connect.data.Time
- timeout(long) - Method in interface org.apache.kafka.connect.sink.SinkTaskContext
-
Set the timeout in milliseconds.
- timestamp() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- Timestamp - Class in org.apache.kafka.connect.data
-
A timestamp representing an absolute time, without timezone information.
- Timestamp() - Constructor for class org.apache.kafka.connect.data.Timestamp
- timestampType() - Method in class org.apache.kafka.connect.sink.SinkRecord
- toConnectData(String, byte[]) - Method in interface org.apache.kafka.connect.storage.Converter
-
Convert a native object to a Kafka Connect data object for deserialization.
- toConnectData(String, byte[]) - Method in class org.apache.kafka.connect.storage.StringConverter
- toConnectData(String, Headers, byte[]) - Method in interface org.apache.kafka.connect.storage.Converter
-
Convert a native object to a Kafka Connect data object for deserialization, potentially using the supplied topic and headers in the record as necessary.
- toConnectHeader(String, String, byte[]) - Method in interface org.apache.kafka.connect.storage.HeaderConverter
-
Convert the header name and byte array value into a
Header
object. - toConnectHeader(String, String, byte[]) - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- toConnectHeader(String, String, byte[]) - Method in class org.apache.kafka.connect.storage.StringConverter
- toLogical(Schema, byte[]) - Static method in class org.apache.kafka.connect.data.Decimal
-
Convert a value from its encoded format (byte[]) to its logical format (
BigDecimal
). - toLogical(Schema, int) - Static method in class org.apache.kafka.connect.data.Date
-
Convert a value from its encoded format (int) to its logical format (
Date
). - toLogical(Schema, int) - Static method in class org.apache.kafka.connect.data.Time
-
Convert a value from its encoded format (int) to its logical format (
Date
). - toLogical(Schema, long) - Static method in class org.apache.kafka.connect.data.Timestamp
-
Convert a value from its encoded format (long) to its logical format (
Date
). - topic() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- TOPICS_CONFIG - Static variable in class org.apache.kafka.connect.sink.SinkConnector
-
Configuration key for the list of input topics for this connector.
- TOPICS_CONFIG - Static variable in class org.apache.kafka.connect.sink.SinkTask
-
The configuration key that provides the list of topics that are inputs for this SinkTask.
- TOPICS_REGEX_CONFIG - Static variable in class org.apache.kafka.connect.sink.SinkTask
-
The configuration key that provides a regex specifying which topics to include as inputs for this SinkTask.
- toString() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- toString() - Method in class org.apache.kafka.connect.data.ConnectSchema
- toString() - Method in class org.apache.kafka.connect.data.Field
- toString() - Method in class org.apache.kafka.connect.data.SchemaAndValue
- toString() - Method in class org.apache.kafka.connect.data.Struct
- toString() - Method in class org.apache.kafka.connect.header.ConnectHeaders
- toString() - Method in class org.apache.kafka.connect.health.ConnectorHealth
- toString() - Method in class org.apache.kafka.connect.health.ConnectorState
- toString() - Method in enum class org.apache.kafka.connect.health.ConnectorType
- toString() - Method in class org.apache.kafka.connect.health.TaskState
- toString() - Method in class org.apache.kafka.connect.sink.SinkRecord
- toString() - Method in class org.apache.kafka.connect.source.SourceRecord
- toString() - Method in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- traceMessage() - Method in class org.apache.kafka.connect.health.AbstractState
-
The error message associated with the connector or task.
- TRANSACTION_BOUNDARY_CONFIG - Static variable in class org.apache.kafka.connect.source.SourceTask
-
The configuration key that determines how source tasks will define transaction boundaries when exactly-once support is enabled.
- transactionContext() - Method in interface org.apache.kafka.connect.source.SourceTaskContext
-
Get a
TransactionContext
that can be used to define producer transaction boundaries when exactly-once support is enabled for the connector. - TransactionContext - Interface in org.apache.kafka.connect.source
-
Provided to source tasks to allow them to define their own producer transaction boundaries when exactly-once support is enabled.
- Transformation<R> - Interface in org.apache.kafka.connect.transforms
-
Single message transformation for Kafka Connect record types.
- type() - Method in class org.apache.kafka.connect.data.ConnectSchema
- type() - Method in interface org.apache.kafka.connect.data.Schema
- type() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- type() - Method in class org.apache.kafka.connect.health.ConnectorHealth
-
Provides the type of the connector.
- type() - Method in class org.apache.kafka.connect.storage.ConverterConfig
-
Get the type of converter as defined by the
ConverterConfig.TYPE_CONFIG
configuration. - type(Schema.Type) - Static method in class org.apache.kafka.connect.data.SchemaBuilder
-
Create a SchemaBuilder for the specified type.
- TYPE_CONFIG - Static variable in class org.apache.kafka.connect.storage.ConverterConfig
U
- UNKNOWN - Enum constant in enum class org.apache.kafka.connect.health.ConnectorType
-
Identifies a connector whose type could not be inferred
- UNSUPPORTED - Enum constant in enum class org.apache.kafka.connect.source.ConnectorTransactionBoundaries
-
Signals that a connector cannot define its own transaction boundaries.
- UNSUPPORTED - Enum constant in enum class org.apache.kafka.connect.source.ExactlyOnceSupport
-
Signals that a connector does not support exactly-once semantics.
V
- validate() - Method in class org.apache.kafka.connect.data.Struct
-
Validates that this struct has filled in all the necessary data with valid values.
- validate(Map<String, String>) - Method in class org.apache.kafka.connect.connector.Connector
-
Validate the connector configuration values against configuration definitions.
- validate(ConnectorClientConfigRequest) - Method in interface org.apache.kafka.connect.connector.policy.ConnectorClientConfigOverridePolicy
-
Workers will invoke this before configuring per-connector Kafka admin, producer, and consumer client instances to validate if all the overridden client configurations are allowed per the policy implementation.
- validateValue(Object) - Method in class org.apache.kafka.connect.data.ConnectSchema
-
Validate that the value can be used for this schema, i.e.
- validateValue(String, Schema, Object) - Static method in class org.apache.kafka.connect.data.ConnectSchema
- validateValue(Schema, Object) - Static method in class org.apache.kafka.connect.data.ConnectSchema
-
Validate that the value can be used with the schema, i.e.
- value() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- value() - Method in class org.apache.kafka.connect.data.SchemaAndValue
- value() - Method in interface org.apache.kafka.connect.header.Header
-
Get the header's value as deserialized by Connect's header converter.
- VALUE - Enum constant in enum class org.apache.kafka.connect.storage.ConverterType
- valueOf(String) - Static method in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.data.Schema.Type
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.health.ConnectorType
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.source.ConnectorTransactionBoundaries
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.source.ExactlyOnceSupport
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.kafka.connect.storage.ConverterType
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.data.Schema.Type
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.health.ConnectorType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.source.ConnectorTransactionBoundaries
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.source.ExactlyOnceSupport
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.source.SourceTask.TransactionBoundary
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.kafka.connect.storage.ConverterType
-
Returns an array containing the constants of this enum class, in the order they are declared.
- Values - Class in org.apache.kafka.connect.data
-
Utility for converting from one Connect value to a different form.
- Values() - Constructor for class org.apache.kafka.connect.data.Values
- valueSchema() - Method in class org.apache.kafka.connect.connector.ConnectRecord
- valueSchema() - Method in class org.apache.kafka.connect.data.ConnectSchema
- valueSchema() - Method in interface org.apache.kafka.connect.data.Schema
-
Get the value schema for this map or array schema.
- valueSchema() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- version() - Method in interface org.apache.kafka.connect.components.Versioned
-
Get the version of this component.
- version() - Method in interface org.apache.kafka.connect.connector.Task
-
Get the version of this task.
- version() - Method in class org.apache.kafka.connect.data.ConnectSchema
- version() - Method in interface org.apache.kafka.connect.data.Schema
-
Get the optional version of the schema.
- version() - Method in class org.apache.kafka.connect.data.SchemaBuilder
- version() - Method in class org.apache.kafka.connect.storage.SimpleHeaderConverter
- version() - Method in class org.apache.kafka.connect.storage.StringConverter
- version(Integer) - Method in class org.apache.kafka.connect.data.SchemaBuilder
-
Set the version of this schema.
- Versioned - Interface in org.apache.kafka.connect.components
-
Connect requires some components implement this interface to define a version string.
W
- with(Schema, Object) - Method in interface org.apache.kafka.connect.header.Header
-
Return a new
Header
object that has the same key but with the supplied value. - withName(String) - Static method in enum class org.apache.kafka.connect.storage.ConverterType
-
Find the ConverterType with the given name, using a case-insensitive match.
- workerId() - Method in class org.apache.kafka.connect.health.AbstractState
-
The identifier of the worker associated with the connector or the task.
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form