- canConsume(String) - Method in class org.apache.kafka.connect.data.Values.Parser
-  
- canConsume(String, boolean) - Method in class org.apache.kafka.connect.data.Values.Parser
-  
- canConsumeNextToken() - Method in class org.apache.kafka.connect.data.Values.Parser
-  
- 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. 
- canDetect(Object) - Method in class org.apache.kafka.connect.data.Values.SchemaDetector
-  
- canParseSingleTokenLiteral(Values.Parser, boolean, String) - Static method in class org.apache.kafka.connect.data.Values
-  
- 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
- 
- clientType() - Method in class org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest
- 
- close(Collection<TopicPartition>) - Method in class org.apache.kafka.connect.sink.SinkTask
- 
The SinkTask use this method to close writers for partitions that are no
 longer assigned to the SinkTask. 
- 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. 
- 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) - Method in class org.apache.kafka.connect.source.SourceTask
- 
- 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. 
- commonSchemaFor(Schema, SchemaAndValue) - Static method in class org.apache.kafka.connect.data.Values
-  
- 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 Configurablethat be used to register JAX-RS resources.
 
- configure(Map<String, ?>, boolean) - Method in interface org.apache.kafka.connect.storage.Converter
- 
Configure this class. 
- 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 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 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 org.apache.kafka.connect.errors.ConnectException
-  
- ConnectException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.ConnectException
-  
- ConnectException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.ConnectException
-  
- ConnectHeaders - Class in org.apache.kafka.connect.header
- 
- 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
-  
- 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 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 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 Connectors 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 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 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 extends 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
- 
- ConnectSchema - Class in org.apache.kafka.connect.data
-  
- 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. 
- 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) - Constructor for class org.apache.kafka.connect.data.ConnectSchema
- 
Construct a default schema for a primitive type. 
- context - Variable in class org.apache.kafka.connect.connector.Connector
-  
- context() - Method in class org.apache.kafka.connect.connector.Connector
- 
Returns the context object used to interact with the Kafka Connect runtime. 
- context() - Method in class org.apache.kafka.connect.sink.SinkConnector
-  
- context - Variable in class org.apache.kafka.connect.sink.SinkTask
-  
- context() - Method in class org.apache.kafka.connect.source.SourceConnector
-  
- context - Variable in class org.apache.kafka.connect.source.SourceTask
-  
- 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
- 
- ConverterConfig(ConfigDef, Map<String, ?>) - Constructor for class org.apache.kafka.connect.storage.ConverterConfig
-  
- ConverterType - Enum in org.apache.kafka.connect.storage
- 
- convertTo(Schema, Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the value to the desired type. 
- convertToBoolean(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToByte(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToDate(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to an  date value. 
- convertToDecimal(Schema, Object, int) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to an  decimal value. 
- convertToDouble(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToFloat(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToInteger(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToList(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToLong(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToMap(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToShort(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToString(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToStruct(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
- convertToTime(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to an  time value. 
- convertToTimestamp(Schema, Object) - Static method in class org.apache.kafka.connect.data.Values
- 
Convert the specified value to an  timestamp value. 
- SCALE_FIELD - Static variable in class org.apache.kafka.connect.data.Decimal
-  
- schema() - Method in class org.apache.kafka.connect.data.ConnectSchema
-  
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Date
-  
- schema(int) - Static method in class org.apache.kafka.connect.data.Decimal
-  
- schema() - Method in class org.apache.kafka.connect.data.Field
- 
Get the schema of this field 
- Schema - Interface in org.apache.kafka.connect.data
- 
     Definition of an abstract data type. 
- 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 - Static variable in class org.apache.kafka.connect.data.Time
-  
- SCHEMA - Static variable in class org.apache.kafka.connect.data.Timestamp
-  
- schema() - Method in class org.apache.kafka.connect.data.Values.SchemaDetector
-  
- schema() - Method in interface org.apache.kafka.connect.header.Header
- 
Return the  Schema associated with this header, if there is one. 
- Schema.Type - Enum in org.apache.kafka.connect.data
- 
The type of a schema. 
- SchemaAndValue - Class in org.apache.kafka.connect.data
-  
- 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 in org.apache.kafka.connect.errors
-  
- SchemaBuilderException(String) - Constructor for exception org.apache.kafka.connect.errors.SchemaBuilderException
-  
- SchemaBuilderException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaBuilderException
-  
- SchemaBuilderException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaBuilderException
-  
- SchemaDetector() - Constructor for class org.apache.kafka.connect.data.Values.SchemaDetector
-  
- SchemaProjector - Class in org.apache.kafka.connect.data
- 
     SchemaProjector is 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 in org.apache.kafka.connect.errors
-  
- SchemaProjectorException(String) - Constructor for exception org.apache.kafka.connect.errors.SchemaProjectorException
-  
- SchemaProjectorException(String, Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaProjectorException
-  
- SchemaProjectorException(Throwable) - Constructor for exception org.apache.kafka.connect.errors.SchemaProjectorException
-  
- schemaType(Class<?>) - Static method in class org.apache.kafka.connect.data.ConnectSchema
- 
- 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
-  
- 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 kafkaOffset of
 the record in the Kafka topic-partition 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
-  
- 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 SinkTasks, 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. 
- 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 SourceTasks 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, 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
-  
- 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
-  
- 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 in org.apache.kafka.connect.source
- 
- 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_SCHEMA - Static variable in interface org.apache.kafka.connect.data.Schema
-  
- StringConverter - Class in org.apache.kafka.connect.storage
- 
- StringConverter() - Constructor for class org.apache.kafka.connect.storage.StringConverter
-  
- StringConverterConfig - Class in org.apache.kafka.connect.storage
- 
- 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
- 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 count 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
- 
- 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. 
- toConnectData(String, Headers, byte[]) - Method in interface org.apache.kafka.connect.storage.Converter
- 
Convert a native object to a Kafka Connect data object,
 potentially using the supplied topic and headers in the record as necessary. 
- toConnectData(String, byte[]) - Method in class org.apache.kafka.connect.storage.StringConverter
-  
- 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, int) - Static method in class org.apache.kafka.connect.data.Date
-  
- toLogical(Schema, byte[]) - Static method in class org.apache.kafka.connect.data.Decimal
-  
- toLogical(Schema, int) - Static method in class org.apache.kafka.connect.data.Time
-  
- toLogical(Schema, long) - Static method in class org.apache.kafka.connect.data.Timestamp
-  
- 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 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 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 extends ConnectRecord<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(Schema.Type) - Static method in class org.apache.kafka.connect.data.SchemaBuilder
- 
Create a SchemaBuilder for the specified type. 
- 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
- 
- TYPE_CONFIG - Static variable in class org.apache.kafka.connect.storage.ConverterConfig
-  
- 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
- 
Worker will invoke this while constructing the producer for the SourceConnectors,  DLQ for SinkConnectors and the consumer for the
 SinkConnectors to validate if all of the overridden client configurations are allowed per the
 policy implementation. 
- validate() - Method in class org.apache.kafka.connect.data.Struct
- 
Validates that this struct has filled in all the necessary data with valid values. 
- 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. 
- validateValue(String, Schema, Object) - Static method in class org.apache.kafka.connect.data.ConnectSchema
-  
- validateValue(Object) - Method in class org.apache.kafka.connect.data.ConnectSchema
- 
Validate that the value can be used for this 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. 
- valueOf(String) - Static method in enum org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.apache.kafka.connect.data.Schema.Type
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.apache.kafka.connect.health.ConnectorType
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.apache.kafka.connect.source.ConnectorTransactionBoundaries
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.apache.kafka.connect.source.ExactlyOnceSupport
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- 
Returns the enum constant of this type with the specified name. 
- valueOf(String) - Static method in enum org.apache.kafka.connect.storage.ConverterType
- 
Returns the enum constant of this type with the specified name. 
- values() - Static method in enum org.apache.kafka.connect.connector.policy.ConnectorClientConfigRequest.ClientType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.apache.kafka.connect.data.Schema.Type
- 
Returns an array containing the constants of this enum type, 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
-  
- values() - Static method in enum org.apache.kafka.connect.health.ConnectorType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.apache.kafka.connect.source.ConnectorTransactionBoundaries
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.apache.kafka.connect.source.ExactlyOnceSupport
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.apache.kafka.connect.source.SourceTask.TransactionBoundary
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- values() - Static method in enum org.apache.kafka.connect.storage.ConverterType
- 
Returns an array containing the constants of this enum type, in
the order they are declared. 
- Values.Parser - Class in org.apache.kafka.connect.data
-  
- Values.SchemaDetector - Class in org.apache.kafka.connect.data
-  
- 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(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.