Index

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

aborted() - Static method in class io.debezium.pipeline.spi.SnapshotResult
 
aborted(AbstractSnapshotChangeEventSource.SnapshotContext<P, O>) - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
Completes the snapshot, doing any required clean-up (resource disposal etc.).
ABORTED - Enum constant in enum io.debezium.pipeline.notification.IncrementalSnapshotNotificationService.SnapshotStatus
 
ABORTED - Enum constant in enum io.debezium.pipeline.spi.SnapshotResult.SnapshotResultStatus
 
absolute(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
AbstractChangeRecordEmitter<P extends Partition,T extends DataCollectionSchema> - Class in io.debezium.pipeline
An abstract implementation of ChangeRecordEmitter.
AbstractChangeRecordEmitter(P, OffsetContext, Clock, CommonConnectorConfig) - Constructor for class io.debezium.pipeline.AbstractChangeRecordEmitter
 
AbstractDdlParser - Class in io.debezium.relational.ddl
 
AbstractDdlParser(boolean, boolean) - Constructor for class io.debezium.relational.ddl.AbstractDdlParser
Create a new parser.
AbstractFileBasedSchemaHistory - Class in io.debezium.relational.history
 
AbstractFileBasedSchemaHistory() - Constructor for class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
AbstractIncrementalSnapshotChangeEventSource<P extends Partition,T extends DataCollectionId> - Class in io.debezium.pipeline.source.snapshot.incremental
An incremental snapshot change event source that emits events from a DB log interleaved with snapshot events.
AbstractIncrementalSnapshotChangeEventSource(RelationalDatabaseConnectorConfig, JdbcConnection, EventDispatcher<P, T>, DatabaseSchema<?>, Clock, SnapshotProgressListener<P>, DataChangeEventListener<P>, NotificationService<P, ? extends OffsetContext>) - Constructor for class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
AbstractIncrementalSnapshotContext<T> - Class in io.debezium.pipeline.source.snapshot.incremental
A class describing current state of incremental snapshot
AbstractIncrementalSnapshotContext(boolean) - Constructor for class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
AbstractPartition - Class in io.debezium.relational
An abstract implementation of Partition which provides default facilities for logging.
AbstractPartition(String) - Constructor for class io.debezium.relational.AbstractPartition
 
AbstractRegexTopicNamingStrategy - Class in io.debezium.schema
An abstract regex implementation of TopicNamingStrategy.
AbstractRegexTopicNamingStrategy(Properties) - Constructor for class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
AbstractSchemaHistory - Class in io.debezium.relational.history
 
AbstractSchemaHistory() - Constructor for class io.debezium.relational.history.AbstractSchemaHistory
 
AbstractSnapshotChangeEventSource<P extends Partition,O extends OffsetContext> - Class in io.debezium.pipeline.source
An abstract implementation of SnapshotChangeEventSource that all implementations should extend to inherit common functionality.
AbstractSnapshotChangeEventSource(CommonConnectorConfig, SnapshotProgressListener<P>) - Constructor for class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
 
AbstractSnapshotChangeEventSource.SnapshotContext<P extends Partition,O extends OffsetContext> - Class in io.debezium.pipeline.source
Mutable context which is populated in the course of snapshotting
AbstractSnapshotChangeEventSource.SnapshottingTask - Class in io.debezium.pipeline.source
A configuration describing the task to be performed during snapshotting.
AbstractSnapshotSignal<P extends Partition> - Class in io.debezium.pipeline.signal.actions
 
AbstractSnapshotSignal() - Constructor for class io.debezium.pipeline.signal.actions.AbstractSnapshotSignal
 
AbstractSnapshotSignal.SnapshotType - Enum in io.debezium.pipeline.signal.actions
 
AbstractSourceInfo - Class in io.debezium.connector
Common information provided by all connectors in either source field or offsets
AbstractSourceInfo(CommonConnectorConfig) - Constructor for class io.debezium.connector.AbstractSourceInfo
 
AbstractSourceInfoStructMaker<T extends AbstractSourceInfo> - Class in io.debezium.connector
Common information provided by all connectors in either source field or offsets.
AbstractSourceInfoStructMaker(String, String, CommonConnectorConfig) - Constructor for class io.debezium.connector.AbstractSourceInfoStructMaker
 
AbstractTopicNamingStrategy<I extends DataCollectionId> - Class in io.debezium.schema
An abstract implementation of TopicNamingStrategy.
AbstractTopicNamingStrategy(Properties) - Constructor for class io.debezium.schema.AbstractTopicNamingStrategy
 
AbstractUnicodeTopicNamingStrategy - Class in io.debezium.schema
An abstract unicode converter topic naming strategy implementation of TopicNamingStrategy.
AbstractUnicodeTopicNamingStrategy(Properties) - Constructor for class io.debezium.schema.AbstractUnicodeTopicNamingStrategy
 
accept(boolean) - Method in interface io.debezium.function.BooleanConsumer
Performs this operation on the given argument.
accept(Field, Object, String) - Method in interface io.debezium.config.Field.ValidationOutput
Accept a problem with the given value for the field.
accept(String, String, String) - Method in interface io.debezium.schema.SchemaNameAdjuster.ReplacementOccurred
Accept that the original value was not Avro-compatible and was replaced.
accept(CallableStatement) - Method in interface io.debezium.jdbc.JdbcConnection.CallPreparer
 
accept(PreparedStatement) - Method in interface io.debezium.jdbc.JdbcConnection.StatementPreparer
 
accept(ResultSet) - Method in interface io.debezium.jdbc.JdbcConnection.BlockingResultSetConsumer
 
accept(ResultSet) - Method in interface io.debezium.jdbc.JdbcConnection.ResultSetConsumer
 
accept(ResultSet[]) - Method in interface io.debezium.jdbc.JdbcConnection.BlockingMultiResultSetConsumer
 
accept(ResultSet[]) - Method in interface io.debezium.jdbc.JdbcConnection.MultiResultSetConsumer
 
accept(List<?>, ResultSet) - Method in interface io.debezium.jdbc.JdbcConnection.ParameterResultSetConsumer
 
accept(T) - Method in interface io.debezium.function.BlockingConsumer
Performs this operation on the given argument.
accessQueue - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRS
The accessQueue for reducing lock contention See "BP-Wrapper: a system framework making any replacement algorithms (almost) lock contention free"
accessQueue - Variable in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
accumulateParsingFailure(MultipleParsingExceptions, Collection<ParsingException>) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Utility method to accumulate a parsing exception.
accumulateParsingFailure(ParsingException, Collection<ParsingException>) - Static method in class io.debezium.relational.ddl.AbstractDdlParser
Utility method to accumulate a parsing exception.
accumulating() - Static method in class io.debezium.util.Stopwatch
Create a new Stopwatch that records all of the measured durations of the stopwatch.
ActivateTracingSpan<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.transforms.tracing
This SMT enables integration with a tracing system.
ActivateTracingSpan() - Constructor for class io.debezium.transforms.tracing.ActivateTracingSpan
 
adapt(Configuration) - Static method in interface io.debezium.jdbc.JdbcConfiguration
Obtain a JdbcConfiguration adapter for the given Configuration.
ADAPTIVE - Enum constant in enum io.debezium.jdbc.TemporalPrecisionMode
Represent time and date values based upon the resolution in the database, using io.debezium.time semantic types.
ADAPTIVE_TIME_MICROSECONDS - Enum constant in enum io.debezium.jdbc.TemporalPrecisionMode
Represent timestamp, datetime and date values based upon the resolution in the database, using io.debezium.time semantic types.
adaptiveTimeMicrosecondsPrecisionMode - Variable in class io.debezium.jdbc.JdbcValueConverters
 
adaptiveTimePrecisionMode - Variable in class io.debezium.jdbc.JdbcValueConverters
 
add(boolean) - Method in interface io.debezium.document.Array
Adds the boolean value to the end of this array.
add(double) - Method in interface io.debezium.document.Array
Adds the double value to the end of this array.
add(float) - Method in interface io.debezium.document.Array
Adds the float value to the end of this array.
add(int) - Method in interface io.debezium.document.Array
Adds the integer value to the end of this array.
add(long) - Method in interface io.debezium.document.Array
Adds the long value to the end of this array.
add(Array) - Method in interface io.debezium.document.Array
Adds the array value to the end of this array.
add(Document) - Method in interface io.debezium.document.Array
Adds the document value to the end of this array.
add(Value) - Method in interface io.debezium.document.Array
Adds the value to the end of this array.
add(Value) - Method in class io.debezium.document.BasicArray
 
add(Column) - Method in class io.debezium.relational.TableEditorImpl
 
add(TableId) - Method in class io.debezium.relational.Tables.TableIds
 
add(Position) - Method in class io.debezium.text.Position
Return a new position that is the addition of this position and that supplied.
add(Boolean) - Method in interface io.debezium.document.Array
Adds the boolean value to the end of this array.
add(Double) - Method in interface io.debezium.document.Array
Adds the double value to the end of this array.
add(Double, double) - Static method in class io.debezium.util.MathOps
 
add(Double, float) - Static method in class io.debezium.util.MathOps
 
add(Double, int) - Static method in class io.debezium.util.MathOps
 
add(Double, long) - Static method in class io.debezium.util.MathOps
 
add(Double, short) - Static method in class io.debezium.util.MathOps
 
add(Double, Double) - Static method in class io.debezium.util.MathOps
 
add(Double, Float) - Static method in class io.debezium.util.MathOps
 
add(Double, Integer) - Static method in class io.debezium.util.MathOps
 
add(Double, Long) - Static method in class io.debezium.util.MathOps
 
add(Double, Number) - Static method in class io.debezium.util.MathOps
 
add(Double, Short) - Static method in class io.debezium.util.MathOps
 
add(Double, BigDecimal) - Static method in class io.debezium.util.MathOps
 
add(Double, BigInteger) - Static method in class io.debezium.util.MathOps
 
add(Double, AtomicInteger) - Static method in class io.debezium.util.MathOps
 
add(Double, AtomicLong) - Static method in class io.debezium.util.MathOps
 
add(Float) - Method in interface io.debezium.document.Array
Adds the float value to the end of this array.
add(Float, double) - Static method in class io.debezium.util.MathOps
 
add(Float, float) - Static method in class io.debezium.util.MathOps
 
add(Float, int) - Static method in class io.debezium.util.MathOps
 
add(Float, long) - Static method in class io.debezium.util.MathOps
 
add(Float, short) - Static method in class io.debezium.util.MathOps
 
add(Float, Double) - Static method in class io.debezium.util.MathOps
 
add(Float, Float) - Static method in class io.debezium.util.MathOps
 
add(Float, Integer) - Static method in class io.debezium.util.MathOps
 
add(Float, Long) - Static method in class io.debezium.util.MathOps
 
add(Float, Number) - Static method in class io.debezium.util.MathOps
 
add(Float, Short) - Static method in class io.debezium.util.MathOps
 
add(Float, BigDecimal) - Static method in class io.debezium.util.MathOps
 
add(Float, BigInteger) - Static method in class io.debezium.util.MathOps
 
add(Float, AtomicInteger) - Static method in class io.debezium.util.MathOps
 
add(Float, AtomicLong) - Static method in class io.debezium.util.MathOps
 
add(Integer) - Method in interface io.debezium.document.Array
Adds the integer value to the end of this array.
add(Integer, double) - Static method in class io.debezium.util.MathOps
 
add(Integer, float) - Static method in class io.debezium.util.MathOps
 
add(Integer, int) - Static method in class io.debezium.util.MathOps
 
add(Integer, long) - Static method in class io.debezium.util.MathOps
 
add(Integer, short) - Static method in class io.debezium.util.MathOps
 
add(Integer, Double) - Static method in class io.debezium.util.MathOps
 
add(Integer, Float) - Static method in class io.debezium.util.MathOps
 
add(Integer, Integer) - Static method in class io.debezium.util.MathOps
 
add(Integer, Long) - Static method in class io.debezium.util.MathOps
 
add(Integer, Number) - Static method in class io.debezium.util.MathOps
 
add(Integer, Short) - Static method in class io.debezium.util.MathOps
 
add(Integer, BigDecimal) - Static method in class io.debezium.util.MathOps
 
add(Integer, BigInteger) - Static method in class io.debezium.util.MathOps
 
add(Integer, AtomicInteger) - Static method in class io.debezium.util.MathOps
 
add(Integer, AtomicLong) - Static method in class io.debezium.util.MathOps
 
add(Long) - Method in interface io.debezium.document.Array
Adds the long value to the end of this array.
add(Long, double) - Static method in class io.debezium.util.MathOps
 
add(Long, float) - Static method in class io.debezium.util.MathOps
 
add(Long, int) - Static method in class io.debezium.util.MathOps
 
add(Long, long) - Static method in class io.debezium.util.MathOps
 
add(Long, short) - Static method in class io.debezium.util.MathOps
 
add(Long, Double) - Static method in class io.debezium.util.MathOps
 
add(Long, Float) - Static method in class io.debezium.util.MathOps
 
add(Long, Integer) - Static method in class io.debezium.util.MathOps
 
add(Long, Long) - Static method in class io.debezium.util.MathOps
 
add(Long, Number) - Static method in class io.debezium.util.MathOps
 
add(Long, Short) - Static method in class io.debezium.util.MathOps
 
add(Long, BigDecimal) - Static method in class io.debezium.util.MathOps
 
add(Long, BigInteger) - Static method in class io.debezium.util.MathOps
 
add(Long, AtomicInteger) - Static method in class io.debezium.util.MathOps
 
add(Long, AtomicLong) - Static method in class io.debezium.util.MathOps
 
add(Number, Number) - Static method in class io.debezium.util.MathOps
 
add(Short, double) - Static method in class io.debezium.util.MathOps
 
add(Short, float) - Static method in class io.debezium.util.MathOps
 
add(Short, int) - Static method in class io.debezium.util.MathOps
 
add(Short, long) - Static method in class io.debezium.util.MathOps
 
add(Short, short) - Static method in class io.debezium.util.MathOps
 
add(Short, Double) - Static method in class io.debezium.util.MathOps
 
add(Short, Float) - Static method in class io.debezium.util.MathOps
 
add(Short, Integer) - Static method in class io.debezium.util.MathOps
 
add(Short, Long) - Static method in class io.debezium.util.MathOps
 
add(Short, Number) - Static method in class io.debezium.util.MathOps
 
add(Short, Short) - Static method in class io.debezium.util.MathOps
 
add(Short, BigDecimal) - Static method in class io.debezium.util.MathOps
 
add(Short, BigInteger) - Static method in class io.debezium.util.MathOps
 
add(Short, AtomicInteger) - Static method in class io.debezium.util.MathOps
 
add(Short, AtomicLong) - Static method in class io.debezium.util.MathOps
 
add(String) - Method in interface io.debezium.document.Array
Adds the string value to the end of this array.
add(BigDecimal) - Method in interface io.debezium.document.Array
Adds the decimal value to the end of this array.
add(BigDecimal, double) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, float) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, int) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, long) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, short) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, Double) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, Float) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, Integer) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, Long) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, Number) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, Short) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, BigDecimal) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, BigInteger) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, AtomicInteger) - Static method in class io.debezium.util.MathOps
 
add(BigDecimal, AtomicLong) - Static method in class io.debezium.util.MathOps
 
add(BigInteger) - Method in interface io.debezium.document.Array
Adds the big integer value to the end of this array.
add(BigInteger, double) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, float) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, int) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, long) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, short) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, Double) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, Float) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, Integer) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, Long) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, Number) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, Short) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, BigDecimal) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, BigInteger) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, AtomicInteger) - Static method in class io.debezium.util.MathOps
 
add(BigInteger, AtomicLong) - Static method in class io.debezium.util.MathOps
 
add(Duration) - Method in class io.debezium.util.Stopwatch.BaseDurations
 
add(Duration) - Method in class io.debezium.util.Stopwatch.MultipleDurations
 
add(Duration) - Method in class io.debezium.util.Stopwatch.SingleDuration
 
add(AtomicInteger, double) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, float) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, int) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, long) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, short) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, Double) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, Float) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, Integer) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, Long) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, Number) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, Short) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, BigDecimal) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, BigInteger) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, AtomicInteger) - Static method in class io.debezium.util.MathOps
 
add(AtomicInteger, AtomicLong) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, double) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, float) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, int) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, long) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, short) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, Double) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, Float) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, Integer) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, Long) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, Number) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, Short) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, BigDecimal) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, BigInteger) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, AtomicInteger) - Static method in class io.debezium.util.MathOps
 
add(AtomicLong, AtomicLong) - Static method in class io.debezium.util.MathOps
 
ADD_FIELDS - Static variable in class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
ADD_FIELDS_PREFIX - Static variable in class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
ADD_HEADERS - Static variable in class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
ADD_HEADERS_PREFIX - Static variable in class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
addAll(Value...) - Method in interface io.debezium.document.Array
Sets on this object all name/value pairs from the supplied object.
addAll(Iterable<Value>) - Method in interface io.debezium.document.Array
Sets on this object all name/value pairs from the supplied object.
addAll(Object...) - Method in interface io.debezium.document.Array
Sets on this object all name/value pairs from the supplied object.
addAll(Stream<Value>) - Method in interface io.debezium.document.Array
Sets on this object all name/value pairs from the supplied object.
addArrayDimension(int) - Method in class io.debezium.relational.ddl.DataTypeBuilder
 
addAttribute(Attribute) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
addAttribute(Attribute) - Method in interface io.debezium.relational.TableEditor
Add a new attribute to this table.
addAttribute(Attribute) - Method in class io.debezium.relational.TableEditorImpl
 
addAttributes(List<Attribute>) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
addAttributes(List<Attribute>) - Method in interface io.debezium.relational.TableEditor
Add attributes to this table.
addAttributes(List<Attribute>) - Method in class io.debezium.relational.TableEditorImpl
 
addByte(MurmurHash3.State, byte, int) - Method in class io.debezium.util.MurmurHash3
 
addColumn(Column) - Method in interface io.debezium.relational.TableEditor
Add one columns to this table, regardless of the position of the supplied columns.
addColumns(Column...) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
addColumns(Column...) - Method in interface io.debezium.relational.TableEditor
Add one or more columns to this table, regardless of the position of the supplied columns.
addColumns(Column...) - Method in class io.debezium.relational.TableEditorImpl
 
addColumns(Iterable<Column>) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
addColumns(Iterable<Column>) - Method in interface io.debezium.relational.TableEditor
Add one or more columns to the end of this table's list of columns, regardless of the position of the supplied columns.
addColumns(Iterable<Column>) - Method in class io.debezium.relational.TableEditorImpl
 
addDataCollectionNamesToSnapshot(SignalPayload<P>, List<String>, Optional<String>, Optional<String>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
addDataCollectionNamesToSnapshot(SignalPayload<P>, List<String>, Optional<String>, Optional<String>) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
addDataCollectionNamesToSnapshot(String, List<String>, Optional<String>, Optional<String>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
addDataCollectionNamesToSnapshot(String, List<String>, Optional<String>, Optional<String>) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
addDelimiter() - Method in class io.debezium.pipeline.source.spi.EventFormatter
 
addField(SchemaBuilder, Table, Column, ColumnMapper) - Method in class io.debezium.relational.TableSchemaBuilder
Add to the supplied SchemaBuilder a field for the column with the given information.
addFields(List<ExtractNewRecordState.FieldReference>, R, R) - Method in class io.debezium.transforms.ExtractNewRecordState
 
addFieldToSpan(Tracer.SpanBuilder, Struct, String, String) - Method in class io.debezium.transforms.tracing.ActivateTracingSpan
 
ADDITIONAL_DATA - Static variable in class io.debezium.pipeline.notification.Notification
 
additionalColumnFilter(P, TableId, String) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Additional filter handling for preparing column names for snapshot select
additionalCondition - Variable in class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
additionalData - Variable in class io.debezium.pipeline.notification.Notification
 
additionalData - Variable in class io.debezium.pipeline.notification.Notification.Builder
 
additionalData - Variable in class io.debezium.pipeline.signal.SignalPayload
 
additionalData - Variable in class io.debezium.pipeline.signal.SignalRecord
 
AdditionalField(EventRouterConfigDefinition.AdditionalFieldPlacement, String, String) - Constructor for class io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalField
 
AdditionalFieldPlacement(String) - Constructor for enum io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalFieldPlacement
 
additionalFields - Variable in class io.debezium.transforms.ExtractNewRecordState
 
additionalFields - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
AdditionalFieldsValidator - Class in io.debezium.transforms.outbox
Validator for additional fields in outbox event router
AdditionalFieldsValidator() - Constructor for class io.debezium.transforms.outbox.AdditionalFieldsValidator
 
additionalHeaders - Variable in class io.debezium.transforms.ExtractNewRecordState
 
addKeyColumnsToCondition(Table, StringBuilder, String) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
addLowerBound(Table, StringBuilder) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
addNull() - Method in interface io.debezium.document.Array
Adds a null value to the end of this array.
adds - Variable in class io.debezium.crdt.StateBasedGCounter
 
adds - Variable in class io.debezium.crdt.StateBasedPNCounter
 
addSignalingCollectionAndSort(Set<TableId>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
addTablesIdsToSnapshot(List<DataCollection<T>>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
addToConfigDef(ConfigDef, String, List<Field>) - Method in class io.debezium.config.ConfigDefinition
 
addToken(Position, int) - Method in interface io.debezium.text.TokenStream.Tokens
Create a single-character token at the supplied index in the character stream.
addToken(Position, int, int) - Method in interface io.debezium.text.TokenStream.Tokens
Create a single- or multi-character token with the characters in the range given by the starting and ending index in the character stream.
addToken(Position, int, int, int) - Method in class io.debezium.text.TokenStream.CaseInsensitiveTokenFactory
 
addToken(Position, int, int, int) - Method in class io.debezium.text.TokenStream.CaseSensitiveTokenFactory
 
addToken(Position, int, int, int) - Method in interface io.debezium.text.TokenStream.Tokens
Create a single- or multi-character token with the supplied type and with the characters in the range given by the starting and ending index in the character stream.
addToList(List<Field>, List<Field>) - Method in class io.debezium.config.ConfigDefinition
 
addToName(String) - Method in class io.debezium.relational.ddl.DataTypeBuilder
 
addToQueueBefore(BoundedConcurrentHashMap.LIRSHashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Inserts this entry before the specified existing entry in the queue.
addToStackBefore(BoundedConcurrentHashMap.LIRSHashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Inserts this entry before the specified existing entry in the stack.
adjust(String) - Method in interface io.debezium.schema.SchemaNameAdjuster
Convert the proposed string to a valid Avro fullname, replacing all invalid characters with the underscore ('_') character.
adjuster - Variable in class io.debezium.jdbc.JdbcValueConverters
 
adjustExtensionName(String) - Static method in class io.debezium.converters.CloudEventsConverter
Adjust the name of CloudEvents attributes for Debezium events, following CloudEvents attribute naming convention as follows: prefixed with CloudEventsConverter.EXTENSION_NAME_PREFIX CloudEvents attribute names MUST consist of lower-case letters ('a' to 'z') or digits ('0' to '9') from the ASCII character set, so any other characters are removed
adjustSignedUnsignedZerofill(StringBuilder) - Method in class io.debezium.relational.ddl.DataTypeBuilder
This method will adjust the suffix names of numeric data type.
advance() - Method in class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
advance(TokenStream.Marker) - Method in class io.debezium.text.TokenStream
Advance the stream back to the position described by the supplied marker.
ADVANCED - Enum constant in enum io.debezium.config.Field.Group
 
ADVANCED_HEARTBEAT - Enum constant in enum io.debezium.config.Field.Group
 
AFTER - Static variable in class io.debezium.data.Envelope.FieldName
The after field is used to store the state of a record after an operation.
AFTER_SEPARATOR - Enum constant in enum io.debezium.relational.TableIdParser.ParsingState
 
afterDelegate - Variable in class io.debezium.transforms.ExtractNewRecordState
 
afterExtractor - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
afterLast() - Method in class io.debezium.jdbc.CancellableResultSet
 
AGGREGATE_TYPE - Static variable in class io.debezium.pipeline.notification.Notification
 
aggregateType - Variable in class io.debezium.pipeline.notification.Notification
 
aggregateType - Variable in class io.debezium.pipeline.notification.Notification.Builder
 
alias - Variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalField
 
all() - Method in class io.debezium.config.ConfigDefinition
 
ALL_FIELD_NAMES - Static variable in class io.debezium.data.Envelope
The immutable set of all Envelope.FieldNames.
ALL_FIELDS - Static variable in class io.debezium.relational.history.AbstractSchemaHistory
 
ALL_KNOWN_FIELDS - Static variable in interface io.debezium.jdbc.JdbcConfiguration
The set of names of the pre-defined JDBC configuration fields, including JdbcConfiguration.DATABASE, JdbcConfiguration.USER, JdbcConfiguration.PASSWORD, JdbcConfiguration.HOSTNAME, and JdbcConfiguration.PORT.
allFieldNames() - Method in class io.debezium.config.Field.Set
 
allowedValues - Variable in class io.debezium.config.Field
 
allowedValues() - Method in class io.debezium.config.Field
Get the allowed values for this field.
alter(TableChanges.TableChange) - Method in class io.debezium.relational.history.TableChanges
 
alter(Table) - Method in class io.debezium.relational.history.TableChanges
 
ALTER - Enum constant in enum io.debezium.relational.history.TableChanges.TableChangeType
 
ALTER - Enum constant in enum io.debezium.schema.SchemaChangeEvent.SchemaChangeEventType
 
ALTER_DATABASE - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
ALTER_TABLE - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
alterFieldSchema(Column, SchemaBuilder) - Method in interface io.debezium.relational.mapping.ColumnMapper
Optionally annotate the schema with properties to better capture the mapping behavior.
alterFieldSchema(Column, SchemaBuilder) - Method in class io.debezium.relational.mapping.MaskStrings
 
alterFieldSchema(Column, SchemaBuilder) - Method in class io.debezium.relational.mapping.PropagateSourceTypeToSchemaParameter
 
alterFieldSchema(Column, SchemaBuilder) - Method in class io.debezium.relational.mapping.TruncateStrings
 
alwaysDispatchHeartbeatEvent(P, OffsetContext) - Method in class io.debezium.pipeline.EventDispatcher
 
and(Field.Validator) - Method in interface io.debezium.config.Field.Validator
Obtain a new Field.Validator object that validates using this validator and the supplied validator.
and(ValueConverter) - Method in interface io.debezium.relational.ValueConverter
Return a new converter that calls this converter and passes the result to the specified converter.
andThen(BlockingFunction<? super R, ? extends V>) - Method in interface io.debezium.function.BlockingFunction
 
andThen(BooleanConsumer) - Method in interface io.debezium.function.BooleanConsumer
Returns a composed BooleanConsumer that performs, in sequence, this operation followed by the after operation.
andThen(SchemaNameAdjuster.ReplacementOccurred) - Method in interface io.debezium.schema.SchemaNameAdjuster.ReplacementOccurred
Create a new function that calls this function and then calls the next function.
ANY_TYPE - Static variable in class io.debezium.text.TokenStream
A constant that can be used with the TokenStream.matches(int), TokenStream.matches(int, int...), TokenStream.consume(int), and TokenStream.canConsume(int) methods to signal that any token type is allowed to be matched.
ANY_VALUE - Static variable in class io.debezium.text.TokenStream
anyMatch(RelationalTableFilters) - Method in class io.debezium.relational.ddl.DdlChanges
 
anyMatch(Predicate<String>, Predicate<TableId>) - Method in class io.debezium.relational.ddl.DdlChanges
Deprecated.
APICURIO_AVRO_CONVERTER - Static variable in class io.debezium.config.CommonConnectorConfig
 
APICURIO_AVRO_CONVERTER_CLASS - Static variable in class io.debezium.converters.CloudEventsConverter
 
APICURIO_SCHEMA_REGISTRY_URL_CONFIG - Static variable in class io.debezium.converters.CloudEventsConverter
 
append(byte[]) - Method in class io.debezium.data.SchemaUtil.RecordWriter
 
append(Path) - Method in interface io.debezium.document.Path
Create a new path consisting of this path appended with the given path that will be treated as a relative path.
append(Path) - Method in class io.debezium.document.Paths.ChildPath
 
append(Path) - Method in class io.debezium.document.Paths.MultiSegmentPath
 
append(Path) - Method in class io.debezium.document.Paths.RootPath
 
append(Path) - Method in class io.debezium.document.Paths.SingleSegmentPath
 
append(Object) - Method in class io.debezium.data.SchemaUtil.RecordWriter
 
append(String) - Method in interface io.debezium.document.Path
Create a new path consisting of this path with one or more additional segments given by the relative path.
append(ByteBuffer) - Method in class io.debezium.data.SchemaUtil.RecordWriter
 
appendAdditional(String, Object) - Method in class io.debezium.data.SchemaUtil.RecordWriter
 
appendFirst(String, Object) - Method in class io.debezium.data.SchemaUtil.RecordWriter
 
apply(ResultSet) - Method in interface io.debezium.jdbc.JdbcConnection.ResultSetExtractor
 
apply(ResultSet) - Method in interface io.debezium.jdbc.JdbcConnection.ResultSetMapper
 
apply(Statement) - Method in interface io.debezium.jdbc.JdbcConnection.Operations
Apply a series of operations against the given JDBC statement.
apply(Consumer<B>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder.
apply(Consumer<Configuration.Builder>) - Method in class io.debezium.config.Configuration.Builder
 
apply(R) - Method in class io.debezium.transforms.ByLogicalTableRouter
 
apply(R) - Method in class io.debezium.transforms.ExtractChangedRecordState
 
apply(R) - Method in class io.debezium.transforms.ExtractNewRecordState
 
apply(R) - Method in class io.debezium.transforms.HeaderToValue
 
apply(R) - Method in class io.debezium.transforms.outbox.EventRouter
 
apply(R) - Method in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
apply(R) - Method in class io.debezium.transforms.partitions.PartitionRouting
 
apply(R) - Method in class io.debezium.transforms.tracing.ActivateTracingSpan
 
apply(R, EventRouterDelegate.RecordConverter<R>) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
apply(T) - Method in interface io.debezium.function.BlockingFunction
 
applySchemaChange(SchemaChangeEvent) - Method in interface io.debezium.schema.HistorizedDatabaseSchema
 
ApproximateStructSizeCalculator - Class in io.debezium.util
 
ApproximateStructSizeCalculator() - Constructor for class io.debezium.util.ApproximateStructSizeCalculator
 
around(Iterable<? extends T>, Iterable<? extends U>, BiFunction<T, U, V>) - Static method in class io.debezium.util.Iterators
 
around(Iterable<? extends V>, Function<V, T>) - Static method in class io.debezium.util.Iterators
 
around(Iterator<? extends T>, Iterator<? extends U>, BiFunction<T, U, V>) - Static method in class io.debezium.util.Iterators
 
around(Iterator<? extends V>, Function<V, T>) - Static method in class io.debezium.util.Iterators
 
around(Iterator<T>) - Static method in class io.debezium.util.Iterators
 
Array - Interface in io.debezium.document
An array of Values.
ARRAY - Enum constant in enum io.debezium.document.Value.Type
 
ARRAY_READER - Static variable in class io.debezium.document.ArraySerdes
 
ARRAY_WRITER - Static variable in class io.debezium.document.ArraySerdes
 
Array.Entry - Interface in io.debezium.document
 
arrayDimensions - Variable in class io.debezium.relational.ddl.DataType
 
arrayDimensions() - Method in class io.debezium.relational.ddl.DataType
 
arrayDims - Variable in class io.debezium.relational.ddl.DataTypeBuilder
 
arrayDimsLength - Variable in class io.debezium.relational.ddl.DataTypeBuilder
 
arrayListOf(Iterable<T>) - Static method in class io.debezium.util.Collect
 
arrayListOf(T[]) - Static method in class io.debezium.util.Collect
 
arrayListOf(T, List<T>) - Static method in class io.debezium.util.Collect
 
arrayListOf(T, T...) - Static method in class io.debezium.util.Collect
 
ArrayReader - Interface in io.debezium.document
Reads Array instances from a variety of input forms.
ArraySerdes - Class in io.debezium.document
A Kafka Serializer and Serializer that operates upon Debezium Arrays.
ArraySerdes() - Constructor for class io.debezium.document.ArraySerdes
 
arrayToSerializedString(Object[]) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
arrayToString(Object[]) - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
ArrayWriter - Interface in io.debezium.document
Writes Array instances to a variety of output forms.
arrived(SignalPayload<P>) - Method in class io.debezium.pipeline.signal.actions.Log
 
arrived(SignalPayload<P>) - Method in class io.debezium.pipeline.signal.actions.SchemaChanges
 
arrived(SignalPayload<P>) - Method in interface io.debezium.pipeline.signal.actions.SignalAction
 
arrived(SignalPayload<P>) - Method in class io.debezium.pipeline.signal.actions.snapshotting.CloseIncrementalSnapshotWindow
 
arrived(SignalPayload<P>) - Method in class io.debezium.pipeline.signal.actions.snapshotting.ExecuteSnapshot
 
arrived(SignalPayload<P>) - Method in class io.debezium.pipeline.signal.actions.snapshotting.OpenIncrementalSnapshotWindow
 
arrived(SignalPayload<P>) - Method in class io.debezium.pipeline.signal.actions.snapshotting.PauseIncrementalSnapshot
 
arrived(SignalPayload<P>) - Method in class io.debezium.pipeline.signal.actions.snapshotting.ResumeIncrementalSnapshot
 
arrived(SignalPayload<P>) - Method in class io.debezium.pipeline.signal.actions.snapshotting.StopSnapshot
 
asArray() - Method in class io.debezium.config.Field.Set
Get the fields in this set as an array.
asArray() - Method in class io.debezium.document.BinaryValue
 
asArray() - Method in class io.debezium.document.ComparableValue
 
asArray() - Method in class io.debezium.document.ConvertingValue
 
asArray() - Method in class io.debezium.document.NullValue
 
asArray() - Method in interface io.debezium.document.Value
 
asBigDecimal() - Method in class io.debezium.document.BinaryValue
 
asBigDecimal() - Method in class io.debezium.document.ComparableValue
 
asBigDecimal() - Method in class io.debezium.document.ConvertingValue
 
asBigDecimal() - Method in class io.debezium.document.NullValue
 
asBigDecimal() - Method in interface io.debezium.document.Value
 
asBigDecimal() - Method in interface io.debezium.relational.Attribute
Get the attribute value as a big decimal value.
asBigDecimal() - Method in interface io.debezium.relational.AttributeEditor
Get the attribute value as a big decimal value.
asBigDecimal() - Method in class io.debezium.relational.AttributeEditorImpl
 
asBigDecimal() - Method in class io.debezium.relational.AttributeImpl
 
asBigInteger() - Method in class io.debezium.document.BinaryValue
 
asBigInteger() - Method in class io.debezium.document.ComparableValue
 
asBigInteger() - Method in class io.debezium.document.ConvertingValue
 
asBigInteger() - Method in class io.debezium.document.NullValue
 
asBigInteger() - Method in interface io.debezium.document.Value
 
asBigInteger() - Method in interface io.debezium.relational.Attribute
Get the attribute value as a big integer value.
asBigInteger() - Method in interface io.debezium.relational.AttributeEditor
Get the attribute value as a big integer value.
asBigInteger() - Method in class io.debezium.relational.AttributeEditorImpl
 
asBigInteger() - Method in class io.debezium.relational.AttributeImpl
 
asBoolean() - Method in class io.debezium.document.BinaryValue
 
asBoolean() - Method in class io.debezium.document.ComparableValue
 
asBoolean() - Method in class io.debezium.document.ConvertingValue
 
asBoolean() - Method in class io.debezium.document.NullValue
 
asBoolean() - Method in interface io.debezium.document.Value
 
asBoolean() - Method in interface io.debezium.relational.Attribute
Get the attribute value as a boolean value.
asBoolean() - Method in interface io.debezium.relational.AttributeEditor
Get the attribute value as a boolean value.
asBoolean() - Method in class io.debezium.relational.AttributeEditorImpl
 
asBoolean() - Method in class io.debezium.relational.AttributeImpl
 
asBoolean(String, boolean) - Static method in class io.debezium.util.Strings
Parse the supplied string as a boolean value.
asBytes() - Method in class io.debezium.document.BinaryValue
 
asBytes() - Method in class io.debezium.document.ComparableValue
 
asBytes() - Method in class io.debezium.document.ConvertingValue
 
asBytes() - Method in class io.debezium.document.NullValue
 
asBytes() - Method in interface io.debezium.document.Value
 
ASCENDING - Enum constant in enum io.debezium.relational.RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder
 
asDecimalMode() - Method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
 
asDetailedString(Field) - Static method in class io.debezium.data.SchemaUtil
Obtain a JSON string representation of the specified field.
asDetailedString(Schema) - Static method in class io.debezium.data.SchemaUtil
Obtain a JSON string representation of the specified Schema.
asDetailedString(Struct) - Static method in class io.debezium.data.SchemaUtil
Obtain a JSON string representation of the specified Struct.
asDetailedString(SourceRecord) - Static method in class io.debezium.data.SchemaUtil
Obtain a JSON string representation of the specified SourceRecord.
asDocument() - Method in class io.debezium.document.BinaryValue
 
asDocument() - Method in class io.debezium.document.ComparableValue
 
asDocument() - Method in class io.debezium.document.ConvertingValue
 
asDocument() - Method in class io.debezium.document.NullValue
 
asDocument() - Method in interface io.debezium.document.Value
 
asDouble() - Method in class io.debezium.document.BinaryValue
 
asDouble() - Method in class io.debezium.document.ComparableValue
 
asDouble() - Method in class io.debezium.document.ConvertingValue
 
asDouble() - Method in class io.debezium.document.NullValue
 
asDouble() - Method in interface io.debezium.document.Value
 
asDouble() - Method in interface io.debezium.relational.Attribute
Get the attribute value as a double value.
asDouble() - Method in interface io.debezium.relational.AttributeEditor
Get the attribute value as a double value.
asDouble() - Method in class io.debezium.relational.AttributeEditorImpl
 
asDouble() - Method in class io.debezium.relational.AttributeImpl
 
asDouble(String, double) - Static method in class io.debezium.util.Strings
Parse the supplied string as a double value.
asDuration(String) - Static method in class io.debezium.util.Strings
Converts the given string (in the format 00:00:00(.0*)) into a Duration.
asEnvelope() - Method in class io.debezium.serde.json.JsonSerdeConfig
 
asFloat() - Method in class io.debezium.document.BinaryValue
 
asFloat() - Method in class io.debezium.document.ComparableValue
 
asFloat() - Method in class io.debezium.document.ConvertingValue
 
asFloat() - Method in class io.debezium.document.NullValue
 
asFloat() - Method in interface io.debezium.document.Value
 
asFloat() - Method in interface io.debezium.relational.Attribute
Get the attribute value as a float value.
asFloat() - Method in interface io.debezium.relational.AttributeEditor
Get the attribute value as a float value.
asFloat() - Method in class io.debezium.relational.AttributeEditorImpl
 
asFloat() - Method in class io.debezium.relational.AttributeImpl
 
asInt(String, int) - Static method in class io.debezium.util.Strings
Parse the supplied string as a integer value.
asInteger() - Method in class io.debezium.document.BinaryValue
 
asInteger() - Method in class io.debezium.document.ComparableValue
 
asInteger() - Method in class io.debezium.document.ConvertingValue
 
asInteger() - Method in class io.debezium.document.NullValue
 
asInteger() - Method in interface io.debezium.document.Value
 
asInteger() - Method in interface io.debezium.relational.Attribute
Get the attribute value as an integer value.
asInteger() - Method in interface io.debezium.relational.AttributeEditor
Get the attribute value as an integer value.
asInteger() - Method in class io.debezium.relational.AttributeEditorImpl
 
asInteger() - Method in class io.debezium.relational.AttributeImpl
 
asInteger(String) - Static method in interface io.debezium.document.Path.Segments
 
asInteger(Optional<String>) - Static method in interface io.debezium.document.Path.Segments
 
asLong() - Method in class io.debezium.document.BinaryValue
 
asLong() - Method in class io.debezium.document.ComparableValue
 
asLong() - Method in class io.debezium.document.ConvertingValue
 
asLong() - Method in class io.debezium.document.NullValue
 
asLong() - Method in interface io.debezium.document.Value
 
asLong() - Method in interface io.debezium.relational.Attribute
Get the attribute value as a long value.
asLong() - Method in interface io.debezium.relational.AttributeEditor
Get the attribute value as a long value.
asLong() - Method in class io.debezium.relational.AttributeEditorImpl
 
asLong() - Method in class io.debezium.relational.AttributeImpl
 
asLong(String, long) - Static method in class io.debezium.util.Strings
Parse the supplied string as a long value.
asMap() - Method in interface io.debezium.config.Configuration
Get a copy of these configuration properties as a Properties object.
asMap(Field.Set) - Method in interface io.debezium.config.Configuration
Get a copy of these configuration properties with defaults as a Map.
asNumber() - Method in class io.debezium.document.BinaryValue
 
asNumber() - Method in class io.debezium.document.ComparableValue
 
asNumber() - Method in class io.debezium.document.ConvertingValue
 
asNumber() - Method in class io.debezium.document.NullValue
 
asNumber() - Method in interface io.debezium.document.Value
 
asNumber(String) - Static method in class io.debezium.util.Strings
Parse the supplied string as a number.
asNumber(String, Supplier<Number>) - Static method in class io.debezium.util.Strings
Parse the supplied string as a number.
asObject() - Method in class io.debezium.document.BinaryValue
 
asObject() - Method in class io.debezium.document.ComparableValue
 
asObject() - Method in class io.debezium.document.ConvertingValue
 
asObject() - Method in class io.debezium.document.NullValue
 
asObject() - Method in interface io.debezium.document.Value
Get the raw value.
asProperties() - Method in interface io.debezium.config.Configuration
Get a copy of these configuration properties as a Properties object.
asProperties(Field.Set) - Method in interface io.debezium.config.Configuration
Get a copy of these configuration properties as a Properties object.
assertDelegateProvided(String, Object) - Method in class io.debezium.converters.BinaryDataConverter
 
assertDelegateProvided(String, Object) - Method in class io.debezium.converters.ByteArrayConverter
 
asString() - Method in class io.debezium.document.BinaryValue
 
asString() - Method in class io.debezium.document.ComparableValue
 
asString() - Method in class io.debezium.document.ConvertingValue
 
asString() - Method in class io.debezium.document.NullValue
 
asString() - Method in interface io.debezium.document.Value
 
asString() - Method in interface io.debezium.relational.Attribute
Get the attribute value as a string value.
asString() - Method in interface io.debezium.relational.AttributeEditor
Get the attribute value as a string value.
asString() - Method in class io.debezium.relational.AttributeEditorImpl
 
asString() - Method in class io.debezium.relational.AttributeImpl
 
asString(Object) - Static method in class io.debezium.data.SchemaUtil
Obtain a JSON string representation of the specified field.
asString(Duration) - Static method in class io.debezium.util.Stopwatch
Compute the readable string representation of the supplied duration.
asString(Field) - Static method in class io.debezium.data.SchemaUtil
Obtain a JSON string representation of the specified field.
asString(Schema) - Static method in class io.debezium.data.SchemaUtil
Obtain a JSON string representation of the specified Schema.
asString(Struct) - Static method in class io.debezium.data.SchemaUtil
Obtain a JSON string representation of the specified Struct.
asString(SourceRecord) - Static method in class io.debezium.data.SchemaUtil
Obtain a JSON string representation of the specified SourceRecord.
assureNonEmptySchema() - Method in class io.debezium.relational.RelationalDatabaseSchema
 
assureNonEmptySchema() - Method in interface io.debezium.schema.DatabaseSchema
 
atLeast(Number) - Static method in class io.debezium.config.Field.RangeValidator
A validator that checks only the lower numerical bound.
attemptEviction(boolean) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
Attribute - Interface in io.debezium.relational
An immutable attribute associated with a relational table.
AttributeEditor - Interface in io.debezium.relational
An editor for Attribute instances.
AttributeEditorImpl - Class in io.debezium.relational
Implementation of the AttributeEditor contract.
AttributeEditorImpl() - Constructor for class io.debezium.relational.AttributeEditorImpl
 
AttributeImpl - Class in io.debezium.relational
Relational model implementation of Attribute.
AttributeImpl(String, String) - Constructor for class io.debezium.relational.AttributeImpl
 
attributes - Variable in class io.debezium.relational.TableEditorImpl
 
attributes - Variable in class io.debezium.relational.TableImpl
 
attributes() - Method in class io.debezium.relational.NoOpTableEditorImpl
 
attributes() - Method in interface io.debezium.relational.Table
Get the attributes of the table.
attributes() - Method in interface io.debezium.relational.TableEditor
Get the definitions for the attributes in this table.
attributes() - Method in class io.debezium.relational.TableEditorImpl
 
attributes() - Method in class io.debezium.relational.TableImpl
 
attributeWithName(String) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
attributeWithName(String) - Method in interface io.debezium.relational.Table
Get the definition for an attribute in this table with the supplied name.
attributeWithName(String) - Method in interface io.debezium.relational.TableEditor
Get the definition for the attribute in this table with the supplied name.
attributeWithName(String) - Method in class io.debezium.relational.TableEditorImpl
 
attributeWithName(String) - Method in class io.debezium.relational.TableImpl
 
AUTO_INCREMENTED_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
autoIncremented - Variable in class io.debezium.relational.ColumnEditorImpl
 
autoIncremented - Variable in class io.debezium.relational.ColumnImpl
 
autoIncremented(boolean) - Method in interface io.debezium.relational.ColumnEditor
Set whether the column's values are automatically incremented.
autoIncremented(boolean) - Method in class io.debezium.relational.ColumnEditorImpl
 
availableSignalChannels - Variable in class io.debezium.connector.common.BaseSourceTask
 
AVRO - Enum constant in enum io.debezium.config.CommonConnectorConfig.FieldNameAdjustmentMode
Adjust names for compatibility with Avro
AVRO - Enum constant in enum io.debezium.config.CommonConnectorConfig.SchemaNameAdjustmentMode
Adjust names for compatibility with Avro
AVRO - Enum constant in enum io.debezium.converters.spi.SerializerType
Using Avro as serialization format
AVRO - Static variable in interface io.debezium.schema.SchemaNameAdjuster
 
AVRO_FIELD_NAMER - Static variable in interface io.debezium.schema.SchemaNameAdjuster
 
AVRO_UNICODE - Enum constant in enum io.debezium.config.CommonConnectorConfig.FieldNameAdjustmentMode
Adjust names for compatibility with Avro, replace invalid character to corresponding unicode
AVRO_UNICODE - Enum constant in enum io.debezium.config.CommonConnectorConfig.SchemaNameAdjustmentMode
Adjust names for compatibility with Avro, replace invalid character to corresponding unicode
AVRO_UNICODE - Static variable in interface io.debezium.schema.SchemaNameAdjuster
 
AVRO_UNICODE_FIELD_NAMER - Static variable in interface io.debezium.schema.SchemaNameAdjuster
 
avroConverter - Variable in class io.debezium.converters.CloudEventsConverter
 
await() - Method in interface io.debezium.util.Stopwatch.StopwatchSet
Block until all running stopwatches have been stopped.
await() - Method in class io.debezium.util.VariableLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted.
await(long, TimeUnit) - Method in interface io.debezium.util.Stopwatch.StopwatchSet
Block until all stopwatches that have been created and started are stopped.
await(long, TimeUnit) - Method in class io.debezium.util.VariableLatch
Causes the current thread to wait until the latch has counted down to zero, unless the thread is interrupted, or the specified waiting time elapses.

B

BACKTICKS - Static variable in class io.debezium.relational.TableIdParser
 
BASE64 - Enum constant in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
Represent binary values as base64-encoded string
BASE64_URL_SAFE - Enum constant in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
Represent binary values as base64-url-safe-encoded string
BaseDurations() - Constructor for class io.debezium.util.Stopwatch.BaseDurations
 
BaseSourceInfo - Class in io.debezium.connector.common
 
BaseSourceInfo(CommonConnectorConfig) - Constructor for class io.debezium.connector.common.BaseSourceInfo
 
BaseSourceTask<P extends Partition,O extends OffsetContext> - Class in io.debezium.connector.common
Base class for Debezium's CDC SourceTask implementations.
BaseSourceTask() - Constructor for class io.debezium.connector.common.BaseSourceTask
 
BaseSourceTask.State - Enum in io.debezium.connector.common
 
BasicArray - Class in io.debezium.document
Package-level implementation of Array.
BasicArray() - Constructor for class io.debezium.document.BasicArray
 
BasicArray(Value[]) - Constructor for class io.debezium.document.BasicArray
 
BasicArray(List<Value>) - Constructor for class io.debezium.document.BasicArray
 
BasicDocument - Class in io.debezium.document
Package-level implementation of Document.
BasicDocument() - Constructor for class io.debezium.document.BasicDocument
 
BasicEntry - Class in io.debezium.document
Package-level implementation of Array.Entry in an Array.
BasicEntry(int, Value) - Constructor for class io.debezium.document.BasicEntry
 
BasicField - Class in io.debezium.document
Package-level implementation of a Document.Field inside a Document.
BasicField(CharSequence, Value) - Constructor for class io.debezium.document.BasicField
 
basicTokenizer(boolean) - Static method in class io.debezium.text.TokenStream
Obtain a basic TokenStream.Tokenizer implementation that ignores whitespace but includes tokens for individual symbols, the period ('.'), single-quoted strings, double-quoted strings, whitespace-delimited words, and optionally comments.
BasicTokenizer(boolean) - Constructor for class io.debezium.text.TokenStream.BasicTokenizer
 
batchThresholdFactor - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
batchThresholdFactor - Variable in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
BEFORE - Static variable in class io.debezium.data.Envelope.FieldName
The before field is used to store the state of a record before an operation.
BEFORE_SEPARATOR - Enum constant in enum io.debezium.relational.TableIdParser.ParsingState
 
beforeDelegate - Variable in class io.debezium.transforms.ExtractNewRecordState
 
beforeFirst() - Method in class io.debezium.jdbc.CancellableResultSet
 
BEGIN - Enum constant in enum io.debezium.pipeline.txmetadata.TransactionStatus
 
beginTransaction(Partition, OffsetContext, Instant) - Method in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
beginTransaction(String) - Method in class io.debezium.pipeline.txmetadata.TransactionContext
 
between(Number, Number) - Static method in class io.debezium.config.Field.RangeValidator
A validator that checks both the upper and lower bound.
BIG_INTEGER - Enum constant in enum io.debezium.document.Value.Type
 
bigIntUnsignedMode - Variable in class io.debezium.jdbc.JdbcValueConverters
 
BigIntUnsignedMode() - Constructor for enum io.debezium.jdbc.JdbcValueConverters.BigIntUnsignedMode
 
BINARY - Enum constant in enum io.debezium.document.Value.Type
 
BINARY_HANDLING_MODE - Static variable in class io.debezium.config.CommonConnectorConfig
 
BinaryDataConverter - Class in io.debezium.converters
A custom value converter that allows Avro messages to be delivered as raw binary data to kafka.
BinaryDataConverter() - Constructor for class io.debezium.converters.BinaryDataConverter
 
binaryHandlingMode - Variable in class io.debezium.config.CommonConnectorConfig
 
binaryHandlingMode() - Method in class io.debezium.config.CommonConnectorConfig
 
BinaryHandlingMode(String, Supplier<SchemaBuilder>) - Constructor for enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
 
binaryMode - Variable in class io.debezium.jdbc.JdbcValueConverters
 
BinaryValue - Class in io.debezium.document
A specialization of Value that represents a binary value.
BinaryValue(byte[]) - Constructor for class io.debezium.document.BinaryValue
 
Bits - Class in io.debezium.data
A set of bits of arbitrary length.
Bits() - Constructor for class io.debezium.data.Bits
 
BlockingConsumer<T> - Interface in io.debezium.function
A variant of Consumer that can be blocked and interrupted.
BlockingFunction<T,R> - Interface in io.debezium.function
A variant of Function that can be blocked and interrupted.
bmix(MurmurHash3.State) - Static method in class io.debezium.util.MurmurHash3
 
BOOLEAN - Enum constant in enum io.debezium.document.Value.Type
 
BooleanConsumer - Interface in io.debezium.function
Represents an operation that accepts a single boolean-valued argument and returns no result.
BOOTSTRAP_SERVERS - Static variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
BoundedConcurrentHashMap<K,V> - Class in io.debezium.util
A hash table supporting full concurrency of retrievals and adjustable expected concurrency for updates.
BoundedConcurrentHashMap() - Constructor for class io.debezium.util.BoundedConcurrentHashMap
Creates a new, empty map with the default maximum capacity
BoundedConcurrentHashMap(int) - Constructor for class io.debezium.util.BoundedConcurrentHashMap
Creates a new, empty map with the specified maximum capacity, default concurrency level and LRU eviction policy.
BoundedConcurrentHashMap(int, int) - Constructor for class io.debezium.util.BoundedConcurrentHashMap
Creates a new, empty map with the specified maximum capacity, load factor, concurrency level and LRU eviction policy.
BoundedConcurrentHashMap(int, int, BoundedConcurrentHashMap.Eviction) - Constructor for class io.debezium.util.BoundedConcurrentHashMap
Creates a new, empty map with the specified maximum capacity, load factor, concurrency level and eviction strategy.
BoundedConcurrentHashMap(int, int, BoundedConcurrentHashMap.Eviction, BoundedConcurrentHashMap.EvictionListener<K, V>) - Constructor for class io.debezium.util.BoundedConcurrentHashMap
Creates a new, empty map with the specified maximum capacity, load factor and concurrency level.
BoundedConcurrentHashMap.EntryIterator - Class in io.debezium.util
 
BoundedConcurrentHashMap.EntrySet - Class in io.debezium.util
 
BoundedConcurrentHashMap.Eviction - Enum in io.debezium.util
 
BoundedConcurrentHashMap.EvictionListener<K,V> - Interface in io.debezium.util
 
BoundedConcurrentHashMap.EvictionPolicy<K,V> - Interface in io.debezium.util
 
BoundedConcurrentHashMap.HashEntry<K,V> - Class in io.debezium.util
ConcurrentHashMap list entry.
BoundedConcurrentHashMap.HashIterator - Class in io.debezium.util
 
BoundedConcurrentHashMap.KeyIterator - Class in io.debezium.util
 
BoundedConcurrentHashMap.KeySet - Class in io.debezium.util
 
BoundedConcurrentHashMap.LIRS<K,V> - Class in io.debezium.util
 
BoundedConcurrentHashMap.LIRSHashEntry<K,V> - Class in io.debezium.util
Adapted to Infinispan BoundedConcurrentHashMap using LIRS implementation ideas from Charles Fry ([email protected]) See http://code.google.com/p/concurrentlinkedhashmap/source/browse/trunk/src/test/java/com/googlecode/concurrentlinkedhashmap/caches/LirsMap.java for original sources
BoundedConcurrentHashMap.LRU<K,V> - Class in io.debezium.util
 
BoundedConcurrentHashMap.NullEvictionListener<K,V> - Class in io.debezium.util
 
BoundedConcurrentHashMap.NullEvictionPolicy<K,V> - Class in io.debezium.util
 
BoundedConcurrentHashMap.Recency - Enum in io.debezium.util
 
BoundedConcurrentHashMap.Segment<K,V> - Class in io.debezium.util
Segments are specialized versions of hash tables.
BoundedConcurrentHashMap.ValueIterator - Class in io.debezium.util
 
BoundedConcurrentHashMap.Values - Class in io.debezium.util
 
BoundedConcurrentHashMap.WriteThroughEntry - Class in io.debezium.util
Custom Entry class used by EntryIterator.next(), that relays setValue changes to the underlying map.
BufferedBlockingConsumer<T> - Interface in io.debezium.function
A BlockingConsumer that retains a maximum number of values in a buffer before sending them to a delegate consumer.
BufferedDataChangeEvent() - Constructor for class io.debezium.pipeline.EventDispatcher.BufferedDataChangeEvent
 
bufferedEvent - Variable in class io.debezium.connector.base.ChangeEventQueue
 
bufferedEventRef - Variable in class io.debezium.pipeline.EventDispatcher.BufferingSnapshotChangeRecordReceiver
 
buffering - Variable in class io.debezium.connector.base.ChangeEventQueue
 
buffering - Variable in class io.debezium.connector.base.ChangeEventQueue.Builder
 
buffering() - Method in class io.debezium.connector.base.ChangeEventQueue.Builder
 
BufferingSnapshotChangeRecordReceiver() - Constructor for class io.debezium.pipeline.EventDispatcher.BufferingSnapshotChangeRecordReceiver
 
bufferLast(BlockingConsumer<T>) - Static method in interface io.debezium.function.BufferedBlockingConsumer
Get a BufferedBlockingConsumer that buffers just the last value seen by the consumer.
build() - Method in class io.debezium.config.Configuration.Builder
 
build() - Method in interface io.debezium.config.Configuration.ConfigBuilder
Build and return the immutable configuration.
build() - Method in class io.debezium.connector.base.ChangeEventQueue.Builder
 
build() - Method in interface io.debezium.converters.CloudEventsConverter.CESchemaBuilder
 
build() - Method in interface io.debezium.converters.CloudEventsConverter.CEValueBuilder
 
build() - Method in interface io.debezium.data.Envelope.Builder
Create the message envelope descriptor.
build() - Method in class io.debezium.pipeline.notification.Notification.Builder
 
build() - Method in class io.debezium.relational.Key.Builder
 
build() - Static method in class io.debezium.relational.mapping.ColumnMappers
Obtain a new builder for a table selection predicate.
build() - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
Build the Predicate that determines whether a table identified by a given TableId is to be included.
build() - Method in class io.debezium.relational.Selectors.DatabaseSelectionPredicateBuilder
Build the Predicate that determines whether a database identified by its name is to be included.
build() - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
Build the Predicate that determines whether a table identified by a given TableId is to be included.
buildAndRegisterSchema(Table) - Method in class io.debezium.relational.RelationalDatabaseSchema
Builds up the CDC event schema for the given table and stores it in this schema.
buildCacheKey(Struct, Struct) - Static method in class io.debezium.transforms.ExtractNewRecordState
 
buildChunkQuery(Table, int, Optional<String>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
buildChunkQuery(Table, Optional<String>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
builder() - Static method in class io.debezium.data.geometry.Geography
Returns a SchemaBuilder for a Geography field.
builder() - Static method in class io.debezium.data.geometry.Geometry
Returns a SchemaBuilder for a Geometry field.
builder() - Static method in class io.debezium.data.geometry.Point
Returns a SchemaBuilder for a Point field.
builder() - Static method in class io.debezium.data.Json
Returns a SchemaBuilder for a JSON field.
builder() - Static method in class io.debezium.data.Uuid
Returns a SchemaBuilder for a Uuid field.
builder() - Static method in class io.debezium.data.VariableScaleDecimal
Returns a SchemaBuilder for a VariableScaleDecimal.
builder() - Static method in class io.debezium.data.Xml
Returns a SchemaBuilder for an XML field.
builder() - Static method in class io.debezium.pipeline.notification.Notification.Builder
 
builder() - Static method in class io.debezium.time.Date
Returns a SchemaBuilder for a Date.
builder() - Static method in class io.debezium.time.Interval
Returns a SchemaBuilder for a Interval.
builder() - Static method in class io.debezium.time.MicroDuration
Returns a SchemaBuilder for a MicroDuration.
builder() - Static method in class io.debezium.time.MicroTime
Returns a SchemaBuilder for a MicroTime.
builder() - Static method in class io.debezium.time.MicroTimestamp
Returns a SchemaBuilder for a MicroTimestamp.
builder() - Static method in class io.debezium.time.NanoDuration
Returns a SchemaBuilder for a NanoDuration.
builder() - Static method in class io.debezium.time.NanoTime
Returns a SchemaBuilder for a NanoTime.
builder() - Static method in class io.debezium.time.NanoTimestamp
Returns a SchemaBuilder for a NanoTimestamp.
builder() - Static method in class io.debezium.time.Time
Returns a SchemaBuilder for a Time.
builder() - Static method in class io.debezium.time.Timestamp
Returns a SchemaBuilder for a Timestamp.
builder() - Static method in class io.debezium.time.Year
Returns a SchemaBuilder for a Year.
builder() - Static method in class io.debezium.time.ZonedTime
Returns a SchemaBuilder for a ZonedTime.
builder() - Static method in class io.debezium.time.ZonedTimestamp
Returns a SchemaBuilder for a ZonedTimestamp.
builder(int) - Static method in class io.debezium.data.Bits
Returns a SchemaBuilder for a Bits.
builder(JdbcValueConverters.DecimalMode, int, int) - Static method in class io.debezium.data.SpecialValueDecimal
Returns a SchemaBuilder for a decimal number depending on JdbcValueConverters.DecimalMode.
builder(String) - Static method in class io.debezium.data.Enum
Returns a SchemaBuilder for an enumeration.
builder(String) - Static method in class io.debezium.data.EnumSet
Returns a SchemaBuilder for a set of enumerated values.
builder(List<String>) - Static method in class io.debezium.data.Enum
Returns a SchemaBuilder for an enumeration.
builder(List<String>) - Static method in class io.debezium.data.EnumSet
Returns a SchemaBuilder for a set of enumerated values.
Builder() - Constructor for class io.debezium.config.Configuration.Builder
 
Builder() - Constructor for class io.debezium.connector.base.ChangeEventQueue.Builder
 
Builder() - Constructor for class io.debezium.pipeline.notification.Notification.Builder
 
Builder(Selectors.TableIdToStringMapper) - Constructor for class io.debezium.relational.mapping.ColumnMappers.Builder
 
Builder(Table) - Constructor for class io.debezium.relational.Key.Builder
 
Builder(Properties) - Constructor for class io.debezium.config.Configuration.Builder
 
buildJmxNotification(Notification) - Method in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
buildKafkaConfiguration(String, Configuration) - Static method in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
buildMaxPrimaryKeyQuery(Table, Optional<String>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
buildNewRecord(R, Struct, int) - Method in class io.debezium.transforms.partitions.PartitionRouting
 
buildNewSchema(String, Schema, Map<String, Header>, List<String>, int) - Method in class io.debezium.transforms.HeaderToValue
 
buildNotificationWith(IncrementalSnapshotContext<T>, IncrementalSnapshotNotificationService.SnapshotStatus, Map<String, String>, OffsetContext) - Method in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
buildProjection(Table) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
buildSelectWithRowLimits(TableId, int, String, Optional<String>, Optional<String>, String) - Method in class io.debezium.jdbc.JdbcConnection
 
buildSignalRecordFromChangeEventSource(Struct, CommonConnectorConfig) - Static method in class io.debezium.pipeline.signal.SignalRecord
 
buildStartingFromDbFilter(Predicate<String>, Predicate<String>, Predicate<TableId>) - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
 
buildStartingFromSchemaFilter(Predicate<String>, Predicate<TableId>) - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
 
buildUpdatedValue(String, Struct, Map<String, Header>, Schema, List<String>, int) - Method in class io.debezium.transforms.HeaderToValue
 
buildWKBPoint(double, double) - Static method in class io.debezium.data.geometry.Point
Creates WKB for a 2D {x,y} point.
ByLogicalTableRouter<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.transforms
A logical table consists of one or more physical tables with the same schema.
ByLogicalTableRouter() - Constructor for class io.debezium.transforms.ByLogicalTableRouter
 
BYTE_BUFFER_ZERO - Static variable in class io.debezium.util.NumberConversions
 
BYTE_FALSE - Static variable in class io.debezium.util.NumberConversions
 
BYTE_TRUE - Static variable in class io.debezium.util.NumberConversions
 
BYTE_ZERO - Static variable in class io.debezium.util.NumberConversions
 
ByteArrayConverter - Class in io.debezium.converters
A customized value converter to allow avro message to be delivered as it is (byte[]) to kafka, this is used for outbox pattern where payload is serialized by KafkaAvroSerializer, the consumer need to get the deseralized payload.
ByteArrayConverter() - Constructor for class io.debezium.converters.ByteArrayConverter
 
byteOrderOfBitType() - Method in class io.debezium.jdbc.JdbcValueConverters
Determine whether the byte[] values for columns of type BIT(n) are big-endian or little-endian.
BYTES - Enum constant in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
Represent binary values as byte array
bytesToString(byte[]) - Method in class io.debezium.document.ArraySerdes
 
bytesToString(byte[]) - Method in class io.debezium.document.DocumentSerdes
 

C

c1 - Variable in class io.debezium.util.MurmurHash3.State
 
c2 - Variable in class io.debezium.util.MurmurHash3.State
 
CACHE_SIZE - Static variable in class io.debezium.transforms.HeaderToValue
 
calculateLIRSize(int) - Static method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
call() - Method in interface io.debezium.document.Value.NullHandler
 
call() - Method in interface io.debezium.function.Callable
 
call(String, JdbcConnection.CallPreparer, JdbcConnection.ResultSetConsumer) - Method in class io.debezium.jdbc.JdbcConnection
Execute a stored procedure.
Callable - Interface in io.debezium.function
 
CancellableResultSet - Class in io.debezium.jdbc
A decorator for a ResultSet that cancels the parent Statement before the delegate set is closed.
CancellableResultSet(ResultSet) - Constructor for class io.debezium.jdbc.CancellableResultSet
 
cancelRowUpdates() - Method in class io.debezium.jdbc.CancellableResultSet
 
canConsume(char) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token if it matches the expected value, and return whether this method was indeed able to consume the token.
canConsume(int) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token if it matches the expected token type, and return whether this method was indeed able to consume the token.
canConsume(int, String) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token if it matches the expected value, and return whether this method was indeed able to consume the token.
canConsume(int, String, String...) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token and the next tokens if and only if they match the expected type and values, and return whether this method was indeed able to consume all of the supplied tokens.
canConsume(Iterable<String>) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token and the next tokens if and only if they match the expected values, and return whether this method was indeed able to consume all of the supplied tokens.
canConsume(String) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token if it matches the expected value, and return whether this method was indeed able to consume the token.
canConsume(String[]) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token and the next tokens if and only if they match the expected values, and return whether this method was indeed able to consume all of the supplied tokens.
canConsume(String, String...) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token and the next tokens if and only if they match the expected values, and return whether this method was indeed able to consume all of the supplied tokens.
canConsumeAnyOf(int[]) - Method in class io.debezium.text.TokenStream
Attempt to consume the next token if it matches one of the supplied types.
canConsumeAnyOf(int, int...) - Method in class io.debezium.text.TokenStream
Attempt to consume the next token if it matches one of the supplied types.
canConsumeAnyOf(Iterable<String>) - Method in class io.debezium.text.TokenStream
Attempt to consume the next token if it matches one of the supplied values.
canConsumeAnyOf(String[]) - Method in class io.debezium.text.TokenStream
Attempt to consume the next token if it matches one of the supplied values.
canConsumeAnyOf(String, String...) - Method in class io.debezium.text.TokenStream
Attempt to consume the next token if it matches one of the supplied values.
canConsumeBoolean(BooleanConsumer) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token if it can be parsed as a boolean, and return whether this method was indeed able to consume the token.
canConsumeInteger(IntConsumer) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token if it can be parsed as an integer, and return whether this method was indeed able to consume the token.
canConsumeLong(LongConsumer) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token if it can be parsed as a long, and return whether this method was indeed able to consume the token.
canConsumeWord(String) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token if it is TokenStream.BasicTokenizer.WORD and it matches the expected value, and return whether this method was indeed able to consume the token.
canConsumeWords(String, String...) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token and the next tokens if and only if they are of TokenStream.BasicTokenizer.WORD and match the expected values, and return whether this method was indeed able to consume all of the supplied tokens.
capturedDataCollections() - Method in class io.debezium.connector.common.CdcSourceTaskContext
 
capturedSchemaTables - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource.RelationalSnapshotContext
 
capturedTables - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
capturedTables - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource.RelationalSnapshotContext
 
captureInstance - Variable in class io.debezium.relational.ChangeTable
 
CaseInsensitiveToken(int, int, int, Position) - Constructor for class io.debezium.text.TokenStream.CaseInsensitiveToken
 
CaseInsensitiveTokenFactory() - Constructor for class io.debezium.text.TokenStream.CaseInsensitiveTokenFactory
 
caseSensitive - Variable in class io.debezium.text.TokenStream
 
CaseSensitiveToken(int, int, int, Position) - Constructor for class io.debezium.text.TokenStream.CaseSensitiveToken
 
CaseSensitiveTokenFactory() - Constructor for class io.debezium.text.TokenStream.CaseSensitiveTokenFactory
 
CASSANDRA_CONNECTOR - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
catalog() - Method in class io.debezium.relational.ColumnId
Get the name of the JDBC catalog.
catalog() - Method in class io.debezium.relational.TableId
Get the name of the JDBC catalog.
CATALOG - Enum constant in enum io.debezium.relational.ColumnFilterMode
 
catalogName - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource.RelationalSnapshotContext
 
catalogName - Variable in class io.debezium.relational.TableId
 
CatchUpStreamingResult(boolean) - Constructor for class io.debezium.pipeline.ChangeEventSourceCoordinator.CatchUpStreamingResult
 
CdcSourceTaskContext - Class in io.debezium.connector.common
Contains contextual information and objects scoped to the lifecycle of Debezium's SourceTask implementations.
CdcSourceTaskContext(String, String, String, Supplier<Collection<? extends DataCollectionId>>) - Constructor for class io.debezium.connector.common.CdcSourceTaskContext
 
CdcSourceTaskContext(String, String, Supplier<Collection<? extends DataCollectionId>>) - Constructor for class io.debezium.connector.common.CdcSourceTaskContext
 
ceDataAttribute() - Method in class io.debezium.converters.spi.CloudEventsMaker
Construct the value of the data attribute of CloudEvents.
ceDataAttributeSchema - Variable in class io.debezium.converters.spi.CloudEventsMaker
 
ceDataAttributeSchema() - Method in class io.debezium.converters.spi.CloudEventsMaker
Construct the schema of the data attribute of CloudEvents.
ceDatacontenttype() - Method in class io.debezium.converters.spi.CloudEventsMaker
Get the data content type of CloudEvents envelope.
ceDataschemaUri(String) - Method in class io.debezium.converters.spi.CloudEventsMaker
Get the data schema url of CloudEvents envelope.
ceEnvelopeSchemaName() - Method in class io.debezium.converters.spi.CloudEventsMaker
Construct the name of the schema of CloudEvents envelope.
ceId() - Method in class io.debezium.converters.spi.CloudEventsMaker
Construct the id of CloudEvents envelope.
CENTER - Enum constant in enum io.debezium.util.Strings.Justify
 
ceSchemaFromSchema(Schema, CloudEventsConverter.CESchemaBuilder, Function<String, String>, boolean) - Method in class io.debezium.converters.CloudEventsConverter
 
ceSerializerType - Variable in class io.debezium.converters.CloudEventsConverter
 
ceSource(String) - Method in class io.debezium.converters.spi.CloudEventsMaker
Construct the source field of CloudEvents envelope, e.g.
ceSpecversion() - Method in class io.debezium.converters.spi.CloudEventsMaker
Get the version of CloudEvents specification.
ceTime() - Method in class io.debezium.converters.spi.CloudEventsMaker
Get the timestamp of CloudEvents envelope using the format defined in RFC 3339.
ceType() - Method in class io.debezium.converters.spi.CloudEventsMaker
Construct the type field of CloudEvents envelope.
ceValueFromStruct(Struct, Schema, CloudEventsConverter.CEValueBuilder, Function<String, String>) - Method in class io.debezium.converters.CloudEventsConverter
 
CHANGE_SPECIAL_FIELD - Static variable in class io.debezium.transforms.partitions.PartitionRouting
 
changeBoolean(Field, Function<Boolean, Boolean>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing boolean field.
changeBoolean(String, Function<Boolean, Boolean>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing boolean field.
changeDouble(Field, Function<Double, Double>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing double field.
changeDouble(String, Function<Double, Double>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing double field.
changedSchema - Variable in class io.debezium.transforms.ExtractChangedRecordState
 
changeEventCreator - Variable in class io.debezium.pipeline.EventDispatcher
 
ChangeEventCreator - Interface in io.debezium.pipeline.spi
 
ChangeEventQueue<T extends Sizeable> - Class in io.debezium.connector.base
A queue which serves as handover point between producer threads (e.g.
ChangeEventQueue(Duration, int, int, Supplier<LoggingContext.PreviousContext>, long, boolean) - Constructor for class io.debezium.connector.base.ChangeEventQueue
 
ChangeEventQueue.Builder<T extends Sizeable> - Class in io.debezium.connector.base
 
changeEventQueueMetrics - Variable in class io.debezium.pipeline.metrics.PipelineMetrics
 
ChangeEventQueueMetrics - Interface in io.debezium.connector.base
 
ChangeEventSource - Interface in io.debezium.pipeline.source.spi
 
ChangeEventSource.ChangeEventSourceContext - Interface in io.debezium.pipeline.source.spi
 
ChangeEventSourceContextImpl() - Constructor for class io.debezium.pipeline.ChangeEventSourceCoordinator.ChangeEventSourceContextImpl
 
ChangeEventSourceCoordinator<P extends Partition,O extends OffsetContext> - Class in io.debezium.pipeline
Coordinates one or more ChangeEventSources and executes them in order.
ChangeEventSourceCoordinator(Offsets<P, O>, ErrorHandler, Class<? extends SourceConnector>, CommonConnectorConfig, ChangeEventSourceFactory<P, O>, ChangeEventSourceMetricsFactory<P>, EventDispatcher<P, ?>, DatabaseSchema<?>, SignalProcessor<P, O>, NotificationService<P, O>) - Constructor for class io.debezium.pipeline.ChangeEventSourceCoordinator
 
ChangeEventSourceCoordinator.CatchUpStreamingResult - Class in io.debezium.pipeline
 
ChangeEventSourceCoordinator.ChangeEventSourceContextImpl - Class in io.debezium.pipeline
 
changeEventSourceFactory - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
ChangeEventSourceFactory<P extends Partition,O extends OffsetContext> - Interface in io.debezium.pipeline.source.spi
A factory for creating ChangeEventSources specific to one database.
ChangeEventSourceMetrics<P extends Partition> - Interface in io.debezium.pipeline.metrics
Common API for all change event source metrics regardless of the connector phase.
changeEventSourceMetricsFactory - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
ChangeEventSourceMetricsFactory<P extends Partition> - Interface in io.debezium.pipeline.metrics.spi
ChangeEventSourceMetricsMXBean - Interface in io.debezium.pipeline.metrics
Metrics that are common for both snapshot and streaming change event sources
changeFloat(Field, Function<Float, Float>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing float field.
changeFloat(String, Function<Float, Float>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing float field.
changeInteger(Field, Function<Integer, Integer>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing integer field.
changeInteger(String, Function<Integer, Integer>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing integer field.
changeLong(Field, Function<Long, Long>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing long field.
changeLong(String, Function<Long, Long>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing long field.
changeRecord(P, DataCollectionSchema, Envelope.Operation, Object, Struct, OffsetContext, ConnectHeaders) - Method in class io.debezium.pipeline.EventDispatcher.BufferingSnapshotChangeRecordReceiver
 
changeRecord(P, DataCollectionSchema, Envelope.Operation, Object, Struct, OffsetContext, ConnectHeaders) - Method in class io.debezium.pipeline.EventDispatcher.IncrementalSnapshotChangeRecordReceiver
 
changeRecord(P, DataCollectionSchema, Envelope.Operation, Object, Struct, OffsetContext, ConnectHeaders) - Method in class io.debezium.pipeline.EventDispatcher.StreamingChangeRecordReceiver
 
changeRecord(P, DataCollectionSchema, Envelope.Operation, Object, Struct, OffsetContext, ConnectHeaders) - Method in interface io.debezium.pipeline.spi.ChangeRecordEmitter.Receiver
 
ChangeRecordEmitter<P extends Partition> - Interface in io.debezium.pipeline.spi
Represents a change applied to a source database and emits one or more corresponding change records.
ChangeRecordEmitter.Receiver<P extends Partition> - Interface in io.debezium.pipeline.spi
Callback passed to ChangeRecordEmitters, allowing them to produce one or more change records.
changes - Variable in class io.debezium.relational.history.TableChanges
 
changes - Variable in class io.debezium.relational.Tables
 
changeSchema - Variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
changesRecovered - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
changeString(Field, Function<String, String>) - Method in class io.debezium.config.Configuration.Builder
 
changeString(Field, Function<String, String>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing string field.
changeString(String, String, Function<String, String>) - Method in class io.debezium.config.Configuration.Builder
 
changeString(String, Function<String, String>) - Method in class io.debezium.config.Configuration.Builder
 
changeString(String, Function<String, String>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Apply the function to this builder to change a potentially existing string field.
changeTable - Variable in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
ChangeTable - Class in io.debezium.relational
A logical representation of a change table containing changes for a given source table.
ChangeTable(String, TableId, TableId, int) - Constructor for class io.debezium.relational.ChangeTable
Creates an object that represents a source table's change table.
changeTableId - Variable in class io.debezium.relational.ChangeTable
 
changeTableObjectId - Variable in class io.debezium.relational.ChangeTable
 
ChangeTableResultSet<C extends ChangeTable,T extends Comparable<T>> - Class in io.debezium.pipeline.source.spi
A wrapper around a JDBC ResultSet for a change table for processing rows.
ChangeTableResultSet(C, ResultSet, int) - Constructor for class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
CHANNEL_NAME - Static variable in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
CHANNEL_NAME - Static variable in class io.debezium.pipeline.notification.channels.LogNotificationChannel
 
CHANNEL_NAME - Static variable in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
CHANNEL_NAME - Static variable in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
CHANNEL_NAME - Static variable in class io.debezium.pipeline.signal.channels.jmx.JmxSignalChannel
 
CHANNEL_NAME - Static variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
CHANNEL_NAME - Static variable in class io.debezium.pipeline.signal.channels.SourceSignalChannel
 
CHANNEL_OFFSET - Static variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
CharacterArrayStream(char[]) - Constructor for class io.debezium.text.TokenStream.CharacterArrayStream
 
CHARSET_NAME_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
charsetName - Variable in class io.debezium.relational.ColumnEditorImpl
 
charsetName - Variable in class io.debezium.relational.ColumnImpl
 
charsetName() - Method in interface io.debezium.relational.Column
Get the database-specific name of the character set used by this column.
charsetName() - Method in interface io.debezium.relational.ColumnEditor
Get the database-specific name of the character set used by this column.
charsetName() - Method in class io.debezium.relational.ColumnEditorImpl
 
charsetName() - Method in class io.debezium.relational.ColumnImpl
 
charsetName(String) - Method in interface io.debezium.relational.ColumnEditor
Set the database-specific name of the character set used by this column.
charsetName(String) - Method in class io.debezium.relational.ColumnEditorImpl
 
charsetNameOfTable() - Method in interface io.debezium.relational.ColumnEditor
Get the database-specific name of the character set defined by this column's table, which is used if a character set is not explicitly set on this column.
charsetNameOfTable() - Method in class io.debezium.relational.ColumnEditorImpl
 
charsetNameOfTable(String) - Method in interface io.debezium.relational.ColumnEditor
Set the database-specific name of the character set defined by this column's table.
charsetNameOfTable(String) - Method in class io.debezium.relational.ColumnEditorImpl
 
checkConfigurationConsistency() - Method in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
checkSchemaChanges(ResultSet) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
ChildPath(Path, String) - Constructor for class io.debezium.document.Paths.ChildPath
 
children(Path) - Method in interface io.debezium.document.Document
Find a document at the given path and obtain a stream over its fields.
children(String) - Method in interface io.debezium.document.Document
Find the document at the given field name and obtain a stream over its fields.
chunkEndPosition - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
The last primary key in chunk that is now in process.
chunkEndPosititon() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
chunkEndPosititon() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
chunkFrom - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
chunkId - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
chunkTo - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
className - Variable in class io.debezium.metadata.ConnectorDescriptor
 
cleanupPreparedStatement(PreparedStatement) - Method in class io.debezium.jdbc.JdbcConnection
 
clear() - Method in class io.debezium.document.BasicDocument
 
clear() - Method in interface io.debezium.document.Document
Remove all fields from this document.
clear() - Method in class io.debezium.relational.RelationalDatabaseSchema.SchemasByTableId
 
clear() - Method in class io.debezium.relational.Tables
 
clear() - Method in class io.debezium.relational.Tables.TableIds
 
clear() - Method in class io.debezium.relational.Tables.TablesById
 
clear() - Method in class io.debezium.util.BoundedConcurrentHashMap
Removes all of the mappings from this map.
clear() - Method in class io.debezium.util.BoundedConcurrentHashMap.EntrySet
 
clear() - Method in interface io.debezium.util.BoundedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that all Segment entries have been cleared.
clear() - Method in class io.debezium.util.BoundedConcurrentHashMap.KeySet
 
clear() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
clear() - Method in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
clear() - Method in class io.debezium.util.BoundedConcurrentHashMap.NullEvictionPolicy
 
clear() - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
clear() - Method in class io.debezium.util.BoundedConcurrentHashMap.Values
 
clearSchemas() - Method in class io.debezium.relational.RelationalDatabaseSchema
 
clearWarnings() - Method in class io.debezium.jdbc.CancellableResultSet
 
clock - Variable in class io.debezium.connector.common.BaseSourceTask
 
clock - Variable in class io.debezium.connector.common.CdcSourceTaskContext
 
clock - Variable in class io.debezium.pipeline.AbstractChangeRecordEmitter
 
clock - Variable in class io.debezium.pipeline.meters.CommonEventMeter
 
clock - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
clock - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
clock - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
clock - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
Clock - Interface in io.debezium.util
An abstraction for a clock.
clone() - Method in interface io.debezium.document.Array
Obtain a complete copy of this array.
clone() - Method in class io.debezium.document.BasicArray
 
clone() - Method in class io.debezium.document.BasicDocument
 
clone() - Method in class io.debezium.document.BinaryValue
 
clone() - Method in class io.debezium.document.ComparableValue
 
clone() - Method in class io.debezium.document.ConvertingValue
 
clone() - Method in interface io.debezium.document.Document
Obtain a clone of this document.
clone() - Method in class io.debezium.document.NullValue
 
clone() - Method in interface io.debezium.document.Value
Obtain a clone of this value.
clone() - Method in class io.debezium.relational.Tables
 
close() - Method in class io.debezium.converters.BinaryDataConverter
 
close() - Method in class io.debezium.converters.ByteArrayConverter
 
close() - Method in class io.debezium.document.ArraySerdes
 
close() - Method in class io.debezium.document.DocumentSerdes
 
close() - Method in class io.debezium.heartbeat.DatabaseHeartbeatImpl
 
close() - Method in interface io.debezium.heartbeat.Heartbeat
 
close() - Method in class io.debezium.jdbc.CancellableResultSet
 
close() - Method in class io.debezium.jdbc.JdbcConnection
Close the connection and release any resources.
close() - Method in class io.debezium.pipeline.EventDispatcher
 
close() - Method in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
close() - Method in class io.debezium.pipeline.notification.channels.LogNotificationChannel
 
close() - Method in interface io.debezium.pipeline.notification.channels.NotificationChannel
 
close() - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
close() - Method in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
close() - Method in class io.debezium.pipeline.signal.channels.jmx.JmxSignalChannel
 
close() - Method in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
close() - Method in interface io.debezium.pipeline.signal.channels.SignalChannelReader
 
close() - Method in class io.debezium.pipeline.signal.channels.SourceSignalChannel
 
close() - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
Completes the snapshot, doing any required clean-up (resource disposal etc.).
close() - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshotContext
 
close() - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
close() - Method in class io.debezium.relational.RelationalDatabaseSchema
 
close() - Method in class io.debezium.serde.json.JsonSerde
 
close() - Method in class io.debezium.serde.json.JsonSerde.JsonDeserializer
 
close() - Method in class io.debezium.serde.json.JsonSerde.JsonSerializer
 
close() - Method in class io.debezium.transforms.ByLogicalTableRouter
 
close() - Method in class io.debezium.transforms.ExtractChangedRecordState
 
close() - Method in class io.debezium.transforms.ExtractNewRecordState
 
close() - Method in class io.debezium.transforms.HeaderToValue
 
close() - Method in class io.debezium.transforms.outbox.EventRouter
 
close() - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
close() - Method in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
close() - Method in class io.debezium.transforms.partitions.PartitionRouting
 
close() - Method in class io.debezium.transforms.tracing.ActivateTracingSpan
 
close(Function<T, T>) - Method in interface io.debezium.function.BufferedBlockingConsumer
Flush all of the buffered values to the delegate by first running each buffered value through the given function to generate a new value to be flushed to the delegate consumer.
CloseIncrementalSnapshotWindow<P extends Partition> - Class in io.debezium.pipeline.signal.actions.snapshotting
 
CloseIncrementalSnapshotWindow(EventDispatcher<P, ? extends DataCollectionId>) - Constructor for class io.debezium.pipeline.signal.actions.snapshotting.CloseIncrementalSnapshotWindow
 
closeWindow(String) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
closeWindow(String) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
closeWindow(P, String, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
closeWindow(P, String, OffsetContext) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
closingQuoteCharacter - Variable in class io.debezium.jdbc.JdbcConnection
 
CLOUDEVENTS_DATA_SERIALIZER_TYPE_CONFIG - Static variable in class io.debezium.converters.CloudEventsConverterConfig
 
CLOUDEVENTS_DATA_SERIALIZER_TYPE_DEFAULT - Static variable in class io.debezium.converters.CloudEventsConverterConfig
 
CLOUDEVENTS_DATA_SERIALIZER_TYPE_DOC - Static variable in class io.debezium.converters.CloudEventsConverterConfig
 
CLOUDEVENTS_SCHEMA_NAME_ADJUSTMENT_MODE_CONFIG - Static variable in class io.debezium.converters.CloudEventsConverterConfig
 
CLOUDEVENTS_SCHEMA_NAME_ADJUSTMENT_MODE_DEFAULT - Static variable in class io.debezium.converters.CloudEventsConverterConfig
 
CLOUDEVENTS_SCHEMA_NAME_ADJUSTMENT_MODE_DOC - Static variable in class io.debezium.converters.CloudEventsConverterConfig
 
CLOUDEVENTS_SERIALIZER_TYPE_CONFIG - Static variable in class io.debezium.converters.CloudEventsConverterConfig
 
CLOUDEVENTS_SERIALIZER_TYPE_DEFAULT - Static variable in class io.debezium.converters.CloudEventsConverterConfig
 
CLOUDEVENTS_SERIALIZER_TYPE_DOC - Static variable in class io.debezium.converters.CloudEventsConverterConfig
 
CLOUDEVENTS_SPECVERSION - Static variable in class io.debezium.converters.spi.CloudEventsMaker
 
CloudEventsConverter - Class in io.debezium.converters
Implementation of Converter that express schemas and objects with CloudEvents specification.
CloudEventsConverter() - Constructor for class io.debezium.converters.CloudEventsConverter
 
CloudEventsConverter(Converter) - Constructor for class io.debezium.converters.CloudEventsConverter
 
CloudEventsConverter.CESchemaBuilder - Interface in io.debezium.converters
Builder of a CloudEvents envelope schema.
CloudEventsConverter.CEValueBuilder - Interface in io.debezium.converters
Builder of a CloudEvents value.
CloudEventsConverterConfig - Class in io.debezium.converters
Configuration options for CloudEventsConverter instances.
CloudEventsConverterConfig(Map<String, ?>) - Constructor for class io.debezium.converters.CloudEventsConverterConfig
 
cloudeventsDataSerializerTypeConfig() - Method in class io.debezium.converters.CloudEventsConverterConfig
Return which serializer type is used to serialize the data field of CloudEvents values.
CloudEventsMaker - Class in io.debezium.converters.spi
An abstract class that builds CloudEvents attributes using fields of change records provided by RecordParser.
CloudEventsMaker(RecordParser, SerializerType, String) - Constructor for class io.debezium.converters.spi.CloudEventsMaker
 
CloudEventsMaker.FieldName - Class in io.debezium.converters.spi
The constants for the names of CloudEvents attributes.
CloudEventsProvider - Interface in io.debezium.converters.spi
A ServiceLoader interface that connectors should implement if they wish to provide a way to emit change events using the CloudEvents converter and format.
cloudeventsSerializerType() - Method in class io.debezium.converters.CloudEventsConverterConfig
Return which serializer type is used to serialize CloudEvents values.
code - Variable in enum io.debezium.data.Envelope.Operation
 
code() - Method in enum io.debezium.data.Envelope.Operation
 
cold() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Marks this entry as cold.
coldHit(Set<BoundedConcurrentHashMap.HashEntry<K, V>>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Records a cache hit on a cold block.
Collect - Class in io.debezium.util
A set of utilities for more easily creating various kinds of collections.
Collect() - Constructor for class io.debezium.util.Collect
 
COLLECTION_FIELD_NAME - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
COLLECTION_NAME_KEY - Static variable in class io.debezium.connector.AbstractSourceInfo
 
collectionsSupplier - Variable in class io.debezium.connector.common.CdcSourceTaskContext
Obtains the data collections captured at the point of invocation.
column - Variable in class io.debezium.text.Position
 
column() - Method in class io.debezium.text.Position
Get the 1-based column number of the character.
Column - Interface in io.debezium.relational
An immutable definition of a column.
COLUMN_COMMENT_PARAMETER_KEY - Static variable in class io.debezium.relational.mapping.PropagateSourceTypeToSchemaParameter
 
COLUMN_EXCLUDE_LIST - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
A comma-separated list of regular expressions that match fully-qualified names of columns to be excluded from monitoring and change messages.
COLUMN_INCLUDE_LIST - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
A comma-separated list of regular expressions that match fully-qualified names of columns to be excluded from monitoring and change messages.
COLUMN_INCLUDE_LIST_ALREADY_SPECIFIED_ERROR_MSG - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
COLUMN_SPLIT - Static variable in class io.debezium.relational.Key.CustomKeyMapper
 
ColumnArray(Column[], int) - Constructor for class io.debezium.util.ColumnUtils.ColumnArray
 
columnDataOffset - Variable in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
columnDefs - Variable in class io.debezium.relational.TableImpl
 
ColumnEditor - Interface in io.debezium.relational
An editor for Column instances.
ColumnEditorImpl - Class in io.debezium.relational
 
ColumnEditorImpl() - Constructor for class io.debezium.relational.ColumnEditorImpl
 
columnFilter - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
columnFilter - Variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
columnFilter - Variable in class io.debezium.relational.RelationalDatabaseSchema
 
ColumnFilterMode - Enum in io.debezium.relational
Modes for column name filters, either including a catalog (database) or schema name.
ColumnFilterMode() - Constructor for enum io.debezium.relational.ColumnFilterMode
 
columnId(TableId, String) - Static method in class io.debezium.relational.ColumnId
 
ColumnId - Class in io.debezium.relational
Unique identifier for a column in a database table.
ColumnId(TableId, String) - Constructor for class io.debezium.relational.ColumnId
Create a new column identifier.
ColumnId(String, String, String, String) - Constructor for class io.debezium.relational.ColumnId
Create a new column identifier.
ColumnImpl - Class in io.debezium.relational
 
ColumnImpl(String, int, int, int, String, String, String, String, int, Integer, boolean, boolean, boolean) - Constructor for class io.debezium.relational.ColumnImpl
 
ColumnImpl(String, int, int, int, String, String, String, String, int, Integer, boolean, boolean, boolean, String, boolean) - Constructor for class io.debezium.relational.ColumnImpl
 
ColumnImpl(String, int, int, int, String, String, String, String, int, Integer, List<String>, boolean, boolean, boolean, String, boolean, String) - Constructor for class io.debezium.relational.ColumnImpl
 
ColumnMapper - Interface in io.debezium.relational.mapping
A factory for a function used to map values of a column.
columnMappers - Variable in class io.debezium.relational.RelationalDatabaseSchema
 
ColumnMappers - Class in io.debezium.relational.mapping
A set of ColumnMapper objects for columns.
ColumnMappers(List<ColumnMappers.MapperRule>) - Constructor for class io.debezium.relational.mapping.ColumnMappers
 
ColumnMappers.Builder - Class in io.debezium.relational.mapping
A builder of Selectors.
ColumnMappers.MapperRule - Class in io.debezium.relational.mapping
 
columnName - Variable in class io.debezium.relational.ColumnId
 
columnName() - Method in class io.debezium.relational.ColumnId
Get the name of the table.
ColumnNameFilterFactory() - Constructor for class io.debezium.relational.Tables.ColumnNameFilterFactory
 
columnNames() - Method in interface io.debezium.relational.TableEditor
Get the names of the columns in this table.
columnNumber - Variable in class io.debezium.text.TokenStream.CharacterArrayStream
 
columns - Variable in class io.debezium.util.ColumnUtils.ColumnArray
 
columns() - Method in class io.debezium.relational.NoOpTableEditorImpl
 
columns() - Method in interface io.debezium.relational.Table
Get the definitions for the columns in this table, in the same order in which the table defines them.
columns() - Method in interface io.debezium.relational.TableEditor
Get the definitions for the columns in this table.
columns() - Method in class io.debezium.relational.TableEditorImpl
 
columns() - Method in class io.debezium.relational.TableImpl
 
COLUMNS_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
columnsByLowercaseName - Variable in class io.debezium.relational.TableImpl
 
columnSchema - Variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
columnsFiltered - Variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
ColumnUtils - Class in io.debezium.util
Utility class for mapping columns to various data structures from from Table and ResultSet.
ColumnUtils() - Constructor for class io.debezium.util.ColumnUtils
 
ColumnUtils.ColumnArray - Class in io.debezium.util
 
ColumnUtils.MappedColumns - Class in io.debezium.util
 
columnWithName(String) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
columnWithName(String) - Method in interface io.debezium.relational.Table
Get the definition for the column in this table with the supplied name.
columnWithName(String) - Method in interface io.debezium.relational.TableEditor
Get the definition for the column in this table with the supplied name.
columnWithName(String) - Method in class io.debezium.relational.TableEditorImpl
 
columnWithName(String) - Method in class io.debezium.relational.TableImpl
 
combineVariables(Field[], Field...) - Static method in class io.debezium.jdbc.JdbcConnection
 
comment - Variable in class io.debezium.relational.ColumnEditorImpl
 
comment - Variable in class io.debezium.relational.ColumnImpl
 
comment - Variable in class io.debezium.relational.NoOpTableEditorImpl
 
comment - Variable in class io.debezium.relational.TableEditorImpl
 
comment - Variable in class io.debezium.relational.TableImpl
 
comment() - Method in interface io.debezium.relational.Column
Get the comment of the column.
comment() - Method in interface io.debezium.relational.ColumnEditor
Get the comment of the column.
comment() - Method in class io.debezium.relational.ColumnEditorImpl
 
comment() - Method in class io.debezium.relational.ColumnImpl
 
comment() - Method in interface io.debezium.relational.Table
Get the comment of the table.
comment() - Method in class io.debezium.relational.TableImpl
 
comment(String) - Method in interface io.debezium.relational.ColumnEditor
Set the comment of the column
comment(String) - Method in class io.debezium.relational.ColumnEditorImpl
 
COMMENT - Static variable in class io.debezium.text.TokenStream.BasicTokenizer
The token type for tokens that consist of all the characters between "/*" and "*/" or between "//" and the next line terminator (e.g., '\n', '\r' or "\r\n").
COMMENT_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
commentParsed(String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
commit() - Method in class io.debezium.connector.common.BaseSourceTask
 
commit() - Method in class io.debezium.jdbc.JdbcConnection
 
commitOffset(Map<String, ?>, Map<String, ?>) - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
commitOffset(Map<String, ?>, Map<String, ?>) - Method in interface io.debezium.pipeline.source.spi.StreamingChangeEventSource
Commits the given offset with the source database.
commitOffsetLock - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
commitRecord(SourceRecord) - Method in class io.debezium.connector.common.BaseSourceTask
 
CommonConnectorConfig - Class in io.debezium.config
Configuration options common to all Debezium connectors.
CommonConnectorConfig(Configuration, int) - Constructor for class io.debezium.config.CommonConnectorConfig
 
CommonConnectorConfig.BinaryHandlingMode - Enum in io.debezium.config
The set of predefined BinaryHandlingMode options or aliases
CommonConnectorConfig.EventProcessingFailureHandlingMode - Enum in io.debezium.config
The set of predefined modes for dealing with failures during event processing.
CommonConnectorConfig.FieldNameAdjustmentMode - Enum in io.debezium.config
The set of predefined FieldNameAdjustmentMode options
CommonConnectorConfig.SchemaNameAdjustmentMode - Enum in io.debezium.config
The set of predefined SchemaNameAdjustmentMode options
CommonConnectorConfig.Version - Enum in io.debezium.config
The set of predefined versions e.g.
commonEventMeter - Variable in class io.debezium.pipeline.metrics.PipelineMetrics
 
CommonEventMeter - Class in io.debezium.pipeline.meters
Carries common event metrics.
CommonEventMeter(Clock, EventMetadataProvider) - Constructor for class io.debezium.pipeline.meters.CommonEventMeter
 
CommonEventMetricsMXBean - Interface in io.debezium.pipeline.metrics.traits
Exposes common event metrics.
CommonOffsetContext<T extends BaseSourceInfo> - Class in io.debezium.pipeline
 
CommonOffsetContext(T) - Constructor for class io.debezium.pipeline.CommonOffsetContext
 
commonSchemaBuilder() - Method in class io.debezium.connector.AbstractSourceInfoStructMaker
 
commonSchemaBuilder() - Method in class io.debezium.connector.LegacyV1AbstractSourceInfoStructMaker
 
commonStruct() - Method in class io.debezium.connector.LegacyV1AbstractSourceInfoStructMaker
 
commonStruct(T) - Method in class io.debezium.connector.AbstractSourceInfoStructMaker
 
communicationExceptions() - Method in class io.debezium.pipeline.ErrorHandler
 
comparable() - Method in interface io.debezium.document.Value
Get a Value representation that will allow semantic comparison of values, rather than the literal comparison normally performed by Value.compareTo(io.debezium.document.Value, io.debezium.document.Value).
ComparableValue - Class in io.debezium.document
A specialization of Value that wraps another Value that is not comparable.
ComparableValue(Comparable<?>) - Constructor for class io.debezium.document.ComparableValue
 
comparator - Variable in class io.debezium.relational.history.AbstractSchemaHistory
 
compare(Value, Value) - Method in class io.debezium.document.BasicDocument
Semantically compare two values.
compareNonNull(Value, Value) - Method in class io.debezium.document.BasicDocument
Semantically compare two non-null values.
compareTo(Array) - Method in class io.debezium.document.BasicArray
 
compareTo(Array.Entry) - Method in interface io.debezium.document.Array.Entry
 
compareTo(Array.Entry) - Method in class io.debezium.document.BasicEntry
 
compareTo(Document) - Method in class io.debezium.document.BasicDocument
 
compareTo(Document) - Method in interface io.debezium.document.Document
Compare this Document to the specified Document, taking into account the order of the fields.
compareTo(Document.Field) - Method in class io.debezium.document.BasicField
 
compareTo(Document.Field) - Method in interface io.debezium.document.Document.Field
 
compareTo(Document, boolean) - Method in class io.debezium.document.BasicDocument
 
compareTo(Document, boolean) - Method in interface io.debezium.document.Document
Compare this Document to the specified Document, optionally comparing the fields in the same order.
compareTo(Value) - Method in class io.debezium.document.BinaryValue
 
compareTo(Value) - Method in class io.debezium.document.ComparableValue
 
compareTo(Value) - Method in class io.debezium.document.ConvertingValue
 
compareTo(Value) - Method in class io.debezium.document.NullValue
 
compareTo(Value, Value) - Static method in interface io.debezium.document.Value
Compare two Value objects, which may or may not be null.
compareTo(ChangeTableResultSet<C, T>) - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
compareTo(Column) - Method in interface io.debezium.relational.Column
 
compareTo(ColumnId) - Method in class io.debezium.relational.ColumnId
 
compareTo(TableId) - Method in class io.debezium.relational.TableId
 
compareTo(TokenStream.Marker) - Method in class io.debezium.text.TokenStream.Marker
 
compareTo(CharSequence, CharSequence) - Static method in class io.debezium.util.Strings
Compare two CharSequence instances.
compareToIgnoreCase(ColumnId) - Method in class io.debezium.relational.ColumnId
 
compareToIgnoreCase(TableId) - Method in class io.debezium.relational.TableId
 
compareToUsingSimilarFields(Document) - Method in class io.debezium.document.BasicDocument
 
compareToUsingSimilarFields(Document) - Method in interface io.debezium.document.Document
Compare this Document to the specified Document, without regard to the order of the fields and only using the fields that are in both documents.
compareToWithoutFieldOrder(Document) - Method in class io.debezium.document.BasicDocument
 
compareToWithoutFieldOrder(Document) - Method in interface io.debezium.document.Document
Compare this Document to the specified Document, without regard to the order of the fields.
completed - Variable in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
completed - Variable in class io.debezium.text.TokenStream
 
completed(AbstractSnapshotChangeEventSource.SnapshotContext<P, O>) - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
Completes the snapshot, doing any required clean-up (resource disposal etc.).
completed(O) - Static method in class io.debezium.pipeline.spi.SnapshotResult
 
COMPLETED - Enum constant in enum io.debezium.pipeline.notification.IncrementalSnapshotNotificationService.SnapshotStatus
 
COMPLETED - Enum constant in enum io.debezium.pipeline.spi.SnapshotResult.SnapshotResultStatus
 
completeSnapshot() - Method in class io.debezium.pipeline.EventDispatcher.BufferingSnapshotChangeRecordReceiver
 
completeSnapshot() - Method in class io.debezium.pipeline.EventDispatcher.IncrementalSnapshotChangeRecordReceiver
 
completeSnapshot() - Method in interface io.debezium.pipeline.EventDispatcher.SnapshotReceiver
 
composeMessage(Notification) - Method in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
compute(Object...) - Static method in class io.debezium.util.HashCode
Compute a combined hash code from the supplied objects.
computeHashCode(int, Object...) - Static method in class io.debezium.util.HashCode
Compute a combined hash code from the supplied objects using the supplied seed.
computePartition(Integer, List<Object>) - Method in class io.debezium.transforms.partitions.PartitionRouting
 
computePartition(Object, String) - Method in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
ComputePartition<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.transforms.partitions
Deprecated.
This SMT will be soon removed.

Use PartitionRouting instead.

ComputePartition() - Constructor for class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
ComputePartitionConfigDefinition - Class in io.debezium.transforms.partitions
Deprecated.
This Configuration will be soon removed.

Use PartitionRouting instead.

ComputePartitionConfigDefinition() - Constructor for class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
ComputePartitionException - Exception in io.debezium.transforms.partitions
Deprecated.
ComputePartitionException() - Constructor for exception io.debezium.transforms.partitions.ComputePartitionException
Deprecated.
 
ComputePartitionException(String) - Constructor for exception io.debezium.transforms.partitions.ComputePartitionException
Deprecated.
 
ComputePartitionException(String, Throwable) - Constructor for exception io.debezium.transforms.partitions.ComputePartitionException
Deprecated.
 
ComputePartitionException(String, Throwable, boolean, boolean) - Constructor for exception io.debezium.transforms.partitions.ComputePartitionException
Deprecated.
 
ComputePartitionException(Throwable) - Constructor for exception io.debezium.transforms.partitions.ComputePartitionException
Deprecated.
 
config - Variable in class io.debezium.config.CommonConnectorConfig
 
config - Variable in class io.debezium.connector.AbstractSourceInfo
 
config - Variable in class io.debezium.connector.common.BaseSourceTask
 
config - Variable in class io.debezium.jdbc.JdbcConnection
 
config - Variable in class io.debezium.relational.history.AbstractSchemaHistory
 
config - Variable in class io.debezium.serde.json.JsonSerde
 
config() - Method in class io.debezium.converters.BinaryDataConverter
 
config() - Method in class io.debezium.converters.ByteArrayConverter
 
config() - Method in class io.debezium.jdbc.JdbcConnection
Obtain the configuration for this connection.
config() - Method in class io.debezium.transforms.ByLogicalTableRouter
 
config() - Method in class io.debezium.transforms.ExtractChangedRecordState
 
config() - Method in class io.debezium.transforms.ExtractNewRecordState
 
config() - Method in class io.debezium.transforms.HeaderToValue
 
config() - Method in class io.debezium.transforms.outbox.EventRouter
 
config() - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
config() - Method in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
config() - Method in class io.debezium.transforms.partitions.PartitionRouting
 
config() - Method in class io.debezium.transforms.tracing.ActivateTracingSpan
 
CONFIG - Static variable in class io.debezium.converters.CloudEventsConverterConfig
 
CONFIG - Static variable in class io.debezium.serde.json.JsonSerdeConfig
 
CONFIG_DEF - Static variable in class io.debezium.converters.BinaryDataConverter
 
CONFIG_DEF - Static variable in class io.debezium.converters.ByteArrayConverter
 
CONFIG_DEFINITION - Static variable in class io.debezium.config.CommonConnectorConfig
 
CONFIG_DEFINITION - Static variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
CONFIG_DEFINITION - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
CONFIG_FIELDS - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
configDef() - Method in class io.debezium.config.ConfigDefinition
 
configDef() - Static method in class io.debezium.converters.CloudEventsConverterConfig
 
configDef() - Static method in class io.debezium.serde.json.JsonSerdeConfig
 
configDef() - Static method in class io.debezium.transforms.outbox.EventRouterConfigDefinition
There are 3 configuration groups available: - Table: Allows you to customize each of The column names in the outbox table for your convenience - Router: The behavior behind the events routing - Debezium: Specific to Debezium behavior which might impact the transform
ConfigDefinition - Class in io.debezium.config
Defines the configuration options of a connector.
ConfigDefinition(String, List<Field>, List<Field>, List<Field>, List<Field>) - Constructor for class io.debezium.config.ConfigDefinition
 
ConfigDefinitionEditor - Class in io.debezium.config
Editor for creating ConfigDefinitions.
ConfigDefinitionEditor() - Constructor for class io.debezium.config.ConfigDefinitionEditor
 
ConfigDefinitionEditor(ConfigDefinition) - Constructor for class io.debezium.config.ConfigDefinitionEditor
 
Configuration - Interface in io.debezium.config
An immutable representation of a Debezium configuration.
CONFIGURATION_FIELD_PREFIX_STRING - Static variable in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
CONFIGURATION_FIELD_PREFIX_STRING - Static variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
CONFIGURATION_FIELD_PREFIX_STRING - Static variable in interface io.debezium.relational.history.SchemaHistory
 
CONFIGURATION_LOGGER - Static variable in interface io.debezium.config.Configuration
 
Configuration.Builder - Class in io.debezium.config
A builder of Configuration objects.
Configuration.ConfigBuilder<C extends Configuration,B extends Configuration.ConfigBuilder<C,B>> - Interface in io.debezium.config
The basic interface for configuration builders.
ConfigurationDefaults - Class in io.debezium.config
 
ConfigurationDefaults() - Constructor for class io.debezium.config.ConfigurationDefaults
 
configurationProviders - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
configure(JsonGenerator) - Method in class io.debezium.document.JacksonWriter
 
configure(Configuration, HistoryRecordComparator, SchemaHistoryListener, boolean) - Method in class io.debezium.relational.history.AbstractSchemaHistory
 
configure(Configuration, HistoryRecordComparator, SchemaHistoryListener, boolean) - Method in interface io.debezium.relational.history.SchemaHistory
Configure this instance.
configure(Map<String, ?>) - Method in class io.debezium.converters.BinaryDataConverter
 
configure(Map<String, ?>) - Method in class io.debezium.converters.ByteArrayConverter
 
configure(Map<String, ?>) - Method in class io.debezium.transforms.ByLogicalTableRouter
 
configure(Map<String, ?>) - Method in class io.debezium.transforms.ExtractChangedRecordState
 
configure(Map<String, ?>) - Method in class io.debezium.transforms.ExtractNewRecordState
 
configure(Map<String, ?>) - Method in class io.debezium.transforms.HeaderToValue
 
configure(Map<String, ?>) - Method in class io.debezium.transforms.outbox.EventRouter
 
configure(Map<String, ?>) - Method in interface io.debezium.transforms.outbox.EventRouterConfigurationProvider
Configures the value provider
configure(Map<String, ?>) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
configure(Map<String, ?>) - Method in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
configure(Map<String, ?>) - Method in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
configure(Map<String, ?>) - Method in class io.debezium.transforms.partitions.PartitionRouting
 
configure(Map<String, ?>) - Method in class io.debezium.transforms.tracing.ActivateTracingSpan
 
configure(Map<String, ?>, boolean) - Method in class io.debezium.converters.BinaryDataConverter
 
configure(Map<String, ?>, boolean) - Method in class io.debezium.converters.ByteArrayConverter
 
configure(Map<String, ?>, boolean) - Method in class io.debezium.converters.CloudEventsConverter
 
configure(Map<String, ?>, boolean) - Method in class io.debezium.document.ArraySerdes
 
configure(Map<String, ?>, boolean) - Method in class io.debezium.document.DocumentSerdes
 
configure(Map<String, ?>, boolean) - Method in class io.debezium.serde.json.JsonSerde
 
configure(Map<String, ?>, boolean) - Method in class io.debezium.serde.json.JsonSerde.JsonDeserializer
 
configure(Map<String, ?>, boolean) - Method in class io.debezium.serde.json.JsonSerde.JsonSerializer
 
configure(Properties) - Method in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
configure(Properties) - Method in class io.debezium.schema.AbstractTopicNamingStrategy
 
configureLoggingContext(String) - Method in class io.debezium.connector.common.CdcSourceTaskContext
Configure the logger's Mapped Diagnostic Context (MDC) properties for the thread making this call.
configureLoggingContext(String, Partition) - Method in class io.debezium.connector.common.CdcSourceTaskContext
 
CONFLUENT_AVRO_CONVERTER - Static variable in class io.debezium.config.CommonConnectorConfig
 
CONFLUENT_AVRO_CONVERTER_CLASS - Static variable in class io.debezium.converters.CloudEventsConverter
Instantiated reflectively to avoid hard dependency to Avro converter.
CONFLUENT_SCHEMA_REGISTRY_URL_CONFIG - Static variable in class io.debezium.converters.CloudEventsConverter
 
conn - Variable in class io.debezium.jdbc.JdbcConnection
 
connect() - Method in class io.debezium.jdbc.JdbcConnection
Ensure a connection to the database is established.
connect(JdbcConfiguration) - Method in interface io.debezium.jdbc.JdbcConnection.ConnectionFactory
Establish a connection to the database denoted by the given configuration.
connect(JdbcConfiguration) - Method in class io.debezium.jdbc.JdbcConnection.ConnectionFactoryDecorator
 
CONNECT - Enum constant in enum io.debezium.jdbc.TemporalPrecisionMode
Represent time and date values using Kafka Connect org.apache.kafka.connect.data logical types, which always have millisecond precision.
ConnectChannel - Interface in io.debezium.pipeline.notification.channels
A special channel that is strictly connected to Kafka Connect API
connected - Variable in class io.debezium.pipeline.meters.ConnectionMeter
 
connected(boolean) - Method in class io.debezium.pipeline.meters.ConnectionMeter
 
connected(boolean) - Method in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
connected(boolean) - Method in interface io.debezium.pipeline.source.spi.StreamingProgressListener
 
connection() - Method in class io.debezium.jdbc.JdbcConnection
 
connection(boolean) - Method in class io.debezium.jdbc.JdbcConnection
 
CONNECTION - Enum constant in enum io.debezium.config.Field.Group
 
CONNECTION_ADVANCED - Enum constant in enum io.debezium.config.Field.Group
 
CONNECTION_ADVANCED_PUBLICATION - Enum constant in enum io.debezium.config.Field.Group
 
CONNECTION_ADVANCED_REPLICATION - Enum constant in enum io.debezium.config.Field.Group
 
CONNECTION_ADVANCED_SSL - Enum constant in enum io.debezium.config.Field.Group
 
CONNECTION_FACTORY_CLASS - Static variable in interface io.debezium.jdbc.JdbcConfiguration
An optional field for datasource factory class that will be used to build the datasource connection pool.
CONNECTION_TIMEOUT_MS - Static variable in interface io.debezium.jdbc.JdbcConfiguration
 
CONNECTION_VALID_CHECK_TIMEOUT_IN_SEC - Static variable in class io.debezium.jdbc.JdbcConnection
 
connectionCreated(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Executes steps which have to be taken just after the database connection is created.
ConnectionFactory<T extends JdbcConnection> - Interface in io.debezium.jdbc
An on-demand provider of a JDBC connection.
ConnectionFactoryDecorator(JdbcConnection.ConnectionFactory) - Constructor for class io.debezium.jdbc.JdbcConnection.ConnectionFactoryDecorator
 
connectionMeter - Variable in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
ConnectionMeter - Class in io.debezium.pipeline.meters
Carries connection metrics.
ConnectionMeter() - Constructor for class io.debezium.pipeline.meters.ConnectionMeter
 
connectionMetricHandledByCoordinator() - Method in interface io.debezium.pipeline.metrics.spi.ChangeEventSourceMetricsFactory
 
ConnectionMetricsMXBean - Interface in io.debezium.pipeline.metrics.traits
Exposes connection metrics.
connectionPoolConnectionCreated(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, JdbcConnection) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Executes steps which have to be taken just after a connection pool connection is created.
connectionProvider - Variable in class io.debezium.heartbeat.HeartbeatFactory
 
connectionString(String) - Method in class io.debezium.jdbc.JdbcConnection
Returns a JDBC connection string using the current configuration and url.
connector - Variable in class io.debezium.config.ConfigDefinition
 
connector - Variable in class io.debezium.config.ConfigDefinitionEditor
 
connector - Variable in class io.debezium.connector.AbstractSourceInfoStructMaker
 
connector - Variable in class io.debezium.connector.LegacyV1AbstractSourceInfoStructMaker
 
connector() - Method in class io.debezium.config.ConfigDefinition
 
connector(Field...) - Method in class io.debezium.config.ConfigDefinitionEditor
 
CONNECTOR - Enum constant in enum io.debezium.config.Field.Group
 
CONNECTOR_ADVANCED - Enum constant in enum io.debezium.config.Field.Group
 
CONNECTOR_CONTEXT - Static variable in class io.debezium.util.LoggingContext
The key for the connector context name MDC property.
CONNECTOR_FIELD_NAME - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
CONNECTOR_NAME - Static variable in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
CONNECTOR_NAME - Static variable in class io.debezium.util.LoggingContext
The key for the connector logical name MDC property.
CONNECTOR_SNAPSHOT - Enum constant in enum io.debezium.config.Field.Group
 
CONNECTOR_TYPE - Static variable in class io.debezium.util.LoggingContext
The key for the connector type MDC property.
connectorClass - Variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
connectorConfig - Variable in class io.debezium.heartbeat.HeartbeatFactory
 
connectorConfig - Variable in class io.debezium.pipeline.AbstractChangeRecordEmitter
 
connectorConfig - Variable in class io.debezium.pipeline.ErrorHandler
 
connectorConfig - Variable in class io.debezium.pipeline.EventDispatcher
 
connectorConfig - Variable in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
connectorConfig - Variable in class io.debezium.pipeline.signal.channels.jmx.JmxSignalChannel
 
connectorConfig - Variable in class io.debezium.pipeline.signal.channels.SourceSignalChannel
 
connectorConfig - Variable in class io.debezium.pipeline.signal.SignalProcessor
 
connectorConfig - Variable in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
 
connectorConfig - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
connectorConfig - Variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
connectorConfig - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
ConnectorDescriptor - Class in io.debezium.metadata
 
ConnectorDescriptor(String, String, String, String) - Constructor for class io.debezium.metadata.ConnectorDescriptor
 
ConnectorEvent - Interface in io.debezium.pipeline
A marker interface for an event with the connector that isn't dispatched to the change event stream but instead is potentially of interest to other parts of the framework such as metrics.
ConnectorMetadata - Interface in io.debezium.metadata
 
ConnectorMetadataProvider - Interface in io.debezium.metadata
 
connectorName - Variable in class io.debezium.config.ConfigDefinition
 
connectorName - Variable in class io.debezium.config.ConfigDefinitionEditor
 
connectorName - Variable in class io.debezium.connector.common.CdcSourceTaskContext
 
connectorName - Variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
connectorName() - Method in class io.debezium.config.ConfigDefinition
 
connectorType - Variable in class io.debezium.connector.common.CdcSourceTaskContext
 
connectorType - Variable in class io.debezium.converters.spi.RecordParser
 
connectorType() - Method in class io.debezium.converters.spi.RecordParser
Get the type of the connector which produced this record .
ConnectTableChangeSerializer - Class in io.debezium.relational.history
Ther serializer responsible for converting of TableChanges into an array of Structs.
ConnectTableChangeSerializer(SchemaNameAdjuster) - Constructor for class io.debezium.relational.history.ConnectTableChangeSerializer
 
constant(Clock, long) - Static method in interface io.debezium.util.ElapsedTimeStrategy
Create a strategy whose time periods are constant.
constant(Clock, Duration) - Static method in interface io.debezium.util.ElapsedTimeStrategy
Create a strategy whose time periods are constant.
constant(Duration) - Static method in interface io.debezium.util.DelayStrategy
Create a delay strategy that applies a constant delay as long as the criteria is met.
consume() - Method in class io.debezium.text.TokenStream
Return the value of this token and move to the next token.
consume(char) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token as long as it matches the expected character, or throw an exception if the token does not match.
consume(int) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token as long as it matches the expected character, or throw an exception if the token does not match.
consume(SchemaChangeEvent, Collection<TableId>) - Method in interface io.debezium.schema.HistorizedDatabaseSchema.SchemaChangeEventConsumer
 
consume(Iterable<String>) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token as the next tokens as long as they match the expected values, or throw an exception if the token does not match.
consume(String) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token as long as it matches the expected value, or throw an exception if the token does not match.
consume(String[]) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token as the next tokens as long as they match the expected values, or throw an exception if the token does not match.
consume(String, String...) - Method in class io.debezium.text.TokenStream
Attempt to consume this current token as the next tokens as long as they match the expected values, or throw an exception if the token does not match.
consume(String, List<DdlParserListener.Event>) - Method in interface io.debezium.relational.ddl.DdlChanges.DatabaseEventConsumer
 
consumeAnyOf(int...) - Method in class io.debezium.text.TokenStream
Consume and return the next token that must match one of the supplied values.
consumeAnyOf(String...) - Method in class io.debezium.text.TokenStream
Consume and return the next token that must match one of the supplied values.
consumer - Variable in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
CONSUMER_PREFIX - Static variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
consumeThrough(char) - Method in class io.debezium.text.TokenStream
Attempt to consume all tokens until the specified token is consumed, and then stop.
consumeThrough(char, char) - Method in class io.debezium.text.TokenStream
Attempt to consume all tokens until the specified token is consumed, and then stop.
consumeThrough(String) - Method in class io.debezium.text.TokenStream
Attempt to consume all tokens until the specified token is consumed, and then stop.
consumeThrough(String, String) - Method in class io.debezium.text.TokenStream
Attempt to consume all tokens until the specified token is consumed, and then stop.
consumeUntil(char) - Method in class io.debezium.text.TokenStream
Attempt to consume all tokens until the specified token is found, and then stop before consuming that token.
consumeUntil(char, char) - Method in class io.debezium.text.TokenStream
Attempt to consume all tokens until the specified token is found, and then stop before consuming that token.
consumeUntil(String) - Method in class io.debezium.text.TokenStream
Attempt to consume all tokens until the specified token is found, and then stop before consuming that token.
consumeUntil(String, String...) - Method in class io.debezium.text.TokenStream
Attempt to consume all tokens until the specified token is found, and then stop before consuming that token.
consumeUntilEndOrOneOf(String...) - Method in class io.debezium.text.TokenStream
Consume the token stream until one of the stop tokens or the end of the stream is found.
contains(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap
Legacy method testing if some key maps into the specified value in this table.
contains(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap.EntrySet
 
contains(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap.KeySet
 
contains(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap.Values
 
containsKey(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap
Tests if the specified object is a key in this table.
containsKey(Object, int) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
containsValue(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap
Returns true if this map maps one or more keys to the specified value.
containsValue(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
content - Variable in class io.debezium.text.TokenStream.CharacterArrayStream
 
CONTENT_CHARACTER - Static variable in class io.debezium.text.XmlCharacters
 
CONTENT_TYPE_NAME_MAP - Static variable in class io.debezium.converters.spi.CloudEventsMaker
 
context - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
context - Variable in class io.debezium.util.LoggingContext.PreviousContext
 
CONTEXT_NAME - Static variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
conversionFunctionMap - Variable in class io.debezium.relational.CustomConverterRegistry
 
Conversions - Class in io.debezium.time
Temporal conversion constants.
Conversions() - Constructor for class io.debezium.time.Conversions
 
convert() - Method in class io.debezium.document.BinaryValue
 
convert() - Method in class io.debezium.document.ComparableValue
 
convert() - Method in class io.debezium.document.ConvertingValue
 
convert() - Method in class io.debezium.document.NullValue
 
convert() - Method in interface io.debezium.document.Value
Get a Value representation that will convert attempt to convert values.
convert(ResultReceiver) - Method in interface io.debezium.jdbc.ValueConversionCallback
 
convert(Object) - Method in class io.debezium.relational.mapping.MaskStrings.HashValueConverter
 
convert(Object) - Method in class io.debezium.relational.mapping.MaskStrings.MaskingValueConverter
 
convert(Object) - Method in class io.debezium.relational.mapping.TruncateStrings.TruncatingValueConverter
 
convert(Object) - Method in interface io.debezium.relational.ValueConverter
Convert the column's data value.
convert(R) - Method in interface io.debezium.transforms.outbox.EventRouterDelegate.RecordConverter
 
CONVERT_ENTRY_TO_FIELD - Static variable in class io.debezium.document.BasicDocument
 
CONVERT_PAIR_TO_ENTRY - Static variable in class io.debezium.document.BasicArray
 
CONVERT_TO_CONNECT_METHOD - Static variable in class io.debezium.converters.CloudEventsConverter
 
convertBigInt(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.INTEGER.
convertBinary(Column, Field, Object, CommonConnectorConfig.BinaryHandlingMode) - Method in class io.debezium.jdbc.JdbcValueConverters
 
convertBinaryToBase64(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.BLOB, Types.BINARY, Types.VARBINARY, Types.LONGVARBINARY.
convertBinaryToBase64UrlSafe(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.BLOB, Types.BINARY, Types.VARBINARY, Types.LONGVARBINARY.
convertBinaryToBytes(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.BLOB, Types.BINARY, Types.VARBINARY, Types.LONGVARBINARY.
convertBinaryToHex(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.BLOB, Types.BINARY, Types.VARBINARY, Types.LONGVARBINARY.
convertBit(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.BIT.
convertBits(Column, Field) - Method in class io.debezium.jdbc.JdbcValueConverters
 
convertBits(Column, Field, Object, int) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.BIT of length 2+.
convertBoolean(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.BOOLEAN.
convertDateToEpochDays(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.DATE to the number of days past epoch.
convertDateToEpochDaysAsDate(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.DATE to the number of days past epoch, but represented as a Date value at midnight on the date.
convertDecimal(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.NUMERIC.
convertDouble(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.DOUBLE.
converter - Variable in class io.debezium.relational.CustomConverterRegistry.ConverterDefinition
 
converter - Variable in class io.debezium.relational.mapping.TruncateStrings
 
converter(Column, Field) - Method in class io.debezium.jdbc.JdbcValueConverters
 
converter(Column, Field) - Method in interface io.debezium.relational.ValueConverterProvider
Returns a ValueConverter that can be used to convert the JDBC values corresponding to the given JDBC temporal type into literal values described by the schema.
CONVERTER_TYPE_SUFFIX - Static variable in class io.debezium.config.CommonConnectorConfig
 
ConverterDefinition(S, CustomConverter.Converter) - Constructor for class io.debezium.relational.CustomConverterRegistry.ConverterDefinition
 
converterFromColumn - Variable in class io.debezium.relational.mapping.MaskStrings
 
converters - Variable in class io.debezium.relational.CustomConverterRegistry
 
convertersForColumns(Schema, TableId, List<Column>, ColumnMappers) - Method in class io.debezium.relational.TableSchemaBuilder
Obtain the array of converters for each column in a row.
convertFloat(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.FLOAT.
convertFromHex(char[]) - Static method in class io.debezium.util.HexConverter
Take the incoming character of hex encoded data and convert to the raw byte values.
convertFromHex(String) - Static method in class io.debezium.util.HexConverter
Take the incoming String of hex encoded data and convert to the raw byte values.
ConvertingValue - Class in io.debezium.document
A specialization of Value that wraps another Value to allow conversion of types.
ConvertingValue(Value) - Constructor for class io.debezium.document.ConvertingValue
 
convertInteger(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.INTEGER.
convertNumeric(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.NUMERIC.
convertReal(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.REAL.
convertRowId(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.ROWID.
convertSmallInt(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.SMALLINT.
convertString(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
convertTime(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
 
convertTimestampToEpochMicros(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TIMESTAMP to MicroTimestamp values, or microseconds past epoch.
convertTimestampToEpochMillis(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TIMESTAMP to Timestamp values, or milliseconds past epoch.
convertTimestampToEpochMillisAsDate(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TIMESTAMP to Date values representing milliseconds past epoch.
convertTimestampToEpochNanos(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TIMESTAMP to NanoTimestamp values, or nanoseconds past epoch.
convertTimestampWithZone(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TIMESTAMP_WITH_TIMEZONE.
convertTimeToMicrosPastMidnight(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TIME to MicroTime values, or microseconds past midnight.
convertTimeToMillisPastMidnight(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TIME to Time values, or milliseconds past midnight.
convertTimeToMillisPastMidnightAsDate(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TIME to Date values representing the milliseconds past midnight on the epoch day.
convertTimeToNanosPastMidnight(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TIME to NanoTime values, or nanoseconds past midnight.
convertTimeWithZone(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TIME_WITH_TIMEZONE.
convertTinyInt(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts a value object for an expected JDBC type of Types.TINYINT.
convertToCeExtensionSchema(Schema) - Method in class io.debezium.converters.CloudEventsConverter
 
convertToCeExtensionSchema(Schema, boolean) - Method in class io.debezium.converters.CloudEventsConverter
Converts the given source attribute schema into a corresponding CE extension schema.
convertToCloudEventsFormat(RecordParser, CloudEventsMaker, Schema, String, Object) - Method in class io.debezium.converters.CloudEventsConverter
 
convertToCloudEventsFormatWithDataAsAvro(String, RecordParser, CloudEventsMaker) - Method in class io.debezium.converters.CloudEventsConverter
Creates a CloudEvents wrapper, converting the "data" to Avro.
convertToHexadecimalFormat(byte[]) - Method in class io.debezium.relational.mapping.MaskStrings.HashValueConverter
 
convertToHexBytes(byte[]) - Static method in class io.debezium.util.HexConverter
Take the supplied byte array and convert it to to a byte array of the encoded hex values.
convertToHexString(byte[]) - Static method in class io.debezium.util.HexConverter
Take the supplied byte array and convert it to a hex encoded String.
convertValue(Column, Field, Object, Object, ValueConversionCallback) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts the given value for the given column/field.
coordinator - Variable in class io.debezium.connector.common.BaseSourceTask
The change event source coordinator for those connectors adhering to the new framework structure, null for legacy-style connectors.
copy(Configuration) - Static method in interface io.debezium.config.Configuration
Create a new configuration builder that starts with a copy of the supplied configuration.
copy(Configuration) - Static method in interface io.debezium.jdbc.JdbcConfiguration
Create a new configuration builder that starts with a copy of the supplied configuration.
COPY - Enum constant in enum io.debezium.transforms.HeaderToValue.Operation
 
COPY_OPERATION - Static variable in class io.debezium.transforms.HeaderToValue
 
copyInto(String[], int) - Method in class io.debezium.document.Paths.ChildPath
 
copyInto(String[], int) - Method in interface io.debezium.document.Paths.InnerPath
 
copyInto(String[], int) - Method in class io.debezium.document.Paths.MultiSegmentPath
 
copyInto(String[], int) - Method in class io.debezium.document.Paths.RootPath
 
copyInto(String[], int) - Method in class io.debezium.document.Paths.SingleSegmentPath
 
copyOffset(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
copyPathInto(Path, String[], int) - Static method in class io.debezium.document.Paths
 
copySchemaExcludingName(Schema, SchemaBuilder) - Method in class io.debezium.transforms.ByLogicalTableRouter
 
copySchemaExcludingName(Schema, SchemaBuilder, boolean) - Method in class io.debezium.transforms.ByLogicalTableRouter
 
CORRELATION_ID - Static variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
correlationId - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
count - Variable in class io.debezium.util.BoundedConcurrentHashMap.Segment
The number of elements in this segment's region.
Count - Interface in io.debezium.crdt
A read-only result of a counter.
countDown() - Method in class io.debezium.util.VariableLatch
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
countDown(int) - Method in class io.debezium.util.VariableLatch
Decrements the count of the latch, releasing all waiting threads if the count reaches zero.
countUp() - Method in class io.debezium.util.VariableLatch
Increments the count of the latch by one.
countUp(int) - Method in class io.debezium.util.VariableLatch
Increments the count of the latch by a positive number.
CRDT - Class in io.debezium.crdt
Conflict-free Replicated Data Types (CRDT)s.
CRDT() - Constructor for class io.debezium.crdt.CRDT
 
create() - Method in class io.debezium.config.ConfigDefinitionEditor
 
create() - Static method in interface io.debezium.config.Configuration
Create a new configuration builder.
create() - Static method in interface io.debezium.document.Array
 
create() - Static method in interface io.debezium.document.Document
 
create() - Static method in interface io.debezium.jdbc.JdbcConfiguration
Create a new configuration builder that starts with an empty configuration.
create() - Static method in interface io.debezium.jdbc.ResultReceiver
 
create() - Method in interface io.debezium.relational.AttributeEditor
Obtain an immutable attribute definition representing the current state of this editor.
create() - Method in class io.debezium.relational.AttributeEditorImpl
 
create() - Method in interface io.debezium.relational.ColumnEditor
Obtain an immutable column definition representing the current state of this editor.
create() - Method in class io.debezium.relational.ColumnEditorImpl
 
create() - Method in class io.debezium.relational.ddl.DataTypeBuilder
 
create() - Method in class io.debezium.relational.NoOpTableEditorImpl
 
create() - Method in interface io.debezium.relational.TableEditor
Obtain an immutable table definition representing the current state of this editor.
create() - Method in class io.debezium.relational.TableEditorImpl
 
create() - Static method in interface io.debezium.schema.SchemaNameAdjuster
Create a stateful Avro fullname adjuster that logs a warning the first time an invalid fullname is seen and replaced with a valid fullname, and throws an error if the replacement conflicts with that of a different original.
create() - Method in interface io.debezium.util.Stopwatch.StopwatchSet
Create a new stopwatch that records durations with this set.
create() - Static method in class io.debezium.util.VariableLatch
Create a new variable latch.
create(boolean) - Static method in interface io.debezium.document.Value
 
create(byte[]) - Static method in interface io.debezium.document.Value
 
create(char, SchemaNameAdjuster.ReplacementOccurred) - Static method in interface io.debezium.schema.SchemaNameAdjuster
Create a stateful Avro fullname adjuster that calls the supplied SchemaNameAdjuster.ReplacementOccurred function when an invalid fullname is seen and replaced with a valid fullname.
create(double) - Static method in interface io.debezium.document.Value
 
create(float) - Static method in interface io.debezium.document.Value
 
create(int) - Static method in interface io.debezium.document.Value
 
create(int) - Static method in class io.debezium.util.VariableLatch
Create a new variable latch.
create(long) - Static method in interface io.debezium.document.Value
 
create(CommonConnectorConfig) - Static method in class io.debezium.schema.DefaultTopicNamingStrategy
 
create(CommonConnectorConfig) - Static method in class io.debezium.schema.DefaultUnicodeTopicNamingStrategy
 
create(CommonConnectorConfig) - Static method in class io.debezium.schema.SchemaTopicNamingStrategy
 
create(CommonConnectorConfig) - Static method in class io.debezium.schema.SchemaUnicodeTopicNamingStrategy
 
create(CommonConnectorConfig, boolean) - Static method in class io.debezium.schema.SchemaTopicNamingStrategy
 
create(Array) - Static method in interface io.debezium.document.Value
 
create(Document) - Static method in interface io.debezium.document.Value
 
create(Value[]) - Static method in interface io.debezium.document.Array
 
create(Value, Value, Value...) - Static method in interface io.debezium.document.Array
 
create(Column) - Method in interface io.debezium.relational.mapping.ColumnMapper
Create for the given column a function that maps values.
create(Column) - Method in class io.debezium.relational.mapping.MaskStrings
 
create(Column) - Method in class io.debezium.relational.mapping.PropagateSourceTypeToSchemaParameter
 
create(Column) - Method in class io.debezium.relational.mapping.TruncateStrings
 
create(RelationalDatabaseConnectorConfig) - Static method in class io.debezium.relational.mapping.ColumnMappers
Builds a new ColumnMappers instance based on the given configuration.
create(Table) - Method in class io.debezium.relational.history.TableChanges
 
create(ReplacementFunction) - Static method in interface io.debezium.schema.SchemaNameAdjuster
This method replaces all invalid characters with ReplacementFunction
create(ReplacementFunction, SchemaNameAdjuster.ReplacementOccurred) - Static method in interface io.debezium.schema.SchemaNameAdjuster
Create a stateful Avro fullname adjuster that logs a warning the first time an invalid fullname is seen and replaced with a valid fullname.
create(TopicNamingStrategy, Table, Tables.ColumnNameFilter, ColumnMappers, Key.KeyMapper) - Method in class io.debezium.relational.TableSchemaBuilder
Create a TableSchema from the given table definition.
create(CharSequence, Object) - Static method in interface io.debezium.document.Document
 
create(CharSequence, Object, CharSequence, Object) - Static method in interface io.debezium.document.Document
 
create(CharSequence, Object, CharSequence, Object, CharSequence, Object) - Static method in interface io.debezium.document.Document
 
create(CharSequence, Object, CharSequence, Object, CharSequence, Object, CharSequence, Object) - Static method in interface io.debezium.document.Document
 
create(CharSequence, Object, CharSequence, Object, CharSequence, Object, CharSequence, Object, CharSequence, Object) - Static method in interface io.debezium.document.Document
 
create(CharSequence, Object, CharSequence, Object, CharSequence, Object, CharSequence, Object, CharSequence, Object, CharSequence, Object) - Static method in interface io.debezium.document.Document
 
create(Double) - Static method in interface io.debezium.document.Value
 
create(Float) - Static method in interface io.debezium.document.Value
 
create(Integer) - Static method in interface io.debezium.document.Value
 
create(Iterable<?>) - Static method in interface io.debezium.document.Array
 
create(Long) - Static method in interface io.debezium.document.Value
 
create(Object) - Static method in interface io.debezium.document.Value
 
create(Object...) - Static method in interface io.debezium.document.Array
 
create(Object, Struct, Instant) - Method in class io.debezium.data.Envelope
Generate a create message with the given information.
create(String) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name.
create(String) - Static method in interface io.debezium.document.Value
 
create(String, SchemaNameAdjuster.ReplacementOccurred) - Static method in interface io.debezium.schema.SchemaNameAdjuster
Create a stateful Avro fullname adjuster that calls the supplied SchemaNameAdjuster.ReplacementOccurred function when an invalid fullname is seen and replaced with a valid fullname.
create(String, String) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name.
create(String, String, String) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name and description.
create(String, String, String, boolean) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name, description, and default value.
create(String, String, String, int) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name, description, and default value.
create(String, String, String, long) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name, description, and default value.
create(String, String, String, String) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name, description, and default value.
create(String, String, String, BooleanSupplier) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name, description, and default value.
create(String, String, String, IntSupplier) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name, description, and default value.
create(String, String, String, LongSupplier) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name, description, and default value.
create(String, String, String, Supplier<Object>) - Static method in class io.debezium.config.Field
Create an immutable Field instance with the given property name, description, and default value.
create(BigDecimal) - Static method in interface io.debezium.document.Value
 
create(BigInteger) - Static method in interface io.debezium.document.Value
 
create(ReadWriteLock) - Static method in class io.debezium.util.FunctionalReadWriteLock
Create a read-write lock around the given standard ReadWriteLock.
create(List<Value>) - Static method in interface io.debezium.document.Array
 
CREATE - Enum constant in enum io.debezium.data.Envelope.Operation
An operation that resulted in a new record being created in the source.
CREATE - Enum constant in enum io.debezium.relational.history.TableChanges.TableChangeType
 
CREATE - Enum constant in enum io.debezium.schema.SchemaChangeEvent.SchemaChangeEventType
 
CREATE_DATABASE - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
CREATE_INDEX - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
CREATE_TABLE - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
createAdjuster() - Method in enum io.debezium.config.CommonConnectorConfig.FieldNameAdjustmentMode
 
createAdjuster() - Method in enum io.debezium.config.CommonConnectorConfig.SchemaNameAdjustmentMode
 
createColumnFromConstant(String, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
createConnectionPool(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
createDataChangeEvent(SourceRecord) - Method in interface io.debezium.pipeline.spi.ChangeEventCreator
 
createDataEvents(ChangeEventSource.ChangeEventSourceContext, RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, Queue<JdbcConnection>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
createDataEventsForTable(P) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
Dispatches the data change events for the records of a single table.
createDataEventsForTableCallable(ChangeEventSource.ChangeEventSourceContext, RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, EventDispatcher.SnapshotReceiver<P>, Table, boolean, boolean, int, int, String, OptionalLong, Queue<JdbcConnection>, Queue<O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
createDdlFilter(Configuration) - Method in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
createDirectory(Path) - Static method in class io.debezium.util.IoUtil
Create a directory at the given absolute or relative path.
createDirectory(Path, boolean) - Static method in class io.debezium.util.IoUtil
Create a directory at the given absolute or relative path, removing any existing content beforehand.
createExcludeListFilter(String, ColumnFilterMode) - Static method in class io.debezium.relational.Tables.ColumnNameFilterFactory
Build the Tables.ColumnNameFilter that determines whether a column identified by a given ColumnId is to be included, using the given comma-separated regular expression patterns defining which columns (if any) should be excluded.
createFile(Path) - Static method in class io.debezium.util.IoUtil
Create a file at the given absolute or relative path.
createGroupEntry(Field.Group) - Static method in class io.debezium.config.Field
 
createGroupEntry(Field.Group, int) - Static method in class io.debezium.config.Field
 
createHeartbeat() - Method in class io.debezium.heartbeat.HeartbeatFactory
 
createHeartbeat(TopicNamingStrategy, SchemaNameAdjuster, HeartbeatConnectionProvider, HeartbeatErrorHandler) - Method in class io.debezium.config.CommonConnectorConfig
 
createHeartbeat(TopicNamingStrategy, SchemaNameAdjuster, HeartbeatConnectionProvider, HeartbeatErrorHandler) - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
createIncludeListFilter(String, ColumnFilterMode) - Static method in class io.debezium.relational.Tables.ColumnNameFilterFactory
Build the Tables.ColumnNameFilter that determines whether a column identified by a given ColumnId is to be included, using the given comma-separated regular expression patterns defining which columns (if any) should be included.
createInternal(String) - Static method in class io.debezium.config.Field
Create an immutable internal Field instance with the given property name.
createKeyGenerator(Schema, TableId, List<Column>, TopicNamingStrategy) - Method in class io.debezium.relational.TableSchemaBuilder
Creates the function that produces a Kafka Connect key object for a row of data.
createMaker(RecordParser, SerializerType, String) - Method in interface io.debezium.converters.spi.CloudEventsProvider
Create a concrete CloudEvents maker using the outputs of a record parser.
createNewEntry(K, int, BoundedConcurrentHashMap.HashEntry<K, V>, V) - Method in interface io.debezium.util.BoundedConcurrentHashMap.EvictionPolicy
 
createNewEntry(K, int, BoundedConcurrentHashMap.HashEntry<K, V>, V) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
createNewEntry(K, int, BoundedConcurrentHashMap.HashEntry<K, V>, V) - Method in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
createNewEntry(K, int, BoundedConcurrentHashMap.HashEntry<K, V>, V) - Method in class io.debezium.util.BoundedConcurrentHashMap.NullEvictionPolicy
 
createNewSystemVariablesInstance() - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
createParser(Schema, Struct) - Method in interface io.debezium.converters.spi.CloudEventsProvider
Create a concrete parser of a change record for the connector.
createPreparedStatement(String) - Method in class io.debezium.jdbc.JdbcConnection
 
createSchemaChangeEventsForTables(ChangeEventSource.ChangeEventSourceContext, RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, AbstractSnapshotChangeEventSource.SnapshottingTask) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
createSnapshotConnection() - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
createStatement(Connection) - Method in interface io.debezium.jdbc.JdbcConnection.StatementFactory
Use the given connection to create a statement.
createStatistics(LongSummaryStatistics) - Static method in class io.debezium.util.Stopwatch
 
createString(char, int) - Static method in class io.debezium.util.Strings
Create a new string containing the specified character repeated a specific number of times.
createValue(Schema, byte[], Integer) - Static method in class io.debezium.data.geometry.Geometry
Create a value for this schema using WKB and SRID
createValue(Schema, byte[], Integer) - Static method in class io.debezium.data.geometry.Point
Create a value for this schema using WKB
createValue(Schema, double, double) - Static method in class io.debezium.data.geometry.Point
Creates a value for this schema using 2 given coordinates.
createValueConverterFor(TableId, Column, Field) - Method in class io.debezium.relational.TableSchemaBuilder
Create a ValueConverter that can be used to convert row values for the given column into the Kafka Connect value object described by the field definition.
createValueGenerator(Schema, TableId, List<Column>, Tables.ColumnNameFilter, ColumnMappers) - Method in class io.debezium.relational.TableSchemaBuilder
Creates the function that produces a Kafka Connect value object for a row of data.
createWith(Stopwatch.BaseDurations, Runnable, Runnable) - Static method in class io.debezium.util.Stopwatch
Create a new stopwatch that updates the given duration, and optionally has functions to be called after the stopwatch is started and stopped.
createWithNulls(int) - Static method in interface io.debezium.document.Array
 
CURLY_PREFIX - Static variable in class io.debezium.util.Strings
 
CURLY_SUFFIX - Static variable in class io.debezium.util.Strings
 
CURRENT_COLLECTION_IN_PROGRESS - Static variable in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
currentChangePosition - Variable in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
currentChunk(String, Object[], Object[]) - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
currentChunk(String, Object[], Object[], Object[]) - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
currentChunk(P, String, Object[], Object[]) - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
currentChunk(P, String, Object[], Object[]) - Method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
currentChunk(P, String, Object[], Object[], Object[]) - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
currentChunk(P, String, Object[], Object[], Object[]) - Method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
currentChunkId - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
currentChunkId() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
currentChunkId() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
currentDataCollectionId() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
currentDataCollectionId() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
currentQueueSizeInBytes - Variable in class io.debezium.connector.base.ChangeEventQueue
 
currentQueueSizeInBytes() - Method in class io.debezium.connector.base.ChangeEventQueue
 
currentQueueSizeInBytes() - Method in interface io.debezium.connector.base.ChangeEventQueueMetrics
 
currentSchema - Variable in class io.debezium.relational.ddl.AbstractDdlParser
 
currentSchema() - Method in class io.debezium.relational.ddl.AbstractDdlParser
Get the name of the current schema.
currentTable - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
currentTable - Variable in class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
currentTime() - Method in interface io.debezium.util.Clock
 
currentTimeAsInstant() - Method in interface io.debezium.util.Clock
Get the current time as an instant
currentTimeInMicros() - Method in interface io.debezium.util.Clock
Get the current time in microseconds.
currentTimeInMillis() - Method in interface io.debezium.util.Clock
Get the current time in milliseconds.
currentTimeInNanos() - Method in interface io.debezium.util.Clock
Get the current time in nanoseconds.
currentToken - Variable in class io.debezium.text.TokenStream
 
currentToken() - Method in class io.debezium.text.TokenStream
Get the current token.
CUSTOM_CONVERTERS - Static variable in class io.debezium.config.CommonConnectorConfig
 
CUSTOM_RETRIABLE_EXCEPTION - Static variable in class io.debezium.config.CommonConnectorConfig
 
customConnectionFactory - Variable in class io.debezium.jdbc.JdbcConnection.ConnectionFactoryDecorator
 
customConverterRegistry - Variable in class io.debezium.config.CommonConnectorConfig
 
customConverterRegistry - Variable in class io.debezium.relational.TableSchemaBuilder
 
customConverterRegistry() - Method in class io.debezium.config.CommonConnectorConfig
 
CustomConverterRegistry - Class in io.debezium.relational
The registry of all converters that were provided by the connector configuration.
CustomConverterRegistry(List<CustomConverter<SchemaBuilder, ConvertedField>>) - Constructor for class io.debezium.relational.CustomConverterRegistry
 
CustomConverterRegistry.ConverterDefinition<S> - Class in io.debezium.relational
Class binding together the schema of the conversion result and the converter code.
customKeyMapper(Key.KeyMapper) - Method in class io.debezium.relational.Key.Builder
 
CustomKeyMapper() - Constructor for class io.debezium.relational.Key.CustomKeyMapper
 
customKeysMapper - Variable in class io.debezium.relational.RelationalDatabaseSchema
 
customRetriableException() - Method in class io.debezium.config.CommonConnectorConfig
 

D

data - Variable in class io.debezium.pipeline.signal.SignalPayload
 
data - Variable in class io.debezium.pipeline.signal.SignalRecord
 
data() - Method in class io.debezium.converters.spi.RecordParser
Get the value of the data field in the record; may not be null.
DATA - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
Event data
DATA_COLLECTIONS - Static variable in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
DATA_COLLECTIONS_TO_SNAPSHOT_KEY - Static variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
DATA_COLLECTIONS_TO_SNAPSHOT_KEY_ADDITIONAL_CONDITION - Static variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
DATA_COLLECTIONS_TO_SNAPSHOT_KEY_ID - Static variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
DATA_COLLECTIONS_TO_SNAPSHOT_KEY_SURROGATE_KEY - Static variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
DATA_SCHEMA_SUFFIX - Static variable in class io.debezium.converters.CloudEventsConverter
Suffix appended to schema names of data schema in case of Avro/Avro, to keep data schema and CE schema apart from each other
database - Variable in class io.debezium.schema.SchemaChangeEvent
 
database() - Method in class io.debezium.connector.AbstractSourceInfo
 
database() - Method in class io.debezium.jdbc.JdbcConnection
Returns the database name for this connection
DATABASE - Enum constant in enum io.debezium.schema.SchemaChangeEvent.SchemaChangeEventType
 
DATABASE - Static variable in interface io.debezium.jdbc.JdbcConfiguration
A field for the name of the database.
DATABASE_CONFIG_PREFIX - Static variable in class io.debezium.config.CommonConnectorConfig
 
DATABASE_EXCLUDE_LIST - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
A comma-separated list of regular expressions that match database names to be excluded from monitoring.
DATABASE_EXCLUDE_LIST_NAME - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
DATABASE_INCLUDE_LIST - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
A comma-separated list of regular expressions that match database names to be monitored.
DATABASE_INCLUDE_LIST_ALREADY_SPECIFIED_ERROR_MSG - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
DATABASE_INCLUDE_LIST_NAME - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
DATABASE_NAME - Static variable in class io.debezium.relational.history.HistoryRecord.Fields
 
DATABASE_NAME - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
DATABASE_NAME - Static variable in class io.debezium.util.LoggingContext
The key for the database name MDC property.
DATABASE_NAME_KEY - Static variable in class io.debezium.connector.AbstractSourceInfo
 
DatabaseAlteredEvent(String, String, String) - Constructor for class io.debezium.relational.ddl.DdlParserListener.DatabaseAlteredEvent
 
DatabaseCreatedEvent(String, String) - Constructor for class io.debezium.relational.ddl.DdlParserListener.DatabaseCreatedEvent
 
DatabaseDroppedEvent(String, String) - Constructor for class io.debezium.relational.ddl.DdlParserListener.DatabaseDroppedEvent
 
DatabaseEvent(DdlParserListener.EventType, String, String) - Constructor for class io.debezium.relational.ddl.DdlParserListener.DatabaseEvent
 
databaseFilter - Variable in class io.debezium.relational.RelationalTableFilters
 
databaseFilter() - Method in class io.debezium.relational.RelationalTableFilters
 
DatabaseHeartbeatImpl - Class in io.debezium.heartbeat
Implementation of the heartbeat feature that allows for a DB query to be executed with every heartbeat.
DatabaseHeartbeatImpl(Duration, String, String, JdbcConnection, String, HeartbeatErrorHandler, SchemaNameAdjuster) - Constructor for class io.debezium.heartbeat.DatabaseHeartbeatImpl
 
databaseName - Variable in class io.debezium.relational.AbstractPartition
 
databaseName - Variable in class io.debezium.relational.ddl.DdlParserListener.DatabaseEvent
 
databaseName - Variable in class io.debezium.relational.ddl.DdlParserListener.SetVariableEvent
 
databaseName() - Method in class io.debezium.relational.ddl.DdlParserListener.DatabaseEvent
Get the database name affected by this event.
databaseName() - Method in class io.debezium.relational.ddl.DdlParserListener.SetVariableEvent
 
databaseName() - Method in class io.debezium.relational.history.HistoryRecord
 
databaseNames - Variable in class io.debezium.relational.ddl.DdlChanges
 
databaseParts() - Method in class io.debezium.relational.TableId
 
databaseSchema - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
DatabaseSchema<I extends DataCollectionId> - Interface in io.debezium.schema
The schema of a database.
DatabaseSelectionPredicateBuilder() - Constructor for class io.debezium.relational.Selectors.DatabaseSelectionPredicateBuilder
 
databaseSelector() - Static method in class io.debezium.relational.Selectors
Obtain a new builder for a table selection predicate.
DatabaseSwitchedEvent(String, String) - Constructor for class io.debezium.relational.ddl.DdlParserListener.DatabaseSwitchedEvent
 
dataChangeEvent - Variable in class io.debezium.pipeline.EventDispatcher.BufferedDataChangeEvent
 
DataChangeEvent - Class in io.debezium.pipeline
 
DataChangeEvent(SourceRecord) - Constructor for class io.debezium.pipeline.DataChangeEvent
 
DataChangeEventListener<P extends Partition> - Interface in io.debezium.pipeline.source.spi
A class invoked by EventDispatcher whenever an event is available for processing.
dataChangeTopic(I) - Method in class io.debezium.schema.AbstractTopicNamingStrategy
 
dataChangeTopic(DataCollectionId) - Method in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
dataChangeTopic(DataCollectionId) - Method in class io.debezium.schema.DefaultTopicNamingStrategy
 
dataChangeTopic(DataCollectionId) - Method in class io.debezium.schema.DefaultUnicodeTopicNamingStrategy
 
dataChangeTopic(DataCollectionId) - Method in class io.debezium.schema.SchemaTopicNamingStrategy
 
dataChangeTopic(DataCollectionId) - Method in class io.debezium.schema.SchemaUnicodeTopicNamingStrategy
 
DataCollection<T> - Class in io.debezium.pipeline.source.snapshot.incremental
A class describing DataCollection for incremental snapshot
DataCollection(T) - Constructor for class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
DataCollection(T, Optional<String>, Optional<String>) - Constructor for class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
dataCollectionFilter() - Method in class io.debezium.relational.RelationalTableFilters
 
dataCollectionFilter() - Method in interface io.debezium.schema.DataCollectionFilters
 
DataCollectionFilters - Interface in io.debezium.schema
Provides factory methods for obtaining DataCollectionFilters.DataCollectionFilter instances as per the current connector configuration.
DataCollectionFilters.DataCollectionFilter<T extends DataCollectionId> - Interface in io.debezium.schema
 
DataCollectionSchema - Interface in io.debezium.schema
 
dataCollectionSnapshotCompleted(DataCollectionId, long) - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
dataCollectionSnapshotCompleted(P, DataCollectionId, long) - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
dataCollectionSnapshotCompleted(P, DataCollectionId, long) - Method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
dataCollectionsToBeSnapshottedCount() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
dataCollectionsToBeSnapshottedCount() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
dataCollectionsToSnapshot - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
dataCollectionsToSnapshotAsString() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
dataCollectionTopicNamer - Variable in class io.debezium.schema.TopicSelector
Deprecated.
 
dataContentType - Variable in class io.debezium.converters.spi.CloudEventsMaker
 
DATACONTENTTYPE - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
CloudEvents context attributes (OPTIONAL)
dataEvent(Partition, DataCollectionId, OffsetContext, Object, Struct) - Method in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
dataListener - Variable in class io.debezium.pipeline.EventDispatcher.IncrementalSnapshotChangeRecordReceiver
 
dataListener - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
dataSchema - Variable in class io.debezium.converters.spi.RecordParser
 
dataSchema() - Method in class io.debezium.converters.spi.RecordParser
Get the schema of the data field in the record; may be not be null.
DATASCHEMA - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
 
dataSchemaUriBase - Variable in class io.debezium.converters.spi.CloudEventsMaker
 
dataSerializerType - Variable in class io.debezium.converters.CloudEventsConverter
 
DataType - Class in io.debezium.relational.ddl
An immutable representation of a data type
DataType(String, String, int, long, int, int[], int) - Constructor for class io.debezium.relational.ddl.DataType
 
datatypeBitsSchema(int) - Method in class io.debezium.schema.SchemaFactory
 
DataTypeBuilder - Class in io.debezium.relational.ddl
 
DataTypeBuilder() - Constructor for class io.debezium.relational.ddl.DataTypeBuilder
 
datatypeEnumSchema(String) - Method in class io.debezium.schema.SchemaFactory
 
datatypeEnumSetSchema(String) - Method in class io.debezium.schema.SchemaFactory
 
datatypeEnvelopeSchema() - Method in class io.debezium.schema.SchemaFactory
 
datatypeJsonSchema() - Method in class io.debezium.schema.SchemaFactory
 
datatypeUuidSchema() - Method in class io.debezium.schema.SchemaFactory
 
datatypeVariableScaleDecimalSchema() - Method in class io.debezium.schema.SchemaFactory
 
datatypeXmlSchema() - Method in class io.debezium.schema.SchemaFactory
 
Date - Class in io.debezium.time
A utility for converting various Java temporal object representations into the signed INT32 number of days since January 1, 1970, at 00:00:00UTC, and for defining a Kafka Connect Schema for date values with no time or timezone information.
Date() - Constructor for class io.debezium.time.Date
 
DAYS_PER_MONTH_AVG - Static variable in class io.debezium.time.MicroDuration
The approximation used by the plugins when converting a duration to micros
DB_FIELD_NAME - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
DB_FIELDS_PREFIX - Static variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
DB2_CONNECTOR - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
dbExclusions - Variable in class io.debezium.relational.Selectors.DatabaseSelectionPredicateBuilder
 
dbExclusions - Variable in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
 
dbInclusions - Variable in class io.debezium.relational.Selectors.DatabaseSelectionPredicateBuilder
 
dbInclusions - Variable in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
 
ddl - Variable in class io.debezium.schema.SchemaChangeEvent
 
ddl() - Method in class io.debezium.relational.history.HistoryRecord
 
DDL_FILTER - Static variable in interface io.debezium.relational.history.SchemaHistory
 
DDL_STATEMENTS - Static variable in class io.debezium.relational.history.HistoryRecord.Fields
 
ddlChanges - Variable in class io.debezium.relational.ddl.AbstractDdlParser
 
DdlChanges - Class in io.debezium.relational.ddl
A DdlParserListener that accumulates changes, allowing them to be consumed in the same order by database.
DdlChanges() - Constructor for class io.debezium.relational.ddl.DdlChanges
 
DdlChanges.DatabaseEventConsumer - Interface in io.debezium.relational.ddl
 
ddlFilter - Variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
ddlFilter - Variable in class io.debezium.relational.history.AbstractSchemaHistory
 
ddlFilter() - Method in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
ddlFilter() - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
ddlFilter() - Method in interface io.debezium.schema.HistorizedDatabaseSchema
 
DdlParser - Interface in io.debezium.relational.ddl
A parser interface for DDL statements.
DdlParserListener - Interface in io.debezium.relational.ddl
An interface that can listen to various actions of a DdlParser.
DdlParserListener.DatabaseAlteredEvent - Class in io.debezium.relational.ddl
An event describing the altering of a database.
DdlParserListener.DatabaseCreatedEvent - Class in io.debezium.relational.ddl
An event describing the creation of a database.
DdlParserListener.DatabaseDroppedEvent - Class in io.debezium.relational.ddl
An event describing the dropping of a database.
DdlParserListener.DatabaseEvent - Class in io.debezium.relational.ddl
The base class for all table-related events.
DdlParserListener.DatabaseSwitchedEvent - Class in io.debezium.relational.ddl
An event describing the switching of a database.
DdlParserListener.Event - Class in io.debezium.relational.ddl
The base class for all concrete events.
DdlParserListener.EventType - Enum in io.debezium.relational.ddl
The type of concrete DdlParserListener.Events.
DdlParserListener.SetVariableEvent - Class in io.debezium.relational.ddl
An event describing the setting of a variable.
DdlParserListener.TableAlteredEvent - Class in io.debezium.relational.ddl
An event describing the altering of a table.
DdlParserListener.TableCreatedEvent - Class in io.debezium.relational.ddl
An event describing the creation (or replacement) of a table.
DdlParserListener.TableDroppedEvent - Class in io.debezium.relational.ddl
An event describing the dropping of a table.
DdlParserListener.TableEvent - Class in io.debezium.relational.ddl
The base class for all table-related events.
DdlParserListener.TableIndexCreatedEvent - Class in io.debezium.relational.ddl
An event describing the creation of an index on a table.
DdlParserListener.TableIndexDroppedEvent - Class in io.debezium.relational.ddl
An event describing the dropping of an index on a table.
DdlParserListener.TableIndexEvent - Class in io.debezium.relational.ddl
The abstract base class for all index-related events.
DdlParserListener.TableTruncatedEvent - Class in io.debezium.relational.ddl
An event describing the truncating of a table.
DEBEZIUM_CONNECTOR_KEY - Static variable in class io.debezium.connector.AbstractSourceInfo
 
DEBEZIUM_CONNECTOR_KEY - Static variable in class io.debezium.connector.LegacyV1AbstractSourceInfoStructMaker
 
DEBEZIUM_NOTIFICATION_TYPE - Static variable in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
DEBEZIUM_OPERATION_HEADER_KEY - Static variable in class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
DEBEZIUM_THREAD_NAME_PREFIX - Static variable in class io.debezium.util.Threads
 
DEBEZIUM_TRANSACTION_COLLECTION_KEY - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
DEBEZIUM_TRANSACTION_DATA_COLLECTION_ORDER_KEY - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
DEBEZIUM_TRANSACTION_DATA_COLLECTIONS_KEY - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
DEBEZIUM_TRANSACTION_EVENT_COUNT_KEY - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
DEBEZIUM_TRANSACTION_ID_KEY - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
DEBEZIUM_TRANSACTION_KEY - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
DEBEZIUM_TRANSACTION_STATUS_KEY - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
DEBEZIUM_TRANSACTION_TOTAL_ORDER_KEY - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
DEBEZIUM_TRANSACTION_TS_MS - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
DEBEZIUM_VERSION_KEY - Static variable in class io.debezium.connector.AbstractSourceInfo
 
DEBEZIUM_VERSION_KEY - Static variable in class io.debezium.connector.LegacyV1AbstractSourceInfoStructMaker
 
DebeziumSerdes - Class in io.debezium.serde
A factory class for Debezium provided serializers/deserializers.
DebeziumSerdes() - Constructor for class io.debezium.serde.DebeziumSerdes
 
DebeziumTextMap - Class in io.debezium.transforms.tracing
 
DebeziumTextMap() - Constructor for class io.debezium.transforms.tracing.DebeziumTextMap
 
DebeziumTextMap(String) - Constructor for class io.debezium.transforms.tracing.DebeziumTextMap
 
debugParsed(String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
debugSkipped(String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
DECIMAL - Enum constant in enum io.debezium.document.Value.Type
 
DECIMAL - Static variable in class io.debezium.text.TokenStream.BasicTokenizer
The token type for tokens that consist of an individual '.' character.
DECIMAL_HANDLING_MODE - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
DecimalHandlingMode(String) - Constructor for enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
 
decimalMode - Variable in class io.debezium.jdbc.JdbcValueConverters
 
DecimalMode() - Constructor for enum io.debezium.jdbc.JdbcValueConverters.DecimalMode
 
decimalValue - Variable in class io.debezium.data.SpecialValueDecimal
 
decrement() - Method in interface io.debezium.crdt.DeltaCounter
Decrement the counter and get the result.
decrement() - Method in interface io.debezium.crdt.PNCounter
Decrement the counter and get the result.
decrement() - Method in class io.debezium.crdt.StateBasedPNCounter
 
decrement() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
decrementAndGet() - Method in interface io.debezium.crdt.PNCounter
Decrement the counter and get the result.
decrementAndGet() - Method in class io.debezium.crdt.StateBasedPNCounter
 
decrementAndGet() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
deduplicateWindow(DataCollectionId, Object) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
deduplicationNeeded() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
deduplicationNeeded() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
DEFAULT_CHARSET_NAME_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
DEFAULT_CONCURRENCY_LEVEL - Static variable in class io.debezium.util.BoundedConcurrentHashMap
The default concurrency level for this table, used when not otherwise specified in a constructor.
DEFAULT_DELIM - Static variable in class io.debezium.util.Strings
 
DEFAULT_HEARTBEAT_INTERVAL - Static variable in class io.debezium.heartbeat.HeartbeatImpl
Default length of interval in which connector generates periodically heartbeat messages.
DEFAULT_HEARTBEAT_TOPIC_PREFIX - Static variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
DEFAULT_HEARTBEAT_TOPICS_PREFIX - Static variable in class io.debezium.heartbeat.HeartbeatImpl
Default prefix for names of heartbeat topics
DEFAULT_INSTANCE - Static variable in class io.debezium.document.JacksonReader
 
DEFAULT_LOAD_FACTOR - Static variable in class io.debezium.util.BoundedConcurrentHashMap
The default load factor for this table, used when not otherwise specified in a constructor.
DEFAULT_MAX_BATCH_SIZE - Static variable in class io.debezium.config.CommonConnectorConfig
 
DEFAULT_MAX_QUEUE_SIZE - Static variable in class io.debezium.config.CommonConnectorConfig
 
DEFAULT_MAX_QUEUE_SIZE_IN_BYTES - Static variable in class io.debezium.config.CommonConnectorConfig
 
DEFAULT_MAXIMUM_CAPACITY - Static variable in class io.debezium.util.BoundedConcurrentHashMap
The default initial capacity for this table, used when not otherwise specified in a constructor.
DEFAULT_NOOP_ERRORHANDLER - Static variable in interface io.debezium.heartbeat.HeartbeatErrorHandler
 
DEFAULT_NOOP_HEARTBEAT - Static variable in interface io.debezium.heartbeat.Heartbeat
No-op Heartbeat implementation
DEFAULT_POLL_INTERVAL_MILLIS - Static variable in class io.debezium.config.CommonConnectorConfig
 
DEFAULT_QUERY_FETCH_SIZE - Static variable in class io.debezium.config.CommonConnectorConfig
 
DEFAULT_RETRIABLE_RESTART_WAIT - Static variable in class io.debezium.config.CommonConnectorConfig
 
DEFAULT_SCHEMA_HISTORY - Static variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
DEFAULT_SCOPE - Enum constant in enum io.debezium.relational.SystemVariables.DefaultScope
 
DEFAULT_SNAPSHOT_FETCH_SIZE - Static variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
DEFAULT_SNAPSHOT_LOCK_TIMEOUT_MILLIS - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
DEFAULT_TRACING_OPERATION_NAME - Static variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
DEFAULT_TRACING_SPAN_CONTEXT_FIELD - Static variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
DEFAULT_TRANSACTION_TOPIC - Static variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
DEFAULT_UNAVAILABLE_VALUE_PLACEHOLDER - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
DEFAULT_VALUE_EXPRESSION - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
DefaultChangeEventSourceMetricsFactory<P extends Partition> - Class in io.debezium.pipeline.metrics
 
DefaultChangeEventSourceMetricsFactory() - Constructor for class io.debezium.pipeline.metrics.DefaultChangeEventSourceMetricsFactory
 
defaultCharsetName - Variable in class io.debezium.relational.NoOpTableEditorImpl
 
defaultCharsetName - Variable in class io.debezium.relational.TableEditorImpl
 
defaultCharsetName - Variable in class io.debezium.relational.TableImpl
 
defaultCharsetName() - Method in interface io.debezium.relational.Table
Get the database-specific name of the default character set used by columns in this table.
defaultCharsetName() - Method in class io.debezium.relational.TableImpl
 
defaultConfigurationProvider - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
DefaultConfigurationProvider() - Constructor for class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
defaultConnectionFactory - Variable in class io.debezium.jdbc.JdbcConnection.ConnectionFactoryDecorator
 
DefaultMainConnectionProvidingConnectionFactory<T extends JdbcConnection> - Class in io.debezium.jdbc
 
DefaultMainConnectionProvidingConnectionFactory(ConnectionFactory<T>) - Constructor for class io.debezium.jdbc.DefaultMainConnectionProvidingConnectionFactory
 
defaultNonRelationalSelector(SchemaNameAdjuster) - Static method in class io.debezium.schema.FieldNameSelector
 
defaultOffset - Variable in class io.debezium.jdbc.JdbcValueConverters
 
defaultReader() - Static method in interface io.debezium.document.ArrayReader
Get the default ArrayReader instance.
defaultReader() - Static method in interface io.debezium.document.DocumentReader
Get the default DocumentReader instance.
DefaultRegexTopicNamingStrategy - Class in io.debezium.schema
Implement a regex expression strategy to determine data event topic names using DataCollectionId.databaseParts().
DefaultRegexTopicNamingStrategy(Properties) - Constructor for class io.debezium.schema.DefaultRegexTopicNamingStrategy
 
DefaultScope(int) - Constructor for enum io.debezium.relational.SystemVariables.DefaultScope
 
defaultSelector(CommonConnectorConfig, TopicSelector.DataCollectionTopicNamer<I>) - Static method in class io.debezium.schema.TopicSelector
Deprecated.
 
defaultSelector(SchemaNameAdjuster) - Static method in class io.debezium.schema.FieldNameSelector
 
defaultSelector(String, String, String, TopicSelector.DataCollectionTopicNamer<I>) - Static method in class io.debezium.schema.TopicSelector
Deprecated.
 
DefaultSnapshotChangeEventSourceMetrics<P extends Partition> - Class in io.debezium.pipeline.metrics
The default implementation of metrics related to the snapshot phase of a connector.
DefaultSnapshotChangeEventSourceMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider) - Constructor for class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
DefaultSnapshotChangeEventSourceMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider, Map<String, String>) - Constructor for class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
DefaultStreamingChangeEventSourceMetrics<P extends Partition> - Class in io.debezium.pipeline.metrics
The default implementation of metrics related to the streaming phase of a connector.
DefaultStreamingChangeEventSourceMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider) - Constructor for class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
DefaultStreamingChangeEventSourceMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider, Map<String, String>) - Constructor for class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
DefaultTopicNamingStrategy - Class in io.debezium.schema
Determine data event topic names using DataCollectionId.databaseParts().
DefaultTopicNamingStrategy(Properties) - Constructor for class io.debezium.schema.DefaultTopicNamingStrategy
 
DefaultUnicodeTopicNamingStrategy - Class in io.debezium.schema
Implement a unicode converter strategy to determine data event topic names using DataCollectionId.databaseParts().
DefaultUnicodeTopicNamingStrategy(Properties) - Constructor for class io.debezium.schema.DefaultUnicodeTopicNamingStrategy
 
defaultValue() - Method in class io.debezium.config.Field
Get the default value of the field.
defaultValueAsString() - Method in class io.debezium.config.Field
Get the string representation of the default value of the field.
defaultValueConverter - Variable in class io.debezium.relational.TableSchemaBuilder
 
DefaultValueConverter - Interface in io.debezium.relational
This interface is used to convert the string default value to a Java type recognized by value converters for a subset of types.
DefaultValueConverter.DefaultValueMapper - Interface in io.debezium.relational
Converts the raw JDBC default value expression for a column into an object.
defaultValueExpression - Variable in class io.debezium.relational.ColumnEditorImpl
 
defaultValueExpression - Variable in class io.debezium.relational.ColumnImpl
 
defaultValueExpression() - Method in interface io.debezium.relational.Column
Get the database-specific complete expression defining the column's default value.
defaultValueExpression() - Method in interface io.debezium.relational.ColumnEditor
Get the database-specific complete expression defining the column's default value.
defaultValueExpression() - Method in class io.debezium.relational.ColumnEditorImpl
 
defaultValueExpression() - Method in class io.debezium.relational.ColumnImpl
 
defaultValueExpression(String) - Method in interface io.debezium.relational.ColumnEditor
Set the default value expression of the column;
defaultValueExpression(String) - Method in class io.debezium.relational.ColumnEditorImpl
 
defaultValueGenerator - Variable in class io.debezium.config.Field
 
defaultWriter() - Static method in interface io.debezium.document.ArrayWriter
Get the default ArrayWriter instance.
defaultWriter() - Static method in interface io.debezium.document.DocumentWriter
Get the default DocumentWriter instance.
defineRecordKey(String, Struct) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
defineRecordKeySchema(String, Schema) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
defineSchema() - Static method in class io.debezium.converters.CloudEventsConverter
 
defineSchema() - Static method in class io.debezium.data.Envelope
 
delaySnapshotIfNeeded(ChangeEventSource.ChangeEventSourceContext) - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
Delays snapshot execution as per the CommonConnectorConfig.SNAPSHOT_DELAY_MS parameter.
DelayStrategy - Interface in io.debezium.util
Encapsulates the logic of determining a delay when some criteria is met.
delegate - Variable in class io.debezium.jdbc.DefaultMainConnectionProvidingConnectionFactory
 
delegate - Variable in class io.debezium.schema.FieldNameSelector.FieldNameCache
 
delegate - Variable in class io.debezium.schema.FieldNameSelector.FieldNameSanitizer
 
delegate - Variable in class io.debezium.schema.TopicSelector.TopicNameCache
Deprecated.
 
delegate - Variable in class io.debezium.schema.TopicSelector.TopicNameSanitizer
Deprecated.
 
delegate - Variable in class io.debezium.util.LRUCacheMap
 
DELEGATE_CONVERTER_TYPE - Static variable in class io.debezium.converters.BinaryDataConverter
 
DELEGATE_CONVERTER_TYPE - Static variable in class io.debezium.converters.ByteArrayConverter
 
delegateConverter - Variable in class io.debezium.converters.BinaryDataConverter
 
delegateConverter - Variable in class io.debezium.converters.ByteArrayConverter
 
delete(File) - Static method in class io.debezium.util.IoUtil
A method that will delete a file or folder.
delete(File...) - Static method in class io.debezium.util.IoUtil
A method that will delete multiple file and/or folders.
delete(Object, Struct, Instant) - Method in class io.debezium.data.Envelope
Generate an delete message with the given information.
delete(String) - Static method in class io.debezium.util.IoUtil
A method that will delete a file or folder only if it is within the 'target' directory (for safety).
delete(Path) - Static method in class io.debezium.util.IoUtil
A method that will recursively delete a file or folder.
DELETE - Enum constant in enum io.debezium.data.Envelope.Operation
An operation that resulted in an existing record being removed from or deleted in the source.
DELETED_FIELD - Static variable in class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
DeleteHandling(String) - Constructor for enum io.debezium.transforms.ExtractNewRecordStateConfigDefinition.DeleteHandling
 
deleteRow() - Method in class io.debezium.jdbc.CancellableResultSet
 
delimiter - Variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
delimiter - Variable in class io.debezium.schema.TopicSelector
Deprecated.
 
delimiter(int, int[]) - Method in class io.debezium.jdbc.JdbcConnection
 
deliver(Object) - Method in interface io.debezium.jdbc.ResultReceiver
Send the object to the receiver.
delta - Variable in class io.debezium.crdt.StateBasedPNDeltaCounter
 
DeltaCount - Interface in io.debezium.crdt
A Count that also tracks changes to the value within the last interval.
DeltaCounter - Interface in io.debezium.crdt
A simple counter that maintains a single changing value by separately tracking the positive and negative changes, and by tracking recent changes in this value since last reset.
dependents - Variable in class io.debezium.config.Field
 
dependents() - Method in class io.debezium.config.Field
Get the names of the fields that are or may be dependent upon this field.
deriveQuotingChar(String) - Static method in class io.debezium.util.Strings
 
desc - Variable in class io.debezium.config.Field
 
DESCENDING - Enum constant in enum io.debezium.relational.RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder
 
description() - Method in class io.debezium.config.Field
Get the description of the field.
deserialize(Array, boolean) - Method in class io.debezium.relational.history.JsonTableChangeSerializer
 
deserialize(String, byte[]) - Method in class io.debezium.document.ArraySerdes
 
deserialize(String, byte[]) - Method in class io.debezium.document.DocumentSerdes
 
deserialize(String, byte[]) - Method in class io.debezium.serde.json.JsonSerde.JsonDeserializer
 
deserialize(List<Struct>, boolean) - Method in class io.debezium.relational.history.ConnectTableChangeSerializer
 
deserialize(T, boolean) - Method in interface io.debezium.relational.history.TableChanges.TableChangesSerializer
 
deserializer() - Method in class io.debezium.serde.json.JsonSerde
 
detailed - Variable in class io.debezium.data.SchemaUtil.RecordWriter
 
detailed(boolean) - Method in class io.debezium.data.SchemaUtil.RecordWriter
 
determineCapturedTables(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
determineDataCollectionsToBeSnapshotted(Collection<T>) - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
 
determineFeatureVersion() - Static method in class io.debezium.util.JvmVersionUtil
Returns the feature version of the current JVM, e.g.
determineNewTopic(DataCollectionId, String) - Method in class io.debezium.schema.AbstractRegexTopicNamingStrategy
Determine the new topic name.
determineNewTopic(String) - Method in class io.debezium.transforms.ByLogicalTableRouter
Determine the new topic name.
determineSkippedOperations(Configuration) - Static method in class io.debezium.config.CommonConnectorConfig
 
determineSnapshotOffset(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, O) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Determines the current offset (MySQL binlog position, Oracle SCN etc.), storing it into the passed context object.
determineSnapshotSelect(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, TableId) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Returns a valid query string for the specified table, either given by the user via snapshot select overrides or defaulting to a statement provided by the DB-specific change event source.
determineStruct(String) - Static method in class io.debezium.transforms.ExtractNewRecordState.FieldReference
Determines the struct hosting the given unqualified field.
disableBuffering() - Method in class io.debezium.connector.base.ChangeEventQueue
Disable buffering for the queue
DISABLED - Enum constant in enum io.debezium.relational.RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder
 
dispatchConnectorEvent(P, ConnectorEvent) - Method in class io.debezium.pipeline.EventDispatcher
 
dispatchDataChangeEvent(P, T, ChangeRecordEmitter<P>) - Method in class io.debezium.pipeline.EventDispatcher
Dispatches one or more DataChangeEvents.
dispatcher - Variable in class io.debezium.pipeline.signal.actions.SchemaChanges
 
dispatcher - Variable in class io.debezium.pipeline.signal.actions.snapshotting.CloseIncrementalSnapshotWindow
 
dispatcher - Variable in class io.debezium.pipeline.signal.actions.snapshotting.ExecuteSnapshot
 
dispatcher - Variable in class io.debezium.pipeline.signal.actions.snapshotting.PauseIncrementalSnapshot
 
dispatcher - Variable in class io.debezium.pipeline.signal.actions.snapshotting.ResumeIncrementalSnapshot
 
dispatcher - Variable in class io.debezium.pipeline.signal.actions.snapshotting.StopSnapshot
 
dispatcher - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
dispatcher - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
dispatchFilteredEvent(P, OffsetContext) - Method in class io.debezium.pipeline.EventDispatcher
 
dispatchHeartbeatEvent(P, OffsetContext) - Method in class io.debezium.pipeline.EventDispatcher
 
dispatchSchemaChangeEvent(Collection<T>, SchemaChangeEventEmitter) - Method in class io.debezium.pipeline.EventDispatcher
 
dispatchSchemaChangeEvent(P, OffsetContext, T, SchemaChangeEventEmitter) - Method in class io.debezium.pipeline.EventDispatcher
 
dispatchServerHeartbeatEvent(P, OffsetContext) - Method in class io.debezium.pipeline.EventDispatcher
 
dispatchSnapshotEvent(P, T, ChangeRecordEmitter<P>, EventDispatcher.SnapshotReceiver<P>) - Method in class io.debezium.pipeline.EventDispatcher
 
dispatchTransactionCommittedEvent(P, OffsetContext, Instant) - Method in class io.debezium.pipeline.EventDispatcher
 
dispatchTransactionStartedEvent(P, String, OffsetContext, Instant) - Method in class io.debezium.pipeline.EventDispatcher
 
displayName - Variable in class io.debezium.config.Field
 
displayName() - Method in class io.debezium.config.Field
Get the display name of the field.
doc - Variable in class io.debezium.relational.history.HistoryRecord
 
doClose() - Method in class io.debezium.jdbc.JdbcConnection
 
doCreateDataEventsForTable(ChangeEventSource.ChangeEventSourceContext, P, O, EventDispatcher.SnapshotReceiver<P>, Table, boolean, boolean, int, int, String, OptionalLong, JdbcConnection) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
document() - Method in class io.debezium.relational.history.HistoryRecord
 
Document - Interface in io.debezium.document
A document contains multiple Document.Fields, each with a name and possibly-null Value.
DOCUMENT - Enum constant in enum io.debezium.document.Value.Type
 
DOCUMENT_READER - Static variable in class io.debezium.document.DocumentSerdes
 
DOCUMENT_WRITER - Static variable in class io.debezium.document.DocumentSerdes
 
Document.Field - Interface in io.debezium.document
 
documentReader - Variable in class io.debezium.pipeline.signal.SignalProcessor
 
documentReader - Variable in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
DocumentReader - Interface in io.debezium.document
Reads Document instances from a variety of input forms.
DocumentSerdes - Class in io.debezium.document
A Kafka Deserializer and Serializer that operates upon Debezium Documents.
DocumentSerdes() - Constructor for class io.debezium.document.DocumentSerdes
 
documentWriter - Variable in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
DocumentWriter - Interface in io.debezium.document
Writes Document instances to a variety of output forms.
doEnqueue(T) - Method in class io.debezium.connector.base.ChangeEventQueue
 
doExecute(ChangeEventSource.ChangeEventSourceContext, O, AbstractSnapshotChangeEventSource.SnapshotContext<P, O>, AbstractSnapshotChangeEventSource.SnapshottingTask) - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
Executes this source.
doExecute(ChangeEventSource.ChangeEventSourceContext, O, AbstractSnapshotChangeEventSource.SnapshotContext<P, O>, AbstractSnapshotChangeEventSource.SnapshottingTask) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
doOnEntry(TableIdParser.ParsingContext) - Method in enum io.debezium.relational.TableIdParser.ParsingState
 
doOnExit(TableIdParser.ParsingContext) - Method in enum io.debezium.relational.TableIdParser.ParsingState
 
doPoll() - Method in class io.debezium.connector.common.BaseSourceTask
Returns the next batch of source records, if any are available.
doPreStart() - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
doPreStoreRecord(HistoryRecord) - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
doSnapshot(SnapshotChangeEventSource<P, O>, ChangeEventSource.ChangeEventSourceContext, P, O) - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
doStart() - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
doStop() - Method in class io.debezium.connector.common.BaseSourceTask
 
doStop() - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
doStoreRecord(HistoryRecord) - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
DOUBLE - Enum constant in enum io.debezium.document.Value.Type
 
DOUBLE - Enum constant in enum io.debezium.jdbc.JdbcValueConverters.DecimalMode
 
DOUBLE - Enum constant in enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
Represent DECIMAL and NUMERIC values as precise double values.
DOUBLE_FALSE - Static variable in class io.debezium.util.NumberConversions
 
DOUBLE_QUOTED_STRING - Static variable in class io.debezium.text.TokenStream.BasicTokenizer
The token type for tokens that consist of all the characters within double-quotes.
DOUBLE_QUOTES - Static variable in class io.debezium.relational.TableIdParser
 
DOUBLE_TRUE - Static variable in class io.debezium.util.NumberConversions
 
drainChanges() - Method in class io.debezium.relational.Tables
 
drainRecords(List<T>, int) - Method in class io.debezium.connector.base.ChangeEventQueue
 
DRIVER_CONFIG_PREFIX - Static variable in class io.debezium.config.CommonConnectorConfig
 
drop(Table) - Method in class io.debezium.relational.history.TableChanges
 
DROP - Enum constant in enum io.debezium.relational.history.TableChanges.TableChangeType
 
DROP - Enum constant in enum io.debezium.schema.SchemaChangeEvent.SchemaChangeEventType
 
DROP - Enum constant in enum io.debezium.transforms.ExtractNewRecordStateConfigDefinition.DeleteHandling
 
DROP_DATABASE - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
DROP_FIELDS_FROM_KEY - Static variable in class io.debezium.transforms.ExtractNewRecordState
 
DROP_FIELDS_HEADER - Static variable in class io.debezium.transforms.ExtractNewRecordState
 
DROP_FIELDS_KEEP_SCHEMA_COMPATIBLE - Static variable in class io.debezium.transforms.ExtractNewRecordState
 
DROP_INDEX - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
DROP_TABLE - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
DROP_TOMBSTONES - Static variable in class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
dropFields(R) - Method in class io.debezium.transforms.ExtractNewRecordState
 
dropFieldsFromKey - Variable in class io.debezium.transforms.ExtractNewRecordState
 
dropFieldsHeaderName - Variable in class io.debezium.transforms.ExtractNewRecordState
 
dropFieldsKeepSchemaCompatible - Variable in class io.debezium.transforms.ExtractNewRecordState
 
dropKeyFields(R, List<String>) - Method in class io.debezium.transforms.ExtractNewRecordState
 
dropTombstones - Variable in class io.debezium.transforms.ExtractNewRecordState
 
dropValueFields(R, List<String>) - Method in class io.debezium.transforms.ExtractNewRecordState
 
duration(long) - Static method in class io.debezium.util.Strings
For the given duration in milliseconds, obtain a readable representation of the form HHH:MM:SS.mmm, where HHH is the number of hours written in at least 2 digits (e.g., "03") MM is the number of minutes written in 2 digits (e.g., "05") SS is the number of seconds written in 2 digits (e.g., "09") mmm is the fractional part of seconds, written with 1-3 digits (any trailing zeros are dropped)
durationMicros(int, int, int, int, int, double, int, Double) - Static method in class io.debezium.time.MicroDuration
Converts a number of time units to a duration in microseconds.
durationMicros(int, int, int, int, int, double, Double) - Static method in class io.debezium.time.MicroDuration
Converts a number of time units to a duration in microseconds.
durationNanos(int, int, int, int, int, long) - Static method in class io.debezium.time.NanoDuration
Converts a number of time units to a duration in nanoseconds.
durationNanos(int, int, int, int, int, long, long) - Static method in class io.debezium.time.NanoDuration
Converts a number of time units to a duration in nanoseconds.
durations - Variable in class io.debezium.util.Stopwatch.MultipleDurations
 
durations() - Method in class io.debezium.util.Stopwatch
Get the total and average durations measured by this stopwatch.

E

edit() - Method in class io.debezium.config.ConfigDefinition
Returns an editor for a config definition instance seeded with the values from this config definition.
edit() - Method in interface io.debezium.config.Configuration
Obtain an editor for a copy of this configuration.
edit() - Method in interface io.debezium.relational.Attribute
Obtain an editor that contains the same information as this attribute.
edit() - Method in class io.debezium.relational.AttributeImpl
 
edit() - Method in interface io.debezium.relational.Column
Obtain an editor that contains the same information as this column definition.
edit() - Method in class io.debezium.relational.ColumnImpl
 
edit() - Method in interface io.debezium.relational.Table
Obtain an editor that contains the same information as this table definition.
edit() - Method in class io.debezium.relational.TableImpl
 
editor() - Static method in class io.debezium.config.ConfigDefinition
Returns an editor for new empty config definition instance.
editor() - Static method in interface io.debezium.relational.Attribute
Obtain an attribute editor that can be used to define an attribute.
editor() - Static method in interface io.debezium.relational.Column
Obtain an column definition editor that can be used to define a column.
editor() - Static method in interface io.debezium.relational.Table
Obtain an table definition editor that can be used to define a table.
editOrCreateTable(TableId) - Method in class io.debezium.relational.Tables
Obtain an editor for the table with the given ID.
editTable(TableId) - Method in class io.debezium.relational.Tables
Obtain an editor for the table with the given ID.
elapsedTime() - Method in interface io.debezium.util.Threads.TimeSince
Get the time that has elapsed since the last call to reset.
ElapsedTimeStrategy - Interface in io.debezium.util
Encapsulates the logic of determining a delay when some criteria is met.
elements() - Method in class io.debezium.util.BoundedConcurrentHashMap
Returns an enumeration of the values in this table.
eligibleDataCollectionFilter() - Method in class io.debezium.relational.RelationalTableFilters
 
eligibleForSchemaDataCollectionFilter() - Method in class io.debezium.relational.RelationalTableFilters
 
eligibleTableFilter - Variable in class io.debezium.relational.RelationalTableFilters
 
emitChangeRecords(DataCollectionSchema, ChangeRecordEmitter.Receiver<P>) - Method in class io.debezium.pipeline.AbstractChangeRecordEmitter
 
emitChangeRecords(DataCollectionSchema, ChangeRecordEmitter.Receiver<P>) - Method in interface io.debezium.pipeline.spi.ChangeRecordEmitter
Emits the change record(s) corresponding to data change represented by this emitter.
emitChangeRecords(DataCollectionSchema, ChangeRecordEmitter.Receiver<P>) - Method in class io.debezium.relational.RelationalChangeRecordEmitter
 
emitCreateRecord(ChangeRecordEmitter.Receiver<P>, TableSchema) - Method in class io.debezium.relational.RelationalChangeRecordEmitter
 
emitCreateRecord(ChangeRecordEmitter.Receiver<P>, T) - Method in class io.debezium.pipeline.AbstractChangeRecordEmitter
Emits change record(s) associated with an insert operation.
emitDeleteRecord(ChangeRecordEmitter.Receiver<P>, TableSchema) - Method in class io.debezium.relational.RelationalChangeRecordEmitter
 
emitDeleteRecord(ChangeRecordEmitter.Receiver<P>, T) - Method in class io.debezium.pipeline.AbstractChangeRecordEmitter
Emits change record(s) associated with a delete operation.
emitReadRecord(ChangeRecordEmitter.Receiver<P>, TableSchema) - Method in class io.debezium.relational.RelationalChangeRecordEmitter
 
emitReadRecord(ChangeRecordEmitter.Receiver<P>, T) - Method in class io.debezium.pipeline.AbstractChangeRecordEmitter
Emits change record(s) associated with a snapshot.
emitSchemaChangeEvent(SchemaChangeEventEmitter.Receiver) - Method in interface io.debezium.pipeline.spi.SchemaChangeEventEmitter
 
emitTombstoneOnDelete - Variable in class io.debezium.config.CommonConnectorConfig
 
emitTombstonesOnDelete - Variable in class io.debezium.pipeline.EventDispatcher
 
emitTruncateRecord(ChangeRecordEmitter.Receiver<P>, TableSchema) - Method in class io.debezium.relational.RelationalChangeRecordEmitter
 
emitUpdateAsPrimaryKeyChangeRecord(ChangeRecordEmitter.Receiver<P>, TableSchema, Struct, Struct, Struct, Struct) - Method in class io.debezium.relational.RelationalChangeRecordEmitter
 
emitUpdateRecord(ChangeRecordEmitter.Receiver<P>, TableSchema) - Method in class io.debezium.relational.RelationalChangeRecordEmitter
 
emitUpdateRecord(ChangeRecordEmitter.Receiver<P>, T) - Method in class io.debezium.pipeline.AbstractChangeRecordEmitter
Emits change record(s) associated with an update operation.
emitWindowClose(Partition, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.SignalBasedIncrementalSnapshotChangeEventSource
 
emitWindowClose(P, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
Update high watermark for the incremental snapshot chunk
emitWindowOpen() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
Update low watermark for the incremental snapshot chunk
emitWindowOpen() - Method in class io.debezium.pipeline.source.snapshot.incremental.SignalBasedIncrementalSnapshotChangeEventSource
 
empty() - Static method in interface io.debezium.config.Configuration
Obtain an empty configuration.
empty() - Static method in interface io.debezium.jdbc.JdbcConfiguration
 
empty() - Static method in class io.debezium.util.Iterators
 
EMPTY_ARRAY_SIZE - Static variable in class io.debezium.util.ApproximateStructSizeCalculator
 
EMPTY_BYTES_SIZE - Static variable in class io.debezium.util.ApproximateStructSizeCalculator
 
EMPTY_CONTENT_POSITION - Static variable in class io.debezium.text.Position
The position is used when there is no content.
EMPTY_CONTEXT - Static variable in class io.debezium.util.LoggingContext.PreviousContext
 
EMPTY_MAP_SIZE - Static variable in class io.debezium.util.ApproximateStructSizeCalculator
 
EMPTY_PRIMITIVE - Static variable in class io.debezium.util.ApproximateStructSizeCalculator
 
EMPTY_STRING - Static variable in class io.debezium.config.Field
 
EMPTY_STRING_SIZE - Static variable in class io.debezium.util.ApproximateStructSizeCalculator
 
EMPTY_STRUCT_SIZE - Static variable in class io.debezium.util.ApproximateStructSizeCalculator
 
EmptyOffsetContext() - Constructor for class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
enabledChannels - Variable in class io.debezium.pipeline.notification.NotificationService
 
enabledNotificationChannels - Variable in class io.debezium.config.CommonConnectorConfig
 
enableJsonSchemas - Variable in class io.debezium.converters.CloudEventsConverter
 
END - Enum constant in enum io.debezium.pipeline.txmetadata.TransactionStatus
 
endIndex - Variable in class io.debezium.text.TokenStream.CaseSensitiveToken
 
endIndex() - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
endIndex() - Method in interface io.debezium.text.TokenStream.Token
Get the index in the raw stream past the last character in the token.
endTransaction() - Method in class io.debezium.pipeline.txmetadata.TransactionContext
 
endTransaction(Partition, OffsetContext, Instant) - Method in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
enhanceOverriddenSelect(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, String, TableId) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
This method is overridden for Oracle to implement "as of SCN" predicate
enqueue(T) - Method in class io.debezium.connector.base.ChangeEventQueue
Enqueues a record so that it can be obtained via ChangeEventQueue.poll().
enqueueHeartbeat(SourceRecord) - Method in class io.debezium.pipeline.EventDispatcher
 
enqueueNotification(SourceRecord) - Method in class io.debezium.pipeline.EventDispatcher
 
enqueueSchemaChangeMessage(SourceRecord) - Method in class io.debezium.pipeline.EventDispatcher
 
enqueueTransactionMessage(SourceRecord) - Method in class io.debezium.pipeline.EventDispatcher
 
ensureValid(String, Object) - Method in class io.debezium.config.Field.RangeValidator
 
EntryIterator() - Constructor for class io.debezium.util.BoundedConcurrentHashMap.EntryIterator
 
entrySet - Variable in class io.debezium.util.BoundedConcurrentHashMap
 
entrySet() - Method in class io.debezium.relational.Tables.TablesById
 
entrySet() - Method in class io.debezium.util.BoundedConcurrentHashMap
Returns a Set view of the mappings contained in this map.
EntrySet() - Constructor for class io.debezium.util.BoundedConcurrentHashMap.EntrySet
 
Enum - Class in io.debezium.data
A semantic type for an enumeration, where the string values are one of the enumeration's values.
Enum() - Constructor for class io.debezium.data.Enum
 
ENUM_VALUES - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
EnumeratedValue - Interface in io.debezium.config
A configuration option with a fixed set of possible values, i.e.
EnumRecommender(Class<T>) - Constructor for class io.debezium.config.Field.EnumRecommender
 
EnumSet - Class in io.debezium.data
A semantic type for a set of enumerated values, where the string values contain comma-separated values from an enumeration.
EnumSet() - Constructor for class io.debezium.data.EnumSet
 
enumValues - Variable in class io.debezium.relational.ColumnEditorImpl
 
enumValues - Variable in class io.debezium.relational.ColumnImpl
 
enumValues() - Method in interface io.debezium.relational.Column
Get the list of values associated with the enum
enumValues() - Method in interface io.debezium.relational.ColumnEditor
get the enumeration values for the column.
enumValues() - Method in class io.debezium.relational.ColumnEditorImpl
 
enumValues() - Method in class io.debezium.relational.ColumnImpl
 
enumValues(List<String>) - Method in interface io.debezium.relational.ColumnEditor
Set the list of enumeration values.
enumValues(List<String>) - Method in class io.debezium.relational.ColumnEditorImpl
 
Envelope - Class in io.debezium.data
An immutable descriptor for the structure of Debezium message envelopes.
Envelope(Schema) - Constructor for class io.debezium.data.Envelope
 
ENVELOPE - Enum constant in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalFieldPlacement
 
ENVELOPE_PAYLOAD - Static variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
Envelope.Builder - Interface in io.debezium.data
A builder of an envelope schema.
Envelope.FieldName - Class in io.debezium.data
The constants for the names of the fields in the message envelope.
Envelope.Operation - Enum in io.debezium.data
The constants for the values for the operation field in the message envelope.
envelopeSchema - Variable in class io.debezium.relational.TableSchema
 
envelopeSchemaUpdateCache - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
EPOCH - Static variable in class io.debezium.time.Conversions
 
equals(Object) - Method in class io.debezium.config.Field
 
equals(Object) - Method in class io.debezium.data.SpecialValueDecimal
 
equals(Object) - Method in class io.debezium.document.BasicArray
 
equals(Object) - Method in class io.debezium.document.BasicDocument
 
equals(Object) - Method in class io.debezium.document.BasicEntry
 
equals(Object) - Method in class io.debezium.document.BasicField
 
equals(Object) - Method in class io.debezium.document.BinaryValue
 
equals(Object) - Method in class io.debezium.document.ComparableValue
 
equals(Object) - Method in class io.debezium.document.ConvertingValue
 
equals(Object) - Method in class io.debezium.document.NullValue
 
equals(Object) - Method in class io.debezium.document.Paths.ChildPath
 
equals(Object) - Method in class io.debezium.document.Paths.MultiSegmentPath
 
equals(Object) - Method in class io.debezium.document.Paths.RootPath
 
equals(Object) - Method in class io.debezium.document.Paths.SingleSegmentPath
 
equals(Object) - Method in class io.debezium.pipeline.notification.Notification
 
equals(Object) - Method in class io.debezium.pipeline.signal.SignalRecord
 
equals(Object) - Method in class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
equals(Object) - Method in class io.debezium.relational.AttributeImpl
 
equals(Object) - Method in class io.debezium.relational.ColumnId
 
equals(Object) - Method in class io.debezium.relational.ColumnImpl
 
equals(Object) - Method in class io.debezium.relational.history.TableChanges
 
equals(Object) - Method in class io.debezium.relational.history.TableChanges.TableChange
 
equals(Object) - Method in class io.debezium.relational.TableId
 
equals(Object) - Method in class io.debezium.relational.TableImpl
 
equals(Object) - Method in class io.debezium.relational.Tables
 
equals(Object) - Method in class io.debezium.relational.Tables.TablesById
 
equals(Object) - Method in class io.debezium.relational.TableSchema
 
equals(Object) - Method in class io.debezium.text.Position
 
equals(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap.HashEntry
 
equals(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
 
equals(Object) - Method in class io.debezium.util.MurmurHash3
 
equalsIgnoreCase(String, String) - Static method in class io.debezium.util.Strings
Check whether the two String instances are equal ignoring case.
errorCode - Variable in exception io.debezium.jdbc.JdbcConnectionException
 
errorHandler - Variable in class io.debezium.heartbeat.DatabaseHeartbeatImpl
 
errorHandler - Variable in class io.debezium.heartbeat.HeartbeatFactory
 
errorHandler - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
ErrorHandler - Class in io.debezium.pipeline
 
ErrorHandler(Class<? extends SourceConnector>, CommonConnectorConfig, ChangeEventQueue<?>) - Constructor for class io.debezium.pipeline.ErrorHandler
 
ErrorHandler(Class<? extends SourceConnector>, CommonConnectorConfig, ChangeEventQueue<?>, ErrorHandler) - Constructor for class io.debezium.pipeline.ErrorHandler
 
errorOnMissingSchema(P, T, ChangeRecordEmitter<P>) - Method in class io.debezium.pipeline.EventDispatcher
 
errors - Variable in exception io.debezium.text.MultipleParsingExceptions
 
ESCAPE_CHAR - Static variable in class io.debezium.jdbc.JdbcConnection
 
escaped - Variable in class io.debezium.relational.TableIdParser.ParsingContext
 
escapeEscapeSequence(String) - Method in class io.debezium.jdbc.JdbcConnection
 
event(DataCollectionId) - Method in class io.debezium.pipeline.txmetadata.TransactionContext
 
event(DataCollectionId, Instant) - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
event(DataCollectionId, Instant) - Method in interface io.debezium.pipeline.spi.OffsetContext
Records the name of the collection and the timestamp of the last event
Event(DdlParserListener.EventType, String) - Constructor for class io.debezium.relational.ddl.DdlParserListener.Event
 
EVENT_COUNT_PER_DATA_COLLECTION_SCHEMA - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
EVENT_PRIMARY_KEY - Static variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
EVENT_PROCESSING_FAILURE_HANDLING_MODE - Static variable in class io.debezium.config.CommonConnectorConfig
 
eventDispatcher - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
EventDispatcher<P extends Partition,T extends DataCollectionId> - Class in io.debezium.pipeline
Central dispatcher for data change and schema change events.
EventDispatcher(CommonConnectorConfig, TopicNamingStrategy<T>, DatabaseSchema<T>, ChangeEventQueue<DataChangeEvent>, DataCollectionFilters.DataCollectionFilter<T>, ChangeEventCreator, EventDispatcher.InconsistentSchemaHandler<P, T>, Heartbeat, SchemaNameAdjuster, TransactionMonitor, SignalProcessor<P, ?>) - Constructor for class io.debezium.pipeline.EventDispatcher
 
EventDispatcher(CommonConnectorConfig, TopicNamingStrategy<T>, DatabaseSchema<T>, ChangeEventQueue<DataChangeEvent>, DataCollectionFilters.DataCollectionFilter<T>, ChangeEventCreator, EventDispatcher.InconsistentSchemaHandler<P, T>, EventMetadataProvider, Heartbeat, SchemaNameAdjuster, SignalProcessor<P, ?>) - Constructor for class io.debezium.pipeline.EventDispatcher
 
EventDispatcher(CommonConnectorConfig, TopicNamingStrategy<T>, DatabaseSchema<T>, ChangeEventQueue<DataChangeEvent>, DataCollectionFilters.DataCollectionFilter<T>, ChangeEventCreator, EventMetadataProvider, Heartbeat, SchemaNameAdjuster) - Constructor for class io.debezium.pipeline.EventDispatcher
 
EventDispatcher(CommonConnectorConfig, TopicNamingStrategy<T>, DatabaseSchema<T>, ChangeEventQueue<DataChangeEvent>, DataCollectionFilters.DataCollectionFilter<T>, ChangeEventCreator, EventMetadataProvider, Heartbeat, SchemaNameAdjuster, SignalProcessor<P, ?>) - Constructor for class io.debezium.pipeline.EventDispatcher
 
EventDispatcher(CommonConnectorConfig, TopicNamingStrategy<T>, DatabaseSchema<T>, ChangeEventQueue<DataChangeEvent>, DataCollectionFilters.DataCollectionFilter<T>, ChangeEventCreator, EventMetadataProvider, SchemaNameAdjuster) - Constructor for class io.debezium.pipeline.EventDispatcher
 
EventDispatcher(CommonConnectorConfig, TopicNamingStrategy<T>, DatabaseSchema<T>, ChangeEventQueue<DataChangeEvent>, DataCollectionFilters.DataCollectionFilter<T>, ChangeEventCreator, EventMetadataProvider, SchemaNameAdjuster, SignalProcessor<P, ?>) - Constructor for class io.debezium.pipeline.EventDispatcher
 
EventDispatcher.BufferedDataChangeEvent - Class in io.debezium.pipeline
 
EventDispatcher.BufferingSnapshotChangeRecordReceiver - Class in io.debezium.pipeline
 
EventDispatcher.InconsistentSchemaHandler<P extends Partition,T extends DataCollectionId> - Interface in io.debezium.pipeline
Reaction to an incoming change event for which schema is not found
EventDispatcher.IncrementalSnapshotChangeRecordReceiver - Class in io.debezium.pipeline
 
EventDispatcher.SchemaChangeEventReceiver - Class in io.debezium.pipeline
 
EventDispatcher.SnapshotReceiver<P extends Partition> - Interface in io.debezium.pipeline
Change record receiver used during snapshotting.
EventDispatcher.StreamingChangeRecordReceiver - Class in io.debezium.pipeline
 
EventFormatter - Class in io.debezium.pipeline.source.spi
 
EventFormatter() - Constructor for class io.debezium.pipeline.source.spi.EventFormatter
 
eventListener - Variable in class io.debezium.pipeline.EventDispatcher
 
eventMetadataProvider - Variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
EventMetadataProvider - Interface in io.debezium.pipeline.source.spi
An interface implemented by each connector that enables metrics metadata to be extracted from an event.
eventProcessingFailureHandlingMode - Variable in class io.debezium.config.CommonConnectorConfig
 
EventProcessingFailureHandlingMode(String) - Constructor for enum io.debezium.config.CommonConnectorConfig.EventProcessingFailureHandlingMode
 
EventRouter<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.transforms.outbox
Debezium Outbox Transform Event Router
EventRouter() - Constructor for class io.debezium.transforms.outbox.EventRouter
 
EventRouterConfigDefinition - Class in io.debezium.transforms.outbox
Debezium Outbox Transform configuration definition
EventRouterConfigDefinition() - Constructor for class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
EventRouterConfigDefinition.AdditionalField - Class in io.debezium.transforms.outbox
 
EventRouterConfigDefinition.AdditionalFieldPlacement - Enum in io.debezium.transforms.outbox
 
EventRouterConfigDefinition.InvalidOperationBehavior - Enum in io.debezium.transforms.outbox
 
EventRouterConfigDefinition.JsonPayloadNullFieldBehavior - Enum in io.debezium.transforms.outbox
 
EventRouterConfigurationProvider - Interface in io.debezium.transforms.outbox
Defines a contract allowing a connector to override specific Outbox configuration behavior.
eventRouterDelegate - Variable in class io.debezium.transforms.outbox.EventRouter
 
EventRouterDelegate<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.transforms.outbox
A delegate class having common logic between Outbox Event Routers for SQL DBs and MongoDB
EventRouterDelegate() - Constructor for class io.debezium.transforms.outbox.EventRouterDelegate
 
EventRouterDelegate.DefaultConfigurationProvider - Class in io.debezium.transforms.outbox
 
EventRouterDelegate.RecordConverter<R> - Interface in io.debezium.transforms.outbox
 
events - Variable in class io.debezium.config.ConfigDefinition
 
events - Variable in class io.debezium.config.ConfigDefinitionEditor
 
events - Variable in class io.debezium.relational.ddl.DdlChanges
 
events() - Method in class io.debezium.config.ConfigDefinition
 
events(Field...) - Method in class io.debezium.config.ConfigDefinitionEditor
 
EventType() - Constructor for enum io.debezium.relational.ddl.DdlParserListener.EventType
 
evict() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Evicts this entry, removing it from the queue and setting its status to cold non-resident.
evictCap - Variable in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
evicted - Variable in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
eviction - Variable in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
Eviction() - Constructor for enum io.debezium.util.BoundedConcurrentHashMap.Eviction
 
evictionListener - Variable in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
EXCLUDE - Static variable in class io.debezium.transforms.ExtractNewRecordState
 
excludeColumns - Variable in class io.debezium.relational.RelationalTableFilters
 
excludeDatabases(String) - Method in class io.debezium.relational.Selectors.DatabaseSelectionPredicateBuilder
Specify the names of the databases that should be excluded.
excludeDatabases(String) - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
Specify the names of the databases that should be excluded.
excludes(String) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied string returns true if none of the regular expressions in the supplied comma-separated list matches the predicate parameter.
excludes(String, int) - Static method in class io.debezium.function.Predicates
 
excludes(String, Function<T, String>) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied parameter returns true if none of the regular expressions in the supplied comma-separated list matches the predicate parameter.
excludeSchemas(String) - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
Specify the names of the schemas that should be excluded.
excludesLiterals(String) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied string returns true if none of the literals in the supplied comma-separated list case insensitively matches the predicate parameter.
excludesLiterals(String, Function<T, String>) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied string returns true if none of the literals in the supplied comma-separated list case insensitively matches the predicate parameter.
excludesLiteralsOrPatterns(String, Predicate<String>, Function<T, String>) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied string returns true if none of the regular expressions or literals in the supplied comma-separated list matches the predicate parameter.
excludesUuids(String) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied string returns true if none of the regular expressions or literals in the supplied comma-separated list matches the predicate parameter.
excludeTables(String) - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
Specify the names of the tables that should be excluded.
excludeTables(String, Selectors.TableIdToStringMapper) - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
Specify the names of the tables that should be excluded.
excluding(Field...) - Method in class io.debezium.config.ConfigDefinitionEditor
Removes the given fields from this configuration editor.
execute() - Method in interface io.debezium.util.BoundedConcurrentHashMap.EvictionPolicy
Invokes eviction policy algorithm and returns set of evicted entries.
execute() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
execute() - Method in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
execute() - Method in class io.debezium.util.BoundedConcurrentHashMap.NullEvictionPolicy
 
execute(JdbcConnection.Operations) - Method in class io.debezium.jdbc.JdbcConnection
Execute a series of operations as a single transaction.
execute(ChangeEventSource.ChangeEventSourceContext, P, O) - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
 
execute(ChangeEventSource.ChangeEventSourceContext, P, O) - Method in interface io.debezium.pipeline.source.spi.SnapshotChangeEventSource
Executes this source.
execute(ChangeEventSource.ChangeEventSourceContext, P, O) - Method in interface io.debezium.pipeline.source.spi.StreamingChangeEventSource
Executes this source.
execute(String...) - Method in class io.debezium.jdbc.JdbcConnection
Execute a series of SQL statements as a single transaction.
executeCatchUpStreaming(ChangeEventSource.ChangeEventSourceContext, SnapshotChangeEventSource<P, O>, P, O) - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
executeChangeEventSources(CdcSourceTaskContext, SnapshotChangeEventSource<P, O>, Offsets<P, O>, AtomicReference<LoggingContext.PreviousContext>, ChangeEventSource.ChangeEventSourceContext) - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
executeIteration(ChangeEventSource.ChangeEventSourceContext, P, O) - Method in interface io.debezium.pipeline.source.spi.StreamingChangeEventSource
Executes this source for a single execution iteration.
ExecuteSnapshot<P extends Partition> - Class in io.debezium.pipeline.signal.actions.snapshotting
The action to trigger an ad-hoc snapshot.
ExecuteSnapshot(EventDispatcher<P, ? extends DataCollectionId>) - Constructor for class io.debezium.pipeline.signal.actions.snapshotting.ExecuteSnapshot
 
executeWithoutCommitting(String...) - Method in class io.debezium.jdbc.JdbcConnection
Executes a series of statements without explicitly committing the connection.
executeWithSemaphore(Runnable) - Method in class io.debezium.pipeline.signal.SignalProcessor
 
executor - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
exists() - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
exists() - Method in class io.debezium.relational.history.MemorySchemaHistory
 
exists() - Method in interface io.debezium.relational.history.SchemaHistory
Determines if the database schema history entity exists; i.e.
expand(int) - Method in interface io.debezium.document.Array
If the current size of the array is smaller than the given size, expand it and use a null value for all new entries.
expand(int, boolean) - Method in interface io.debezium.document.Array
If the current size of the array is smaller than the given size, expand it and use the supplied value for all new entries.
expand(int, double) - Method in interface io.debezium.document.Array
If the current size of the array is smaller than the given size, expand it and use the supplied value for all new entries.
expand(int, float) - Method in interface io.debezium.document.Array
If the current size of the array is smaller than the given size, expand it and use the supplied value for all new entries.
expand(int, int) - Method in interface io.debezium.document.Array
If the current size of the array is smaller than the given size, expand it and use the supplied value for all new entries.
expand(int, long) - Method in interface io.debezium.document.Array
If the current size of the array is smaller than the given size, expand it and use the supplied value for all new entries.
expand(int, Value) - Method in interface io.debezium.document.Array
If the current size of the array is smaller than the given size, expand it and use the supplied value for all new entries.
expand(int, Value) - Method in class io.debezium.document.BasicArray
 
expand(int, String) - Method in interface io.debezium.document.Array
If the current size of the array is smaller than the given size, expand it and use the supplied value for all new entries.
EXPAND_JSON_PAYLOAD - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
expandDataCollectionIds(List<String>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
Expands the string-based list of data collection ids if supplied using regex to a list of all matching explicit data collection ids.
expandJsonPayload - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
expired() - Method in interface io.debezium.util.Threads.Timer
 
exponential(Clock, long, long, double) - Static method in interface io.debezium.util.ElapsedTimeStrategy
Create a strategy whose time periods increase exponentially.
exponential(Clock, Duration, Duration) - Static method in interface io.debezium.util.ElapsedTimeStrategy
Create a strategy whose time periods increase exponentially.
exponential(Duration, Duration) - Static method in interface io.debezium.util.DelayStrategy
Create a delay strategy that applies an exponentially-increasing delay as long as the criteria is met.
exponential(Duration, Duration, double) - Static method in interface io.debezium.util.DelayStrategy
Create a delay strategy that applies an exponentially-increasing delay as long as the criteria is met.
export() - Method in class io.debezium.transforms.tracing.DebeziumTextMap
 
expression - Variable in class io.debezium.relational.ddl.DataType
 
expression() - Method in class io.debezium.relational.ddl.DataType
 
EXTENSION_NAME_PREFIX - Static variable in class io.debezium.converters.CloudEventsConverter
 
ExtractChangedRecordState<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.transforms
This SMT to extract the changed and unchanged field names to Connect Headers comparing before and after value.
ExtractChangedRecordState() - Constructor for class io.debezium.transforms.ExtractChangedRecordState
 
ExtractNewRecordState<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.transforms
Debezium generates CDC (Envelope) records that are struct of values containing values before and after change.
ExtractNewRecordState() - Constructor for class io.debezium.transforms.ExtractNewRecordState
 
ExtractNewRecordState.FieldReference - Class in io.debezium.transforms
Represents a field that should be added to the outgoing record as a header attribute or struct field.
ExtractNewRecordStateConfigDefinition - Class in io.debezium.transforms
 
ExtractNewRecordStateConfigDefinition() - Constructor for class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
ExtractNewRecordStateConfigDefinition.DeleteHandling - Enum in io.debezium.transforms
 
extractPayload(Struct) - Method in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 

F

factory - Static variable in class io.debezium.document.JacksonReader
 
factory - Static variable in class io.debezium.document.JacksonWriter
 
factory - Variable in class io.debezium.jdbc.JdbcConnection
 
FAIL - Enum constant in enum io.debezium.config.CommonConnectorConfig.EventProcessingFailureHandlingMode
An exception indicating the problematic events and their position is raised, causing the connector to be stopped.
fallbackTimestampWithTimeZone - Variable in class io.debezium.jdbc.JdbcValueConverters
Fallback value for TIMESTAMP WITH TZ is epoch
fallbackTimeWithTimeZone - Variable in class io.debezium.jdbc.JdbcValueConverters
Fallback value for TIME WITH TZ is 00:00
FALSE - Enum constant in enum io.debezium.connector.SnapshotRecord
Record is from streaming phase.
FATAL - Enum constant in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.InvalidOperationBehavior
 
FEATURE_VERSION - Static variable in class io.debezium.util.JvmVersionUtil
 
field - Variable in class io.debezium.transforms.ExtractNewRecordState.FieldReference
The simple field name.
field - Variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalField
 
field(String, Value) - Static method in interface io.debezium.document.Document
 
field(String, Object) - Static method in interface io.debezium.document.Document
 
Field - Class in io.debezium.config
An immutable definition of a field that make appear within a Configuration instance.
Field(String, String, ConfigDef.Type, ConfigDef.Width, String, ConfigDef.Importance, Supplier<Object>, Field.Validator) - Constructor for class io.debezium.config.Field
 
Field(String, String, ConfigDef.Type, ConfigDef.Width, String, ConfigDef.Importance, List<String>, Supplier<Object>, Field.Validator, Field.Recommender) - Constructor for class io.debezium.config.Field
 
Field(String, String, ConfigDef.Type, ConfigDef.Width, String, ConfigDef.Importance, List<String>, Supplier<Object>, Field.Validator, Field.Recommender, boolean, Field.GroupEntry, Set<?>) - Constructor for class io.debezium.config.Field
 
FIELD_ADDITIONAL_CONDITION - Static variable in class io.debezium.pipeline.signal.actions.AbstractSnapshotSignal
 
FIELD_CHANGES - Static variable in class io.debezium.pipeline.signal.actions.SchemaChanges
 
FIELD_DATA_COLLECTIONS - Static variable in class io.debezium.pipeline.signal.actions.AbstractSnapshotSignal
 
FIELD_DATABASE - Static variable in class io.debezium.pipeline.signal.actions.SchemaChanges
 
FIELD_EVENT_ID - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
FIELD_EVENT_KEY - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
FIELD_EVENT_TIMESTAMP - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
FIELD_EVENT_TYPE - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
FIELD_HASH_FUNCTION - Static variable in class io.debezium.transforms.partitions.PartitionRouting
 
FIELD_MESSAGE - Static variable in class io.debezium.pipeline.signal.actions.Log
 
FIELD_NAME_ADJUSTMENT_MODE - Static variable in class io.debezium.config.CommonConnectorConfig
 
FIELD_PAYLOAD - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
FIELD_PAYLOAD_FIELD_CONF - Static variable in class io.debezium.transforms.partitions.PartitionRouting
 
FIELD_SCHEMA - Static variable in class io.debezium.pipeline.signal.actions.SchemaChanges
 
FIELD_SCHEMA_VERSION - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
FIELD_SEPARATOR - Static variable in class io.debezium.transforms.ExtractNewRecordState
 
FIELD_SURROGATE_KEY - Static variable in class io.debezium.pipeline.signal.actions.AbstractSnapshotSignal
 
FIELD_TABLE_FIELD_NAME_MAPPINGS_CONF - Static variable in class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
FIELD_TABLE_PARTITION_NUM_MAPPINGS_CONF - Static variable in class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
FIELD_TABLE_PARTITION_NUM_MAPPINGS_FIELD - Static variable in class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
FIELD_TOPIC_PARTITION_NUM_CONF - Static variable in class io.debezium.transforms.partitions.PartitionRouting
 
FIELD_TYPE - Static variable in class io.debezium.pipeline.signal.actions.AbstractSnapshotSignal
 
Field.EnumRecommender<T extends Enum<T>> - Class in io.debezium.config
 
Field.Group - Enum in io.debezium.config
 
Field.GroupEntry - Class in io.debezium.config
 
Field.InvisibleRecommender - Class in io.debezium.config
A Field.Recommender that will look at several fields that are deemed to be exclusive, such that when the first of them has a value the others are made invisible.
Field.OneOfRecommender - Class in io.debezium.config
A Field.Recommender that will look at several fields that are deemed to be exclusive, such that when the first of them has a value the others are made invisible.
Field.RangeValidator - Class in io.debezium.config
Validation logic for numeric ranges
Field.Recommender - Interface in io.debezium.config
A component that is able to provide recommended values for a field given a configuration.
Field.Set - Class in io.debezium.config
A set of fields.
Field.ValidationOutput - Interface in io.debezium.config
A functional interface that accepts validation results.
Field.Validator - Interface in io.debezium.config
A functional interface that can be used to validate field values.
fieldEventId - Variable in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
fieldEventKey - Variable in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
fieldEventTimestamp - Variable in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
FieldName() - Constructor for class io.debezium.converters.spi.CloudEventsMaker.FieldName
 
FieldName() - Constructor for class io.debezium.data.Envelope.FieldName
 
fieldNameAdjuster - Variable in class io.debezium.schema.FieldNameSelector.FieldNameSanitizer
 
fieldNameAdjuster() - Method in class io.debezium.config.CommonConnectorConfig
 
fieldNameAdjustmentMode - Variable in class io.debezium.config.CommonConnectorConfig
 
FieldNameAdjustmentMode(String) - Constructor for enum io.debezium.config.CommonConnectorConfig.FieldNameAdjustmentMode
 
fieldNameByTable - Variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
FieldNameCache(FieldNameSelector.FieldNamer<T>) - Constructor for class io.debezium.schema.FieldNameSelector.FieldNameCache
 
fieldNameFor(T) - Method in class io.debezium.schema.FieldNameSelector.FieldNameCache
 
fieldNameFor(T) - Method in interface io.debezium.schema.FieldNameSelector.FieldNamer
 
fieldNameFor(T) - Method in class io.debezium.schema.FieldNameSelector.FieldNameSanitizer
 
fieldNamer - Variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
fieldNamer - Variable in class io.debezium.relational.TableSchemaBuilder
 
fieldNames - Variable in class io.debezium.schema.FieldNameSelector.FieldNameCache
 
FieldNameSanitizer(FieldNameSelector.FieldNamer<T>, SchemaNameAdjuster) - Constructor for class io.debezium.schema.FieldNameSelector.FieldNameSanitizer
 
FieldNameSelector - Class in io.debezium.schema
Implementations return names for fields.
FieldNameSelector() - Constructor for class io.debezium.schema.FieldNameSelector
 
FieldNameSelector.FieldNameCache<T> - Class in io.debezium.schema
A field namer that caches names it has obtained from a delegate
FieldNameSelector.FieldNamer<T> - Interface in io.debezium.schema
Implementations determine the field name corresponding to a given column.
FieldNameSelector.FieldNameSanitizer<T> - Class in io.debezium.schema
A field namer that replaces any characters invalid in a field with _.
FieldNameUnderscoreReplacementFunction - Class in io.debezium.schema
A field name underscore replacement implementation of ReplacementFunction
FieldNameUnderscoreReplacementFunction() - Constructor for class io.debezium.schema.FieldNameUnderscoreReplacementFunction
 
FieldNameUnicodeReplacementFunction - Class in io.debezium.schema
A field name unicode replacement inheritance of UnicodeReplacementFunction
FieldNameUnicodeReplacementFunction() - Constructor for class io.debezium.schema.FieldNameUnicodeReplacementFunction
 
fieldPayload - Variable in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
FieldReference(String, String) - Constructor for class io.debezium.transforms.ExtractNewRecordState.FieldReference
 
fields - Variable in class io.debezium.document.BasicDocument
 
fields - Variable in class io.debezium.transforms.HeaderToValue
 
Fields() - Constructor for class io.debezium.relational.history.HistoryRecord.Fields
 
FIELDS_ADDITIONAL_PLACEMENT - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
FIELDS_CONF - Static variable in class io.debezium.transforms.HeaderToValue
 
FIELDS_FIELD - Static variable in class io.debezium.transforms.HeaderToValue
 
fieldsByName - Variable in class io.debezium.config.Field.Set
 
fieldSchema - Variable in class io.debezium.relational.CustomConverterRegistry.ConverterDefinition
 
fieldSchemaVersion - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
fieldsForColumns(Schema, List<Column>) - Method in class io.debezium.relational.TableSchemaBuilder
 
fieldWithName(String) - Method in class io.debezium.config.Field.Set
Get the field with the given {Field#name() name}.
FileSignalChannel - Class in io.debezium.pipeline.signal.channels
The class responsible for processing of signals delivered to Debezium via a file.
FileSignalChannel() - Constructor for class io.debezium.pipeline.signal.channels.FileSignalChannel
 
filter - Variable in class io.debezium.pipeline.EventDispatcher
 
filter(String) - Static method in class io.debezium.relational.ColumnId
Create the map of predicate functions that specify which columns are to be included.
filter(Predicate<? super String>) - Method in interface io.debezium.config.Configuration
Return a new Configuration that contains only the subset of keys that satisfy the given predicate.
filter(Predicate<T>, Predicate<T>) - Static method in class io.debezium.function.Predicates
Create a predicate function that allows only those values are allowed or not disallowed by the supplied predicates.
filterColumns(Predicate<Column>) - Method in interface io.debezium.relational.Table
Utility to obtain a copy of a list of the columns that satisfy the specified predicate.
filtered(Predicate<Field>) - Method in class io.debezium.config.Field.Set
 
FILTERS - Enum constant in enum io.debezium.config.Field.Group
 
find(Path) - Method in interface io.debezium.document.Document
Attempt to find the value at the given path.
find(Path, BiFunction<Path, Integer, Optional<Value>>, Consumer<Path>) - Method in interface io.debezium.document.Document
Attempt to find the value at the given path, optionally creating missing segments.
findAndReplace(String, String, Properties, String) - Static method in class io.debezium.jdbc.JdbcConnection
 
findAndReplace(String, Properties, Field...) - Static method in class io.debezium.jdbc.JdbcConnection
 
findColumn(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
findMaxLength(ResultSet) - Method in class io.debezium.jdbc.JdbcConnection
 
first() - Method in class io.debezium.jdbc.CancellableResultSet
 
FIRST - Enum constant in enum io.debezium.connector.SnapshotRecord
Record is from snapshot is the first record generated in snapshot phase.
FIRST_IN_DATA_COLLECTION - Enum constant in enum io.debezium.connector.SnapshotRecord
Record is from snapshot and the first record generated from the table, but not in the entire snapshot.
firstTimeOnly() - Method in interface io.debezium.schema.SchemaNameAdjuster.ReplacementOccurred
Create a new function that calls this function only the first time it sees each unique original, and ignores subsequent calls for originals it has already seen.
fixedSizeMap(int) - Static method in class io.debezium.util.Collect
Create a fixed sized Map that removes the least-recently used entry when the map becomes too large.
FLOAT - Enum constant in enum io.debezium.document.Value.Type
 
FLOAT_FALSE - Static variable in class io.debezium.util.NumberConversions
 
FLOAT_NUMBERS_AS_TEXT_INSTANCE - Static variable in class io.debezium.document.JacksonReader
 
FLOAT_TRUE - Static variable in class io.debezium.util.NumberConversions
 
floatNumbersAsTextReader() - Static method in interface io.debezium.document.DocumentReader
Get DocumentReader instance that returns fp numbers as text.
flushBuffer(Function<T, T>) - Method in class io.debezium.connector.base.ChangeEventQueue
Applies a function to the event and the buffer and adds it to the queue.
fmix(long) - Static method in class io.debezium.util.MurmurHash3
 
forcedBeat(Map<String, ?>, Map<String, ?>, BlockingConsumer<SourceRecord>) - Method in class io.debezium.heartbeat.DatabaseHeartbeatImpl
 
forcedBeat(Map<String, ?>, Map<String, ?>, BlockingConsumer<SourceRecord>) - Method in interface io.debezium.heartbeat.Heartbeat
Generates a heartbeat record unconditionaly
forcedBeat(Map<String, ?>, Map<String, ?>, BlockingConsumer<SourceRecord>) - Method in class io.debezium.heartbeat.HeartbeatImpl
 
forCode(String) - Static method in enum io.debezium.data.Envelope.Operation
 
forConnector(String, String, String) - Static method in class io.debezium.util.LoggingContext
Configure for a connector the logger's Mapped Diagnostic Context (MDC) properties for the thread making this call.
forConnector(String, String, String, String, Partition) - Static method in class io.debezium.util.LoggingContext
Configure for a connector the logger's Mapped Diagnostic Context (MDC) properties for the thread making this call.
forEach(BiConsumer<? super TableId, ? super Table>) - Method in class io.debezium.relational.Tables.TablesById
 
forEach(BiConsumer<Path, Value>) - Method in interface io.debezium.document.Document
 
forEach(BiConsumer<String, String>) - Method in interface io.debezium.config.Configuration
Call the supplied function for each of the fields.
forEach(Consumer<? super String>) - Method in class io.debezium.document.Paths.MultiSegmentPath
 
forEach(Consumer<? super String>) - Method in class io.debezium.document.Paths.RootPath
 
forEach(Consumer<? super String>) - Method in class io.debezium.document.Paths.SingleSegmentPath
 
forEachError(Consumer<ParsingException>) - Method in exception io.debezium.text.MultipleParsingExceptions
 
forEachMatchingFieldName(String, int, BiFunction<String, String, T>, BiConsumer<String, T>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract a value from the specified group in the regular expression and call the supplied function.
forEachMatchingFieldName(String, BiConsumer<String, String>) - Method in interface io.debezium.config.Configuration
Apply the given function to all fields whose names match the given regular expression.
forEachMatchingFieldName(Pattern, int, BiFunction<String, String, T>, BiConsumer<String, T>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract a value from the specified group in the regular expression and call the supplied function.
forEachMatchingFieldName(Pattern, BiConsumer<String, String>) - Method in interface io.debezium.config.Configuration
Apply the given function to all fields whose names match the given regular expression.
forEachMatchingFieldNameWithBoolean(String, int, BiConsumer<String, Boolean>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract a boolean value from the first group in the regular expression and call the supplied function.
forEachMatchingFieldNameWithBoolean(String, BiConsumer<String, Boolean>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract a boolean value from the first group in the regular expression and call the supplied function.
forEachMatchingFieldNameWithBoolean(Pattern, int, BiConsumer<String, Boolean>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract a boolean value from the first group in the regular expression and call the supplied function.
forEachMatchingFieldNameWithInteger(String, int, BiConsumer<String, Integer>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract an integer from the first group in the regular expression and call the supplied function.
forEachMatchingFieldNameWithInteger(String, BiConsumer<String, Integer>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract an integer from the first group in the regular expression and call the supplied function.
forEachMatchingFieldNameWithInteger(Pattern, int, BiConsumer<String, Integer>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract an integer from the first group in the regular expression and call the supplied function.
forEachMatchingFieldNameWithString(String, int, BiConsumer<String, String>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract a string value from the first group in the regular expression and call the supplied function.
forEachMatchingFieldNameWithString(String, BiConsumer<String, String>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract a string value from the first group in the regular expression and call the supplied function.
forEachMatchingFieldNameWithString(Pattern, int, BiConsumer<String, String>) - Method in interface io.debezium.config.Configuration
For all fields whose names match the given regular expression, extract a string value from the first group in the regular expression and call the supplied function.
forEachMissingDependent(Consumer<String>) - Method in class io.debezium.config.Field.Set
Call the supplied function for each of this set's fields that have non-existent dependents.
forEachTopLevelField(Consumer<Field>) - Method in class io.debezium.config.Field.Set
Call the supplied function for each of this set's fields that are not included as dependents in other fields.
FORMATTER - Static variable in class io.debezium.time.ZonedTime
 
FORMATTER - Static variable in class io.debezium.time.ZonedTimestamp
The ISO date-time format includes the date, time (including fractional parts), and offset from UTC, such as '2011-12-03T10:15:30.030431+01:00'.
forScope(SystemVariables.Scope) - Method in class io.debezium.relational.SystemVariables
 
forTable(TableId) - Method in class io.debezium.relational.Tables
Obtain the definition of the identified table.
forTable(String, String, String) - Method in class io.debezium.relational.Tables
Obtain the definition of the identified table.
from(ResultSet) - Static method in class io.debezium.jdbc.CancellableResultSet
 
from(Map<String, ?>) - Static method in interface io.debezium.config.Configuration
Obtain a configuration instance by copying the supplied map of string keys and object values.
from(Map<String, T>, Function<T, String>) - Static method in interface io.debezium.config.Configuration
Obtain a configuration instance by copying the supplied map of string keys and object values.
from(Properties) - Static method in interface io.debezium.config.Configuration
Obtain a configuration instance by copying the supplied Properties object.
FROM_FIELD - Static variable in class io.debezium.serde.json.JsonSerdeConfig
 
fromBitSet(Schema, BitSet) - Static method in class io.debezium.data.Bits
Convert a value from its logical format (BitSet) to it's encoded format.
fromConfiguration(String, String) - Static method in class io.debezium.transforms.ExtractNewRecordState.FieldReference
 
fromConnectData(String, Schema, Object) - Method in class io.debezium.converters.BinaryDataConverter
 
fromConnectData(String, Schema, Object) - Method in class io.debezium.converters.ByteArrayConverter
 
fromConnectData(String, Schema, Object) - Method in class io.debezium.converters.CloudEventsConverter
 
fromConnectHeader(String, String, Schema, Object) - Method in class io.debezium.converters.BinaryDataConverter
 
fromConnectHeader(String, String, Schema, Object) - Method in class io.debezium.converters.ByteArrayConverter
 
fromDocument(Document, boolean) - Static method in class io.debezium.relational.history.JsonTableChangeSerializer
 
fromDocument(TableId, Document) - Static method in class io.debezium.relational.history.JsonTableChangeSerializer
 
fromHistoryRecord(HistoryRecord) - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
fromLogical(SpecialValueDecimal, JdbcValueConverters.DecimalMode, String) - Static method in class io.debezium.data.SpecialValueDecimal
 
fromLogical(Schema, SpecialValueDecimal) - Static method in class io.debezium.data.VariableScaleDecimal
Converts a value from its logical format to its encoded format - a struct containing the scale of the number and a binary representation of the number.
fromLogical(Schema, BigDecimal) - Static method in class io.debezium.data.VariableScaleDecimal
Converts a value from its logical format to its encoded format - a struct containing the scale of the number and a binary representation of the number.
fromName(String) - Static method in enum io.debezium.transforms.HeaderToValue.Operation
 
fromPredicate(Predicate<TableId>) - Static method in interface io.debezium.relational.Tables.TableFilter
Creates a Tables.TableFilter from the given predicate.
fromRoot(Consumer<Path>) - Method in interface io.debezium.document.Path
Call the consumer with the path of every ancestor (except root) down to this path.
fromSchema(Schema) - Static method in class io.debezium.data.Envelope
 
fromSource(Struct) - Static method in enum io.debezium.connector.SnapshotRecord
 
fromSystemProperties(String) - Static method in interface io.debezium.config.Configuration
Create a Configuration object that is populated by system properties, per Configuration.withSystemProperties(String).
fullColumnName(TableId, Column) - Method in class io.debezium.relational.CustomConverterRegistry
 
fullMiss(Set<BoundedConcurrentHashMap.HashEntry<K, V>>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Records a miss when the hot entry set is full.
fullyQualifiedColumnDatatype(TableId, Column) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
 
fullyQualifiedColumnName(TableId, Column) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
 
FunctionalReadWriteLock - Class in io.debezium.util
A form of a read-write lock that has methods that allow lambdas to be performed while the read or write lock is acquired and held.
FunctionalReadWriteLock(ReadWriteLock) - Constructor for class io.debezium.util.FunctionalReadWriteLock
 

G

GCount - Interface in io.debezium.crdt
A read-only result of the state of a grow-only GCounter.
GCounter - Interface in io.debezium.crdt
A simple grow-only counter that maintains a single changing value by tracking the positive changes to the value.
generated - Variable in class io.debezium.relational.ColumnEditorImpl
 
generated - Variable in class io.debezium.relational.ColumnImpl
 
generated(boolean) - Method in interface io.debezium.relational.ColumnEditor
Set whether the column's values are generated by the database.
generated(boolean) - Method in class io.debezium.relational.ColumnEditorImpl
 
GENERATED_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
generateFragment() - Method in class io.debezium.text.TokenStream
 
generateFragment(String, int, int, String) - Static method in class io.debezium.text.TokenStream
Utility method to generate a highlighted fragment of a particular point in the stream.
generateValue(Object[]) - Method in interface io.debezium.relational.StructGenerator
Converts the given tuple into a corresponding change event key or value struct.
Geography - Class in io.debezium.data.geometry
A semantic type for a Geography class.
Geography() - Constructor for class io.debezium.data.geometry.Geography
 
Geometry - Class in io.debezium.data.geometry
A semantic type for an OGC Simple Features for SQL Geometry.
Geometry() - Constructor for class io.debezium.data.geometry.Geometry
 
get() - Method in interface io.debezium.crdt.Count
Get the current value.
get() - Method in interface io.debezium.crdt.PNCount
Get the current value.
get() - Method in class io.debezium.crdt.StateBasedGCounter
 
get() - Method in class io.debezium.crdt.StateBasedPNCounter
 
get() - Method in interface io.debezium.heartbeat.HeartbeatConnectionProvider
 
get() - Method in interface io.debezium.jdbc.ResultReceiver
 
get() - Static method in class io.debezium.schema.SchemaFactory
 
get(int) - Method in interface io.debezium.document.Array
Gets the value in this array at the given index.
get(int) - Method in class io.debezium.document.BasicArray
 
get(int, Object) - Method in interface io.debezium.document.Array
Gets the value in this document for the given field name.
get(TableId) - Method in class io.debezium.relational.RelationalDatabaseSchema.SchemasByTableId
 
get(TableId) - Method in class io.debezium.relational.Tables.TablesById
 
get(CharSequence) - Method in interface io.debezium.document.Document
Gets the value in this document for the given field name.
get(CharSequence, Comparable<?>) - Method in class io.debezium.document.BasicDocument
 
get(CharSequence, Comparable<?>) - Method in interface io.debezium.document.Document
Gets the value in this document for the given field name.
get(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get(Object, int) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
get(K) - Method in class io.debezium.util.LRUCacheMap
 
getAdditionalCondition() - Method in class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
getAdditionalCondition(Document) - Static method in class io.debezium.pipeline.signal.actions.snapshotting.ExecuteSnapshot
 
getAdditionalData() - Method in class io.debezium.pipeline.notification.Notification
 
getAdditionalData() - Method in class io.debezium.pipeline.signal.SignalRecord
 
getAdditionalDataProperty(String, Class<T>) - Method in class io.debezium.pipeline.signal.SignalRecord
 
getAggregateType() - Method in class io.debezium.pipeline.notification.Notification
 
getAlias() - Method in class io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalField
 
getAllConfigurationFields() - Method in class io.debezium.connector.common.BaseSourceTask
Returns all configuration Field supported by this source task.
getAllTableIds(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Returns all candidate tables; the current filter configuration will be applied to the result set, resulting in the effective set of captured tables.
getAndDecrement() - Method in interface io.debezium.crdt.PNCounter
Decrement the counter and get the result.
getAndDecrement() - Method in class io.debezium.crdt.StateBasedPNCounter
 
getAndDecrement() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
getAndIncrement() - Method in interface io.debezium.crdt.GCounter
Increment the counter and get the result.
getAndIncrement() - Method in class io.debezium.crdt.StateBasedGCounter
 
getAndIncrement() - Method in class io.debezium.crdt.StateBasedPNCounter
 
getAndIncrement() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
getApproximateRecordSize(SourceRecord) - Static method in class io.debezium.util.ApproximateStructSizeCalculator
 
getArray(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getArray(CharSequence) - Method in interface io.debezium.document.Document
Get the array value in this document for the given field name.
getArray(CharSequence, Array) - Method in interface io.debezium.document.Document
Get the array value in this document for the given field name.
getArray(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getArrayAsList(ArrayNode, Schema) - Method in class io.debezium.transforms.outbox.JsonSchemaData
 
getArraySize(Schema, List<Object>) - Static method in class io.debezium.util.ApproximateStructSizeCalculator
 
getAsciiStream(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getAsciiStream(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getAttributeDetails(TableId) - Method in class io.debezium.jdbc.JdbcConnection
 
getAvailablePort() - Static method in class io.debezium.util.IoUtil
Find a port that is available.
getAvailableSignalChannels() - Method in class io.debezium.connector.common.BaseSourceTask
 
getAverage() - Method in interface io.debezium.util.Stopwatch.Statistics
Returns the arithmetic mean of all recorded durations.
getAverageAsString() - Method in interface io.debezium.util.Stopwatch.Statistics
Returns a string representation of the arithmetic mean of all recorded durations.
getBegin(String, int) - Static method in class io.debezium.util.Strings
Returns the first length characters of the given string.
getBigDecimal(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBigDecimal(int, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBigDecimal(Boolean) - Static method in class io.debezium.util.NumberConversions
Convert boolean object to bigDecimal object.
getBigDecimal(CharSequence) - Method in interface io.debezium.document.Document
Get the big decimal value in this document for the given field name.
getBigDecimal(CharSequence, BigDecimal) - Method in interface io.debezium.document.Document
Get the big decimal value in this document for the given field name.
getBigDecimal(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBigDecimal(String, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBigInteger(CharSequence) - Method in interface io.debezium.document.Document
Get the big integer value in this document for the given field name.
getBigInteger(CharSequence, BigInteger) - Method in interface io.debezium.document.Document
Get the big integer value in this document for the given field name.
getBinaryStream(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBinaryStream(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBlob(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBlob(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getblock(byte[], int) - Static method in class io.debezium.util.MurmurHash3
 
getBoolean(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBoolean(Field) - Method in interface io.debezium.config.Configuration
Get the boolean value associated with the given field when that field has a default value.
getBoolean(Field, boolean) - Method in interface io.debezium.config.Configuration
Get the boolean value associated with the given field, returning the field's default value if there is no such key-value pair.
getBoolean(Field, BooleanSupplier) - Method in interface io.debezium.config.Configuration
Get the boolean value associated with the given key, using the given supplier to obtain a default value if there is no such key-value pair.
getBoolean(CharSequence) - Method in interface io.debezium.document.Document
Get the boolean value in this document for the given field name.
getBoolean(CharSequence, boolean) - Method in interface io.debezium.document.Document
Get the boolean value in this document for the given field name.
getBoolean(String) - Method in interface io.debezium.config.Configuration
Get the boolean value associated with the given key.
getBoolean(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBoolean(String, boolean) - Method in interface io.debezium.config.Configuration
Get the boolean value associated with the given key, returning the default value if there is no such key-value pair or if the value could not be parsed as a boolean value.
getBoolean(String, BooleanSupplier) - Method in interface io.debezium.config.Configuration
Get the boolean value associated with the given key, using the given supplier to obtain a default value if there is no such key-value pair.
getByte(boolean) - Static method in class io.debezium.util.NumberConversions
Convert boolean object to short object.
getByte(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getByte(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBytes(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getBytes(CharSequence) - Method in interface io.debezium.document.Document
Get the Base64 encoded binary value in this document for the given field name.
getBytes(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getCapturedTables() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getCapturedTables() - Method in class io.debezium.pipeline.meters.StreamingMeter
 
getCapturedTables() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getCapturedTables() - Method in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
getCapturedTables() - Method in interface io.debezium.pipeline.metrics.traits.SchemaMetricsMXBean
 
getCaptureInstance() - Method in class io.debezium.relational.ChangeTable
 
getChangePosition() - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
getChangeRecordEmitter(P, O, TableId, Object[], Instant) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Returns a ChangeRecordEmitter producing the change records for the given table row.
getChangeRecordEmitter(P, T, OffsetContext, Object[]) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
Returns a ChangeRecordEmitter producing the change records for the given table row.
getChanges() - Method in interface io.debezium.crdt.DeltaCount
Get the changes in the current value during the last interval.
getChanges() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
getChangesApplied() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
getChangesApplied() - Method in interface io.debezium.relational.history.SchemaHistoryMXBean
 
getChangeSchema() - Method in class io.debezium.relational.history.ConnectTableChangeSerializer
 
getChangesRecovered() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
getChangesRecovered() - Method in interface io.debezium.relational.history.SchemaHistoryMXBean
 
getChangeTable() - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
getChangeTableId() - Method in class io.debezium.relational.ChangeTable
 
getChangeTableObjectId() - Method in class io.debezium.relational.ChangeTable
 
getCharacterStream(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getCharacterStream(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getChunkFrom() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getChunkFrom() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getChunkFrom() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getChunkId() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getChunkId() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getChunkId() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getChunkTo() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getChunkTo() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getChunkTo() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getClassLoader() - Static method in class io.debezium.config.Instantiator
 
getClassName() - Method in class io.debezium.metadata.ConnectorDescriptor
 
getClob(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getClob(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getClock() - Method in class io.debezium.connector.common.CdcSourceTaskContext
Returns a clock for obtaining the current time.
getClock() - Method in class io.debezium.pipeline.AbstractChangeRecordEmitter
Returns the clock of the change record(s) emitted.
getClock() - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
getColumnData(ResultSet, int) - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
Get the value of a specific column in the result-set.
getColumnFilter() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
getColumns() - Method in class io.debezium.util.ColumnUtils.ColumnArray
 
getColumnsDetails(String, String, String, Tables.TableFilter, Tables.ColumnNameFilter, DatabaseMetaData, Set<TableId>) - Method in class io.debezium.jdbc.JdbcConnection
 
getColumnValue(ResultSet, int, Column, Table) - Method in class io.debezium.jdbc.JdbcConnection
Reads a value from JDBC result set and execute per-connector conversion if needed
getConcurrency() - Method in class io.debezium.jdbc.CancellableResultSet
 
getConfig() - Method in class io.debezium.config.CommonConnectorConfig
Deprecated.
getConnectionFactoryClassName() - Method in interface io.debezium.jdbc.JdbcConfiguration
Get the datasource factory property from the configuration.
getConnectionTimeout() - Method in interface io.debezium.jdbc.JdbcConfiguration
Get the connection timeout from the configuration.
getConnectorDescriptor() - Method in interface io.debezium.metadata.ConnectorMetadata
 
getConnectorFields() - Method in interface io.debezium.metadata.ConnectorMetadata
 
getConnectorMetadata() - Method in interface io.debezium.metadata.ConnectorMetadataProvider
 
getConnectorName() - Method in class io.debezium.config.CommonConnectorConfig
 
getConnectorName() - Method in class io.debezium.connector.common.CdcSourceTaskContext
 
getConnectorType() - Method in class io.debezium.connector.common.CdcSourceTaskContext
 
getContentBetween(int, Position) - Method in class io.debezium.text.TokenStream
 
getContentBetween(Position, Position) - Method in class io.debezium.text.TokenStream
Gets the content string starting at the first position (inclusive) and continuing up to the end position (exclusive).
getContentBetween(TokenStream.Marker, Position) - Method in class io.debezium.text.TokenStream
Gets the content string starting at the specified marker (inclusive) and continuing up to the end position (exclusive).
getContentFrom(TokenStream.Marker) - Method in class io.debezium.text.TokenStream
Gets the content string starting at the specified marker (inclusive) and continuing up to the next position (exclusive).
getContextName() - Method in class io.debezium.config.CommonConnectorConfig
 
getCorrelationId() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
getCorrelationId() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
getCount() - Method in interface io.debezium.util.Stopwatch.Statistics
Returns the count of durations recorded.
getCount() - Method in class io.debezium.util.VariableLatch
Returns the current count.
getCount() - Method in class io.debezium.util.VariableLatch.Sync
 
getCreateTableEvent(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, Table) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Creates a SchemaChangeEvent representing the creation of the given table.
getCurrentQueueSizeInBytes() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getCurrentQueueSizeInBytes() - Method in interface io.debezium.pipeline.metrics.traits.QueueMetricsMXBean
 
getCurrentTimestamp() - Method in class io.debezium.jdbc.JdbcConnection
 
getCursorName() - Method in class io.debezium.jdbc.CancellableResultSet
 
getCustomConverters() - Method in class io.debezium.config.CommonConnectorConfig
 
getData() - Method in class io.debezium.pipeline.signal.SignalRecord
 
getData() - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
Get the column data from the source change table's result-set
getDatabase() - Method in interface io.debezium.jdbc.JdbcConfiguration
Get the database name property from the configuration.
getDatabase() - Method in class io.debezium.schema.SchemaChangeEvent
 
getDatabase(DdlParserListener.Event) - Method in class io.debezium.relational.ddl.DdlChanges
 
getDataCollections() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
getDataCollections() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
getDataCollections(Document) - Static method in class io.debezium.pipeline.signal.actions.snapshotting.ExecuteSnapshot
 
getDataCollections(Document) - Static method in class io.debezium.pipeline.signal.actions.snapshotting.StopSnapshot
 
getDataCollectionsToBeSnapshotted() - Method in class io.debezium.config.CommonConnectorConfig
 
getDataSchema(Schema, String, String...) - Static method in class io.debezium.converters.spi.RecordParser
 
getDate(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getDate(int, Calendar) - Method in class io.debezium.jdbc.CancellableResultSet
 
getDate(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getDate(String, Calendar) - Method in class io.debezium.jdbc.CancellableResultSet
 
getDateTimeFormatter(Integer) - Static method in class io.debezium.time.ZonedTimestamp
Returns a DateTimeFormatter that ensures that exactly fractionalWidth number of digits are present in the nanosecond part of the datetime.
getDdl() - Method in class io.debezium.schema.SchemaChangeEvent
 
getDdlChanges() - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
getDdlChanges() - Method in interface io.debezium.relational.ddl.DdlParser
 
getDdlParser() - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
Returns a new instance of the DdlParser to be used when recovering the schema from a previously persisted history.
getDecimalMode() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
Returns the Decimal mode Enum for decimal.handling.mode configuration.
getDecimalValue() - Method in class io.debezium.data.SpecialValueDecimal
 
getDecrement() - Method in interface io.debezium.crdt.PNCount
Get the amount that the value decremented.
getDecrement() - Method in class io.debezium.crdt.StateBasedPNCounter
 
getDocument(CharSequence) - Method in interface io.debezium.document.Document
Get the document value in this document for the given field name.
getDouble(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getDouble(Boolean) - Static method in class io.debezium.util.NumberConversions
Convert boolean object to double object
getDouble(CharSequence) - Method in interface io.debezium.document.Document
Get the double value in this document for the given field name.
getDouble(CharSequence, double) - Method in interface io.debezium.document.Document
Get the double value in this document for the given field name.
getDouble(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getDuration(Field, TemporalUnit) - Method in interface io.debezium.config.Configuration
Gets the duration value associated with the given key.
getEnabledChannels() - Method in class io.debezium.config.CommonConnectorConfig
 
getEnabledNotificationChannels() - Method in class io.debezium.config.CommonConnectorConfig
 
getEnumLiterals(Class<T>) - Static method in class io.debezium.config.Field
 
getEnvelopeSchema() - Method in class io.debezium.relational.TableSchema
Get the Schema that represents the entire value of messages for the table, i.e.
getEnvelopeSchema() - Method in interface io.debezium.schema.DataCollectionSchema
 
getErrorCode() - Method in exception io.debezium.jdbc.JdbcConnectionException
Returns the SQL error code from the original exception
getErrorHandler() - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
getErrors() - Method in exception io.debezium.text.MultipleParsingExceptions
Get the set of parsing exceptions.
getEventProcessingFailureHandlingMode() - Method in class io.debezium.config.CommonConnectorConfig
 
getEventsByDatabase(DdlChanges.DatabaseEventConsumer) - Method in class io.debezium.relational.ddl.DdlChanges
Consume the events in the same order they were recorded, but grouped by database name.
getEventSourcePosition(DataCollectionId, OffsetContext, Object, Struct) - Method in interface io.debezium.pipeline.source.spi.EventMetadataProvider
 
getEventTimestamp(DataCollectionId, OffsetContext, Object, Struct) - Method in interface io.debezium.pipeline.source.spi.EventMetadataProvider
 
getEventTimestampMs(String, Struct, Struct) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
Returns the Kafka record timestamp for the outgoing record.
getEvictionListener() - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
getExcludeColumns() - Method in class io.debezium.relational.RelationalTableFilters
 
getFeatureVersion() - Static method in class io.debezium.util.JvmVersionUtil
 
getFetchDirection() - Method in class io.debezium.jdbc.CancellableResultSet
 
getFetchSize() - Method in class io.debezium.jdbc.CancellableResultSet
 
getField() - Method in class io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalField
 
getField(CharSequence) - Method in interface io.debezium.document.Document
Gets the field in this document with the given field name.
getField(Schema) - Method in class io.debezium.transforms.ExtractNewRecordState.FieldReference
 
getFieldEventId() - Method in interface io.debezium.transforms.outbox.EventRouterConfigurationProvider
Get the FIELD_EVENT_ID field name
getFieldEventId() - Method in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
getFieldEventKey() - Method in interface io.debezium.transforms.outbox.EventRouterConfigurationProvider
Get the FIELD_EVENT_KEY field name
getFieldEventKey() - Method in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
getFieldEventTimestamp() - Method in interface io.debezium.transforms.outbox.EventRouterConfigurationProvider
Get the FIELD_EVENT_TIMESTAMP field name
getFieldEventTimestamp() - Method in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
getFieldName(String, String, int) - Method in class io.debezium.transforms.HeaderToValue
 
getFieldName(Struct, String[], int) - Static method in class io.debezium.transforms.partitions.PartitionRouting
 
getFieldNamer() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
getFieldPayload() - Method in interface io.debezium.transforms.outbox.EventRouterConfigurationProvider
Get the FIELD_PAYLOAD field name
getFieldPayload() - Method in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
getFieldsToDropFromSchema(Schema, List<String>) - Method in class io.debezium.transforms.ExtractNewRecordState
 
getFirst(int) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
Returns properly casted first entry of bin for given hash.
getFirstArrayElement(ArrayNode) - Method in class io.debezium.transforms.outbox.JsonSchemaData
 
getFloat(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getFloat(Boolean) - Static method in class io.debezium.util.NumberConversions
Convert boolean object to float object
getFloat(CharSequence) - Method in interface io.debezium.document.Document
Get the double value in this document for the given field name.
getFloat(CharSequence, float) - Method in interface io.debezium.document.Document
Get the float value in this document for the given field name.
getFloat(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getGreatestColumnPosition() - Method in class io.debezium.util.ColumnUtils.ColumnArray
 
getGreatestColumnPosition() - Method in class io.debezium.util.ColumnUtils.MappedColumns
 
getGroup() - Method in class io.debezium.config.Field.GroupEntry
 
getHash() - Method in enum io.debezium.transforms.partitions.PartitionRouting.HashFunction
 
getHeaderByName(R, String) - Method in class io.debezium.transforms.ExtractNewRecordState
 
getHeartbeatActionQuery() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
getHeartbeatInterval() - Method in class io.debezium.config.CommonConnectorConfig
 
getHeartbeatTopic() - Method in class io.debezium.schema.TopicSelector
Deprecated.
Get the name of the heartbeat topic for the given server.
getHeartbeatTopicsPrefix() - Method in class io.debezium.config.CommonConnectorConfig
 
getHistorizedSchema() - Method in class io.debezium.pipeline.EventDispatcher
 
getHistoryRecordComparator() - Method in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
Returns a comparator to be used when recovering records from the schema history, making sure no history entries newer than the offset we resume from are recovered (which could happen when restarting a connector after history records have been persisted but no new offset has been committed yet).
getHoldability() - Method in class io.debezium.jdbc.CancellableResultSet
 
getHostname() - Method in interface io.debezium.jdbc.JdbcConfiguration
Get the hostname property from the configuration.
getId() - Method in class io.debezium.metadata.ConnectorDescriptor
 
getId() - Method in class io.debezium.pipeline.notification.Notification
 
getId() - Method in class io.debezium.pipeline.signal.SignalRecord
 
getId() - Method in class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
getId() - Method in class io.debezium.relational.history.TableChanges.TableChange
 
getIncrement() - Method in interface io.debezium.crdt.GCount
Get the amount that the value incremented.
getIncrement() - Method in class io.debezium.crdt.StateBasedGCounter
 
getIncrement() - Method in class io.debezium.crdt.StateBasedPNCounter
 
getIncrementalSnapshotChangeEventReceiver(DataChangeEventListener<P>) - Method in class io.debezium.pipeline.EventDispatcher
 
getIncrementalSnapshotChangeEventSource() - Method in class io.debezium.pipeline.EventDispatcher
 
getIncrementalSnapshotChangeEventSource(O, SnapshotProgressListener<P>, DataChangeEventListener<P>, NotificationService<P, O>) - Method in interface io.debezium.pipeline.source.spi.ChangeEventSourceFactory
Returns and incremental snapshot change event source that can run in parallel with streaming and read and send data collection content in chunk.
getIncrementalSnapshotChunkSize() - Method in class io.debezium.config.CommonConnectorConfig
 
getIncrementalSnapshotContext() - Method in interface io.debezium.pipeline.spi.OffsetContext
Provide a context used by IncrementalSnapshotChangeEventSource so persist its internal state into offsets to survive between restarts.
getIndex() - Method in interface io.debezium.document.Array.Entry
Get the index of the entry
getIndex() - Method in class io.debezium.document.BasicEntry
 
getInputString() - Method in class io.debezium.text.TokenStream
 
getInstance() - Static method in class io.debezium.relational.Key.IdentityKeyMapper
 
getInstance() - Static method in class io.debezium.util.MurmurHash3
 
getInstance(Field, Class<T>) - Method in interface io.debezium.config.Configuration
Get an instance of the class given by the value in the configuration associated with the given field.
getInstance(Field, Class<T>, Configuration) - Method in interface io.debezium.config.Configuration
Get an instance of the class given by the value in the configuration associated with the given field.
getInstance(Field, Class<T>, Properties) - Method in interface io.debezium.config.Configuration
Get an instance of the class given by the value in the configuration associated with the given field.
getInstance(String) - Static method in class io.debezium.config.Instantiator
Instantiates the specified class either using the no-args constructor.
getInstance(String, Configuration) - Static method in class io.debezium.config.Instantiator
Instantiates the specified class either using the no-args constructor or the constructor with a single parameter of type Configuration, if a configuration object is passed.
getInstance(String, Selectors.TableIdToStringMapper) - Static method in class io.debezium.relational.Key.CustomKeyMapper
Getting an instance with a list of regexp (table:column1,column2) delimited by ';' matching the tables keys.
getInstance(String, Class<T>) - Method in interface io.debezium.config.Configuration
Get an instance of the class given by the value in the configuration associated with the given key.
getInstance(String, Class<T>, Configuration) - Method in interface io.debezium.config.Configuration
Get an instance of the class given by the value in the configuration associated with the given key.
getInstanceWithProperties(String, Properties) - Static method in class io.debezium.config.Instantiator
Instantiates the specified class either using the no-args constructor or the constructor with a single parameter of type Properties, if a properties object is passed.
getInstanceWithProvidedConstructorType(String, Class<C>, C) - Static method in class io.debezium.config.Instantiator
 
getInt(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getInt(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getInteger(Field) - Method in interface io.debezium.config.Configuration
Get the integer value associated with the given field, returning the field's default value if there is no such key-value pair.
getInteger(Field, int) - Method in interface io.debezium.config.Configuration
Get the integer value associated with the given field, returning the field's default value if there is no such key-value pair.
getInteger(Field, IntSupplier) - Method in interface io.debezium.config.Configuration
Get the integer value associated with the given key, using the given supplier to obtain a default value if there is no such key-value pair.
getInteger(Boolean) - Static method in class io.debezium.util.NumberConversions
Convert boolean object to Integer
getInteger(CharSequence) - Method in interface io.debezium.document.Document
Get the integer value in this document for the given field name.
getInteger(CharSequence, int) - Method in interface io.debezium.document.Document
Get the integer value in this document for the given field name.
getInteger(String) - Method in interface io.debezium.config.Configuration
Get the integer value associated with the given key.
getInteger(String, int) - Method in interface io.debezium.config.Configuration
Get the integer value associated with the given key, returning the default value if there is no such key-value pair or if the value could not be parsed as an integer.
getInteger(String, IntSupplier) - Method in interface io.debezium.config.Configuration
Get the integer value associated with the given key, using the given supplier to obtain a default value if there is no such key-value pair.
getJdbcConfig() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
Returns a "raw" configuration object exposing all the database driver related settings, without the "database." prefix.
getKeyKolumns(Table) - Method in interface io.debezium.relational.Key.KeyMapper
 
getKeyMapper() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
getKeyMapper() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
getLastAppliedChange() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
getLastAppliedChange() - Method in interface io.debezium.relational.history.SchemaHistoryMXBean
 
getLastEvent() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
getLastEvent() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getLastEvent() - Method in interface io.debezium.pipeline.metrics.traits.CommonEventMetricsMXBean
 
getLastRecoveredChange() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
getLastRecoveredChange() - Method in interface io.debezium.relational.history.SchemaHistoryMXBean
 
getLastStruct(Struct, String[]) - Static method in class io.debezium.transforms.partitions.PartitionRouting
 
getLastTransactionId() - Method in class io.debezium.pipeline.meters.StreamingMeter
 
getLastTransactionId() - Method in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
getLastTransactionId() - Method in interface io.debezium.pipeline.metrics.traits.StreamingMetricsMXBean
 
getList(Field) - Method in interface io.debezium.config.Configuration
 
getList(Field, String, Function<String, T>) - Method in interface io.debezium.config.Configuration
 
getList(String) - Method in interface io.debezium.config.Configuration
 
getList(String, String, Function<String, T>) - Method in interface io.debezium.config.Configuration
 
getLoggingContext() - Method in interface io.debezium.pipeline.spi.Partition
Returns the partition representation in the logging context.
getLoggingContext() - Method in class io.debezium.relational.AbstractPartition
 
getLogicalName() - Method in class io.debezium.config.CommonConnectorConfig
 
getLong(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getLong(Field) - Method in interface io.debezium.config.Configuration
Get the long value associated with the given field, returning the field's default value if there is no such key-value pair.
getLong(Field, long) - Method in interface io.debezium.config.Configuration
Get the long value associated with the given field, returning the field's default value if there is no such key-value pair.
getLong(Field, LongSupplier) - Method in interface io.debezium.config.Configuration
Get the long value associated with the given key, using the given supplier to obtain a default value if there is no such key-value pair.
getLong(Boolean) - Static method in class io.debezium.util.NumberConversions
Convert boolean object to long object.
getLong(CharSequence) - Method in interface io.debezium.document.Document
Get the integer value in this document for the given field name.
getLong(CharSequence, long) - Method in interface io.debezium.document.Document
Get the long value in this document for the given field name.
getLong(String) - Method in interface io.debezium.config.Configuration
Get the long value associated with the given key.
getLong(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getLong(String, long) - Method in interface io.debezium.config.Configuration
Get the long value associated with the given key, returning the default value if there is no such key-value pair or if the value could not be parsed as a long.
getLong(String, LongSupplier) - Method in interface io.debezium.config.Configuration
Get the long value associated with the given key, using the given supplier to obtain a default value if there is no such key-value pair.
getManagementJmxObjectName(String, String, CommonConnectorConfig) - Static method in class io.debezium.pipeline.JmxUtils
 
getMapSize(Schema, Schema, Map<Object, Object>) - Static method in class io.debezium.util.ApproximateStructSizeCalculator
 
getMaxBatchSize() - Method in class io.debezium.config.CommonConnectorConfig
 
getMaximum() - Method in interface io.debezium.util.Stopwatch.Statistics
Returns the maximum of all recorded durations.
getMaximumAsString() - Method in interface io.debezium.util.Stopwatch.Statistics
Returns a string representation of the maximum of all recorded durations.
getMaxQueueSize() - Method in class io.debezium.config.CommonConnectorConfig
 
getMaxQueueSizeInBytes() - Method in class io.debezium.config.CommonConnectorConfig
 
getMaxQueueSizeInBytes() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getMaxQueueSizeInBytes() - Method in interface io.debezium.pipeline.metrics.traits.QueueMetricsMXBean
 
getMaxRetriesOnError() - Method in class io.debezium.config.CommonConnectorConfig
 
getMetadata(String) - Method in class io.debezium.converters.spi.RecordParser
Search for metadata of the record by name, which are defined in the source field; throw a DataException if not found.
getMetaData() - Method in class io.debezium.jdbc.CancellableResultSet
 
getMilliSecondsBehindSource() - Method in class io.debezium.pipeline.meters.StreamingMeter
 
getMilliSecondsBehindSource() - Method in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
getMilliSecondsBehindSource() - Method in interface io.debezium.pipeline.metrics.traits.StreamingMetricsMXBean
 
getMilliSecondsSinceLastAppliedChange() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
getMilliSecondsSinceLastAppliedChange() - Method in interface io.debezium.relational.history.SchemaHistoryMXBean
 
getMilliSecondsSinceLastEvent() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
getMilliSecondsSinceLastEvent() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getMilliSecondsSinceLastEvent() - Method in interface io.debezium.pipeline.metrics.traits.CommonEventMetricsMXBean
 
getMilliSecondsSinceLastRecoveredChange() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
getMilliSecondsSinceLastRecoveredChange() - Method in interface io.debezium.relational.history.SchemaHistoryMXBean
 
getMinimum() - Method in interface io.debezium.util.Stopwatch.Statistics
Returns the minimum of all recorded durations.
getMinimumAsString() - Method in interface io.debezium.util.Stopwatch.Statistics
Returns a string representation of the minimum of all recorded durations.
getName() - Method in interface io.debezium.converters.spi.CloudEventsProvider
The connector name specified in the record's source info block.
getName() - Method in enum io.debezium.converters.spi.SerializerType
 
getName() - Method in class io.debezium.document.BasicField
 
getName() - Method in interface io.debezium.document.Document.Field
Get the name of the field
getName() - Method in class io.debezium.metadata.ConnectorDescriptor
 
getName() - Method in interface io.debezium.transforms.outbox.EventRouterConfigurationProvider
Returns the module name associated with the configuration provider, typically connector name.
getName() - Method in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
getNCharacterStream(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getNCharacterStream(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getNClob(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getNClob(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getNewColumnValues() - Method in class io.debezium.relational.RelationalChangeRecordEmitter
Returns the new row state in case of a CREATE or READ.
getNewColumnValues() - Method in class io.debezium.relational.SnapshotChangeRecordEmitter
 
getNewField() - Method in class io.debezium.transforms.ExtractNewRecordState.FieldReference
 
getNextChangePosition(ResultSet) - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
getNotificationChannels() - Method in class io.debezium.connector.common.BaseSourceTask
 
getNotificationInfo() - Method in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
getNotifications() - Method in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
getNotifications() - Method in interface io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannelMXBean
 
getNotificationTopic() - Method in class io.debezium.config.CommonConnectorConfig
 
getNString(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getNString(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getNumber(Field) - Method in interface io.debezium.config.Configuration
Get the numeric value associated with the given field, returning the field's default value if there is no such key-value pair.
getNumber(CharSequence) - Method in interface io.debezium.document.Document
Get the number value in this document for the given field name.
getNumber(CharSequence, Number) - Method in interface io.debezium.document.Document
Get the number value in this document for the given field name.
getNumber(String, Supplier<Number>) - Method in interface io.debezium.config.Configuration
Get the integer value associated with the given key, using the given supplier to obtain a default value if there is no such key-value pair.
getNumberOfCommittedTransactions() - Method in class io.debezium.pipeline.meters.StreamingMeter
 
getNumberOfCommittedTransactions() - Method in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
getNumberOfCommittedTransactions() - Method in interface io.debezium.pipeline.metrics.traits.StreamingMetricsMXBean
 
getNumberOfErroneousEvents() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
getNumberOfErroneousEvents() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getNumberOfErroneousEvents() - Method in interface io.debezium.pipeline.metrics.traits.CommonEventMetricsMXBean
 
getNumberOfEventsFiltered() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
getNumberOfEventsFiltered() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getNumberOfEventsFiltered() - Method in interface io.debezium.pipeline.metrics.traits.CommonEventMetricsMXBean
 
getObject(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getObject(int, Class<T>) - Method in class io.debezium.jdbc.CancellableResultSet
 
getObject(int, Map<String, Class<?>>) - Method in class io.debezium.jdbc.CancellableResultSet
 
getObject(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getObject(String, Class<T>) - Method in class io.debezium.jdbc.CancellableResultSet
 
getObject(String, Map<String, Class<?>>) - Method in class io.debezium.jdbc.CancellableResultSet
 
getOffset() - Method in class io.debezium.pipeline.AbstractChangeRecordEmitter
 
getOffset() - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
getOffset() - Method in interface io.debezium.pipeline.spi.ChangeRecordEmitter
Returns the offset of the change record(s) emitted.
getOffset() - Method in interface io.debezium.pipeline.spi.OffsetContext
 
getOffset() - Method in class io.debezium.pipeline.spi.SnapshotResult
 
getOffset() - Method in class io.debezium.schema.SchemaChangeEvent
 
getOffsetContext() - Method in interface io.debezium.pipeline.source.spi.StreamingChangeEventSource
 
getOffsets() - Method in class io.debezium.pipeline.spi.Offsets
 
getOldColumnValues() - Method in class io.debezium.relational.RelationalChangeRecordEmitter
Returns the old row state in case of an UPDATE or DELETE.
getOldColumnValues() - Method in class io.debezium.relational.SnapshotChangeRecordEmitter
 
getOperation() - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
getOperation() - Method in interface io.debezium.pipeline.spi.ChangeRecordEmitter
Returns the operation done by the represented change.
getOperation() - Method in class io.debezium.relational.SnapshotChangeRecordEmitter
 
getOperation(ResultSet) - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
getOrCreateArray(CharSequence) - Method in interface io.debezium.document.Document
Get the existing array value in this document for the given field name, or create a new array if there is no existing array at this field.
getOrCreateDocument(CharSequence) - Method in interface io.debezium.document.Document
Get the existing document value in this document for the given field name, or create a new document if there is no existing document at this field.
getOrderedSystemVariablesByScopePriority() - Method in class io.debezium.relational.SystemVariables
 
getOriginTopic(DataCollectionId) - Method in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
getOriginTopic(DataCollectionId) - Method in class io.debezium.schema.DefaultRegexTopicNamingStrategy
 
getOriginTopic(DataCollectionId) - Method in class io.debezium.schema.SchemaRegexTopicNamingStrategy
 
getPartition() - Method in class io.debezium.pipeline.AbstractChangeRecordEmitter
 
getPartition() - Method in interface io.debezium.pipeline.spi.ChangeRecordEmitter
Returns the partition of the change record(s) emitted.
getPartition() - Method in class io.debezium.schema.SchemaChangeEvent
 
getPartitions() - Method in class io.debezium.pipeline.spi.Offsets
 
getPartitions() - Method in interface io.debezium.pipeline.spi.Partition.Provider
 
getPassword() - Method in interface io.debezium.jdbc.JdbcConfiguration
Get the password property from the configuration.
getPerTableEventCount() - Method in class io.debezium.pipeline.txmetadata.TransactionContext
 
getPlacement() - Method in class io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalField
 
getPollInterval() - Method in class io.debezium.config.CommonConnectorConfig
 
getPort() - Method in interface io.debezium.jdbc.JdbcConfiguration
Get the port property from the configuration.
getPortAsString() - Method in interface io.debezium.jdbc.JdbcConfiguration
Get the port property from the configuration.
getPosition() - Method in exception io.debezium.text.ParsingException
 
getPositionInGroup() - Method in class io.debezium.config.Field.GroupEntry
 
getPreparedColumnNames(P, Table) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Prepares a list of columns to be used in the snapshot select.
getPreviousChangePosition() - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
getPreviousId() - Method in class io.debezium.relational.history.TableChanges.TableChange
 
getPreviousOffsets(Partition.Provider<P>, OffsetContext.Loader<O>) - Method in class io.debezium.connector.common.BaseSourceTask
Loads the connector's persistent offsets (if present) via the given loader.
getPrimaryTopic() - Method in class io.debezium.schema.TopicSelector
Deprecated.
Get the name of the primary topic.
getPriorCount() - Method in interface io.debezium.crdt.DeltaCount
Get the value of this count prior to the changes.
getPriorCount() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
getProducerThrowable() - Method in class io.debezium.pipeline.ErrorHandler
 
getQueryColumns(Table) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
getQueryFetchSize() - Method in class io.debezium.config.CommonConnectorConfig
 
getQueueRemainingCapacity() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getQueueRemainingCapacity() - Method in interface io.debezium.pipeline.metrics.traits.QueueMetricsMXBean
 
getQueueTotalCapacity() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getQueueTotalCapacity() - Method in interface io.debezium.pipeline.metrics.traits.QueueMetricsMXBean
 
getRecord() - Method in class io.debezium.pipeline.DataChangeEvent
 
getRecords() - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
getRecoveryStartTime() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
getRecoveryStartTime() - Method in interface io.debezium.relational.history.SchemaHistoryMXBean
 
getRef(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getRef(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getRemainingTableCount() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getRemainingTableCount() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getRemainingTableCount() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getResourceAsStream(String, ClassLoader, Class<?>, String, Consumer<String>) - Static method in class io.debezium.util.IoUtil
Get the input stream to the resource given by the supplied path.
getRetriableRestartWait() - Method in class io.debezium.config.CommonConnectorConfig
 
getRetries() - Method in class io.debezium.pipeline.ErrorHandler
 
getRootCause(Throwable) - Static method in class io.debezium.util.Throwables
 
getRouteByField() - Method in interface io.debezium.transforms.outbox.EventRouterConfigurationProvider
Get the ROUTE_BY_FIELD field name
getRouteByField() - Method in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
getRow() - Method in class io.debezium.jdbc.CancellableResultSet
 
getRowId(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getRowId(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getRowsScanned() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getRowsScanned() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getRowsScanned() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getSchema() - Method in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
 
getSchema() - Method in class io.debezium.pipeline.EventDispatcher
 
getSchema() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
getSchema() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
getSchema() - Method in class io.debezium.schema.SchemaChangeEvent
 
getSchema(Schema) - Method in class io.debezium.transforms.ExtractNewRecordState.FieldReference
 
getSchemaBuilder(Schema, Schema, String) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
getSchemaChangeAction(CommonConnectorConfig) - Method in class io.debezium.pipeline.EventDispatcher
 
getSchemaHistory() - Method in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
Returns a configured (but not yet started) instance of the database schema history.
getSchemaIdFromAvroMessage(byte[]) - Method in class io.debezium.converters.CloudEventsConverter
Obtains the schema id from the given Avro record.
getSchemaName(Schema, String) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
getSchemaPartsTopicName(DataCollectionId) - Method in class io.debezium.schema.AbstractTopicNamingStrategy
 
getShort(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getShort(Boolean) - Static method in class io.debezium.util.NumberConversions
Convert boolean object to short object.
getShort(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getSignalChannel(Class<T>) - Method in class io.debezium.pipeline.signal.SignalProcessor
The method permits to get specified SignalChannelReader instance from the available SPI implementations
getSignalEnabledChannels(Configuration) - Static method in class io.debezium.config.CommonConnectorConfig
 
getSignalingActions() - Method in class io.debezium.pipeline.EventDispatcher
 
getSignalingDataCollectionId() - Method in class io.debezium.config.CommonConnectorConfig
 
getSignalPollInterval() - Method in class io.debezium.config.CommonConnectorConfig
 
getSignalProcessor() - Method in class io.debezium.pipeline.EventDispatcher
 
getSignalProcessor(Offsets<P, O>) - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
getSignalTableName(String) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
getSkippedOperations() - Method in class io.debezium.config.CommonConnectorConfig
 
getSnapshotAborted() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getSnapshotAborted() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getSnapshotAborted() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getSnapshotChangeEventReceiver() - Method in class io.debezium.pipeline.EventDispatcher
 
getSnapshotChangeEventSource(SnapshotProgressListener<P>) - Method in interface io.debezium.pipeline.source.spi.ChangeEventSourceFactory
Returns a snapshot change event source that may emit change events for schema and/or data changes.
getSnapshotCompleted() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getSnapshotCompleted() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getSnapshotCompleted() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getSnapshotConnectionFirstSelect(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, TableId) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
getSnapshotDelay() - Method in class io.debezium.config.CommonConnectorConfig
 
getSnapshotDurationInSeconds() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getSnapshotDurationInSeconds() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getSnapshotDurationInSeconds() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getSnapshotFetchSize() - Method in class io.debezium.config.CommonConnectorConfig
 
getSnapshotMaxThreads() - Method in class io.debezium.config.CommonConnectorConfig
 
getSnapshotMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider) - Method in class io.debezium.pipeline.metrics.DefaultChangeEventSourceMetricsFactory
 
getSnapshotMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider) - Method in interface io.debezium.pipeline.metrics.spi.ChangeEventSourceMetricsFactory
Returns the snapshot change event source metrics.
getSnapshotPaused() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getSnapshotPaused() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getSnapshotPaused() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getSnapshotPausedDurationInSeconds() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getSnapshotPausedDurationInSeconds() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getSnapshotPausedDurationInSeconds() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getSnapshotRunning() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getSnapshotRunning() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getSnapshotRunning() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getSnapshotSelect(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, TableId, List<String>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Returns the SELECT statement to be used for scanning the given table or empty value if the table will be streamed from but not snapshotted
getSnapshotSelectOverridesByTable() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
Returns any SELECT overrides, if present.
getSnapshotSelectOverridesByTable(TableId) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
getSnapshotSourceTimestamp(JdbcConnection, O, TableId) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
For the given table gets source.ts_ms value from the database for snapshot data! For Postgresql its globally static for all tables since postgresql snapshot process setting auto commit off.
getSnapshottingTask(P, O) - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
Returns the snapshotting task based on the previous offset (if available) and the connector's snapshotting mode.
getSnapshotType(Document) - Static method in class io.debezium.pipeline.signal.actions.AbstractSnapshotSignal
 
getSource() - Method in class io.debezium.schema.SchemaChangeEvent
 
getSourceEventPosition() - Method in class io.debezium.pipeline.meters.StreamingMeter
 
getSourceEventPosition() - Method in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
getSourceEventPosition() - Method in interface io.debezium.pipeline.metrics.traits.StreamingMetricsMXBean
 
getSourceInfo() - Method in class io.debezium.pipeline.CommonOffsetContext
 
getSourceInfo() - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
getSourceInfo() - Method in interface io.debezium.pipeline.spi.OffsetContext
 
getSourceInfoSchema() - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
getSourceInfoSchema() - Method in interface io.debezium.pipeline.spi.OffsetContext
 
getSourceInfoStructMaker() - Method in class io.debezium.config.CommonConnectorConfig
 
getSourceInfoStructMaker(CommonConnectorConfig.Version) - Method in class io.debezium.config.CommonConnectorConfig
Returns the connector-specific SourceInfoStructMaker based on the given configuration.
getSourcePartition() - Method in interface io.debezium.pipeline.spi.Partition
 
getSourceTable() - Method in class io.debezium.relational.ChangeTable
 
getSourceTableColumns() - Method in class io.debezium.util.ColumnUtils.MappedColumns
 
getSourceTableId() - Method in class io.debezium.relational.ChangeTable
 
getSqlState() - Method in exception io.debezium.jdbc.JdbcConnectionException
Returns the SQL state from the original exception
getSQLXML(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getSQLXML(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getStackTrace(Throwable) - Static method in class io.debezium.util.Strings
Get the stack trace of the supplied exception.
getStatement() - Method in class io.debezium.jdbc.CancellableResultSet
 
getStatus() - Method in class io.debezium.pipeline.spi.SnapshotResult
 
getStatus() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
getStatus() - Method in interface io.debezium.relational.history.SchemaHistoryMXBean
The schema history starts in STOPPED state.
getStreamingChangeEventSource() - Method in interface io.debezium.pipeline.source.spi.ChangeEventSourceFactory
Returns a streaming change event source that starts streaming at the given offset.
getStreamingMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider) - Method in class io.debezium.pipeline.metrics.DefaultChangeEventSourceMetricsFactory
 
getStreamingMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider) - Method in interface io.debezium.pipeline.metrics.spi.ChangeEventSourceMetricsFactory
Returns the streaming change event source metrics.
getString(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getString(Field) - Method in interface io.debezium.config.Configuration
Get the string value associated with the given field, returning the field's default value if there is no such key-value pair in this configuration.
getString(Field, String) - Method in interface io.debezium.config.Configuration
Get the string value associated with the given field, returning the field's default value if there is no such key-value pair in this configuration.
getString(Field, Supplier<String>) - Method in interface io.debezium.config.Configuration
Get the boolean value associated with the given key, using the given supplier to obtain a default value if there is no such key-value pair.
getString(CharSequence) - Method in interface io.debezium.document.Document
Get the string value in this document for the given field name.
getString(CharSequence, String) - Method in interface io.debezium.document.Document
Get the string value in this document for the given field name.
getString(String) - Method in interface io.debezium.config.Configuration
Get the string value associated with the given key.
getString(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getString(String, String) - Method in interface io.debezium.config.Configuration
Get the string value associated with the given key, returning the default value if there is no such key-value pair.
getString(String, Supplier<String>) - Method in interface io.debezium.config.Configuration
Get the string value associated with the given key, returning the default value if there is no such key-value pair.
getStrings(Field, String) - Method in interface io.debezium.config.Configuration
Get the string value(s) associated with the given key, where the supplied regular expression is used to parse the single string value into multiple values.
getStrings(String, String) - Method in interface io.debezium.config.Configuration
Get the string value(s) associated with the given key, where the supplied regular expression is used to parse the single string value into multiple values.
getStructFieldValue(JsonNode, Schema) - Method in class io.debezium.transforms.outbox.JsonSchemaData
 
getStructSize(Struct) - Static method in class io.debezium.util.ApproximateStructSizeCalculator
 
getSurrogateKey() - Method in class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
getSurrogateKey(Document) - Static method in class io.debezium.pipeline.signal.actions.snapshotting.ExecuteSnapshot
 
getTable() - Method in class io.debezium.relational.history.TableChanges.TableChange
 
getTable(ResultSet) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
getTableChanges() - Method in class io.debezium.schema.SchemaChangeEvent
 
getTableFilter() - Method in class io.debezium.relational.RelationalDatabaseSchema
 
getTableFilters() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
getTableFrom() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getTableFrom() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getTableFrom() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getTableIdForFilter(String, String, String) - Method in enum io.debezium.relational.ColumnFilterMode
 
getTableIdMapper() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
getTableName(Struct) - Method in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
getTables() - Method in class io.debezium.schema.SchemaChangeEvent
 
getTableScanLogTimer() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
getTableScanLogTimer() - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
getTablesForSchemaChange(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
getTableTo() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getTableTo() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getTableTo() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getTaskId() - Method in class io.debezium.config.CommonConnectorConfig
 
getTaskId() - Method in class io.debezium.connector.common.CdcSourceTaskContext
 
getTaskState() - Method in class io.debezium.connector.common.BaseSourceTask
 
getTemporalPrecisionMode() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
Returns the temporal precision mode Enum for time.precision.mode configuration.
getTheOnlyOffset() - Method in class io.debezium.pipeline.spi.Offsets
Returns the offset of the only offset that the task is configured to use.
getTheOnlyPartition() - Method in class io.debezium.pipeline.spi.Offsets
Returns the offset of the only partition that the task is configured to use.
getTime(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getTime(int, Calendar) - Method in class io.debezium.jdbc.CancellableResultSet
 
getTime(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getTime(String, Calendar) - Method in class io.debezium.jdbc.CancellableResultSet
 
getTimePrecision(Column) - Method in class io.debezium.jdbc.JdbcValueConverters
 
getTimestamp() - Method in class io.debezium.schema.SchemaChangeEvent
 
getTimestamp(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getTimestamp(int, Calendar) - Method in class io.debezium.jdbc.CancellableResultSet
 
getTimestamp(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getTimestamp(String, Calendar) - Method in class io.debezium.jdbc.CancellableResultSet
 
getTokens() - Method in class io.debezium.text.TokenStream.TokenFactory
 
getTopicNamingStrategy(Field) - Method in class io.debezium.config.CommonConnectorConfig
 
getTopicNamingStrategy(Field, boolean) - Method in class io.debezium.config.CommonConnectorConfig
 
getTotal() - Method in interface io.debezium.util.Stopwatch.Statistics
Returns the total of all recorded durations.
getTotalAsString() - Method in interface io.debezium.util.Stopwatch.Statistics
Returns a string representation of the total of all recorded durations.
getTotalEventCount() - Method in class io.debezium.pipeline.txmetadata.TransactionContext
 
getTotalNumberOfCreateEventsSeen() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
getTotalNumberOfCreateEventsSeen() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getTotalNumberOfCreateEventsSeen() - Method in interface io.debezium.pipeline.metrics.traits.CommonEventMetricsMXBean
 
getTotalNumberOfDeleteEventsSeen() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
getTotalNumberOfDeleteEventsSeen() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getTotalNumberOfDeleteEventsSeen() - Method in interface io.debezium.pipeline.metrics.traits.CommonEventMetricsMXBean
 
getTotalNumberOfEventsSeen() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
getTotalNumberOfEventsSeen() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getTotalNumberOfEventsSeen() - Method in interface io.debezium.pipeline.metrics.traits.CommonEventMetricsMXBean
 
getTotalNumberOfUpdateEventsSeen() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
getTotalNumberOfUpdateEventsSeen() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
getTotalNumberOfUpdateEventsSeen() - Method in interface io.debezium.pipeline.metrics.traits.CommonEventMetricsMXBean
 
getTotalTableCount() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
getTotalTableCount() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
getTotalTableCount() - Method in interface io.debezium.pipeline.metrics.traits.SnapshotMetricsMXBean
 
getTransactionContext() - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
getTransactionContext() - Method in interface io.debezium.pipeline.spi.OffsetContext
Provide a context used by TransactionMonitor so persist its internal state into offsets to survive between restarts.
getTransactionId() - Method in class io.debezium.pipeline.txmetadata.TransactionContext
 
getTransactionId(DataCollectionId, OffsetContext, Object, Struct) - Method in interface io.debezium.pipeline.source.spi.EventMetadataProvider
 
getTrimmedStrings(Field, String) - Method in interface io.debezium.config.Configuration
Get the string value(s) associated with the given key, where the supplied regular expression is used to parse the single string value into multiple values.
getType() - Method in class io.debezium.document.BinaryValue
 
getType() - Method in class io.debezium.document.ComparableValue
 
getType() - Method in class io.debezium.document.ConvertingValue
 
getType() - Method in class io.debezium.document.NullValue
 
getType() - Method in interface io.debezium.document.Value
 
getType() - Method in class io.debezium.jdbc.CancellableResultSet
 
getType() - Method in class io.debezium.pipeline.notification.Notification
 
getType() - Method in class io.debezium.pipeline.signal.SignalRecord
 
getType() - Method in class io.debezium.relational.history.TableChanges.TableChange
 
getType() - Method in class io.debezium.schema.SchemaChangeEvent
 
getUnavailableValuePlaceholder() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
getUnicodeStream(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getUnicodeStream(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getURL(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
getURL(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
getUser() - Method in interface io.debezium.jdbc.JdbcConfiguration
Get the user property from the configuration.
getValue() - Method in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
 
getValue() - Method in enum io.debezium.config.CommonConnectorConfig.EventProcessingFailureHandlingMode
 
getValue() - Method in enum io.debezium.config.CommonConnectorConfig.FieldNameAdjustmentMode
 
getValue() - Method in enum io.debezium.config.CommonConnectorConfig.SchemaNameAdjustmentMode
 
getValue() - Method in enum io.debezium.config.CommonConnectorConfig.Version
 
getValue() - Method in interface io.debezium.config.EnumeratedValue
Returns the string representation of this value
getValue() - Method in interface io.debezium.document.Array.Entry
Get the value of the entry.
getValue() - Method in class io.debezium.document.BasicEntry
 
getValue() - Method in class io.debezium.document.BasicField
 
getValue() - Method in interface io.debezium.document.Document.Field
Get the value of the field.
getValue() - Method in enum io.debezium.jdbc.TemporalPrecisionMode
 
getValue() - Method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
 
getValue() - Method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder
 
getValue() - Method in enum io.debezium.transforms.ExtractNewRecordStateConfigDefinition.DeleteHandling
 
getValue() - Method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalFieldPlacement
 
getValue() - Method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.InvalidOperationBehavior
 
getValue() - Method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.JsonPayloadNullFieldBehavior
 
getValue() - Method in enum io.debezium.transforms.partitions.PartitionRouting.HashFunction
 
getValue(Struct) - Method in class io.debezium.transforms.ExtractNewRecordState.FieldReference
 
getValueConverter(TableId, Column) - Method in class io.debezium.relational.CustomConverterRegistry
Obtain a pre-registered converter for a given column.
getValueSchema(Schema, Schema, Integer, String) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
getValueSchema(Schema, Schema, String) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
getValueSize(Schema, Object) - Static method in class io.debezium.util.ApproximateStructSizeCalculator
 
getVariable(String) - Method in class io.debezium.relational.SystemVariables
Get the variable with the specified name, from the highest priority scope that contain it.
getVariable(String, SystemVariables.Scope) - Method in class io.debezium.relational.SystemVariables
Get the variable with the specified name and scope.
getVersion() - Method in class io.debezium.metadata.ConnectorDescriptor
 
getWarnings() - Method in class io.debezium.jdbc.CancellableResultSet
 
getWithoutDefault(Struct, Struct) - Method in class io.debezium.transforms.ExtractNewRecordState.FieldReference
 
getWrappedValue() - Method in class io.debezium.data.SpecialValueDecimal
 
getWrappedValue() - Method in interface io.debezium.data.ValueWrapper
 
greatestColumnPosition - Variable in class io.debezium.util.ColumnUtils.ColumnArray
 
greatestColumnPosition - Variable in class io.debezium.util.ColumnUtils.MappedColumns
 
group - Variable in class io.debezium.config.Field
 
group - Variable in class io.debezium.config.Field.GroupEntry
 
group() - Method in class io.debezium.config.Field
Get the group of this field.
group(ConfigDef, String, Field...) - Static method in class io.debezium.config.Field
Add this field to the given configuration definition.
Group() - Constructor for enum io.debezium.config.Field.Group
 
GroupEntry(Field.Group, int) - Constructor for class io.debezium.config.Field.GroupEntry
 
GuardedBy - Annotation Type in io.debezium.annotation
 

H

h1 - Variable in class io.debezium.util.MurmurHash3.State
 
h2 - Variable in class io.debezium.util.MurmurHash3.State
 
handle(DdlParserListener.Event) - Method in class io.debezium.relational.ddl.DdlChanges
 
handle(DdlParserListener.Event) - Method in interface io.debezium.relational.ddl.DdlParserListener
Handle a DDL event.
handle(P, T, ChangeRecordEmitter) - Method in interface io.debezium.pipeline.EventDispatcher.InconsistentSchemaHandler
 
HANDLE_DELETES - Static variable in class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
handleCharacter(char, TableIdParser.ParsingContext) - Method in enum io.debezium.relational.TableIdParser.ParsingState
 
handleDeletes - Variable in class io.debezium.transforms.ExtractNewRecordState
 
handleFloatNumbersAsText - Variable in class io.debezium.document.JacksonReader
 
handleUnexpectedOperation(R) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
handleUnknownData(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
Convert an unknown data value.
has(int) - Method in interface io.debezium.document.Array
Determine if this contains an entry at the given index.
has(int) - Method in class io.debezium.document.BasicArray
 
has(CharSequence) - Method in class io.debezium.document.BasicDocument
 
has(CharSequence) - Method in interface io.debezium.document.Document
Determine if this contains a field with the given name.
hasAll(Document) - Method in class io.debezium.document.BasicDocument
 
hasAll(Document) - Method in interface io.debezium.document.Document
Checks if this object contains all of the fields in the supplied document.
hasChanges() - Method in interface io.debezium.crdt.DeltaCount
Determine if there are any changes in this count.
hasChanges() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
hasColumnWithName(String) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
hasColumnWithName(String) - Method in class io.debezium.relational.TableEditorImpl
 
hasComment() - Method in class io.debezium.relational.NoOpTableEditorImpl
 
hasComment() - Method in interface io.debezium.relational.TableEditor
Determine if a comment has been set on this table.
hasComment() - Method in class io.debezium.relational.TableEditorImpl
 
hasDefaultCharsetName() - Method in class io.debezium.relational.NoOpTableEditorImpl
 
hasDefaultCharsetName() - Method in interface io.debezium.relational.TableEditor
Determine if a default character set has been set on this table.
hasDefaultCharsetName() - Method in class io.debezium.relational.TableEditorImpl
 
hasDefaultValue - Variable in class io.debezium.relational.ColumnEditorImpl
 
hasDefaultValue - Variable in class io.debezium.relational.ColumnImpl
 
hasDefaultValue() - Method in interface io.debezium.relational.Column
Determine whether this column's has a default value
hasDefaultValue() - Method in interface io.debezium.relational.ColumnEditor
Determine whether this column's has a default value set
hasDefaultValue() - Method in class io.debezium.relational.ColumnEditorImpl
 
hasDefaultValue() - Method in class io.debezium.relational.ColumnImpl
 
hasElapsed() - Method in interface io.debezium.util.ElapsedTimeStrategy
Determine if the time period has elapsed since this method was last called.
hasField(SchemaBuilder, String) - Method in class io.debezium.transforms.outbox.JsonSchemaData
 
hash - Variable in enum io.debezium.transforms.partitions.PartitionRouting.HashFunction
 
hash - Variable in class io.debezium.util.BoundedConcurrentHashMap.HashEntry
 
hash(byte[]) - Method in class io.debezium.util.MurmurHash3
 
hash(int) - Static method in class io.debezium.util.BoundedConcurrentHashMap
Applies a supplemental hash function to a given hashCode, which defends against poor quality hash functions.
hash(int) - Method in class io.debezium.util.MurmurHash3
 
hash(long[]) - Static method in class io.debezium.util.MurmurHash3
Hashes a byte array efficiently.
hash(Object) - Method in class io.debezium.util.MurmurHash3
 
HASH_FUNCTION_FIELD - Static variable in class io.debezium.transforms.partitions.PartitionRouting
 
hashAlgorithm - Variable in class io.debezium.relational.mapping.MaskStrings.HashValueConverter
 
hashCode() - Method in class io.debezium.config.Field
 
hashCode() - Method in class io.debezium.data.SpecialValueDecimal
 
hashCode() - Method in class io.debezium.document.BasicArray
 
hashCode() - Method in class io.debezium.document.BasicDocument
 
hashCode() - Method in class io.debezium.document.BasicEntry
 
hashCode() - Method in class io.debezium.document.BasicField
 
hashCode() - Method in class io.debezium.document.BinaryValue
 
hashCode() - Method in class io.debezium.document.ComparableValue
 
hashCode() - Method in class io.debezium.document.ConvertingValue
 
hashCode() - Method in class io.debezium.document.NullValue
 
hashCode() - Method in class io.debezium.document.Paths.ChildPath
 
hashCode() - Method in class io.debezium.document.Paths.MultiSegmentPath
 
hashCode() - Method in class io.debezium.document.Paths.RootPath
 
hashCode() - Method in class io.debezium.document.Paths.SingleSegmentPath
 
hashCode() - Method in class io.debezium.pipeline.notification.Notification
 
hashCode() - Method in class io.debezium.pipeline.signal.SignalRecord
 
hashCode() - Method in class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
hashCode() - Method in class io.debezium.relational.AttributeImpl
 
hashCode() - Method in class io.debezium.relational.ColumnId
 
hashCode() - Method in class io.debezium.relational.ColumnImpl
 
hashCode() - Method in class io.debezium.relational.history.TableChanges
 
hashCode() - Method in class io.debezium.relational.history.TableChanges.TableChange
 
hashCode() - Method in class io.debezium.relational.TableId
 
hashCode() - Method in class io.debezium.relational.TableImpl
 
hashCode() - Method in class io.debezium.relational.Tables
 
hashCode() - Method in class io.debezium.relational.Tables.TablesById
 
hashCode() - Method in class io.debezium.relational.TableSchema
 
hashCode() - Method in class io.debezium.text.Position
 
hashCode() - Method in class io.debezium.util.BoundedConcurrentHashMap.HashEntry
 
hashCode() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
 
hashCode() - Method in class io.debezium.util.MurmurHash3
 
HashCode - Class in io.debezium.util
Utilities for easily computing hash codes.
HashCode() - Constructor for class io.debezium.util.HashCode
 
HashEntry(K, int, BoundedConcurrentHashMap.HashEntry<K, V>, V) - Constructor for class io.debezium.util.BoundedConcurrentHashMap.HashEntry
 
hashFc - Variable in class io.debezium.transforms.partitions.PartitionRouting
 
HashFunction(String, Function<Object, Integer>) - Constructor for enum io.debezium.transforms.partitions.PartitionRouting.HashFunction
 
hashingByteArrayStrategy - Variable in class io.debezium.relational.mapping.MaskStrings.HashValueConverter
 
HashingByteArrayStrategy() - Constructor for enum io.debezium.relational.mapping.MaskStrings.HashingByteArrayStrategy
 
HashIterator() - Constructor for class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
hashMapOf(K, V) - Static method in class io.debezium.util.Collect
 
hashMapOf(K, V, K, V) - Static method in class io.debezium.util.Collect
 
hashMapOf(K, V, K, V, K, V) - Static method in class io.debezium.util.Collect
 
hashMapOf(K, V, K, V, K, V, K, V) - Static method in class io.debezium.util.Collect
 
hashMapOf(K, V, K, V, K, V, K, V, K, V) - Static method in class io.debezium.util.Collect
 
hashMapOf(K, V, K, V, K, V, K, V, K, V, K, V) - Static method in class io.debezium.util.Collect
 
hashString(String) - Method in class io.debezium.util.MurmurHash3
 
HashValueConverter(byte[], String, MaskStrings.HashingByteArrayStrategy) - Constructor for class io.debezium.relational.mapping.MaskStrings.HashValueConverter
 
hasKey(Field) - Method in interface io.debezium.config.Configuration
Determine whether this configuration contains a key-value pair associated with the given field and the value is non-null.
hasKey(String) - Method in interface io.debezium.config.Configuration
Determine whether this configuration contains a key-value pair with the given key and the value is non-null
hasMoreElements() - Method in class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
hasMoreRetries() - Method in class io.debezium.pipeline.ErrorHandler
Whether the maximum number of retries has been reached
hasNext() - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
hasNext() - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if there is another character available in this stream.
hasNext() - Method in class io.debezium.text.TokenStream
Determine if this stream has another token to be consumed.
hasNext() - Method in class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
hasPrimaryKey() - Method in interface io.debezium.relational.TableEditor
Determine whether this table has a primary key.
hasReceived() - Method in interface io.debezium.jdbc.ResultReceiver
 
hasUniqueValues() - Method in class io.debezium.relational.NoOpTableEditorImpl
 
hasUniqueValues() - Method in interface io.debezium.relational.TableEditor
Determine whether this table's primary key contains all columns (via TableEditor.setUniqueValues()) such that all rows within the table are unique.
hasUniqueValues() - Method in class io.debezium.relational.TableEditorImpl
 
hc - Variable in class io.debezium.document.Paths.MultiSegmentPath
 
header - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRS
This header encompasses two data structures:
HEADER - Enum constant in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalFieldPlacement
 
HEADER_CHANGED_NAME - Static variable in class io.debezium.transforms.ExtractChangedRecordState
 
HEADER_UNCHANGED_NAME - Static variable in class io.debezium.transforms.ExtractChangedRecordState
 
headerChangedName - Variable in class io.debezium.transforms.ExtractChangedRecordState
 
headers - Variable in class io.debezium.transforms.HeaderToValue
 
HEADERS_CONF - Static variable in class io.debezium.transforms.HeaderToValue
 
HEADERS_FIELD - Static variable in class io.debezium.transforms.HeaderToValue
 
headersToString(Map<?, ?>) - Method in class io.debezium.transforms.HeaderToValue
 
headersUpdateCache - Variable in class io.debezium.transforms.HeaderToValue
 
HeaderToValue<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.transforms
 
HeaderToValue() - Constructor for class io.debezium.transforms.HeaderToValue
 
HeaderToValue.Operation - Enum in io.debezium.transforms
 
headerUnchangedName - Variable in class io.debezium.transforms.ExtractChangedRecordState
 
heartbeat - Variable in class io.debezium.pipeline.EventDispatcher
 
heartbeat(Map<String, ?>, Heartbeat.OffsetProducer, BlockingConsumer<SourceRecord>) - Method in interface io.debezium.heartbeat.Heartbeat
Generates a heartbeat record if defined time has elapsed
heartbeat(Map<String, ?>, Heartbeat.OffsetProducer, BlockingConsumer<SourceRecord>) - Method in class io.debezium.heartbeat.HeartbeatImpl
 
heartbeat(Map<String, ?>, Map<String, ?>, BlockingConsumer<SourceRecord>) - Method in interface io.debezium.heartbeat.Heartbeat
Generates a heartbeat record if defined time has elapsed
heartbeat(Map<String, ?>, Map<String, ?>, BlockingConsumer<SourceRecord>) - Method in class io.debezium.heartbeat.HeartbeatImpl
 
Heartbeat - Interface in io.debezium.heartbeat
A class that is able to generate periodic heartbeat messages based on a pre-configured interval.
HEARTBEAT_ACTION_QUERY - Static variable in class io.debezium.heartbeat.DatabaseHeartbeatImpl
 
HEARTBEAT_ACTION_QUERY_PROPERTY_NAME - Static variable in class io.debezium.heartbeat.DatabaseHeartbeatImpl
 
HEARTBEAT_INTERVAL - Static variable in interface io.debezium.heartbeat.Heartbeat
 
HEARTBEAT_INTERVAL_PROPERTY_NAME - Static variable in interface io.debezium.heartbeat.Heartbeat
 
HEARTBEAT_KEY_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
HEARTBEAT_KEY_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
HEARTBEAT_TOPICS_PREFIX - Static variable in interface io.debezium.heartbeat.Heartbeat
 
HEARTBEAT_VALUE_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
HEARTBEAT_VALUE_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
Heartbeat.OffsetProducer - Interface in io.debezium.heartbeat
Returns the offset to be used when emitting a heartbeat event.
heartbeatActionQuery - Variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
heartBeatActionQuery - Variable in class io.debezium.heartbeat.DatabaseHeartbeatImpl
 
HeartbeatConnectionProvider - Interface in io.debezium.heartbeat
Defines a contract for providing a connection to the DatabaseHeartbeatImpl.
HeartbeatErrorHandler - Interface in io.debezium.heartbeat
 
HeartbeatFactory<T extends DataCollectionId> - Class in io.debezium.heartbeat
A factory for creating the appropriate Heartbeat implementation based on the connector type and its configured properties.
HeartbeatFactory(CommonConnectorConfig, TopicNamingStrategy<T>, SchemaNameAdjuster) - Constructor for class io.debezium.heartbeat.HeartbeatFactory
 
HeartbeatFactory(CommonConnectorConfig, TopicNamingStrategy<T>, SchemaNameAdjuster, HeartbeatConnectionProvider, HeartbeatErrorHandler) - Constructor for class io.debezium.heartbeat.HeartbeatFactory
 
HeartbeatImpl - Class in io.debezium.heartbeat
Default implementation of Heartbeat
HeartbeatImpl(Duration, String, String, SchemaNameAdjuster) - Constructor for class io.debezium.heartbeat.HeartbeatImpl
 
heartbeatInterval - Variable in class io.debezium.config.CommonConnectorConfig
 
heartbeatInterval - Variable in class io.debezium.heartbeat.HeartbeatImpl
 
heartbeatKeySchema(SchemaNameAdjuster) - Method in class io.debezium.schema.SchemaFactory
 
heartbeatPrefix - Variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
heartbeatPrefix - Variable in class io.debezium.schema.TopicSelector
Deprecated.
 
heartbeatRecord(Map<String, ?>, Map<String, ?>) - Method in class io.debezium.heartbeat.HeartbeatImpl
Produce an empty record to the heartbeat topic.
heartbeatsEnabled() - Method in class io.debezium.pipeline.EventDispatcher
 
heartbeatTimeout - Variable in class io.debezium.heartbeat.HeartbeatImpl
 
heartbeatTopic() - Method in class io.debezium.schema.AbstractTopicNamingStrategy
 
heartbeatTopicsPrefix - Variable in class io.debezium.config.CommonConnectorConfig
 
heartbeatValueSchema(SchemaNameAdjuster) - Method in class io.debezium.schema.SchemaFactory
 
HEX - Enum constant in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
Represents binary values as hex-encoded (base16) string
HEX_BYTES - Static variable in class io.debezium.util.HexConverter
 
HEX_CHARS - Static variable in class io.debezium.util.HexConverter
 
HexConverter - Class in io.debezium.util
COPIED FROM https://github.com/undertow-io/undertow/blob/master/core/src/main/java/io/undertow/util/HexConverter.java A utility class for mapping between byte arrays and their hex representation and back again.
HexConverter() - Constructor for class io.debezium.util.HexConverter
 
hexStringToByteArray(String) - Static method in class io.debezium.util.Strings
Restores a byte array that is encoded as a hex string.
HIR_NONRESIDENT - Enum constant in enum io.debezium.util.BoundedConcurrentHashMap.Recency
 
HIR_RESIDENT - Enum constant in enum io.debezium.util.BoundedConcurrentHashMap.Recency
 
historizedConnectorConfig - Variable in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
HistorizedDatabaseSchema<I extends DataCollectionId> - Interface in io.debezium.schema
A database schema that is historized, i.e.
HistorizedDatabaseSchema.SchemaChangeEventConsumer - Interface in io.debezium.schema
 
HistorizedRelationalDatabaseConnectorConfig - Class in io.debezium.relational
Configuration options shared across the relational CDC connectors which use a persistent database schema history.
HistorizedRelationalDatabaseConnectorConfig(Class<? extends SourceConnector>, Configuration, Tables.TableFilter, boolean, int, ColumnFilterMode, boolean) - Constructor for class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
HistorizedRelationalDatabaseConnectorConfig(Class<? extends SourceConnector>, Configuration, Tables.TableFilter, Selectors.TableIdToStringMapper, boolean, int, ColumnFilterMode, boolean) - Constructor for class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
HistorizedRelationalDatabaseConnectorConfig(Class<? extends SourceConnector>, Configuration, Tables.TableFilter, Selectors.TableIdToStringMapper, boolean, ColumnFilterMode, boolean) - Constructor for class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
HistorizedRelationalDatabaseSchema - Class in io.debezium.relational
A DatabaseSchema or a relational database which has a schema history, that can be recovered to the current state when restarting a connector.
HistorizedRelationalDatabaseSchema(HistorizedRelationalDatabaseConnectorConfig, TopicNamingStrategy<TableId>, Tables.TableFilter, Tables.ColumnNameFilter, TableSchemaBuilder, boolean, Key.KeyMapper) - Constructor for class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
historizedSchema - Variable in class io.debezium.pipeline.EventDispatcher
 
history - Variable in class io.debezium.config.ConfigDefinition
 
history - Variable in class io.debezium.config.ConfigDefinitionEditor
 
history() - Method in class io.debezium.config.ConfigDefinition
 
history(Field...) - Method in class io.debezium.config.ConfigDefinitionEditor
 
HistoryRecord - Class in io.debezium.relational.history
 
HistoryRecord(Document) - Constructor for class io.debezium.relational.history.HistoryRecord
 
HistoryRecord(Map<String, ?>, Map<String, ?>, String, String, String, TableChanges, Instant) - Constructor for class io.debezium.relational.history.HistoryRecord
 
HistoryRecord.Fields - Class in io.debezium.relational.history
 
HistoryRecordComparator - Class in io.debezium.relational.history
Compares HistoryRecord instances to determine which came first.
HistoryRecordComparator() - Constructor for class io.debezium.relational.history.HistoryRecordComparator
 
hit(Set<BoundedConcurrentHashMap.HashEntry<K, V>>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Records a cache hit.
HOSTNAME - Static variable in interface io.debezium.jdbc.JdbcConfiguration
A field for the hostname of the database server.
HOSTNAME - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
HOSTNAME_PATTERN - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
hot() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Marks this entry as hot.
hotHit(Set<BoundedConcurrentHashMap.HashEntry<K, V>>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Records a cache hit on a hot block.
hotSize - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRS
The actual number of hot entries.

I

id - Variable in class io.debezium.metadata.ConnectorDescriptor
 
id - Variable in class io.debezium.pipeline.notification.Notification.Builder
 
id - Variable in class io.debezium.pipeline.notification.Notification
 
id - Variable in class io.debezium.pipeline.signal.SignalPayload
 
id - Variable in class io.debezium.pipeline.signal.SignalRecord
 
id - Variable in class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
id - Variable in class io.debezium.relational.ColumnId
 
id - Variable in class io.debezium.relational.history.TableChanges.TableChange
 
id - Variable in class io.debezium.relational.NoOpTableEditorImpl
 
id - Variable in class io.debezium.relational.TableEditorImpl
 
id - Variable in class io.debezium.relational.TableId
 
id - Variable in class io.debezium.relational.TableImpl
 
id - Variable in class io.debezium.relational.TableSchema
 
id() - Method in interface io.debezium.relational.Table
Get the identifier for this table.
id() - Method in class io.debezium.relational.TableImpl
 
id() - Method in class io.debezium.relational.TableSchema
 
id() - Method in interface io.debezium.schema.DataCollectionSchema
 
ID - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
CloudEvents context attributes (REQUIRED)
ID_KEY - Static variable in class io.debezium.pipeline.notification.Notification
 
ID_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
identifier - Variable in class io.debezium.relational.TableIdParser.TableIdTokenizer
 
identifier() - Method in class io.debezium.relational.TableId
 
IDENTIFIER_SEPARATOR_PATTERN - Static variable in class io.debezium.relational.ColumnId
 
identity() - Static method in interface io.debezium.function.BlockingFunction
 
IdentityKeyMapper() - Constructor for class io.debezium.relational.Key.IdentityKeyMapper
 
ids() - Method in class io.debezium.relational.Tables.TablesById
 
ifArray(Consumer<Array>) - Method in interface io.debezium.document.Value
If a value is an array, invoke the specified consumer with the value, otherwise do nothing.
ifBigDecimal(Consumer<BigDecimal>) - Method in interface io.debezium.document.Value
If a value is a variable-sized decimal, invoke the specified consumer with the value, otherwise do nothing.
ifBigInteger(Consumer<BigInteger>) - Method in interface io.debezium.document.Value
If a value is a variable-sized integer, invoke the specified consumer with the value, otherwise do nothing.
ifBinary(Consumer<byte[]>) - Method in interface io.debezium.document.Value
If a value is a byte array, invoke the specified consumer with the value, otherwise do nothing.
ifBoolean(Consumer<Boolean>) - Method in interface io.debezium.document.Value
If a value is a boolean value, invoke the specified consumer with the value, otherwise do nothing.
ifDocument(Consumer<Document>) - Method in interface io.debezium.document.Value
If a value is a document, invoke the specified consumer with the value, otherwise do nothing.
ifDouble(DoubleConsumer) - Method in interface io.debezium.document.Value
If a value is a double, invoke the specified consumer with the value, otherwise do nothing.
ifFloat(DoubleConsumer) - Method in interface io.debezium.document.Value
If a value is a float, invoke the specified consumer with the value, otherwise do nothing.
ifInteger(IntConsumer) - Method in interface io.debezium.document.Value
If a value is an integer, invoke the specified consumer with the value, otherwise do nothing.
ifLong(LongConsumer) - Method in interface io.debezium.document.Value
If a value is a long, invoke the specified consumer with the value, otherwise do nothing.
ifNull(Value.NullHandler) - Method in interface io.debezium.document.Value
If a value is a variable-sized integer, invoke the specified consumer with the value, otherwise do nothing.
ifString(Consumer<String>) - Method in interface io.debezium.document.Value
If a value is a string, invoke the specified consumer with the value, otherwise do nothing.
IGNORE - Enum constant in enum io.debezium.config.CommonConnectorConfig.EventProcessingFailureHandlingMode
Problematic events will be skipped - for transitional period only, scheduled to be removed.
IGNORE - Enum constant in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.JsonPayloadNullFieldBehavior
 
ignoreMissingSchema(T, ChangeRecordEmitter<P>) - Method in class io.debezium.pipeline.EventDispatcher
 
Immutable - Annotation Type in io.debezium.annotation
 
importance - Variable in class io.debezium.config.Field
 
importance() - Method in class io.debezium.config.Field
Get the importance of this field.
IN_DELIMITED_IDENTIFIER - Enum constant in enum io.debezium.relational.TableIdParser.ParsingState
 
IN_IDENTIFIER - Enum constant in enum io.debezium.relational.TableIdParser.ParsingState
 
IN_PROGRESS - Enum constant in enum io.debezium.pipeline.notification.IncrementalSnapshotNotificationService.SnapshotStatus
 
IN_QUOTED_IDENTIFIER - Enum constant in enum io.debezium.relational.TableIdParser.ParsingState
 
INCLUDE_SCHEMA_CHANGES - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
INCLUDE_SCHEMA_COMMENTS - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
includeAll() - Static method in interface io.debezium.relational.Tables.TableFilter
Creates a Tables.TableFilter that includes all tables.
includeDatabases(String) - Method in class io.debezium.relational.Selectors.DatabaseSelectionPredicateBuilder
Specify the names of the databases that should be included.
includeDatabases(String) - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
Specify the names of the databases that should be included.
includedInLiterals(Collection<String>, Function<T, String>) - Static method in class io.debezium.function.Predicates
 
includedInPatterns(Collection<Pattern>, BiFunction<T, U, String>) - Static method in class io.debezium.function.Predicates
 
includedInPatterns(Collection<Pattern>, Function<T, String>) - Static method in class io.debezium.function.Predicates
 
includes(String) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied string returns true if any of the regular expressions in the supplied comma-separated list matches the predicate parameter.
includes(String, int) - Static method in class io.debezium.function.Predicates
 
includes(String, BiFunction<T, U, String>) - Static method in class io.debezium.function.Predicates
 
includes(String, Function<T, String>) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied parameter returns true if any of the regular expressions in the supplied comma-separated list matches the predicate parameter in a case-insensitive manner.
includeSchemas(String) - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
Specify the names of the schemas that should be included.
includesLiterals(String) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied string returns true if any of the literals in the supplied comma-separated list case insensitively matches the predicate parameter.
includesLiterals(String, Function<T, String>) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied string returns true if any of the literals in the supplied comma-separated list case insensitively matches the predicate parameter.
includesLiteralsOrPatterns(String, Predicate<String>, Function<T, String>) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied string returns true if any of the regular expressions or literals in the supplied comma-separated list matches the predicate parameter.
includesUuids(String) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied UUID strings returns true if any of the comma-separated UUID literals or regular expressions matches the predicate parameter.
includeTables(String) - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
Specify the names of the tables that should be included.
includeTables(String, Selectors.TableIdToStringMapper) - Method in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
Specify the names of the tables that should be included.
inconsistentSchemaHandler - Variable in class io.debezium.pipeline.EventDispatcher
 
increment() - Method in interface io.debezium.crdt.DeltaCounter
Increment the counter and get the result.
increment() - Method in interface io.debezium.crdt.GCounter
Increment the counter and get the result.
increment() - Method in interface io.debezium.crdt.PNCounter
Increment the counter and get the result.
increment() - Method in class io.debezium.crdt.StateBasedGCounter
 
increment() - Method in class io.debezium.crdt.StateBasedPNCounter
 
increment() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
increment(int, double) - Method in interface io.debezium.document.Array
Increment the numeric value at the given location by the designated amount.
increment(int, float) - Method in interface io.debezium.document.Array
Increment the numeric value at the given location by the designated amount.
increment(int, int) - Method in interface io.debezium.document.Array
Increment the numeric value at the given location by the designated amount.
increment(int, long) - Method in interface io.debezium.document.Array
Increment the numeric value at the given location by the designated amount.
increment(int, Value) - Method in interface io.debezium.document.Array
Increment the numeric value at the given location by the designated amount.
increment(int, Value) - Method in class io.debezium.document.BasicArray
 
increment(CharSequence, double) - Method in interface io.debezium.document.Document
Increment the numeric value in the given field by the designated amount.
increment(CharSequence, float) - Method in interface io.debezium.document.Document
Increment the numeric value in the given field by the designated amount.
increment(CharSequence, int) - Method in interface io.debezium.document.Document
Increment the numeric value in the given field by the designated amount.
increment(CharSequence, long) - Method in interface io.debezium.document.Document
Increment the numeric value in the given field by the designated amount.
increment(CharSequence, Value) - Method in class io.debezium.document.BasicDocument
 
increment(CharSequence, Value) - Method in interface io.debezium.document.Document
Increment the numeric value in the given field by the designated amount.
INCREMENTAL - Enum constant in enum io.debezium.connector.SnapshotRecord
Record is from incremental snapshot window.
INCREMENTAL - Enum constant in enum io.debezium.pipeline.signal.actions.AbstractSnapshotSignal.SnapshotType
 
INCREMENTAL_SNAPSHOT - Static variable in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
INCREMENTAL_SNAPSHOT_ALLOW_SCHEMA_CHANGES - Static variable in class io.debezium.config.CommonConnectorConfig
 
INCREMENTAL_SNAPSHOT_CHUNK_SIZE - Static variable in class io.debezium.config.CommonConnectorConfig
 
INCREMENTAL_SNAPSHOT_KEY - Static variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
incrementalSnapshotAllowSchemaChanges - Variable in class io.debezium.config.CommonConnectorConfig
 
incrementalSnapshotChangeEventSource - Variable in class io.debezium.pipeline.EventDispatcher
 
IncrementalSnapshotChangeEventSource<P extends Partition,T extends DataCollectionId> - Interface in io.debezium.pipeline.source.snapshot.incremental
A Contract t
IncrementalSnapshotChangeRecordReceiver(DataChangeEventListener<P>) - Constructor for class io.debezium.pipeline.EventDispatcher.IncrementalSnapshotChangeRecordReceiver
 
incrementalSnapshotChunkSize - Variable in class io.debezium.config.CommonConnectorConfig
 
IncrementalSnapshotContext<T> - Interface in io.debezium.pipeline.source.snapshot.incremental
 
incrementalSnapshotEvents() - Method in class io.debezium.pipeline.CommonOffsetContext
 
incrementalSnapshotEvents() - Method in interface io.debezium.pipeline.spi.OffsetContext
Signals that the streaming of a batch of incremental snapshot events will begin, which should reflect in an updated offset state.
incrementalSnapshotNotificationService - Variable in class io.debezium.pipeline.notification.NotificationService
 
incrementalSnapshotNotificationService() - Method in class io.debezium.pipeline.notification.NotificationService
 
IncrementalSnapshotNotificationService<P extends Partition,O extends OffsetContext> - Class in io.debezium.pipeline.notification
 
IncrementalSnapshotNotificationService(NotificationService<P, O>) - Constructor for class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
IncrementalSnapshotNotificationService.SnapshotStatus - Enum in io.debezium.pipeline.notification
 
incrementAndGet() - Method in interface io.debezium.crdt.GCounter
Increment the counter and get the result.
incrementAndGet() - Method in class io.debezium.crdt.StateBasedGCounter
 
incrementAndGet() - Method in class io.debezium.crdt.StateBasedPNCounter
 
incrementAndGet() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
incrementTableRowsScanned(P, long) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
index - Variable in class io.debezium.document.BasicEntry
 
index() - Method in class io.debezium.text.Position
Get the 0-based index of this position in the content character array.
index() - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
index() - Method in interface io.debezium.text.TokenStream.CharacterStream
Get the index for the last character returned from TokenStream.CharacterStream.next().
indexesForColumns(List<Column>) - Method in class io.debezium.relational.TableSchemaBuilder
 
indexFrom(CharSequence) - Method in class io.debezium.document.BasicArray
 
indexInContent - Variable in class io.debezium.text.Position
 
indexName - Variable in class io.debezium.relational.ddl.DdlParserListener.TableIndexEvent
 
indexName() - Method in class io.debezium.relational.ddl.DdlParserListener.TableIndexEvent
Get the name of the index affected by this event.
infiniteIntegers() - Static method in class io.debezium.util.Sequences
Create an iterator over an infinite number of monotonically increasing numbers starting at 0, useful when performing an operation an unknown number of times.
infiniteIntegers(int) - Static method in class io.debezium.util.Sequences
Create an iterator over an infinite number monotonically increasing numbers starting at the given number, useful when performing an operation an unknown number of times.
init(CommonConnectorConfig) - Method in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
init(CommonConnectorConfig) - Method in class io.debezium.pipeline.notification.channels.LogNotificationChannel
 
init(CommonConnectorConfig) - Method in interface io.debezium.pipeline.notification.channels.NotificationChannel
 
init(CommonConnectorConfig) - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
init(CommonConnectorConfig) - Method in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
init(CommonConnectorConfig) - Method in class io.debezium.pipeline.signal.channels.jmx.JmxSignalChannel
 
init(CommonConnectorConfig) - Method in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
init(CommonConnectorConfig) - Method in interface io.debezium.pipeline.signal.channels.SignalChannelReader
 
init(CommonConnectorConfig) - Method in class io.debezium.pipeline.signal.channels.SourceSignalChannel
 
init(AbstractIncrementalSnapshotContext<U>, Map<String, ?>) - Static method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
init(O) - Method in interface io.debezium.pipeline.source.spi.StreamingChangeEventSource
Initializes the streaming source.
init(P, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
init(P, OffsetContext) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
initConnectChannel(SchemaFactory, BlockingConsumer<SourceRecord>) - Method in interface io.debezium.pipeline.notification.channels.ConnectChannel
 
initConnectChannel(SchemaFactory, BlockingConsumer<SourceRecord>) - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
INITIAL - Enum constant in enum io.debezium.connector.common.BaseSourceTask.State
 
INITIAL - Enum constant in enum io.debezium.relational.TableIdParser.ParsingState
 
INITIAL_POLL_PERIOD_IN_MILLIS - Static variable in class io.debezium.connector.common.BaseSourceTask
 
initialize(Configuration) - Method in interface io.debezium.relational.mapping.ColumnMapper
Initialize the ColumnMapper instance based upon the connector's configuration.
initializeStorage() - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
Configures a storage used to store history, e.g.
initializeStorage() - Method in class io.debezium.relational.history.AbstractSchemaHistory
 
initializeStorage() - Method in interface io.debezium.relational.history.SchemaHistory
Called to initialize permanent storage of the history.
initializeStorage() - Method in interface io.debezium.schema.HistorizedDatabaseSchema
 
initializeTokens(List<TokenStream.Token>) - Method in class io.debezium.text.TokenStream
Method to allow subclasses to pre-process the set of tokens and return the correct tokens to use.
initialOps - Variable in class io.debezium.jdbc.JdbcConnection
 
initStreamEvents(P, O) - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
input - Variable in class io.debezium.relational.TableIdParser.ParsingContext
 
inputContent - Variable in class io.debezium.text.TokenStream
 
inputString - Variable in class io.debezium.text.TokenStream
 
inQueue() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Returns true if this entry is in the queue, false otherwise.
insertRow() - Method in class io.debezium.jdbc.CancellableResultSet
 
inStack() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Returns true if this entry is in the stack, false otherwise.
instance - Static variable in class io.debezium.util.MurmurHash3
 
INSTANCE - Static variable in class io.debezium.document.DocumentSerdes
 
INSTANCE - Static variable in class io.debezium.document.JacksonWriter
 
INSTANCE - Static variable in class io.debezium.document.NullValue
 
INSTANCE - Static variable in class io.debezium.document.Paths.RootPath
 
INSTANCE - Static variable in class io.debezium.relational.history.HistoryRecordComparator
A comparator instance that requires the records' sources to be the same and considers only those fields that are in both records' positions.
instantiateMapper(Class<ColumnMapper>, Configuration) - Static method in class io.debezium.relational.mapping.ColumnMappers
 
Instantiator - Class in io.debezium.config
Instantiates given classes reflectively.
Instantiator() - Constructor for class io.debezium.config.Instantiator
 
INTEGER - Enum constant in enum io.debezium.document.Value.Type
 
INTEGER_FALSE - Static variable in class io.debezium.util.NumberConversions
 
INTEGER_TRUE - Static variable in class io.debezium.util.NumberConversions
 
INTERNAL_CONNECTOR_CLASS - Static variable in interface io.debezium.relational.history.SchemaHistory
 
INTERNAL_CONNECTOR_ID - Static variable in interface io.debezium.relational.history.SchemaHistory
 
INTERNAL_PREFER_DDL - Static variable in interface io.debezium.relational.history.SchemaHistory
 
INTERNAL_PREFIX - Static variable in class io.debezium.config.Field
 
interruptAfterTimeout(String, long, TimeUnit, Threads.TimeSince) - Static method in class io.debezium.util.Threads
Create a thread that will interrupt the calling thread when the elapsed time has exceeded the specified amount.
interruptAfterTimeout(String, long, TimeUnit, Threads.TimeSince, Thread) - Static method in class io.debezium.util.Threads
Create a thread that will interrupt the given thread when the elapsed time has exceeded the specified amount.
Interval - Class in io.debezium.time
A utility representing a duration into a string value formatted using ISO string format.
Interval() - Constructor for class io.debezium.time.Interval
 
INVALID_CHAR - Static variable in class io.debezium.util.MurmurHash3
 
invalidOperationBehavior - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
InvalidOperationBehavior(String) - Constructor for enum io.debezium.transforms.outbox.EventRouterConfigDefinition.InvalidOperationBehavior
 
InvisibleRecommender() - Constructor for class io.debezium.config.Field.InvisibleRecommender
 
io.debezium.annotation - package io.debezium.annotation
 
io.debezium.config - package io.debezium.config
 
io.debezium.connector - package io.debezium.connector
 
io.debezium.connector.base - package io.debezium.connector.base
 
io.debezium.connector.common - package io.debezium.connector.common
 
io.debezium.converters - package io.debezium.converters
 
io.debezium.converters.spi - package io.debezium.converters.spi
 
io.debezium.crdt - package io.debezium.crdt
 
io.debezium.data - package io.debezium.data
 
io.debezium.data.geometry - package io.debezium.data.geometry
 
io.debezium.document - package io.debezium.document
 
io.debezium.function - package io.debezium.function
 
io.debezium.heartbeat - package io.debezium.heartbeat
 
io.debezium.jdbc - package io.debezium.jdbc
 
io.debezium.metadata - package io.debezium.metadata
 
io.debezium.metrics - package io.debezium.metrics
 
io.debezium.pipeline - package io.debezium.pipeline
 
io.debezium.pipeline.meters - package io.debezium.pipeline.meters
 
io.debezium.pipeline.metrics - package io.debezium.pipeline.metrics
 
io.debezium.pipeline.metrics.spi - package io.debezium.pipeline.metrics.spi
 
io.debezium.pipeline.metrics.traits - package io.debezium.pipeline.metrics.traits
 
io.debezium.pipeline.notification - package io.debezium.pipeline.notification
 
io.debezium.pipeline.notification.channels - package io.debezium.pipeline.notification.channels
 
io.debezium.pipeline.notification.channels.jmx - package io.debezium.pipeline.notification.channels.jmx
 
io.debezium.pipeline.signal - package io.debezium.pipeline.signal
 
io.debezium.pipeline.signal.actions - package io.debezium.pipeline.signal.actions
 
io.debezium.pipeline.signal.actions.snapshotting - package io.debezium.pipeline.signal.actions.snapshotting
 
io.debezium.pipeline.signal.channels - package io.debezium.pipeline.signal.channels
 
io.debezium.pipeline.signal.channels.jmx - package io.debezium.pipeline.signal.channels.jmx
 
io.debezium.pipeline.source - package io.debezium.pipeline.source
 
io.debezium.pipeline.source.snapshot.incremental - package io.debezium.pipeline.source.snapshot.incremental
 
io.debezium.pipeline.source.spi - package io.debezium.pipeline.source.spi
 
io.debezium.pipeline.spi - package io.debezium.pipeline.spi
 
io.debezium.pipeline.txmetadata - package io.debezium.pipeline.txmetadata
 
io.debezium.relational - package io.debezium.relational
 
io.debezium.relational.ddl - package io.debezium.relational.ddl
 
io.debezium.relational.history - package io.debezium.relational.history
 
io.debezium.relational.mapping - package io.debezium.relational.mapping
 
io.debezium.schema - package io.debezium.schema
 
io.debezium.serde - package io.debezium.serde
 
io.debezium.serde.json - package io.debezium.serde.json
 
io.debezium.text - package io.debezium.text
 
io.debezium.time - package io.debezium.time
 
io.debezium.transforms - package io.debezium.transforms
 
io.debezium.transforms.outbox - package io.debezium.transforms.outbox
 
io.debezium.transforms.partitions - package io.debezium.transforms.partitions
 
io.debezium.transforms.tracing - package io.debezium.transforms.tracing
 
io.debezium.util - package io.debezium.util
 
IoUtil - Class in io.debezium.util
A set of utilities for more easily performing I/O.
IoUtil() - Constructor for class io.debezium.util.IoUtil
 
isAboveThreshold() - Method in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
isAfterLast() - Method in class io.debezium.jdbc.CancellableResultSet
 
isAfterLastIndex(String) - Static method in interface io.debezium.document.Path.Segments
 
isArray() - Method in class io.debezium.document.BinaryValue
 
isArray() - Method in class io.debezium.document.ComparableValue
 
isArray() - Method in class io.debezium.document.ConvertingValue
 
isArray() - Method in class io.debezium.document.NullValue
 
isArray() - Method in interface io.debezium.document.Value
 
isArrayIndex(String) - Static method in interface io.debezium.document.Path.Segments
 
isAtOrBefore(HistoryRecord, HistoryRecord) - Method in class io.debezium.relational.history.HistoryRecordComparator
Determine if the first HistoryRecord is at the same or earlier point in time than the second HistoryRecord.
isAutoIncremented() - Method in interface io.debezium.relational.Column
Determine whether this column's values are automatically incremented by the database.
isAutoIncremented() - Method in interface io.debezium.relational.ColumnEditor
Determine whether this column's values are automatically incremented by the database.
isAutoIncremented() - Method in class io.debezium.relational.ColumnEditorImpl
 
isAutoIncremented() - Method in class io.debezium.relational.ColumnImpl
 
isAutoIncremented(String) - Method in interface io.debezium.relational.Table
Determine if the named column is auto-incremented.
isAvailable() - Method in interface io.debezium.connector.Nullable
 
isBeforeFirst() - Method in class io.debezium.jdbc.CancellableResultSet
 
isBigDecimal() - Method in class io.debezium.document.BinaryValue
 
isBigDecimal() - Method in class io.debezium.document.ComparableValue
 
isBigDecimal() - Method in class io.debezium.document.ConvertingValue
 
isBigDecimal() - Method in class io.debezium.document.NullValue
 
isBigDecimal() - Method in interface io.debezium.document.Value
 
isBigInteger() - Method in class io.debezium.document.BinaryValue
 
isBigInteger() - Method in class io.debezium.document.ComparableValue
 
isBigInteger() - Method in class io.debezium.document.ConvertingValue
 
isBigInteger() - Method in class io.debezium.document.NullValue
 
isBigInteger() - Method in interface io.debezium.document.Value
 
isBinary() - Method in class io.debezium.document.BinaryValue
 
isBinary() - Method in class io.debezium.document.ComparableValue
 
isBinary() - Method in class io.debezium.document.ConvertingValue
 
isBinary() - Method in class io.debezium.document.NullValue
 
isBinary() - Method in interface io.debezium.document.Value
 
isBoolean() - Method in class io.debezium.document.BinaryValue
 
isBoolean() - Method in class io.debezium.document.ComparableValue
 
isBoolean() - Method in class io.debezium.document.ConvertingValue
 
isBoolean() - Method in class io.debezium.document.NullValue
 
isBoolean() - Method in interface io.debezium.document.Value
 
isBoolean(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isBuffered() - Method in class io.debezium.connector.base.ChangeEventQueue
 
isChildrenOf(String, int, String[]) - Static method in class io.debezium.transforms.HeaderToValue
 
isClassName(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isClosed() - Method in class io.debezium.jdbc.CancellableResultSet
 
isColumnsFiltered() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
isCompleted() - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
isCompletedOrSkipped() - Method in class io.debezium.pipeline.spi.SnapshotResult
 
isConnectChannel() - Method in class io.debezium.pipeline.notification.NotificationService
 
isConnected() - Method in class io.debezium.jdbc.JdbcConnection
 
isConnected() - Method in class io.debezium.pipeline.meters.ConnectionMeter
 
isConnected() - Method in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
isConnected() - Method in interface io.debezium.pipeline.metrics.traits.ConnectionMetricsMXBean
 
isContainedIn(String, List<String>) - Method in class io.debezium.transforms.HeaderToValue
 
isCurrentPositionSmallerThanPreviousPosition() - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
isCustomRetriable(Throwable) - Method in class io.debezium.pipeline.ErrorHandler
Whether the given non-retriable matches a custom retriable setting.
isDocument() - Method in class io.debezium.document.BinaryValue
 
isDocument() - Method in class io.debezium.document.ComparableValue
 
isDocument() - Method in class io.debezium.document.ConvertingValue
 
isDocument() - Method in class io.debezium.document.NullValue
 
isDocument() - Method in interface io.debezium.document.Value
 
isDouble() - Method in class io.debezium.document.BinaryValue
 
isDouble() - Method in class io.debezium.document.ComparableValue
 
isDouble() - Method in class io.debezium.document.ConvertingValue
 
isDouble() - Method in class io.debezium.document.NullValue
 
isDouble() - Method in interface io.debezium.document.Value
 
isDouble(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isEmitTombstoneOnDelete() - Method in class io.debezium.config.CommonConnectorConfig
 
isEmpty() - Method in interface io.debezium.config.Configuration
Determine if this configuration is empty and has no properties.
isEmpty() - Method in interface io.debezium.document.Array
Return whether this document contains no fields and is therefore empty.
isEmpty() - Method in class io.debezium.document.BasicArray
 
isEmpty() - Method in class io.debezium.document.BasicDocument
 
isEmpty() - Method in interface io.debezium.document.Document
Return whether this document contains no fields and is therefore empty.
isEmpty() - Method in class io.debezium.relational.CustomConverterRegistry
 
isEmpty() - Method in class io.debezium.relational.ddl.DdlChanges
 
isEmpty() - Method in class io.debezium.relational.Tables.TablesById
 
isEmpty() - Method in class io.debezium.util.BoundedConcurrentHashMap.EntrySet
 
isEmpty() - Method in class io.debezium.util.BoundedConcurrentHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class io.debezium.util.BoundedConcurrentHashMap.KeySet
 
isEmpty() - Method in class io.debezium.util.BoundedConcurrentHashMap.Values
 
isEmpty(String) - Static method in class io.debezium.relational.Selectors
 
isEnabled() - Method in interface io.debezium.heartbeat.Heartbeat
Whether heartbeats are enabled or not.
isEnabled() - Method in class io.debezium.heartbeat.HeartbeatImpl
 
isEnabled() - Method in class io.debezium.pipeline.notification.NotificationService
 
isEnabled() - Method in class io.debezium.pipeline.signal.SignalProcessor
 
isEndDelimiter(char) - Method in interface io.debezium.relational.TableIdPredicates
 
isEnvelopeFieldName(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.serde.json.JsonSerdeConfig
 
isEnvelopeSchema(String) - Static method in class io.debezium.data.Envelope
 
isEnvelopeSchema(Schema) - Static method in class io.debezium.data.Envelope
 
isFieldName(String) - Static method in interface io.debezium.document.Path.Segments
 
isFirst() - Method in class io.debezium.jdbc.CancellableResultSet
 
isFloat() - Method in class io.debezium.document.BinaryValue
 
isFloat() - Method in class io.debezium.document.ComparableValue
 
isFloat() - Method in class io.debezium.document.ConvertingValue
 
isFloat() - Method in class io.debezium.document.NullValue
 
isFloat() - Method in interface io.debezium.document.Value
 
isFromSnapshot - Variable in class io.debezium.schema.SchemaChangeEvent
 
isFromSnapshot() - Method in class io.debezium.schema.SchemaChangeEvent
 
isFull - Variable in class io.debezium.connector.base.ChangeEventQueue
 
isFullColumnScanRequired() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
isGenerated() - Method in interface io.debezium.relational.Column
Determine whether this column's values are generated by the database.
isGenerated() - Method in interface io.debezium.relational.ColumnEditor
Determine whether this column's values are generated by the database.
isGenerated() - Method in class io.debezium.relational.ColumnEditorImpl
 
isGenerated() - Method in class io.debezium.relational.ColumnImpl
 
isGenerated(String) - Method in interface io.debezium.relational.Table
Determine if the values in the named column is generated by the database.
isGenericOrTruncateMessage(SourceRecord) - Static method in class io.debezium.transforms.SmtManager
 
isHistorized() - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
isHistorized() - Method in class io.debezium.relational.RelationalDatabaseSchema
 
isHistorized() - Method in interface io.debezium.schema.DatabaseSchema
Whether this schema is historized (i.e.
isIncluded(TableId) - Method in interface io.debezium.relational.Tables.TableFilter
Determines whether the given table should be included in the current DatabaseSchema.
isIncluded(T) - Method in interface io.debezium.schema.DataCollectionFilters.DataCollectionFilter
 
isIncrementalSnapshotSchemaChangesEnabled() - Method in class io.debezium.config.CommonConnectorConfig
 
isInSchema(Schema) - Method in class io.debezium.transforms.ExtractNewRecordState.FieldReference
 
isInteger() - Method in class io.debezium.document.BinaryValue
 
isInteger() - Method in class io.debezium.document.ComparableValue
 
isInteger() - Method in class io.debezium.document.ConvertingValue
 
isInteger() - Method in class io.debezium.document.NullValue
 
isInteger() - Method in interface io.debezium.document.Value
 
isInteger(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isKey - Variable in class io.debezium.serde.json.JsonSerde
 
isLast() - Method in class io.debezium.jdbc.CancellableResultSet
 
isListOfRegex(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isListOfStringPairs(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.transforms.outbox.AdditionalFieldsValidator
 
isLong() - Method in class io.debezium.document.BinaryValue
 
isLong() - Method in class io.debezium.document.ComparableValue
 
isLong() - Method in class io.debezium.document.ConvertingValue
 
isLong() - Method in class io.debezium.document.NullValue
 
isLong() - Method in interface io.debezium.document.Value
 
isLong(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isMultiPartitionMode() - Method in class io.debezium.relational.TableSchemaBuilder
 
isMultiple() - Method in interface io.debezium.document.Path
Return whether this path has more than one segment.
isNext(char) - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
isNext(char) - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if the next character on the sream is the supplied value.
isNext(char, char) - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
isNext(char, char) - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if the next two characters on the stream match the supplied values.
isNext(char, char, char) - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
isNext(char, char, char) - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if the next three characters on the sream match the supplied values.
isNextAnyOf(char[]) - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
isNextAnyOf(char[]) - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if the next character on the stream matches one of the supplied characters.
isNextAnyOf(String) - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
isNextAnyOf(String) - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if the next character on the stream matches one of the supplied characters.
isNextLetterOrDigit() - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
isNextLetterOrDigit() - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if the next character on the stream is a letter or digit.
isNextValidXmlCharacter() - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
isNextValidXmlCharacter() - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if the next character on the stream is a valid XML character.
isNextValidXmlNameCharacter() - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
isNextValidXmlNameCharacter() - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if the next character on the sream is a valid XML NCName character.
isNextValidXmlNcNameCharacter() - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
isNextValidXmlNcNameCharacter() - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if the next character on the sream is a valid XML NCName character.
isNextWhitespace() - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
isNextWhitespace() - Method in interface io.debezium.text.TokenStream.CharacterStream
Determine if the next character on the stream is a whitespace character.
isNonInitialChunk() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
isNonInitialChunk() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
isNonNegativeInteger(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isNonNegativeLong(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isNotFull - Variable in class io.debezium.connector.base.ChangeEventQueue
 
isNotNull() - Method in interface io.debezium.document.Document.Field
 
isNotNull() - Method in interface io.debezium.document.Value
 
isNull() - Method in class io.debezium.document.BinaryValue
 
isNull() - Method in class io.debezium.document.ComparableValue
 
isNull() - Method in class io.debezium.document.ConvertingValue
 
isNull() - Method in interface io.debezium.document.Document.Field
 
isNull() - Method in class io.debezium.document.NullValue
 
isNull() - Method in interface io.debezium.document.Value
 
isNull(int) - Method in interface io.debezium.document.Array
Determine whether this object has an entry at the given index and the value is null.
isNull(Value) - Static method in interface io.debezium.document.Value
 
isNull(CharSequence) - Method in interface io.debezium.document.Document
Determine whether this object has a field with the given the name and the value is null.
isNullable(int) - Static method in class io.debezium.jdbc.JdbcConnection
 
isNullOrBlank(String) - Static method in class io.debezium.util.Strings
Check if the string is blank (i.e.
isNullOrEmpty(String) - Static method in class io.debezium.util.Strings
Check if the string is empty or null.
isNullOrMissing(int) - Method in interface io.debezium.document.Array
Determine whether this object has an entry at the given index and the value is null, or if this object has no entry at the given index.
isNullOrMissing(CharSequence) - Method in interface io.debezium.document.Document
Determine whether this object has a field with the given the name and the value is null, or if this object has no field with the given name.
isNumber() - Method in class io.debezium.document.BinaryValue
 
isNumber() - Method in class io.debezium.document.ComparableValue
 
isNumber() - Method in class io.debezium.document.ConvertingValue
 
isNumber() - Method in class io.debezium.document.NullValue
 
isNumber() - Method in interface io.debezium.document.Value
 
isNumeric(String) - Static method in class io.debezium.util.Strings
Check if the string contains only digits.
isOpenTracingAvailable() - Static method in class io.debezium.transforms.tracing.ActivateTracingSpan
 
isOptional() - Method in interface io.debezium.relational.Column
Determine whether this column is optional.
isOptional() - Method in interface io.debezium.relational.ColumnEditor
Determine whether this column is optional.
isOptional() - Method in class io.debezium.relational.ColumnEditorImpl
 
isOptional() - Method in class io.debezium.relational.ColumnImpl
 
isOptional(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isOptional(String) - Method in interface io.debezium.relational.Table
Determine if the values in the named column is optional.
isPositionAtOrBefore(Document, Document) - Method in class io.debezium.relational.history.HistoryRecordComparator
 
isPositiveInteger(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isPositiveLong(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isPrimaryKeyColumn(String) - Method in interface io.debezium.relational.Table
Determine if the named column is part of the primary key.
isQuote(char) - Static method in class io.debezium.relational.ddl.AbstractDdlParser
Check if the char is quote.
isQuoted(String) - Static method in class io.debezium.relational.ddl.AbstractDdlParser
Check if the string is enclosed in quotes.
isQuotingChar(char) - Method in interface io.debezium.relational.TableIdPredicates
 
isRegex(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isRequired - Variable in class io.debezium.config.Field
 
isRequired() - Method in class io.debezium.config.Field
Get if the field is required/mandatory.
isRequired() - Method in interface io.debezium.relational.Column
Determine whether this column is required.
isRequired(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isResident() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Returns true if this entry is resident in the cache, false otherwise.
isRetriable(Throwable) - Method in class io.debezium.pipeline.ErrorHandler
Whether the given throwable is retriable (e.g.
isRoot() - Method in interface io.debezium.document.Path
Return whether this path is the root path with no segments.
isRootField(String, String[]) - Static method in class io.debezium.transforms.HeaderToValue
 
isRunning() - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator.ChangeEventSourceContextImpl
 
isRunning() - Method in interface io.debezium.pipeline.source.spi.ChangeEventSource.ChangeEventSourceContext
Whether this source is running or has been requested to stop.
isSameSource(Document, Document) - Method in class io.debezium.relational.history.HistoryRecordComparator
 
isSchemaChangesHistoryEnabled() - Method in class io.debezium.config.CommonConnectorConfig
 
isSchemaChangesHistoryEnabled() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
isSchemaCommentsHistoryEnabled() - Method in class io.debezium.config.CommonConnectorConfig
 
isSchemaCommentsHistoryEnabled() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
isSchemaVerificationPassed() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
isSchemaVerificationPassed() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
isShort(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
isSignal(Class<T>) - Static method in class io.debezium.pipeline.signal.SignalProcessor
 
isSignalDataCollection(DataCollectionId) - Method in class io.debezium.config.CommonConnectorConfig
 
isSingle() - Method in interface io.debezium.document.Path
Return whether this path has a single segment.
isSnapshot() - Method in class io.debezium.connector.common.BaseSourceInfo
 
isSnapshotPaused() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
isSnapshotPaused() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
isSnapshotRunning() - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
isSnapshotRunning() - Method in interface io.debezium.pipeline.spi.OffsetContext
Whether this offset indicates that an (uncompleted) snapshot is currently running or not.
isStartDelimiter(char) - Method in interface io.debezium.relational.TableIdPredicates
 
isString() - Method in class io.debezium.document.BinaryValue
 
isString() - Method in class io.debezium.document.ComparableValue
 
isString() - Method in class io.debezium.document.ConvertingValue
 
isString() - Method in class io.debezium.document.NullValue
 
isString() - Method in interface io.debezium.document.Value
 
isTableInvalid(P, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
isTableType(String) - Method in class io.debezium.jdbc.JdbcConnection
 
isTableUniqueIndexIncluded(String, String) - Method in class io.debezium.jdbc.JdbcConnection
Allows the connector implementation to determine if a table's unique index should be include when resolving a table's unique indices.
isTransactionInProgress() - Method in class io.debezium.pipeline.txmetadata.TransactionContext
 
isTruncationPossible(Column) - Method in class io.debezium.relational.mapping.TruncateStrings
 
isUnknownPropertiesIgnored() - Method in class io.debezium.serde.json.JsonSerdeConfig
 
isUsingAvroConverter(Configuration) - Static method in class io.debezium.config.CommonConnectorConfig
 
isUuid(String) - Static method in class io.debezium.util.Strings
Determine if the supplied string is a valid UUID.
isValid() - Method in class io.debezium.jdbc.JdbcConnection
 
isValid() - Method in class io.debezium.relational.history.HistoryRecord
Verifies that the record contains mandatory fields - source and position
isValid(int) - Static method in class io.debezium.text.XmlCharacters
Determine whether the supplied character is a valid character in XML.
isValid(Object) - Static method in interface io.debezium.document.Value
 
isValidCharacter(char) - Method in class io.debezium.schema.AbstractTopicNamingStrategy
 
isValidCharacter(char) - Method in class io.debezium.schema.AbstractUnicodeTopicNamingStrategy
 
isValidContent(int) - Static method in class io.debezium.text.XmlCharacters
Determine whether the supplied character is a valid character in XML content
isValidEnvelope(R) - Method in class io.debezium.transforms.SmtManager
 
isValidExtensionNameCharacter(char) - Static method in class io.debezium.converters.CloudEventsConverter
 
isValidFirstCharacter(char) - Method in class io.debezium.schema.UnicodeReplacementFunction
Use underscore as escape sequence instead of backslash in UnicodeReplacementFunction, so treat underscore as an invalid character is expected.
isValidFloat(double) - Static method in class io.debezium.document.ComparableValue
 
isValidFullname(String) - Static method in interface io.debezium.schema.SchemaNameAdjuster
Determine if the supplied string is a valid Avro namespace.
isValidIndex(int) - Method in class io.debezium.document.BasicArray
 
isValidInteger(long) - Static method in class io.debezium.document.ComparableValue
 
isValidKey(R) - Method in class io.debezium.transforms.SmtManager
 
isValidMapping(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
isValidName(int) - Static method in class io.debezium.text.XmlCharacters
Determine whether the supplied character is a valid non-first character in an XML Name.
isValidName(String) - Static method in class io.debezium.text.XmlCharacters
Determine if the supplied name is a valid XML Name.
isValidNameStart(int) - Static method in class io.debezium.text.XmlCharacters
Determine whether the supplied character is a valid first character in an XML Name.
isValidNcName(int) - Static method in class io.debezium.text.XmlCharacters
Determine whether the supplied character is a valid non-first character in an XML NCName.
isValidNcName(String) - Static method in class io.debezium.text.XmlCharacters
Determine if the supplied name is a valid XML NCName.
isValidNcNameStart(int) - Static method in class io.debezium.text.XmlCharacters
Determine whether the supplied character is a valid first character in an XML NCName.
isValidNonFirstCharacter(char) - Method in class io.debezium.schema.FieldNameUnderscoreReplacementFunction
Sanitize column names that are illegal in Avro Must conform to https://avro.apache.org/docs/1.7.7/spec.html#Names Legal characters are [a-zA-Z_] for the first character and [a-zA-Z0-9_] thereafter.
isValidNonFirstCharacter(char) - Method in class io.debezium.schema.FieldNameUnicodeReplacementFunction
Use underscore as escape sequence instead of backslash, so treat underscore as an invalid character is expected.
isValidPubid(int) - Static method in class io.debezium.text.XmlCharacters
Determine whether the supplied character is a valid character in an XML Pubid.
isValidSpace(int) - Static method in class io.debezium.text.XmlCharacters
Determine whether the supplied character is a valid whitespace character in XML
isValidTopicNameCharacter(char) - Method in class io.debezium.schema.TopicSelector.TopicNameSanitizer
Deprecated.
Whether the given character is a legal character of a Kafka topic name.
isView - Variable in class io.debezium.relational.ddl.DdlParserListener.TableEvent
 
isView() - Method in class io.debezium.relational.ddl.DdlParserListener.TableEvent
Determine whether the target of the event is a view rather than a table.
isWrapperFor(Class<?>) - Method in class io.debezium.jdbc.CancellableResultSet
 
isZoneOffset(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
iterator() - Method in class io.debezium.config.Field.Set
 
iterator() - Method in class io.debezium.document.BasicArray
 
iterator() - Method in class io.debezium.document.BasicDocument
 
iterator() - Method in class io.debezium.document.Paths.ChildPath
 
iterator() - Method in class io.debezium.document.Paths.MultiSegmentPath
 
iterator() - Method in class io.debezium.document.Paths.RootPath
 
iterator() - Method in class io.debezium.document.Paths.SingleSegmentPath
 
iterator() - Method in class io.debezium.pipeline.spi.Offsets
 
iterator() - Method in class io.debezium.relational.history.TableChanges
 
iterator() - Method in class io.debezium.transforms.tracing.DebeziumTextMap
 
iterator() - Method in class io.debezium.util.BoundedConcurrentHashMap.EntrySet
 
iterator() - Method in class io.debezium.util.BoundedConcurrentHashMap.KeySet
 
iterator() - Method in class io.debezium.util.BoundedConcurrentHashMap.Values
 
Iterators - Class in io.debezium.util
A utility for creating iterators.
Iterators() - Constructor for class io.debezium.util.Iterators
 
Iterators.PreviewIterator<T> - Interface in io.debezium.util
A read only iterator that is able to preview the next value without consuming it or altering the behavior or semantics of the normal Iterator methods.
Iterators.TransformedIterator<F,T> - Interface in io.debezium.util
An iterator that is able to transform its contents to another type.

J

JacksonReader - Class in io.debezium.document
A DocumentReader and ArrayReader that uses the Jackson library to read JSON.
JacksonReader(boolean) - Constructor for class io.debezium.document.JacksonReader
 
JacksonWriter - Class in io.debezium.document
A DocumentWriter and ArrayWriter that uses the Jackson library to write JSON.
JacksonWriter(boolean) - Constructor for class io.debezium.document.JacksonWriter
 
JacksonWriter.WritingError - Exception in io.debezium.document
 
JAVA - Enum constant in enum io.debezium.transforms.partitions.PartitionRouting.HashFunction
Hash function to be used when computing hash of the fields of the record.
JDBC_TYPE_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
jdbcConfig - Variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
JdbcConfiguration - Interface in io.debezium.jdbc
A specialized configuration for the Debezium driver.
JdbcConfiguration.Builder - Interface in io.debezium.jdbc
The JDBC-specific builder used to construct and/or alter JDBC configuration instances.
jdbcConnection - Variable in class io.debezium.heartbeat.DatabaseHeartbeatImpl
 
jdbcConnection - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
jdbcConnection - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
JdbcConnection - Class in io.debezium.jdbc
A utility that simplifies using a JDBC connection and executing transactions composed of multiple statements.
JdbcConnection(JdbcConfiguration, JdbcConnection.ConnectionFactory, JdbcConnection.Operations, String, String) - Constructor for class io.debezium.jdbc.JdbcConnection
Create a new instance with the given configuration and connection factory, and specify the operations that should be run against each newly-established connection.
JdbcConnection(JdbcConfiguration, JdbcConnection.ConnectionFactory, String, String) - Constructor for class io.debezium.jdbc.JdbcConnection
Create a new instance with the given configuration and connection factory.
JdbcConnection.BlockingMultiResultSetConsumer - Interface in io.debezium.jdbc
 
JdbcConnection.BlockingResultSetConsumer - Interface in io.debezium.jdbc
 
JdbcConnection.CallPreparer - Interface in io.debezium.jdbc
 
JdbcConnection.ConnectionFactory - Interface in io.debezium.jdbc
Establishes JDBC connections.
JdbcConnection.ConnectionFactoryDecorator - Class in io.debezium.jdbc
 
JdbcConnection.MultiResultSetConsumer - Interface in io.debezium.jdbc
 
JdbcConnection.Operations - Interface in io.debezium.jdbc
Defines multiple JDBC operations.
JdbcConnection.ParameterResultSetConsumer - Interface in io.debezium.jdbc
 
JdbcConnection.ResultSetConsumer - Interface in io.debezium.jdbc
 
JdbcConnection.ResultSetExtractor<T> - Interface in io.debezium.jdbc
Extracts a data of resultset..
JdbcConnection.ResultSetMapper<T> - Interface in io.debezium.jdbc
 
JdbcConnection.StatementFactory - Interface in io.debezium.jdbc
A function to create a statement from a connection.
JdbcConnection.StatementPreparer - Interface in io.debezium.jdbc
 
JdbcConnectionException - Exception in io.debezium.jdbc
RuntimeException which is raised for various SQLException instances and which retains the error code from the original exception.
JdbcConnectionException(String, SQLException) - Constructor for exception io.debezium.jdbc.JdbcConnectionException
Creates a new exception instance, wrapping the supplied SQLException with a custom message
JdbcConnectionException(SQLException) - Constructor for exception io.debezium.jdbc.JdbcConnectionException
Creates a new exception instance, wrapping the supplied SQLException
jdbcConnectionFactory - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
jdbcType - Variable in class io.debezium.relational.ColumnEditorImpl
 
jdbcType - Variable in class io.debezium.relational.ColumnImpl
 
jdbcType - Variable in class io.debezium.relational.ddl.DataType
 
jdbcType - Variable in class io.debezium.relational.ddl.DataTypeBuilder
 
jdbcType() - Method in interface io.debezium.relational.Column
Get the JDBC type for this column
jdbcType() - Method in interface io.debezium.relational.ColumnEditor
Get the JDBC type for this column
jdbcType() - Method in class io.debezium.relational.ColumnEditorImpl
 
jdbcType() - Method in class io.debezium.relational.ColumnImpl
 
jdbcType() - Method in class io.debezium.relational.ddl.DataType
 
jdbcType(int) - Method in interface io.debezium.relational.ColumnEditor
Set the JDBC type of this column.
jdbcType(int) - Method in class io.debezium.relational.ColumnEditorImpl
 
jdbcType(int) - Method in class io.debezium.relational.ddl.DataTypeBuilder
 
JdbcValueConverters - Class in io.debezium.jdbc
A provider of ValueConverters and SchemaBuilders for various column types.
JdbcValueConverters() - Constructor for class io.debezium.jdbc.JdbcValueConverters
Create a new instance that always uses UTC for the default time zone when converting values without timezone information to values that require timezones, and uses adapts time and timestamp values based upon the precision of the database columns.
JdbcValueConverters(JdbcValueConverters.DecimalMode, TemporalPrecisionMode, ZoneOffset, TemporalAdjuster, JdbcValueConverters.BigIntUnsignedMode, CommonConnectorConfig.BinaryHandlingMode) - Constructor for class io.debezium.jdbc.JdbcValueConverters
Create a new instance, and specify the time zone offset that should be used only when converting values without timezone information to values that require timezones.
JdbcValueConverters.BigIntUnsignedMode - Enum in io.debezium.jdbc
 
JdbcValueConverters.DecimalMode - Enum in io.debezium.jdbc
 
JMX_OBJECT_NAME_FORMAT - Static variable in class io.debezium.pipeline.JmxUtils
 
JmxNotificationChannel - Class in io.debezium.pipeline.notification.channels.jmx
 
JmxNotificationChannel() - Constructor for class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
JmxNotificationChannelMXBean - Interface in io.debezium.pipeline.notification.channels.jmx
 
JmxSignalChannel - Class in io.debezium.pipeline.signal.channels.jmx
 
JmxSignalChannel() - Constructor for class io.debezium.pipeline.signal.channels.jmx.JmxSignalChannel
 
JmxSignalChannelMXBean - Interface in io.debezium.pipeline.signal.channels.jmx
 
JmxUtils - Class in io.debezium.pipeline
 
JmxUtils() - Constructor for class io.debezium.pipeline.JmxUtils
 
join(CharSequence, int[]) - Static method in class io.debezium.util.Strings
Returns a new String composed of the supplied integer values joined together with a copy of the specified delimiter.
join(CharSequence, CharSequence...) - Method in class io.debezium.util.Joiner
 
join(CharSequence, Iterable<T>) - Static method in class io.debezium.util.Strings
Returns a new String composed of the supplied values joined together with a copy of the specified delimiter.
join(CharSequence, Iterable<T>, Function<T, String>) - Static method in class io.debezium.util.Strings
Returns a new String composed of the supplied values joined together with a copy of the specified delimiter.
join(Iterable<?>) - Method in class io.debezium.util.Joiner
 
join(Iterable<?>, CharSequence, CharSequence...) - Method in class io.debezium.util.Joiner
 
join(Iterable<T>, Iterable<T>) - Static method in class io.debezium.util.Iterators
 
join(Iterable<T>, T) - Static method in class io.debezium.util.Iterators
 
join(Iterable<T>, T, T) - Static method in class io.debezium.util.Iterators
 
join(Iterable<T>, T, T, T) - Static method in class io.debezium.util.Iterators
 
join(Iterable<T>, T, T, T, T) - Static method in class io.debezium.util.Iterators
 
join(Object[]) - Method in class io.debezium.util.Joiner
 
join(Iterator<?>) - Method in class io.debezium.util.Joiner
 
join(Iterator<T>, Iterator<T>) - Static method in class io.debezium.util.Iterators
 
joiner - Variable in class io.debezium.util.Joiner
 
Joiner - Class in io.debezium.util
A utility for joining multiple character sequences together.
Joiner(StringJoiner) - Constructor for class io.debezium.util.Joiner
 
Json - Class in io.debezium.data
A semantic type for a JSON string.
Json() - Constructor for class io.debezium.data.Json
 
JSON - Enum constant in enum io.debezium.converters.spi.SerializerType
Using JSON as serialization format
jsonCloudEventsConverter - Variable in class io.debezium.converters.CloudEventsConverter
 
jsonDataConverter - Variable in class io.debezium.converters.CloudEventsConverter
 
jsonDeserializer - Variable in class io.debezium.converters.CloudEventsConverter
 
JsonDeserializer() - Constructor for class io.debezium.serde.json.JsonSerde.JsonDeserializer
 
jsonNodeToStructInternal(JsonNode, Schema) - Method in class io.debezium.transforms.outbox.JsonSchemaData
 
jsonPayloadNullFieldBehavior - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
jsonPayloadNullFieldBehavior - Variable in class io.debezium.transforms.outbox.JsonSchemaData
 
JsonPayloadNullFieldBehavior(String) - Constructor for enum io.debezium.transforms.outbox.EventRouterConfigDefinition.JsonPayloadNullFieldBehavior
 
jsonSchemaData - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
JsonSchemaData - Class in io.debezium.transforms.outbox
 
JsonSchemaData() - Constructor for class io.debezium.transforms.outbox.JsonSchemaData
 
JsonSchemaData(EventRouterConfigDefinition.JsonPayloadNullFieldBehavior) - Constructor for class io.debezium.transforms.outbox.JsonSchemaData
 
JsonSerde<T> - Class in io.debezium.serde.json
A Serde that (de-)serializes JSON.
JsonSerde(Class<T>) - Constructor for class io.debezium.serde.json.JsonSerde
 
JsonSerde.JsonDeserializer - Class in io.debezium.serde.json
 
JsonSerde.JsonSerializer - Class in io.debezium.serde.json
 
JsonSerdeConfig - Class in io.debezium.serde.json
A configuration for JsonSerde serialize/deserializer.
JsonSerdeConfig(Map<String, ?>) - Constructor for class io.debezium.serde.json.JsonSerdeConfig
 
JsonSerializer() - Constructor for class io.debezium.serde.json.JsonSerde.JsonSerializer
 
JsonTableChangeSerializer - Class in io.debezium.relational.history
Ther serializer responsible for converting of TableChanges into a JSON format.
JsonTableChangeSerializer() - Constructor for class io.debezium.relational.history.JsonTableChangeSerializer
 
justify(Strings.Justify, String, int, char) - Static method in class io.debezium.util.Strings
Justify the contents of the string.
Justify() - Constructor for enum io.debezium.util.Strings.Justify
 
justifyCenter(String, int, char) - Static method in class io.debezium.util.Strings
Center the contents of the string.
justifyLeft(String, int, char) - Static method in class io.debezium.util.Strings
Left justify the contents of the string, ensuring that the supplied string begins at the first character and that the resulting string is of the desired length.
justifyLeft(String, int, char, boolean) - Static method in class io.debezium.util.Strings
 
justifyRight(String, int, char) - Static method in class io.debezium.util.Strings
Right justify the contents of the string, ensuring that the string ends at the last character.
JvmVersionUtil - Class in io.debezium.util
Utility class dealing with Java version information.
JvmVersionUtil() - Constructor for class io.debezium.util.JvmVersionUtil
 

K

k1 - Variable in class io.debezium.util.MurmurHash3.State
 
k2 - Variable in class io.debezium.util.MurmurHash3.State
 
KafkaSignalChannel - Class in io.debezium.pipeline.signal.channels
The class responsible for processing of signals delivered to Debezium via a dedicated Kafka topic.
KafkaSignalChannel() - Constructor for class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
key - Variable in class io.debezium.heartbeat.HeartbeatImpl
 
key - Variable in class io.debezium.pipeline.source.spi.EventFormatter
 
key - Variable in class io.debezium.util.BoundedConcurrentHashMap.HashEntry
 
key(Object) - Method in class io.debezium.pipeline.source.spi.EventFormatter
 
Key - Class in io.debezium.relational
An immutable definition of a table's key.
Key(Table, Key.KeyMapper) - Constructor for class io.debezium.relational.Key
 
KEY_ENFORCE_UNIQUENESS - Static variable in class io.debezium.transforms.ByLogicalTableRouter
 
KEY_FIELD_NAME - Static variable in class io.debezium.transforms.ByLogicalTableRouter
 
KEY_FIELD_REGEX - Static variable in class io.debezium.transforms.ByLogicalTableRouter
 
KEY_FIELD_REPLACEMENT - Static variable in class io.debezium.transforms.ByLogicalTableRouter
 
Key.Builder - Class in io.debezium.relational
 
Key.CustomKeyMapper - Class in io.debezium.relational
Custom Key mapper used to override or defining a custom Key
Key.IdentityKeyMapper - Class in io.debezium.relational
Default Key mapper using PK as key.
Key.KeyMapper - Interface in io.debezium.relational
Provides the column(s) that should be used within the message key for a given table.
keyColumns() - Method in class io.debezium.relational.Key
 
keyEnforceUniqueness - Variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
keyEnforceUniqueness - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
keyFieldName - Variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
keyFieldName - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
keyFieldRegex - Variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
keyFieldRegex - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
keyFieldReplacement - Variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
keyFieldReplacement - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
keyFromColumnData(Object[]) - Method in class io.debezium.relational.TableSchema
Convert the specified row of values into a Kafka Connect key.
keyFromRow(Object[]) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
keyGenerator - Variable in class io.debezium.relational.TableSchema
 
KeyIterator() - Constructor for class io.debezium.util.BoundedConcurrentHashMap.KeyIterator
 
keyMapper - Variable in class io.debezium.relational.Key.Builder
 
keyMapper - Variable in class io.debezium.relational.Key
 
keyMapper - Variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
keyRegexReplaceCache - Variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
keyRegexReplaceCache - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
keys() - Method in interface io.debezium.config.Configuration
Get the set of keys in this configuration.
keys() - Method in class io.debezium.util.BoundedConcurrentHashMap
Returns an enumeration of the keys in this table.
keySchema - Variable in class io.debezium.heartbeat.HeartbeatImpl
 
keySchema - Variable in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
keySchema - Variable in class io.debezium.relational.TableSchema
 
keySchema() - Method in class io.debezium.relational.TableSchema
Get the Schema that represents the table's primary key.
keySchema() - Method in interface io.debezium.schema.DataCollectionSchema
 
keySchemaAugment() - Method in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
keySchemaUpdateCache - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
keySet - Variable in class io.debezium.util.BoundedConcurrentHashMap
 
keySet() - Method in class io.debezium.document.BasicDocument
 
keySet() - Method in interface io.debezium.document.Document
Returns this object's fields' names
keySet() - Method in class io.debezium.util.BoundedConcurrentHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class io.debezium.util.LRUCacheMap
 
KeySet() - Constructor for class io.debezium.util.BoundedConcurrentHashMap.KeySet
 
KEYSPACE_FIELD_NAME - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
keyValueAugment() - Method in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
knownFieldNames() - Method in interface io.debezium.jdbc.JdbcConfiguration
Get a predicate that determines if supplied keys are pre-defined field names.

L

L_LIRS - Static variable in class io.debezium.util.BoundedConcurrentHashMap.LIRS
The percentage of the cache which is dedicated to hot blocks.
lagBehindSource - Variable in class io.debezium.pipeline.meters.StreamingMeter
 
last() - Method in class io.debezium.jdbc.CancellableResultSet
 
LAST - Enum constant in enum io.debezium.connector.SnapshotRecord
Record is from snapshot is the last record generated in snapshot phase.
LAST_IN_DATA_COLLECTION - Enum constant in enum io.debezium.connector.SnapshotRecord
Record is from snapshot and the last record generated from the table, but not in the entire snapshot.
LAST_PROCESSED_KEY - Static variable in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
lastAppliedChange - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
lastChangeAppliedLogDelay - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
lastChangeAppliedTimestamp - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
lastChangeRecoveredLogDelay - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
lastChangeRecoveredTimestamp - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
lastEvent - Variable in class io.debezium.pipeline.meters.CommonEventMeter
 
lastEventKeySent - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
The PK of the last record that was passed to Kafka Connect.
lastEventTimestamp - Variable in class io.debezium.pipeline.meters.CommonEventMeter
 
lastIdentifierEnd - Variable in class io.debezium.relational.TableIdParser.ParsingContext
 
lastIndex - Variable in class io.debezium.text.TokenStream.CharacterArrayStream
 
lastOffsets - Variable in class io.debezium.connector.common.BaseSourceTask
The latest offsets that have been acknowledged by the Kafka producer.
lastRecoveredChange - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
lastReturned - Variable in class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
lastSegment() - Method in interface io.debezium.document.Path
Get the last segment, if there is one.
lastSegment() - Method in class io.debezium.document.Paths.ChildPath
 
lastSegment() - Method in class io.debezium.document.Paths.MultiSegmentPath
 
lastSegment() - Method in class io.debezium.document.Paths.RootPath
 
lastSegment() - Method in class io.debezium.document.Paths.SingleSegmentPath
 
lastSnapshotRecord(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
lastTransactionId - Variable in class io.debezium.pipeline.meters.StreamingMeter
 
LEFT - Enum constant in enum io.debezium.util.Strings.Justify
 
LegacyV1AbstractSourceInfoStructMaker<T extends AbstractSourceInfo> - Class in io.debezium.connector
Legacy source info that does not enforce presence of the version and connector fields
LegacyV1AbstractSourceInfoStructMaker(String, String, CommonConnectorConfig) - Constructor for class io.debezium.connector.LegacyV1AbstractSourceInfoStructMaker
 
length - Variable in class io.debezium.relational.ColumnEditorImpl
 
length - Variable in class io.debezium.relational.ColumnImpl
 
length - Variable in class io.debezium.relational.ddl.DataType
 
length - Variable in class io.debezium.relational.ddl.DataTypeBuilder
 
length() - Method in interface io.debezium.relational.Column
Get the maximum length of this column's values.
length() - Method in interface io.debezium.relational.ColumnEditor
Get the maximum length of this column's values.
length() - Method in class io.debezium.relational.ColumnEditorImpl
 
length() - Method in class io.debezium.relational.ColumnImpl
 
length() - Method in class io.debezium.relational.ddl.DataType
 
length() - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
length() - Method in interface io.debezium.text.TokenStream.Token
Get the length of the token, which is equivalent to endIndex() - startIndex().
length(int) - Method in interface io.debezium.relational.ColumnEditor
Set the maximum length of this column's values.
length(int) - Method in class io.debezium.relational.ColumnEditorImpl
 
length(long) - Method in class io.debezium.relational.ddl.DataTypeBuilder
 
LENGTH_FIELD - Static variable in class io.debezium.data.Bits
 
LENGTH_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
line - Variable in class io.debezium.text.Position
 
line() - Method in class io.debezium.text.Position
Get the 1-based line number of the character.
linear(Clock, Duration) - Static method in interface io.debezium.util.ElapsedTimeStrategy
Create a strategy whose time periods linearly increase in length.
linear(Duration) - Static method in interface io.debezium.util.DelayStrategy
Create a delay strategy that applies an linearly-increasing delay as long as the criteria is met.
lineNumber - Variable in class io.debezium.text.TokenStream.CharacterArrayStream
 
linkMapOf(K, V) - Static method in class io.debezium.util.Collect
 
linkMapOf(K, V, K, V) - Static method in class io.debezium.util.Collect
 
linkMapOf(K, V, K, V, K, V) - Static method in class io.debezium.util.Collect
 
linkMapOf(K, V, K, V, K, V, K, V) - Static method in class io.debezium.util.Collect
 
LIR_RESIDENT - Enum constant in enum io.debezium.util.BoundedConcurrentHashMap.Recency
 
LIRS - Enum constant in enum io.debezium.util.BoundedConcurrentHashMap.Eviction
 
LIRS(BoundedConcurrentHashMap.Segment<K, V>, int, int, float) - Constructor for class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
LIRSHashEntry(BoundedConcurrentHashMap.LIRS<K, V>, K, int, BoundedConcurrentHashMap.HashEntry<K, V>, V) - Constructor for class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
 
LIST_DELIMITER - Static variable in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
LIST_SEPARATOR - Static variable in class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
listener - Variable in class io.debezium.relational.history.AbstractSchemaHistory
 
listOf(String, Function<String, String[]>, Function<String, T>) - Static method in class io.debezium.util.Strings
Generate the list of values that are included in the list.
listOfRegex(String, int) - Static method in class io.debezium.util.Strings
Generate the set of regular expression Patterns that are specified in the string containing comma-separated regular expressions.
LITERAL_SEPARATOR_PATTERN - Static variable in class io.debezium.function.Predicates
 
literals - Variable in class io.debezium.config.Field.EnumRecommender
 
literalsStr - Variable in class io.debezium.config.Field.EnumRecommender
 
load(File) - Static method in interface io.debezium.config.Configuration
Obtain a configuration instance by loading the Properties from the supplied file.
load(InputStream) - Static method in interface io.debezium.config.Configuration
Obtain a configuration instance by loading the Properties from the supplied stream.
load(Reader) - Static method in interface io.debezium.config.Configuration
Obtain a configuration instance by loading the Properties from the supplied reader.
load(String) - Method in class io.debezium.transforms.tracing.DebeziumTextMap
 
load(String, Class<?>) - Static method in interface io.debezium.config.Configuration
Obtain a configuration instance by loading the Properties from a file on the file system or classpath given by the supplied path.
load(String, ClassLoader) - Static method in interface io.debezium.config.Configuration
Obtain a configuration instance by loading the Properties from a file on the file system or classpath given by the supplied path.
load(String, ClassLoader, Consumer<String>) - Static method in interface io.debezium.config.Configuration
Obtain a configuration instance by loading the Properties from a file on the file system or classpath given by the supplied path.
load(URL) - Static method in interface io.debezium.config.Configuration
Obtain a configuration instance by loading the Properties from the supplied URL.
load(Map<String, ?>) - Static method in class io.debezium.pipeline.source.snapshot.incremental.SignalBasedIncrementalSnapshotContext
 
load(Map<String, ?>) - Method in interface io.debezium.pipeline.spi.OffsetContext.Loader
 
load(Map<String, ?>) - Static method in class io.debezium.pipeline.txmetadata.TransactionContext
 
load(Map<String, ?>, boolean) - Static method in class io.debezium.pipeline.source.snapshot.incremental.SignalBasedIncrementalSnapshotContext
 
loader - Variable in class io.debezium.connector.common.OffsetReader
 
loadFactor - Variable in class io.debezium.util.BoundedConcurrentHashMap.Segment
The load factor for the hash table.
loadKeyStore(String, char[]) - Method in class io.debezium.jdbc.JdbcConnection
Read JKS type keystore/truststore file according related password.
loadProperties(Class<?>, String) - Static method in class io.debezium.util.IoUtil
Atomically load the properties file at the given location within the designated class' class loader.
loadProperties(ClassLoader, String) - Static method in class io.debezium.util.IoUtil
Atomically load the properties file at the given location within the designated class loader.
loadProperties(Supplier<ClassLoader>, String) - Static method in class io.debezium.util.IoUtil
Atomically load the properties file at the given location within the designated class loader.
lock - Variable in class io.debezium.connector.base.ChangeEventQueue
 
lock - Variable in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
lock - Variable in class io.debezium.relational.history.MemorySchemaHistory
 
lock - Variable in class io.debezium.relational.Tables
 
lock - Variable in class io.debezium.util.FunctionalReadWriteLock
 
lockTablesForSchemaSnapshot(ChangeEventSource.ChangeEventSourceContext, RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Locks all tables to be captured, so that no concurrent schema changes can be applied to them.
Log<P extends Partition> - Class in io.debezium.pipeline.signal.actions
 
Log() - Constructor for class io.debezium.pipeline.signal.actions.Log
 
LOG - Static variable in class io.debezium.relational.RelationalDatabaseSchema
 
LOG_INTERVAL - Static variable in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
Interval for showing a log statement with the progress while scanning a single table.
LOG_PREFIX - Static variable in class io.debezium.pipeline.notification.channels.LogNotificationChannel
 
logDebugAndTraceRecord(Logger, Object, String, Object...) - Static method in class io.debezium.util.Loggings
Log a debug message and explicitly append the source of the debug entry as a separate log entry that uses trace logging to prevent unintended leaking of sensitive data.
logErrorAndTraceRecord(Logger, Object, String, Object...) - Static method in class io.debezium.util.Loggings
Log an error message and explicitly append the source of the error entry as a separate log entry that uses trace logging to prevent unintended leaking of sensitive data.
logErrorAndTraceRecord(Logger, Object, String, Throwable) - Static method in class io.debezium.util.Loggings
Log an error message and explicitly append the source of the error entry as a separate log entry that uses trace logging to prevent unintended leaking of sensitive data.
logger - Variable in class io.debezium.jdbc.JdbcValueConverters
 
logger - Variable in class io.debezium.relational.ddl.AbstractDdlParser
 
logger - Variable in class io.debezium.relational.history.AbstractSchemaHistory
 
LOGGER - Static variable in class io.debezium.config.CommonConnectorConfig
 
LOGGER - Static variable in class io.debezium.connector.base.ChangeEventQueue
 
LOGGER - Static variable in class io.debezium.connector.common.BaseSourceTask
 
LOGGER - Static variable in class io.debezium.connector.common.RelationalBaseSourceConnector
 
LOGGER - Static variable in class io.debezium.converters.BinaryDataConverter
 
LOGGER - Static variable in class io.debezium.converters.ByteArrayConverter
 
LOGGER - Static variable in class io.debezium.converters.CloudEventsConverter
 
LOGGER - Static variable in class io.debezium.heartbeat.DatabaseHeartbeatImpl
 
LOGGER - Static variable in class io.debezium.heartbeat.HeartbeatImpl
 
LOGGER - Static variable in class io.debezium.jdbc.JdbcConnection
 
LOGGER - Static variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
LOGGER - Static variable in class io.debezium.pipeline.ErrorHandler
 
LOGGER - Static variable in class io.debezium.pipeline.EventDispatcher
 
LOGGER - Static variable in class io.debezium.pipeline.JmxUtils
 
LOGGER - Static variable in class io.debezium.pipeline.meters.SnapshotMeter
 
LOGGER - Static variable in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
LOGGER - Static variable in class io.debezium.pipeline.notification.channels.LogNotificationChannel
 
LOGGER - Static variable in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
LOGGER - Static variable in class io.debezium.pipeline.signal.actions.AbstractSnapshotSignal
 
LOGGER - Static variable in class io.debezium.pipeline.signal.actions.Log
 
LOGGER - Static variable in class io.debezium.pipeline.signal.actions.SchemaChanges
 
LOGGER - Static variable in class io.debezium.pipeline.signal.actions.snapshotting.CloseIncrementalSnapshotWindow
 
LOGGER - Static variable in class io.debezium.pipeline.signal.actions.snapshotting.ExecuteSnapshot
 
LOGGER - Static variable in class io.debezium.pipeline.signal.actions.snapshotting.OpenIncrementalSnapshotWindow
 
LOGGER - Static variable in class io.debezium.pipeline.signal.actions.snapshotting.StopSnapshot
 
LOGGER - Static variable in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
LOGGER - Static variable in class io.debezium.pipeline.signal.channels.jmx.JmxSignalChannel
 
LOGGER - Static variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
LOGGER - Static variable in class io.debezium.pipeline.signal.channels.SourceSignalChannel
 
LOGGER - Static variable in class io.debezium.pipeline.signal.SignalProcessor
 
LOGGER - Static variable in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
 
LOGGER - Static variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
LOGGER - Static variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
LOGGER - Static variable in class io.debezium.pipeline.source.snapshot.incremental.SignalBasedIncrementalSnapshotChangeEventSource
 
LOGGER - Static variable in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
LOGGER - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
LOGGER - Static variable in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
LOGGER - Static variable in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
LOGGER - Static variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
LOGGER - Static variable in class io.debezium.relational.mapping.MaskStrings.HashValueConverter
 
LOGGER - Static variable in class io.debezium.relational.RelationalChangeRecordEmitter
 
LOGGER - Static variable in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
LOGGER - Static variable in class io.debezium.relational.TableSchema
 
LOGGER - Static variable in class io.debezium.relational.TableSchemaBuilder
 
LOGGER - Static variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
LOGGER - Static variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
LOGGER - Static variable in interface io.debezium.schema.SchemaNameAdjuster
 
LOGGER - Static variable in class io.debezium.schema.TopicSelector.TopicNameSanitizer
Deprecated.
 
LOGGER - Static variable in class io.debezium.transforms.ByLogicalTableRouter
 
LOGGER - Static variable in class io.debezium.transforms.ExtractNewRecordState
 
LOGGER - Static variable in class io.debezium.transforms.HeaderToValue
 
LOGGER - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
LOGGER - Static variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
LOGGER - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
LOGGER - Static variable in class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
LOGGER - Static variable in class io.debezium.transforms.partitions.PartitionRouting
 
LOGGER - Static variable in class io.debezium.transforms.SmtManager
 
LOGGER - Static variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
LOGGER - Static variable in class io.debezium.util.IoUtil
 
LOGGER - Static variable in class io.debezium.util.JvmVersionUtil
 
LOGGER - Static variable in class io.debezium.util.Loggings
 
LOGGER - Static variable in class io.debezium.util.Threads
 
LoggingContext - Class in io.debezium.util
A utility that provides a consistent set of properties for the Mapped Diagnostic Context (MDC) properties used by Debezium components.
LoggingContext() - Constructor for class io.debezium.util.LoggingContext
 
LoggingContext.PreviousContext - Class in io.debezium.util
A snapshot of an MDC context that can be LoggingContext.PreviousContext.restore().
loggingContextSupplier - Variable in class io.debezium.connector.base.ChangeEventQueue.Builder
 
loggingContextSupplier - Variable in class io.debezium.connector.base.ChangeEventQueue
 
loggingContextSupplier(Supplier<LoggingContext.PreviousContext>) - Method in class io.debezium.connector.base.ChangeEventQueue.Builder
 
Loggings - Class in io.debezium.util
Functionality for dealing with logging.
Loggings() - Constructor for class io.debezium.util.Loggings
 
LOGICAL_NAME - Static variable in class io.debezium.data.Bits
 
LOGICAL_NAME - Static variable in class io.debezium.data.Enum
 
LOGICAL_NAME - Static variable in class io.debezium.data.EnumSet
 
LOGICAL_NAME - Static variable in class io.debezium.data.geometry.Geography
 
LOGICAL_NAME - Static variable in class io.debezium.data.geometry.Geometry
 
LOGICAL_NAME - Static variable in class io.debezium.data.geometry.Point
 
LOGICAL_NAME - Static variable in class io.debezium.data.Json
 
LOGICAL_NAME - Static variable in class io.debezium.data.Uuid
 
LOGICAL_NAME - Static variable in class io.debezium.data.VariableScaleDecimal
 
LOGICAL_NAME - Static variable in class io.debezium.data.Xml
 
LOGICAL_TABLE_CACHE_SIZE - Static variable in class io.debezium.transforms.ByLogicalTableRouter
 
logicalName - Variable in class io.debezium.config.CommonConnectorConfig
 
logMessage(InputStream, Consumer<String>, String, String) - Static method in class io.debezium.util.IoUtil
 
LogNotificationChannel - Class in io.debezium.pipeline.notification.channels
 
LogNotificationChannel() - Constructor for class io.debezium.pipeline.notification.channels.LogNotificationChannel
 
logStatistics(List<SourceRecord>) - Method in class io.debezium.connector.common.BaseSourceTask
 
logWarningAndTraceRecord(Logger, Object, String, Object...) - Static method in class io.debezium.util.Loggings
Log a warning message and explicitly append the source of the warning as a separate log entry that uses trace logging to prevent unintended leaking of sensitive data.
LONG - Enum constant in enum io.debezium.document.Value.Type
 
LONG - Enum constant in enum io.debezium.jdbc.JdbcValueConverters.BigIntUnsignedMode
 
LONG_FALSE - Static variable in class io.debezium.util.NumberConversions
 
LONG_TRUE - Static variable in class io.debezium.util.NumberConversions
 
lookupCloudEventsProvider(Struct) - Static method in class io.debezium.converters.CloudEventsConverter
Lookup the CloudEventsProvider implementation for the source connector.
lookupConfigurationProvider(Struct) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
Lookup the configuration provider for the source connector or use the default if not found.
LRU - Enum constant in enum io.debezium.util.BoundedConcurrentHashMap.Eviction
 
LRU(BoundedConcurrentHashMap.Segment<K, V>, int, float, int, float) - Constructor for class io.debezium.util.BoundedConcurrentHashMap.LRU
 
LRUCacheMap<K,V> - Class in io.debezium.util
A custom implementation of LRUCache that allows exposure to the underlying delegate's key or values collections.
LRUCacheMap(int) - Constructor for class io.debezium.util.LRUCacheMap
 

M

mainConnection - Variable in class io.debezium.jdbc.DefaultMainConnectionProvidingConnectionFactory
 
mainConnection() - Method in class io.debezium.jdbc.DefaultMainConnectionProvidingConnectionFactory
 
mainConnection() - Method in interface io.debezium.jdbc.MainConnectionProvidingConnectionFactory
 
MainConnectionProvidingConnectionFactory<T extends JdbcConnection> - Interface in io.debezium.jdbc
An on-demand provider of a JDBC connection.
make(BoundedConcurrentHashMap.Segment<K, V>, int, float) - Method in enum io.debezium.util.BoundedConcurrentHashMap.Eviction
 
makeHeaders(List<ExtractNewRecordState.FieldReference>, Struct) - Method in class io.debezium.transforms.ExtractNewRecordState
Create an Headers object which contains the headers to be added.
makeNewSchema(Schema, Map<String, Header>) - Method in class io.debezium.transforms.HeaderToValue
 
makeUpdatedSchema(List<ExtractNewRecordState.FieldReference>, Schema, Struct) - Method in class io.debezium.transforms.ExtractNewRecordState
 
makeUpdatedValue(Struct, Map<String, Header>, Schema) - Method in class io.debezium.transforms.HeaderToValue
 
map(String, ColumnMapper) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
Set a mapping function for the columns with fully-qualified names that match the given comma-separated list of regular expression patterns.
map(String, Class<ColumnMapper>) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
Set a mapping function for the columns with fully-qualified names that match the given comma-separated list of regular expression patterns.
map(String, Class<ColumnMapper>, Configuration) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
Set a mapping function for the columns with fully-qualified names that match the given comma-separated list of regular expression patterns.
map(String, String) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
Set a mapping function for the columns with fully-qualified names that match the given comma-separated list of regular expression patterns.
map(String, String, Configuration) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
Set a mapping function for the columns with fully-qualified names that match the given comma-separated list of regular expression patterns.
map(Function<String, String>) - Method in interface io.debezium.config.Configuration
Return a new Configuration that contains only the subset of keys that satisfy the given predicate.
mapByDatatype(String, ColumnMapper) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
 
mapOf(K, V) - Static method in class io.debezium.util.Collect
 
mapped(BiFunction<? super String, ? super String, String>) - Method in interface io.debezium.config.Configuration
Return a new Configuration that contains the mapped values.
MappedColumns(Map<String, Column>, int) - Constructor for class io.debezium.util.ColumnUtils.MappedColumns
 
mappedTableColumnDatatype(TableId, Column) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
 
mappedTableColumnName(TableId, Column) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
 
mappedTableId(TableId) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
 
mapper - Variable in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
mapper - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
mapper - Variable in class io.debezium.relational.mapping.ColumnMappers.MapperRule
 
mapper - Variable in class io.debezium.serde.json.JsonSerde
 
mapperFor(TableId, Column) - Method in class io.debezium.relational.mapping.ColumnMappers
Get the value mapping function for the given column.
MapperRule(BiPredicate<TableId, Column>, ColumnMapper) - Constructor for class io.debezium.relational.mapping.ColumnMappers.MapperRule
 
mapperTypeRef - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
MAPPING_SEPARATOR - Static variable in class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
mappingConverterFor(TableId, Column) - Method in class io.debezium.relational.mapping.ColumnMappers
Get the value mapping function for the given column.
mappingConverterFor(Table, Column) - Method in class io.debezium.relational.mapping.ColumnMappers
Get the value mapping function for the given column.
mark() - Method in class io.debezium.text.TokenStream
Obtain a marker that records the current position so that the stream can be TokenStream.rewind(Marker) back to the mark even after having been advanced beyond the mark.
Marker(Position, int) - Constructor for class io.debezium.text.TokenStream.Marker
 
markSnapshotRecord(SnapshotRecord) - Method in class io.debezium.pipeline.CommonOffsetContext
 
markSnapshotRecord(SnapshotRecord) - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
markSnapshotRecord(SnapshotRecord) - Method in interface io.debezium.pipeline.spi.OffsetContext
Mark the position of the record in the snapshot.
mask(String, String, String...) - Static method in class io.debezium.util.Strings
Masks sensitive data in given string
MASK_COLUMN - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
MASK_COLUMN_WITH_HASH - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
MaskingValueConverter(String) - Constructor for class io.debezium.relational.mapping.MaskStrings.MaskingValueConverter
 
MASKS - Static variable in class io.debezium.text.XmlCharacters
This implementation uses an array that captures for each character the XML classifications.
maskStrings(String, int) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
Use a string of the specified number of '*' characters to mask the string values for each of the columns with fully-qualified names that match the given comma-separated list of regular expression patterns.
maskStrings(String, int, char) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
Use a string of the specified number of characters to mask the string values for each of the columns with fully-qualified names that match the given comma-separated list of regular expression patterns.
maskStrings(String, String) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
Use the specified string to mask the string values for each of the columns with fully-qualified names that match the given comma-separated list of regular expression patterns.
MaskStrings - Class in io.debezium.relational.mapping
A ColumnMapper implementation that ensures that string values are masked.
MaskStrings(byte[], String, MaskStrings.HashingByteArrayStrategy) - Constructor for class io.debezium.relational.mapping.MaskStrings
Create a ColumnMapper that masks string values by hashing the input value.
MaskStrings(String) - Constructor for class io.debezium.relational.mapping.MaskStrings
Create a ColumnMapper that masks string values with a predefined value.
MaskStrings.HashingByteArrayStrategy - Enum in io.debezium.relational.mapping
V1 default and previous version.
MaskStrings.HashValueConverter - Class in io.debezium.relational.mapping
 
MaskStrings.MaskingValueConverter - Class in io.debezium.relational.mapping
 
maskStringsByHashing(String, String, String) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
 
maskStringsByHashingV2(String, String, String) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
 
maskValue - Variable in class io.debezium.relational.mapping.MaskStrings.MaskingValueConverter
 
matchedBy(String) - Static method in class io.debezium.function.Predicates
Generate a predicate function that for any supplied string returns a Pattern representing the first regular expression in the supplied comma-separated list that matches the predicate parameter in a case-insensitive manner.
matchedByPattern(Collection<Pattern>, BiFunction<T, U, String>) - Static method in class io.debezium.function.Predicates
 
matchedByPattern(Collection<Pattern>, Function<T, String>) - Static method in class io.debezium.function.Predicates
 
matches(char) - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
matches(char) - Method in class io.debezium.text.TokenStream
Determine if the current token matches the expected value.
matches(char) - Method in interface io.debezium.text.TokenStream.Token
Determine if the token matches the supplied character.
matches(int) - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
matches(int) - Method in class io.debezium.text.TokenStream
Determine if the current token matches the expected token type.
matches(int) - Method in interface io.debezium.text.TokenStream.Token
Determine if the token matches the supplied type.
matches(int[]) - Method in class io.debezium.text.TokenStream
Determine if the next few tokens have the supplied types.
matches(int, int...) - Method in class io.debezium.text.TokenStream
Determine if the next few tokens have the supplied types.
matches(int, String) - Method in class io.debezium.text.TokenStream
Determine if the current token matches the expected type and a value.
matches(int, String) - Method in interface io.debezium.text.TokenStream.Token
Determine if the token matches the supplied string and is of a requested type.
matches(TableId, Column) - Method in class io.debezium.relational.mapping.ColumnMappers.MapperRule
 
matches(Iterable<String>) - Method in class io.debezium.text.TokenStream
Determine if the next few tokens match the expected values.
matches(String) - Method in class io.debezium.text.TokenStream.CaseInsensitiveToken
 
matches(String) - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
matches(String) - Method in class io.debezium.text.TokenStream
Determine if the current token matches the expected value.
matches(String) - Method in interface io.debezium.text.TokenStream.Token
Determine if the token matches the supplied string.
matches(String[]) - Method in class io.debezium.text.TokenStream
Determine if the next few tokens match the expected values.
matches(String, String...) - Method in class io.debezium.text.TokenStream
Determine if the next few tokens match the expected values.
matches(String, String, String, String) - Method in interface io.debezium.relational.Tables.ColumnNameFilter
Determine whether the named column should be included in the table's Schema definition.
matchesAnyOf(int[]) - Method in class io.debezium.text.TokenStream
Determine if the next token have one of the supplied types.
matchesAnyOf(int, int...) - Method in class io.debezium.text.TokenStream
Determine if the next token have one of the supplied types.
matchesAnyOf(int, String, String...) - Method in class io.debezium.text.TokenStream
Determine if the next token matches one of the supplied values of the expected type.
matchesAnyOf(Iterable<String>) - Method in class io.debezium.text.TokenStream
Determine if the next token matches one of the supplied values.
matchesAnyOf(String[]) - Method in class io.debezium.text.TokenStream
Determine if the next token matches one of the supplied values.
matchesAnyOf(String, String...) - Method in class io.debezium.text.TokenStream
Determine if the next token matches one of the supplied values.
matchesAnyWordOf(String, String...) - Method in class io.debezium.text.TokenStream
Determine if the next token matches one of the supplied values of the type TokenStream.BasicTokenizer.WORD
matchesWord(String) - Method in class io.debezium.text.TokenStream
Determine if the current token is TokenStream.BasicTokenizer.WORD and matches the expected value.
matchString() - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
MathOps - Class in io.debezium.util
Utilities for performing math operations with mixed native and advanced numeric types.
MathOps() - Constructor for class io.debezium.util.MathOps
 
max - Variable in class io.debezium.config.Field.RangeValidator
 
max(Duration, Duration) - Static method in class io.debezium.time.Temporals
Returns that duration from the given ones which represents the larger amount of time ("is longer").
MAX_BATCH_SIZE - Static variable in class io.debezium.config.CommonConnectorConfig
 
MAX_BATCH_SIZE - Static variable in interface io.debezium.util.BoundedConcurrentHashMap.EvictionPolicy
 
MAX_POLL_PERIOD_IN_MILLIS - Static variable in class io.debezium.connector.common.BaseSourceTask
 
MAX_QUEUE_SIZE - Static variable in class io.debezium.config.CommonConnectorConfig
 
MAX_QUEUE_SIZE_IN_BYTES - Static variable in class io.debezium.config.CommonConnectorConfig
 
MAX_SEGMENTS - Static variable in class io.debezium.util.BoundedConcurrentHashMap
The maximum number of segments to allow; used to bound constructor arguments.
maxBatchQueueSize - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRS
The maxBatchQueueSize
maxBatchQueueSize - Variable in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
maxBatchSize - Variable in class io.debezium.config.CommonConnectorConfig
 
maxBatchSize - Variable in class io.debezium.connector.base.ChangeEventQueue.Builder
 
maxBatchSize - Variable in class io.debezium.connector.base.ChangeEventQueue
 
maxBatchSize(int) - Method in class io.debezium.connector.base.ChangeEventQueue.Builder
 
MAXIMUM_CAPACITY - Static variable in class io.debezium.util.BoundedConcurrentHashMap
The maximum capacity, used if a higher value is implicitly specified by either of the constructors with arguments.
MAXIMUM_KEY - Static variable in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
maximumHotSize - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRS
The maximum number of hot entries (L_lirs in the paper).
maximumKey - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
The largest PK in the table at the start of snapshot.
maximumKey() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
maximumKey() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
maximumKey(Object[]) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
maximumKey(Object[]) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
maximumSize - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRS
The maximum number of resident entries (L in the paper).
maxIndex - Variable in class io.debezium.text.TokenStream.CharacterArrayStream
 
maxLength - Variable in class io.debezium.relational.mapping.TruncateStrings.TruncatingValueConverter
 
maxQueueSize - Variable in class io.debezium.config.CommonConnectorConfig
 
maxQueueSize - Variable in class io.debezium.connector.base.ChangeEventQueue.Builder
 
maxQueueSize - Variable in class io.debezium.connector.base.ChangeEventQueue
 
maxQueueSize(int) - Method in class io.debezium.connector.base.ChangeEventQueue.Builder
 
maxQueueSizeInBytes - Variable in class io.debezium.config.CommonConnectorConfig
 
maxQueueSizeInBytes - Variable in class io.debezium.connector.base.ChangeEventQueue.Builder
 
maxQueueSizeInBytes - Variable in class io.debezium.connector.base.ChangeEventQueue
 
maxQueueSizeInBytes() - Method in class io.debezium.connector.base.ChangeEventQueue
 
maxQueueSizeInBytes() - Method in interface io.debezium.connector.base.ChangeEventQueueMetrics
 
maxQueueSizeInBytes(long) - Method in class io.debezium.connector.base.ChangeEventQueue.Builder
 
maxRetries - Variable in class io.debezium.pipeline.ErrorHandler
 
MemorySchemaHistory - Class in io.debezium.relational.history
A SchemaHistory implementation that stores the schema history in memory.
MemorySchemaHistory() - Constructor for class io.debezium.relational.history.MemorySchemaHistory
Create an instance that keeps the history in memory.
merge(Configuration...) - Method in interface io.debezium.config.Configuration
Return a new Configuration that merges several Configurations into one.
merge(Count) - Method in interface io.debezium.crdt.DeltaCounter
Merge the supplied counter into this counter.
merge(Count) - Method in interface io.debezium.crdt.GCounter
Merge the supplied counter into this counter.
merge(Count) - Method in interface io.debezium.crdt.PNCounter
Merge the supplied counter into this counter.
merge(Count) - Method in class io.debezium.crdt.StateBasedGCounter
 
merge(Count) - Method in class io.debezium.crdt.StateBasedPNCounter
 
merge(Count) - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
MESSAGE - Enum constant in enum io.debezium.data.Envelope.Operation
An operation that resulted in a generic message
messageValue() - Method in class io.debezium.heartbeat.HeartbeatImpl
Produce a value struct containing the timestamp
METADATA_FIELD_PREFIX - Static variable in class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
metadataProvider - Variable in class io.debezium.pipeline.meters.CommonEventMeter
 
metadataProvider - Variable in class io.debezium.pipeline.meters.StreamingMeter
 
metadataProvider - Variable in class io.debezium.pipeline.metrics.PipelineMetrics
 
metricName(String, String, String) - Method in class io.debezium.metrics.Metrics
 
metricName(String, Map<String, String>) - Method in class io.debezium.metrics.Metrics
Create a JMX metric name for the given metric.
Metrics - Class in io.debezium.metrics
Base for metrics implementations.
Metrics(CommonConnectorConfig, String, boolean) - Constructor for class io.debezium.metrics.Metrics
 
Metrics(CdcSourceTaskContext, String) - Constructor for class io.debezium.metrics.Metrics
 
Metrics(CdcSourceTaskContext, Map<String, String>) - Constructor for class io.debezium.metrics.Metrics
 
Metronome - Interface in io.debezium.util
A class that can be used to perform an action at a regular interval.
MicroDuration - Class in io.debezium.time
A utility representing a duration into a corresponding INT64 number of microsecond, and for defining a Kafka Connect Schema for duration values.
MicroDuration() - Constructor for class io.debezium.time.MicroDuration
 
MICROSECONDS_PER_DAY - Static variable in class io.debezium.time.Conversions
 
MICROSECONDS_PER_MILLISECOND - Static variable in class io.debezium.time.Conversions
 
MICROSECONDS_PER_SECOND - Static variable in class io.debezium.time.Conversions
 
MicroTime - Class in io.debezium.time
A utility for converting various Java time representations into the INT64 number of microseconds since midnight, and for defining a Kafka Connect Schema for time values with no date or timezone information.
MicroTime() - Constructor for class io.debezium.time.MicroTime
 
MicroTimestamp - Class in io.debezium.time
A utility for converting various Java time representations into the signed INT64 number of microseconds past epoch, and for defining a Kafka Connect Schema for timestamp values with no timezone information.
MicroTimestamp() - Constructor for class io.debezium.time.MicroTimestamp
 
migrateToQueue() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Moves this entry from the stack to the queue, marking it cold (as hot entries must remain in the stack).
migrateToStack() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Moves this entry from the queue to the stack, marking it hot (as cold resident entries must remain in the queue).
MILLISECONDS_PER_SECOND - Static variable in class io.debezium.time.Conversions
 
min - Variable in class io.debezium.config.Field.RangeValidator
 
min(Duration, Duration) - Static method in class io.debezium.time.Temporals
Returns that duration from the given ones which represents the smaller amount of time ("is shorted").
minus(Set<T>, Set<T>) - Static method in class io.debezium.util.Collect
Remove the content of one set from an another one.
miss() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Records a cache miss.
mkString(List<String>, String) - Method in class io.debezium.schema.AbstractTopicNamingStrategy
 
modCount - Variable in class io.debezium.util.BoundedConcurrentHashMap.Segment
Number of updates that alter the size of the table.
MONGODB_CONNECTOR - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
monitoredDataCollectionsDetermined(Iterable<? extends DataCollectionId>) - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
monitoredDataCollectionsDetermined(P, Iterable<? extends DataCollectionId>) - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
monitoredDataCollectionsDetermined(P, Iterable<? extends DataCollectionId>) - Method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
MOVE - Enum constant in enum io.debezium.transforms.HeaderToValue.Operation
 
MOVE_OPERATION - Static variable in class io.debezium.transforms.HeaderToValue
 
moveToCurrentRow() - Method in class io.debezium.jdbc.CancellableResultSet
 
moveToInsertRow() - Method in class io.debezium.jdbc.CancellableResultSet
 
moveToNextToken() - Method in class io.debezium.text.TokenStream
 
moveToNextToken(List<TokenStream.Token>) - Method in class io.debezium.text.TokenStream
 
moveToQueueEnd() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Moves this entry to the end of the queue.
moveToStackBottom() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Moves this entry to the bottom of the stack.
moveToStackTop() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Moves this entry to the top of the stack.
MSG_KEY_COLUMNS - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
MSG_KEY_COLUMNS_PATTERN - Static variable in class io.debezium.relational.Key.CustomKeyMapper
Pattern for defining the PK columns of a given table, in the form of "table:column1(,column2,...)", optionally with leading/trailing whitespace.
MULTI_PARTITION_MODE - Static variable in class io.debezium.config.CommonConnectorConfig
 
multiPartitionMode - Variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
multiPartitionMode - Variable in class io.debezium.relational.TableSchemaBuilder
 
multiPartitionMode - Variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
multiPartitionMode() - Method in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
multiple() - Static method in class io.debezium.util.Stopwatch
Create a new set of stopwatches.
MultipleDurations() - Constructor for class io.debezium.util.Stopwatch.MultipleDurations
 
MultipleParsingExceptions - Exception in io.debezium.text
Representation of multiple ParsingExceptions.
MultipleParsingExceptions(String, Collection<ParsingException>) - Constructor for exception io.debezium.text.MultipleParsingExceptions
 
MultipleParsingExceptions(Collection<ParsingException>) - Constructor for exception io.debezium.text.MultipleParsingExceptions
 
MultiSegmentPath(String[]) - Constructor for class io.debezium.document.Paths.MultiSegmentPath
 
MURMUR - Enum constant in enum io.debezium.transforms.partitions.PartitionRouting.HashFunction
 
MURMUR_HASH_3 - Static variable in class io.debezium.transforms.partitions.PartitionRouting
 
MurmurHash3 - Class in io.debezium.util
MurmurHash3() - Constructor for class io.debezium.util.MurmurHash3
 
MurmurHash3_x64_32(byte[], int) - Static method in class io.debezium.util.MurmurHash3
Hash a value using the x64 32 bit variant of MurmurHash3
MurmurHash3_x64_32(long[], int) - Static method in class io.debezium.util.MurmurHash3
Hash a value using the x64 32 bit variant of MurmurHash3
MurmurHash3_x64_64(byte[], int) - Static method in class io.debezium.util.MurmurHash3
Hash a value using the x64 64 bit variant of MurmurHash3
MurmurHash3_x64_64(long[], int) - Static method in class io.debezium.util.MurmurHash3
Hash a value using the x64 64 bit variant of MurmurHash3
MurmurHash3_x64_64_String(String, long) - Method in class io.debezium.util.MurmurHash3
 
MurmurHash3.State - Class in io.debezium.util
 
MYSQL_CONNECTOR - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 

N

name - Variable in class io.debezium.config.Field
 
name - Variable in enum io.debezium.converters.spi.SerializerType
 
name - Variable in class io.debezium.document.BasicField
 
name - Variable in class io.debezium.metadata.ConnectorDescriptor
 
name - Variable in class io.debezium.metrics.Metrics
 
name - Variable in class io.debezium.relational.AttributeEditorImpl
 
name - Variable in class io.debezium.relational.AttributeImpl
 
name - Variable in class io.debezium.relational.ColumnEditorImpl
 
name - Variable in class io.debezium.relational.ColumnImpl
 
name - Variable in class io.debezium.relational.ddl.DataType
 
name - Variable in enum io.debezium.transforms.HeaderToValue.Operation
 
name - Variable in enum io.debezium.transforms.partitions.PartitionRouting.HashFunction
 
name() - Method in class io.debezium.config.Field
Get the name of the field.
name() - Method in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
name() - Method in class io.debezium.pipeline.notification.channels.LogNotificationChannel
 
name() - Method in interface io.debezium.pipeline.notification.channels.NotificationChannel
 
name() - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
name() - Method in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
name() - Method in class io.debezium.pipeline.signal.channels.jmx.JmxSignalChannel
 
name() - Method in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
name() - Method in interface io.debezium.pipeline.signal.channels.SignalChannelReader
 
name() - Method in class io.debezium.pipeline.signal.channels.SourceSignalChannel
 
name() - Method in interface io.debezium.relational.Attribute
The attribute name.
name() - Method in interface io.debezium.relational.AttributeEditor
Get the name of the attribute.
name() - Method in class io.debezium.relational.AttributeEditorImpl
 
name() - Method in class io.debezium.relational.AttributeImpl
 
name() - Method in interface io.debezium.relational.Column
Get the name of the column.
name() - Method in interface io.debezium.relational.ColumnEditor
Get the name of the column.
name() - Method in class io.debezium.relational.ColumnEditorImpl
 
name() - Method in class io.debezium.relational.ColumnImpl
 
name() - Method in class io.debezium.relational.ddl.DataType
 
name(String) - Method in class io.debezium.config.ConfigDefinitionEditor
 
name(String) - Method in interface io.debezium.relational.AttributeEditor
Set the name of the attribute.
name(String) - Method in class io.debezium.relational.AttributeEditorImpl
 
name(String) - Method in interface io.debezium.relational.ColumnEditor
Set the name of the column.
name(String) - Method in class io.debezium.relational.ColumnEditorImpl
 
NAME - Static variable in class io.debezium.pipeline.signal.actions.Log
 
NAME - Static variable in class io.debezium.pipeline.signal.actions.SchemaChanges
 
NAME - Static variable in class io.debezium.pipeline.signal.actions.snapshotting.CloseIncrementalSnapshotWindow
 
NAME - Static variable in class io.debezium.pipeline.signal.actions.snapshotting.ExecuteSnapshot
 
NAME - Static variable in class io.debezium.pipeline.signal.actions.snapshotting.OpenIncrementalSnapshotWindow
 
NAME - Static variable in class io.debezium.pipeline.signal.actions.snapshotting.PauseIncrementalSnapshot
 
NAME - Static variable in class io.debezium.pipeline.signal.actions.snapshotting.ResumeIncrementalSnapshot
 
NAME - Static variable in class io.debezium.pipeline.signal.actions.snapshotting.StopSnapshot
 
NAME - Static variable in interface io.debezium.relational.history.SchemaHistory
 
NAME_CHARACTER - Static variable in class io.debezium.text.XmlCharacters
 
NAME_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
NAME_START_CHARACTER - Static variable in class io.debezium.text.XmlCharacters
 
NAME_TO_TYPE - Static variable in enum io.debezium.converters.spi.SerializerType
 
NAN - Enum constant in enum io.debezium.data.SpecialValueDecimal.SpecialValue
 
NanoDuration - Class in io.debezium.time
A utility representing a duration into a corresponding INT64 number of nanosecond, and for defining a Kafka Connect Schema for duration values.
NanoDuration() - Constructor for class io.debezium.time.NanoDuration
 
NANOSECONDS_PER_DAY - Static variable in class io.debezium.time.Conversions
 
NANOSECONDS_PER_MICROSECOND - Static variable in class io.debezium.time.Conversions
 
NANOSECONDS_PER_MILLISECOND - Static variable in class io.debezium.time.Conversions
 
NANOSECONDS_PER_SECOND - Static variable in class io.debezium.time.Conversions
 
NanoTime - Class in io.debezium.time
A utility for converting various Java time representations into the INT64 number of nanoseconds since midnight, and for defining a Kafka Connect Schema for time values with no date or timezone information.
NanoTime() - Constructor for class io.debezium.time.NanoTime
 
NanoTimestamp - Class in io.debezium.time
A utility for converting various Java time representations into the signed INT64 number of nanoseconds past epoch, and for defining a Kafka Connect Schema for timestamp values with no timezone information.
NanoTimestamp() - Constructor for class io.debezium.time.NanoTimestamp
 
NATIVE_TYPE_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
nativeType - Variable in class io.debezium.relational.ColumnEditorImpl
 
nativeType - Variable in class io.debezium.relational.ColumnImpl
 
nativeType() - Method in interface io.debezium.relational.Column
Get the database native type for this column
nativeType() - Method in interface io.debezium.relational.ColumnEditor
Get the internal database-specific type identifier for this column.
nativeType() - Method in class io.debezium.relational.ColumnEditorImpl
 
nativeType() - Method in class io.debezium.relational.ColumnImpl
 
nativeType(int) - Method in interface io.debezium.relational.ColumnEditor
Set the native type for this column .
nativeType(int) - Method in class io.debezium.relational.ColumnEditorImpl
 
NCNAME_CHARACTER - Static variable in class io.debezium.text.XmlCharacters
 
NCNAME_START_CHARACTER - Static variable in class io.debezium.text.XmlCharacters
 
NEGATIVE_INF - Static variable in class io.debezium.data.SpecialValueDecimal
 
NEGATIVE_INFINITY - Enum constant in enum io.debezium.data.SpecialValueDecimal.SpecialValue
 
NESTING_SEPARATOR - Static variable in class io.debezium.transforms.HeaderToValue
 
NESTING_SEPARATOR - Static variable in class io.debezium.transforms.partitions.PartitionRouting
 
neverSkip - Variable in class io.debezium.pipeline.EventDispatcher
 
NEW_FIELD_SEPARATOR - Static variable in class io.debezium.transforms.ExtractNewRecordState
 
newArray(int) - Static method in class io.debezium.util.BoundedConcurrentHashMap.HashEntry
 
newArray(int) - Static method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
newConnection() - Method in interface io.debezium.jdbc.ConnectionFactory
 
newConnection() - Method in class io.debezium.jdbc.DefaultMainConnectionProvidingConnectionFactory
 
newDeltaCounter() - Static method in class io.debezium.crdt.CRDT
Create a new CRDT positive and negative (PN) counter that records how much the value has changed since last reset.
newDeltaCounter(long, long, long, long) - Static method in class io.debezium.crdt.CRDT
Create a new CRDT positive and negative (PN) counter that records how much the value has changed since last reset.
newDeltaCounter(DeltaCount) - Static method in class io.debezium.crdt.CRDT
Create a new CRDT positive and negative (PN) counter that records how much the value has changed since last reset.
newField - Variable in class io.debezium.transforms.ExtractNewRecordState.FieldReference
The name for the outgoing attribute/field, e.g.
newFixedThreadPool(Class<? extends SourceConnector>, String, String, int) - Static method in class io.debezium.util.Threads
 
newGCounter() - Static method in class io.debezium.crdt.CRDT
Create a new CRDT grow-only (G) counter.
newGCounter(long) - Static method in class io.debezium.crdt.CRDT
Create a new CRDT grow-only (G) counter pre-populated with the given value.
newPNCounter() - Static method in class io.debezium.crdt.CRDT
Create a new CRDT positive and negative (PN) counter.
newPNCounter(long, long) - Static method in class io.debezium.crdt.CRDT
Create a new CRDT positive and negative (PN) counter pre-populated with the given values.
newSingleThreadExecutor(Class<? extends SourceConnector>, String, String) - Static method in class io.debezium.util.Threads
 
newSingleThreadExecutor(Class<? extends SourceConnector>, String, String, boolean) - Static method in class io.debezium.util.Threads
 
newSingleThreadScheduledExecutor(Class<? extends SourceConnector>, String, String, boolean) - Static method in class io.debezium.util.Threads
 
next - Variable in class io.debezium.util.BoundedConcurrentHashMap.HashEntry
 
next() - Method in class io.debezium.jdbc.CancellableResultSet
 
next() - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
next() - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
next() - Method in interface io.debezium.text.TokenStream.CharacterStream
Obtain the next character value, and advance the stream.
next() - Method in class io.debezium.util.BoundedConcurrentHashMap.EntryIterator
 
next() - Method in class io.debezium.util.BoundedConcurrentHashMap.KeyIterator
 
next() - Method in class io.debezium.util.BoundedConcurrentHashMap.ValueIterator
 
nextCharMayBeLineFeed - Variable in class io.debezium.text.TokenStream.CharacterArrayStream
 
nextChunkPosition(Object[]) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
nextChunkPosition(Object[]) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
nextDataCollection() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
nextDataCollection() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
nextDataCollection(P, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
nextElement() - Method in class io.debezium.util.BoundedConcurrentHashMap.KeyIterator
 
nextElement() - Method in class io.debezium.util.BoundedConcurrentHashMap.ValueIterator
 
nextEntry - Variable in class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
nextEntry() - Method in class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
nextInQueue - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
 
nextInStack - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
 
nextPosition() - Method in class io.debezium.text.TokenStream
Get the position of the next (or current) token.
nextSegmentIndex - Variable in class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
nextTableIndex - Variable in class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
NO_CAPTURED_DATA_COLLECTIONS_WARNING - Static variable in interface io.debezium.schema.DatabaseSchema
 
NO_OP - Static variable in interface io.debezium.schema.SchemaNameAdjuster
 
NO_OP() - Static method in interface io.debezium.pipeline.source.spi.DataChangeEventListener
 
NO_OP() - Static method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
none() - Static method in interface io.debezium.util.DelayStrategy
Create a delay strategy that never delays.
none() - Static method in interface io.debezium.util.ElapsedTimeStrategy
Create an elapsed time strategy that always is elapsed.
NONE - Enum constant in enum io.debezium.config.CommonConnectorConfig.FieldNameAdjustmentMode
Do not adjust names
NONE - Enum constant in enum io.debezium.config.CommonConnectorConfig.SchemaNameAdjustmentMode
Do not adjust names
NONE - Enum constant in enum io.debezium.transforms.ExtractNewRecordStateConfigDefinition.DeleteHandling
 
NONE - Enum constant in enum io.debezium.util.BoundedConcurrentHashMap.Eviction
 
NONE - Static variable in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
nonResident() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Marks this entry as non-resident.
noOp(TableId) - Static method in interface io.debezium.relational.TableEditor
Create a new editor that does nothing.
NOOP - Static variable in interface io.debezium.relational.history.SchemaHistoryListener
 
NOOP - Static variable in interface io.debezium.schema.HistorizedDatabaseSchema.SchemaChangeEventConsumer
 
NoOpTableEditorImpl - Class in io.debezium.relational
 
NoOpTableEditorImpl() - Constructor for class io.debezium.relational.NoOpTableEditorImpl
 
normalizeBinaryData(Column, byte[]) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts the given byte array value into a normalized byte array.
not(Predicate<R>) - Static method in class io.debezium.function.Predicates
 
NOT_A_NUMBER - Static variable in class io.debezium.data.SpecialValueDecimal
 
notContainEmptyElements(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
notContainSpaceInAnyElement(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.Field
 
notExpectedChunk(String) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
The snapshotting process can receive out-of-order windowing signals after connector restart as depending on committed offset position some signals can be replayed.
Notification - Class in io.debezium.pipeline.notification
 
Notification(String, String, String, Map<String, String>) - Constructor for class io.debezium.pipeline.notification.Notification
 
NOTIFICATION_CONFIGURATION_FIELD_PREFIX_STRING - Static variable in class io.debezium.config.CommonConnectorConfig
 
NOTIFICATION_ENABLED_CHANNELS - Static variable in class io.debezium.config.CommonConnectorConfig
 
NOTIFICATION_KEY_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
NOTIFICATION_KEY_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
NOTIFICATION_TOPIC - Static variable in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
NOTIFICATION_VALUE_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
NOTIFICATION_VALUE_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
Notification.Builder - Class in io.debezium.pipeline.notification
 
NotificationChannel - Interface in io.debezium.pipeline.notification.channels
This interface is used to provide custom write channels for the Debezium notification feature: Implementations must: define the name of the channel in NotificationChannel.name(), initialize specific configuration/variables/connections in the NotificationChannel.init(CommonConnectorConfig connectorConfig) method, implement send of the notification on the channel in the NotificationChannel.send(Notification notification) method.
notificationChannels - Variable in class io.debezium.connector.common.BaseSourceTask
 
notificationChannels - Variable in class io.debezium.pipeline.notification.NotificationService
 
notificationKeySchema(SchemaNameAdjuster) - Method in class io.debezium.schema.SchemaFactory
 
NOTIFICATIONS - Static variable in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
notificationSequence - Variable in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
notificationService - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
notificationService - Variable in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
notificationService - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
NotificationService<P extends Partition,O extends OffsetContext> - Class in io.debezium.pipeline.notification
This service can be used to send notification to available and enabled channels
NotificationService(List<NotificationChannel>, CommonConnectorConfig, SchemaFactory, BlockingConsumer<SourceRecord>) - Constructor for class io.debezium.pipeline.notification.NotificationService
 
notificationTopicName - Variable in class io.debezium.config.CommonConnectorConfig
 
notificationValueSchema(SchemaNameAdjuster) - Method in class io.debezium.schema.SchemaFactory
 
notify(Notification) - Method in class io.debezium.pipeline.notification.NotificationService
This method permits to just send a notification.
notify(Notification, Offsets<P, ? extends OffsetContext>) - Method in class io.debezium.pipeline.notification.NotificationService
This method permits to send a notification together with offsets.
notifyAborted(IncrementalSnapshotContext<T>, P, OffsetContext) - Method in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
notifyAborted(IncrementalSnapshotContext<T>, P, OffsetContext, List<String>) - Method in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
notifyCompleted(IncrementalSnapshotContext<T>, P, OffsetContext) - Method in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
notifyEvictionListener(Set<BoundedConcurrentHashMap.HashEntry<K, V>>) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
notifyInProgress(IncrementalSnapshotContext<T>, P, OffsetContext) - Method in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
notifyPaused(IncrementalSnapshotContext<T>, P, OffsetContext) - Method in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
notifyResumed(IncrementalSnapshotContext<T>, P, OffsetContext) - Method in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
notifyStarted(IncrementalSnapshotContext<T>, P, OffsetContext) - Method in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
notifyTableScanCompleted(IncrementalSnapshotContext<T>, P, OffsetContext, long) - Method in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
notNull() - Static method in class io.debezium.function.Predicates
 
notNull(Value) - Static method in interface io.debezium.document.Value
 
NotThreadSafe - Annotation Type in io.debezium.annotation
Denotes that the annotated type isn't safe for concurrent access from multiple threads without external synchronization.
NULL - Enum constant in enum io.debezium.document.Value.Type
 
NULL - Static variable in class io.debezium.pipeline.EventDispatcher.BufferedDataChangeEvent
 
Nullable - Interface in io.debezium.connector
 
NullEvictionListener() - Constructor for class io.debezium.util.BoundedConcurrentHashMap.NullEvictionListener
 
NullEvictionPolicy() - Constructor for class io.debezium.util.BoundedConcurrentHashMap.NullEvictionPolicy
 
nullOr() - Method in interface io.debezium.relational.ValueConverter
Return a new converter that will call this converter only when the input is not null.
nullValue() - Static method in interface io.debezium.document.Value
 
NullValue - Class in io.debezium.document
A specialization of Value that represents a null value.
NullValue() - Constructor for class io.debezium.document.NullValue
 
NUMBER_OF_CHARACTERS - Static variable in class io.debezium.text.XmlCharacters
 
NumberConversions - Class in io.debezium.util
A set of numeric conversion methods.
NumberConversions() - Constructor for class io.debezium.util.NumberConversions
 
numberOfCommittedTransactions - Variable in class io.debezium.pipeline.meters.StreamingMeter
 
numberOfErroneousEvents - Variable in class io.debezium.pipeline.meters.CommonEventMeter
 
numberOfEventsFiltered - Variable in class io.debezium.pipeline.meters.CommonEventMeter
 
numberOfPartitionsByTable - Variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 

O

objectMapper - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
objectSize() - Method in class io.debezium.pipeline.DataChangeEvent
 
objectSize() - Method in interface io.debezium.pipeline.Sizeable
 
of(SchemaChangeEvent.SchemaChangeEventType, Partition, OffsetContext, String, String, String, Table, boolean) - Static method in class io.debezium.schema.SchemaChangeEvent
Create a schema change event for any event type that does not involve a table rename.
of(Map<P, O>) - Static method in class io.debezium.pipeline.spi.Offsets
 
of(P, O) - Static method in class io.debezium.pipeline.spi.Offsets
 
ofAlter(Partition, OffsetContext, String, String, String, Table) - Static method in class io.debezium.schema.SchemaChangeEvent
Create a schema change event for a ALTER TABLE event.
ofCreate(Partition, OffsetContext, String, String, String, Table, boolean) - Static method in class io.debezium.schema.SchemaChangeEvent
Create a schema change event for a CREATE TABLE statement with DDL.
ofDatabase(Partition, OffsetContext, String, String, boolean) - Static method in class io.debezium.schema.SchemaChangeEvent
Create a schema change event for a database-specific DDL operation.
ofDrop(Partition, OffsetContext, String, String, String, Table) - Static method in class io.debezium.schema.SchemaChangeEvent
Create a schema change event for a DROP TABLE event.
offset - Variable in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshotContext
 
offset - Variable in class io.debezium.pipeline.spi.SnapshotResult
 
offset - Variable in class io.debezium.schema.SchemaChangeEvent
 
offset() - Method in interface io.debezium.heartbeat.Heartbeat.OffsetProducer
 
OFFSET_TABLE_COUNT_PREFIX - Static variable in class io.debezium.pipeline.txmetadata.TransactionContext
 
OFFSET_TABLE_COUNT_PREFIX_LENGTH - Static variable in class io.debezium.pipeline.txmetadata.TransactionContext
 
OFFSET_TRANSACTION_ID - Static variable in class io.debezium.pipeline.txmetadata.TransactionContext
 
offsetContext - Variable in class io.debezium.pipeline.AbstractChangeRecordEmitter
 
offsetContext - Variable in class io.debezium.pipeline.EventDispatcher.BufferedDataChangeEvent
 
offsetContext - Variable in class io.debezium.pipeline.signal.SignalPayload
 
OffsetContext - Interface in io.debezium.pipeline.spi
Keeps track of the current offset within the source DB's change stream.
OffsetContext.Loader<O extends OffsetContext> - Interface in io.debezium.pipeline.spi
Implementations load a connector-specific offset context based on the offset values stored in Kafka.
OffsetReader<P extends Partition,O extends OffsetContext,L extends OffsetContext.Loader<O>> - Class in io.debezium.connector.common
Provides access to the partition offsets stored by connectors.
OffsetReader(OffsetStorageReader, L) - Constructor for class io.debezium.connector.common.OffsetReader
 
offsets - Variable in class io.debezium.pipeline.spi.Offsets
 
offsets(Set<P>) - Method in class io.debezium.connector.common.OffsetReader
Given the collection of connector-specific task partitions, returns their respective connector-specific offsets.
Offsets<P extends Partition,O extends OffsetContext> - Class in io.debezium.pipeline.spi
Keeps track the source partitions to be processed by the connector task and their respective offsets.
Offsets(Map<P, O>) - Constructor for class io.debezium.pipeline.spi.Offsets
 
ofRename(Partition, OffsetContext, String, String, String, Table, TableId) - Static method in class io.debezium.schema.SchemaChangeEvent
Create a schema change event for a ALTER TABLE RENAME event.
ofSnapshotCreate(Partition, OffsetContext, String, Table) - Static method in class io.debezium.schema.SchemaChangeEvent
Create a schema change event for a CREATE TABLE statement without DDL from snapshot phase.
ofTableChange(TableChanges.TableChange, Map<String, ?>, Map<String, ?>, Struct, String, String) - Static method in class io.debezium.schema.SchemaChangeEvent
Create a schema change event for a TableChanges.TableChange.
on(CharSequence) - Static method in class io.debezium.util.Joiner
 
on(CharSequence, CharSequence) - Static method in class io.debezium.util.Joiner
 
on(CharSequence, CharSequence, CharSequence) - Static method in class io.debezium.util.Joiner
 
ON_CONNECT_STATEMENTS - Static variable in interface io.debezium.jdbc.JdbcConfiguration
A semicolon separated list of SQL statements to be executed when the connection to database is established.
onChangeApplied(HistoryRecord) - Method in interface io.debezium.relational.history.SchemaHistoryListener
Invoked for every change applied and not filtered.
onChangeApplied(HistoryRecord) - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
onChangeFromHistory(HistoryRecord) - Method in interface io.debezium.relational.history.SchemaHistoryListener
Invoked for every change read from the history during recovery.
onChangeFromHistory(HistoryRecord) - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
onConnectorEvent(P, ConnectorEvent) - Method in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
onConnectorEvent(P, ConnectorEvent) - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
onConnectorEvent(P, ConnectorEvent) - Method in interface io.debezium.pipeline.source.spi.DataChangeEventListener
Invoked for events that represent a connector event.
ONE_DAY - Static variable in class io.debezium.time.MicroTime
 
ONE_DAY - Static variable in class io.debezium.time.NanoTime
 
ONE_DAY - Static variable in class io.debezium.time.Time
 
onEntry(TableIdParser.ParsingContext) - Method in enum io.debezium.relational.TableIdParser.ParsingState
 
onEntryChosenForEviction(V) - Method in interface io.debezium.util.BoundedConcurrentHashMap.EvictionListener
 
onEntryChosenForEviction(V) - Method in class io.debezium.util.BoundedConcurrentHashMap.NullEvictionListener
 
onEntryEviction(Map<K, V>) - Method in interface io.debezium.util.BoundedConcurrentHashMap.EvictionListener
 
onEntryEviction(Map<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.NullEvictionListener
 
onEntryHit(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in interface io.debezium.util.BoundedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that an entry in Segment has been accessed.
onEntryHit(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
onEntryHit(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
onEntryHit(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.NullEvictionPolicy
 
onEntryMiss(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in interface io.debezium.util.BoundedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that there has been an attempt to access an entry in Segment, however that entry was not present in Segment.
onEntryMiss(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
onEntryMiss(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
onEntryMiss(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.NullEvictionPolicy
 
onEntryRemove(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in interface io.debezium.util.BoundedConcurrentHashMap.EvictionPolicy
Invoked to notify EvictionPolicy implementation that an entry e has been removed from Segment.
onEntryRemove(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
onEntryRemove(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
onEntryRemove(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.NullEvictionPolicy
 
OneOfRecommender(String...) - Constructor for class io.debezium.config.Field.OneOfRecommender
 
OneOfRecommender(List<String>) - Constructor for class io.debezium.config.Field.OneOfRecommender
 
onErroneousEvent() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
onErroneousEvent(Envelope.Operation) - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
onErroneousEvent(P, String) - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
onErroneousEvent(P, String) - Method in interface io.debezium.pipeline.source.spi.DataChangeEventListener
Invoked for events that cannot be processed.
onErroneousEvent(P, String, Envelope.Operation) - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
onErroneousEvent(P, String, Envelope.Operation) - Method in interface io.debezium.pipeline.source.spi.DataChangeEventListener
Invoked for events that cannot be processed.
onError(SQLException) - Method in interface io.debezium.heartbeat.HeartbeatErrorHandler
 
onEvent(DataCollectionId, OffsetContext, Object, Struct) - Method in class io.debezium.pipeline.meters.StreamingMeter
 
onEvent(DataCollectionId, OffsetContext, Object, Struct, Envelope.Operation) - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
onEvent(P, DataCollectionId, OffsetContext, Object, Struct, Envelope.Operation) - Method in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
onEvent(P, DataCollectionId, OffsetContext, Object, Struct, Envelope.Operation) - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
onEvent(P, DataCollectionId, OffsetContext, Object, Struct, Envelope.Operation) - Method in interface io.debezium.pipeline.source.spi.DataChangeEventListener
Invoked if an event is processed for a captured table.
onExit(TableIdParser.ParsingContext) - Method in enum io.debezium.relational.TableIdParser.ParsingState
 
onFilteredEvent() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
onFilteredEvent(Envelope.Operation) - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
onFilteredEvent(P, String) - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
onFilteredEvent(P, String) - Method in interface io.debezium.pipeline.source.spi.DataChangeEventListener
Invoked for events pertaining to non-captured tables.
onFilteredEvent(P, String, Envelope.Operation) - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
onFilteredEvent(P, String, Envelope.Operation) - Method in interface io.debezium.pipeline.source.spi.DataChangeEventListener
Invoked for events pertaining to non-captured tables.
onlyHeadersInOutputMessage - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
op - Variable in class io.debezium.converters.spi.RecordParser
 
op() - Method in class io.debezium.converters.spi.RecordParser
Get the value of the op field in the record.
OPEN_TRACING_AVAILABLE - Static variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
OpenIncrementalSnapshotWindow<P extends Partition> - Class in io.debezium.pipeline.signal.actions.snapshotting
 
OpenIncrementalSnapshotWindow() - Constructor for class io.debezium.pipeline.signal.actions.snapshotting.OpenIncrementalSnapshotWindow
 
openingQuoteCharacter - Variable in class io.debezium.jdbc.JdbcConnection
 
openWindow(String) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
openWindow(String) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
operation - Variable in class io.debezium.transforms.HeaderToValue
 
Operation(String) - Constructor for enum io.debezium.data.Envelope.Operation
 
Operation(String) - Constructor for enum io.debezium.transforms.HeaderToValue.Operation
 
OPERATION - Static variable in class io.debezium.data.Envelope.FieldName
The op field is used to store the kind of operation on a record.
OPERATION_CONF - Static variable in class io.debezium.transforms.HeaderToValue
 
OPERATION_FIELD - Static variable in class io.debezium.transforms.HeaderToValue
 
OPERATION_INVALID_BEHAVIOR - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
OPERATION_REQUIRED - Static variable in class io.debezium.data.Envelope
Flag that specifies whether the Envelope.FieldName.OPERATION field is required within the envelope.
operationFor(SourceRecord) - Static method in class io.debezium.data.Envelope
Obtain the operation for the given source record.
operationName - Variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
opSchema - Variable in class io.debezium.converters.spi.RecordParser
 
opSchema() - Method in class io.debezium.converters.spi.RecordParser
Get the schema of the op field in the record.
optional - Variable in class io.debezium.relational.ColumnEditorImpl
 
optional - Variable in class io.debezium.relational.ColumnImpl
 
optional() - Method in class io.debezium.config.Field
 
optional(boolean) - Method in interface io.debezium.relational.ColumnEditor
Set whether the column's values are optional (e.g., can contain nulls).
optional(boolean) - Method in class io.debezium.relational.ColumnEditorImpl
 
OPTIONAL_BYTES - Enum constant in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.JsonPayloadNullFieldBehavior
 
OPTIONAL_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
OPTIONAL_OF_ROOT - Static variable in class io.debezium.document.Paths.RootPath
 
optionalRoot() - Static method in interface io.debezium.document.Path
Get an Optional reference to the root path.
optionalSchema() - Static method in class io.debezium.data.VariableScaleDecimal
Returns a Schema for an optional VariableScaleDecimal but with all other default Schema settings.
or(ValueConverter) - Method in interface io.debezium.relational.ValueConverter
Adapt this converter to call the specified fallback converter when this converter returns null for a non-null input.
ORACLE_CONNECTOR - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
order - Variable in class io.debezium.relational.ddl.DdlParserListener.SetVariableEvent
 
order() - Method in class io.debezium.relational.ddl.DdlParserListener.SetVariableEvent
In case of multiple vars set in the same SET statement the order of the variable in the statement.
overrideColumn(ColumnEditor) - Method in class io.debezium.jdbc.JdbcConnection
Allow implementations an opportunity to adjust the current state of the ColumnEditor that has been seeded with data from the column metadata from the JDBC driver.
overwriteTable(Table) - Method in class io.debezium.relational.Tables
Add or update the definition for the identified table.
overwriteTable(TableId, List<Column>, List<String>, String, List<Attribute>) - Method in class io.debezium.relational.Tables
Add or update the definition for the identified table.
owner - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
 

P

PackagePrivate - Annotation Type in io.debezium.annotation
Indicates that the annotated element intentionally uses default visibility.
pad(String, int, char) - Static method in class io.debezium.util.Strings
Pad the string with the specific character to ensure the string is at least the specified length.
padLittleEndian(int, byte[]) - Method in class io.debezium.jdbc.JdbcValueConverters
 
parameters - Variable in class io.debezium.relational.ddl.DataTypeBuilder
 
parameters(String) - Method in class io.debezium.relational.ddl.DataTypeBuilder
 
parent - Variable in class io.debezium.document.Paths.ChildPath
 
parent() - Method in interface io.debezium.document.Path
Get the optional parent path.
parent() - Method in class io.debezium.document.Paths.ChildPath
 
parent() - Method in class io.debezium.document.Paths.MultiSegmentPath
 
parent() - Method in class io.debezium.document.Paths.RootPath
 
parent() - Method in class io.debezium.document.Paths.SingleSegmentPath
 
parker(Duration, Clock) - Static method in interface io.debezium.util.Metronome
Create a new metronome that starts ticking immediately and that uses LockSupport.parkNanos(long) to wait.
parse(JsonParser) - Method in class io.debezium.document.JacksonReader
 
parse(Column, String) - Method in interface io.debezium.relational.DefaultValueConverter.DefaultValueMapper
Parses the string-representation of the default value to an object.
parse(String) - Static method in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
Determine if the supplied values is one of the predefined options
parse(String) - Static method in enum io.debezium.config.CommonConnectorConfig.EventProcessingFailureHandlingMode
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.config.CommonConnectorConfig.FieldNameAdjustmentMode
Determine if the supplied values is one of the predefined options
parse(String) - Static method in enum io.debezium.config.CommonConnectorConfig.SchemaNameAdjustmentMode
Determine if the supplied values is one of the predefined options
parse(String) - Static method in enum io.debezium.config.CommonConnectorConfig.Version
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in interface io.debezium.document.Path
Parse a JSON Path expression.
parse(String) - Static method in enum io.debezium.jdbc.TemporalPrecisionMode
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in class io.debezium.relational.ColumnId
Parse the supplied string delimited with a period (.) character, extracting the last segment into a column name and the prior segments into the TableID.
parse(String) - Static method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in class io.debezium.relational.TableId
Parse the supplied string, extracting up to the first 3 parts into a TableID.
parse(String) - Static method in class io.debezium.relational.TableIdParser
 
parse(String) - Static method in enum io.debezium.transforms.ExtractNewRecordStateConfigDefinition.DeleteHandling
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalFieldPlacement
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.InvalidOperationBehavior
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.JsonPayloadNullFieldBehavior
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.transforms.partitions.PartitionRouting.HashFunction
 
parse(String[], int, boolean) - Static method in class io.debezium.relational.TableId
Parse the supplied string, extracting up to the first 3 parts into a TableID.
parse(String, boolean) - Static method in interface io.debezium.document.Path
Parse a JSON Path expression.
parse(String, boolean) - Static method in class io.debezium.document.Paths
 
parse(String, boolean) - Static method in class io.debezium.relational.ColumnId
Parse the supplied string delimited with the specified delimiter character, extracting the last segment into a column name and the prior segments into the TableID.
parse(String, boolean) - Static method in class io.debezium.relational.TableId
Parse the supplied string, extracting up to the first 3 parts into a TableID.
parse(String, boolean, TableIdPredicates) - Static method in class io.debezium.relational.TableId
Parse the supplied string, extracting up to the first 3 parts into a TableID.
parse(String, TableIdPredicates) - Static method in class io.debezium.relational.TableId
Parse the supplied string, extracting up to the first 3 parts into a TableID.
parse(String, TableIdPredicates) - Static method in class io.debezium.relational.TableIdParser
 
parse(String, Tables) - Method in interface io.debezium.relational.ddl.DdlParser
Examine the supplied string containing DDL statements, and apply those statements to the specified database table definitions.
parse(String, String) - Static method in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
Determine if the supplied values is one of the predefined options
parse(String, String) - Static method in enum io.debezium.config.CommonConnectorConfig.Version
Determine if the supplied value is one of the predefined options.
parse(String, String) - Static method in enum io.debezium.jdbc.TemporalPrecisionMode
Determine if the supplied value is one of the predefined options.
parse(String, String) - Static method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
Determine if the supplied value is one of the predefined options.
parse(String, String) - Static method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder
Determine if the supplied value is one of the predefined options.
parse(String, String) - Static method in enum io.debezium.transforms.ExtractNewRecordStateConfigDefinition.DeleteHandling
Determine if the supplied value is one of the predefined options.
parseAdditionalFieldsConfig(Configuration) - Static method in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
parseArray(JsonParser, boolean) - Method in class io.debezium.document.JacksonReader
 
parseDefaultValue(Column, String) - Method in interface io.debezium.relational.DefaultValueConverter
This interface is used to convert the default value literal to a Java type recognized by value converters for a subset of types.
parseDocument(JsonParser, boolean) - Method in class io.debezium.document.JacksonReader
 
parseJson(String) - Static method in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
parseJsonPayload(String) - Method in class io.debezium.transforms.outbox.EventRouterDelegate
 
parseMappings(List<String>) - Static method in class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
parseParititionMappings(List<String>) - Static method in class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
parseParts(String) - Static method in class io.debezium.relational.TableId
Parse the supplied string into its tokenized parts.
parseParts(String, TableIdPredicates) - Static method in class io.debezium.relational.TableId
Parse the supplied string into its tokenized parts.
parseSegment(String, boolean) - Static method in class io.debezium.document.Paths
 
parseSignallingMessage(Struct) - Method in class io.debezium.config.CommonConnectorConfig
 
parseSqlStatementString(String) - Method in class io.debezium.jdbc.JdbcConnection
 
parseWKBPoint(byte[]) - Static method in class io.debezium.data.geometry.Point
Parses a 2D WKB Point into a {x,y} coordinate array.
ParsingContext(TokenStream.CharacterStream, TokenStream.Tokens, TableIdPredicates) - Constructor for class io.debezium.relational.TableIdParser.ParsingContext
 
ParsingException - Exception in io.debezium.text
An exception representing a problem during parsing of text.
ParsingException(Position) - Constructor for exception io.debezium.text.ParsingException
 
ParsingException(Position, String) - Constructor for exception io.debezium.text.ParsingException
 
ParsingException(Position, String, Throwable) - Constructor for exception io.debezium.text.ParsingException
 
ParsingState() - Constructor for enum io.debezium.relational.TableIdParser.ParsingState
 
partition - Variable in class io.debezium.pipeline.AbstractChangeRecordEmitter
 
partition - Variable in class io.debezium.pipeline.signal.SignalPayload
 
partition - Variable in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshotContext
 
partition - Variable in class io.debezium.schema.SchemaChangeEvent
 
Partition - Interface in io.debezium.pipeline.spi
Describes the source partition to be processed by the connector in connector-specific terms and provides its representation as a Kafka Connect source partition.
PARTITION - Enum constant in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalFieldPlacement
 
PARTITION_PAYLOAD_FIELDS_FIELD - Static variable in class io.debezium.transforms.partitions.PartitionRouting
 
PARTITION_TABLE_FIELD_NAME_MAPPINGS_FIELD - Static variable in class io.debezium.transforms.partitions.ComputePartitionConfigDefinition
Deprecated.
 
Partition.Provider<P extends Partition> - Interface in io.debezium.pipeline.spi
Implementations provide a set of connector-specific partitions based on the connector task configuration.
partitionNumber - Variable in class io.debezium.transforms.partitions.PartitionRouting
 
PartitionRouting<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.transforms.partitions
This SMT allow to use payload fields to calculate the destination partition.
PartitionRouting() - Constructor for class io.debezium.transforms.partitions.PartitionRouting
 
PartitionRouting.HashFunction - Enum in io.debezium.transforms.partitions
 
parts() - Method in class io.debezium.relational.TableId
 
passthrough() - Static method in interface io.debezium.relational.DefaultValueConverter
Obtain a DefaultValueConverter that passes through values.
passthrough() - Static method in interface io.debezium.relational.ValueConverter
Obtain a ValueConverter that passes through values.
PASSWORD - Static variable in interface io.debezium.jdbc.JdbcConfiguration
A field for the password of the database.
PASSWORD - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
PASSWORD_PATTERN - Static variable in interface io.debezium.config.Configuration
 
Path - Interface in io.debezium.document
A representation of multiple name segments that together form a path within Document.
PATH_SEPARATOR_PATTERN - Static variable in class io.debezium.document.Paths
 
Path.Segments - Interface in io.debezium.document
 
Paths - Class in io.debezium.document
A package-level utility that implements useful operations to create paths.
Paths() - Constructor for class io.debezium.document.Paths
 
Paths.ChildPath - Class in io.debezium.document
 
Paths.InnerPath - Interface in io.debezium.document
 
Paths.MultiSegmentPath - Class in io.debezium.document
 
Paths.RootPath - Class in io.debezium.document
 
Paths.SingleSegmentPath - Class in io.debezium.document
 
PATTERN_SPLIT - Static variable in class io.debezium.relational.Key.CustomKeyMapper
 
patternBasedFactory(String, Field...) - Static method in class io.debezium.jdbc.JdbcConnection
Create a JdbcConnection.ConnectionFactory that replaces variables in the supplied URL pattern.
patternBasedFactory(String, String, ClassLoader, Field...) - Static method in class io.debezium.jdbc.JdbcConnection
Create a JdbcConnection.ConnectionFactory that uses the specific JDBC driver class loaded with the given class loader, and obtains the connection URL by replacing the following variables in the URL pattern: ${hostname} ${port} ${dbname} ${username} ${password}
pause() - Method in interface io.debezium.util.Metronome
Pause until the next tick of the metronome.
PAUSE_BETWEEN_LOG_MESSAGES - Static variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
paused - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
Determines if the incremental snapshot was paused or not.
PAUSED - Enum constant in enum io.debezium.pipeline.notification.IncrementalSnapshotNotificationService.SnapshotStatus
 
pauseDuration - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
PauseIncrementalSnapshot<P extends Partition> - Class in io.debezium.pipeline.signal.actions.snapshotting
 
PauseIncrementalSnapshot(EventDispatcher<P, ? extends DataCollectionId>) - Constructor for class io.debezium.pipeline.signal.actions.snapshotting.PauseIncrementalSnapshot
 
pauseSnapshot() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
pauseSnapshot() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
pauseSnapshot(P, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
pauseSnapshot(P, OffsetContext) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
PAYLOAD_FIELD - Static variable in class io.debezium.serde.json.JsonSerde
 
PAYLOAD_FIELD_NAME - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
 
payloadFields - Variable in class io.debezium.transforms.partitions.PartitionRouting
 
payloadJson(Class<T>) - Static method in class io.debezium.serde.DebeziumSerdes
Provides a Serde implementation that maps JSON Debezium change events into a T Java object.
payloadSchemaCache - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
peek() - Method in class io.debezium.text.TokenStream
 
peek() - Method in interface io.debezium.util.Iterators.PreviewIterator
Peek at the next value without consuming or using it.
performedCatchUpStreaming - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator.CatchUpStreamingResult
 
perTableEventCount - Variable in class io.debezium.pipeline.txmetadata.TransactionContext
 
PipelineMetrics<P extends Partition> - Class in io.debezium.pipeline.metrics
Base for metrics implementations.
PipelineMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider, Map<String, String>) - Constructor for class io.debezium.pipeline.metrics.PipelineMetrics
 
PipelineMetrics(T, String, ChangeEventQueueMetrics, EventMetadataProvider) - Constructor for class io.debezium.pipeline.metrics.PipelineMetrics
 
PK_UPDATE_NEWKEY_FIELD - Static variable in class io.debezium.relational.RelationalChangeRecordEmitter
 
PK_UPDATE_OLDKEY_FIELD - Static variable in class io.debezium.relational.RelationalChangeRecordEmitter
 
pkColumnNames - Variable in class io.debezium.relational.TableEditorImpl
 
pkColumnNames - Variable in class io.debezium.relational.TableImpl
 
placement - Variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalField
 
PNCount - Interface in io.debezium.crdt
A read-only result of the state of a PNCounter.
PNCounter - Interface in io.debezium.crdt
A simple counter that maintains a single changing value by separately tracking the positive and negative changes.
Point - Class in io.debezium.data.geometry
A semantic type for a geometric Point, defined as a set of (x,y) coordinates.
Point() - Constructor for class io.debezium.data.geometry.Point
 
poll() - Method in class io.debezium.connector.base.ChangeEventQueue
Returns the next batch of elements from this queue.
poll() - Method in class io.debezium.connector.common.BaseSourceTask
 
POLL_INTERVAL_MS - Static variable in class io.debezium.config.CommonConnectorConfig
 
pollInterval - Variable in class io.debezium.config.CommonConnectorConfig
 
pollInterval - Variable in class io.debezium.connector.base.ChangeEventQueue.Builder
 
pollInterval - Variable in class io.debezium.connector.base.ChangeEventQueue
 
pollInterval(Duration) - Method in class io.debezium.connector.base.ChangeEventQueue.Builder
 
pollOutputDelay - Variable in class io.debezium.connector.common.BaseSourceTask
 
pollTimeoutMs - Variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
PORT - Static variable in interface io.debezium.jdbc.JdbcConfiguration
A field for the port of the database server.
PORT - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
position - Variable in class io.debezium.relational.ColumnEditorImpl
 
position - Variable in class io.debezium.relational.ColumnImpl
 
position - Variable in exception io.debezium.text.ParsingException
 
position - Variable in class io.debezium.text.TokenStream.CaseSensitiveToken
 
position - Variable in class io.debezium.text.TokenStream.Marker
 
position() - Method in interface io.debezium.relational.Column
Get the position of the column in the table.
position() - Method in interface io.debezium.relational.ColumnEditor
Get the position of the column in the table.
position() - Method in class io.debezium.relational.ColumnEditorImpl
 
position() - Method in class io.debezium.relational.ColumnImpl
 
position() - Method in class io.debezium.relational.history.HistoryRecord
 
position() - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
position() - Method in class io.debezium.text.TokenStream.Marker
Get the position of this marker, or null if this is at the start or end of the token stream.
position() - Method in interface io.debezium.text.TokenStream.Token
Get the position of this token, which includes the line number and column number of the first character in the token.
position(int) - Method in interface io.debezium.relational.ColumnEditor
Set the position of the column within the table definition.
position(int) - Method in class io.debezium.relational.ColumnEditorImpl
 
position(int) - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
position(int) - Method in interface io.debezium.text.TokenStream.CharacterStream
Get the position for the last character returned from TokenStream.CharacterStream.next().
Position - Class in io.debezium.text
A class that represents the position of a particular character in terms of the lines and columns of a character sequence.
Position(int, int, int) - Constructor for class io.debezium.text.Position
 
POSITION - Static variable in class io.debezium.relational.history.HistoryRecord.Fields
 
POSITION_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
positionInGroup - Variable in class io.debezium.config.Field.GroupEntry
 
positionsAreValid() - Method in class io.debezium.relational.TableEditorImpl
 
POSITIVE_INF - Static variable in class io.debezium.data.SpecialValueDecimal
 
POSITIVE_INFINITY - Enum constant in enum io.debezium.data.SpecialValueDecimal.SpecialValue
 
possibleNames - Variable in class io.debezium.config.Field.OneOfRecommender
 
POSTGRES_CONNECTOR - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
postIncrementalSnapshotCompleted() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
postReadChunk(IncrementalSnapshotContext<T>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
postSnapshot() - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
postSnapshotCompletion() - Method in class io.debezium.pipeline.CommonOffsetContext
 
postSnapshotCompletion() - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
postSnapshotCompletion() - Method in interface io.debezium.pipeline.spi.OffsetContext
Signals that a snapshot has been completed, which should reflect in an updated offset state.
PRECISE - Enum constant in enum io.debezium.jdbc.JdbcValueConverters.BigIntUnsignedMode
 
PRECISE - Enum constant in enum io.debezium.jdbc.JdbcValueConverters.DecimalMode
 
PRECISE - Enum constant in enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
Represent DECIMAL and NUMERIC values as precise BigDecimal values, which are represented in change events in a binary form.
PRECISION_PARAMETER_KEY - Static variable in class io.debezium.data.SpecialValueDecimal
Used as a schema parameter by the Avro serializer for creating a corresponding Avro schema with the correct precision.
predicate - Variable in class io.debezium.relational.mapping.ColumnMappers.MapperRule
 
predicates - Variable in class io.debezium.relational.TableIdParser.ParsingContext
 
predicates - Variable in class io.debezium.relational.TableIdParser.TableIdTokenizer
 
Predicates - Class in io.debezium.function
Utilities for constructing various predicates.
Predicates() - Constructor for class io.debezium.function.Predicates
 
preferDdl - Variable in class io.debezium.relational.history.AbstractSchemaHistory
 
prefix - Variable in class io.debezium.relational.ddl.DataTypeBuilder
 
prefix - Variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
prefix - Variable in class io.debezium.schema.TopicSelector
Deprecated.
 
prepare(P) - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
Prepares the taking of a snapshot and returns an initial AbstractSnapshotChangeEventSource.SnapshotContext.
prepareQuery(String) - Method in class io.debezium.jdbc.JdbcConnection
Executes a SQL query, preparing it if encountering it for the first time.
prepareQuery(String[], JdbcConnection.StatementPreparer[], JdbcConnection.BlockingMultiResultSetConsumer) - Method in class io.debezium.jdbc.JdbcConnection
Execute multiple SQL prepared queries where each query is executed with the same set of parameters.
prepareQuery(String[], JdbcConnection.StatementPreparer, JdbcConnection.BlockingMultiResultSetConsumer) - Method in class io.debezium.jdbc.JdbcConnection
Execute multiple SQL prepared queries where each query is executed with the same set of parameters.
prepareQuery(String, JdbcConnection.StatementPreparer, JdbcConnection.ResultSetConsumer) - Method in class io.debezium.jdbc.JdbcConnection
Execute a SQL prepared query.
prepareQuery(String, List<?>, JdbcConnection.ParameterResultSetConsumer) - Method in class io.debezium.jdbc.JdbcConnection
Execute a SQL prepared query.
prepareQueryAndMap(String, JdbcConnection.StatementPreparer, JdbcConnection.ResultSetMapper<T>) - Method in class io.debezium.jdbc.JdbcConnection
Execute a SQL prepared query and map the result set into an expected type..
prepareQueryWithBlockingConsumer(String, JdbcConnection.StatementPreparer, JdbcConnection.BlockingResultSetConsumer) - Method in class io.debezium.jdbc.JdbcConnection
Execute a SQL prepared query.
prepareTxBeginValue(OffsetContext, Instant) - Method in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
prepareTxEndValue(OffsetContext, Instant) - Method in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
prepareTxKey(OffsetContext) - Method in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
prepareTxStruct(OffsetContext, long, Struct) - Method in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
prepareUpdate(String, JdbcConnection.StatementPreparer) - Method in class io.debezium.jdbc.JdbcConnection
Execute a SQL update via a prepared statement.
preReadChunk(IncrementalSnapshotContext<T>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
preSnapshotCompletion() - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
preSnapshotCompletion() - Method in interface io.debezium.pipeline.spi.OffsetContext
Signals that a snapshot will complete, which should reflect in an updated offset state.
preSnapshotStart() - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel.EmptyOffsetContext
 
preSnapshotStart() - Method in interface io.debezium.pipeline.spi.OffsetContext
Signals that a snapshot will begin, which should reflect in an updated offset state.
pretty - Variable in class io.debezium.document.JacksonWriter
 
PRETTY_WRITER - Static variable in class io.debezium.document.JacksonWriter
 
prettyWriter() - Static method in interface io.debezium.document.ArrayWriter
Get the default ArrayWriter instance that outputs nicely-formatted JSON arrays.
prettyWriter() - Static method in interface io.debezium.document.DocumentWriter
Get the default DocumentWriter instance that outputs nicely-formatted JSON arrays.
preview(Iterator<T>) - Static method in class io.debezium.util.Iterators
Get a read-only iterator that can peek at the next value before it is retrieved with Iterator.next().
previous() - Method in class io.debezium.jdbc.CancellableResultSet
 
previousChangePosition - Variable in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
PreviousContext() - Constructor for class io.debezium.util.LoggingContext.PreviousContext
 
previousDatabaseName - Variable in class io.debezium.relational.ddl.DdlParserListener.DatabaseAlteredEvent
 
previousDatabaseName() - Method in class io.debezium.relational.ddl.DdlParserListener.DatabaseAlteredEvent
If the table was renamed, then get the old identifier of the table before it was renamed.
previousId - Variable in class io.debezium.relational.history.TableChanges.TableChange
 
previousInQueue - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
 
previousInStack - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
 
previousOffsets - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
previousOffsets - Variable in class io.debezium.pipeline.signal.SignalProcessor
 
previousOutputBatchSize - Variable in class io.debezium.connector.common.BaseSourceTask
 
previousOutputInstant - Variable in class io.debezium.connector.common.BaseSourceTask
 
previousPosition() - Method in class io.debezium.text.TokenStream
Get the position of the previous token.
previousPosition(int) - Method in class io.debezium.text.TokenStream
Get the position of a token earlier in the stream from the current position.
previousTableId - Variable in class io.debezium.relational.ddl.DdlParserListener.TableAlteredEvent
 
previousTableId() - Method in class io.debezium.relational.ddl.DdlParserListener.TableAlteredEvent
If the table was renamed, then get the old identifier of the table before it was renamed.
previousToken(int) - Method in class io.debezium.text.TokenStream
Get the previous token.
PRIMARY_KEY_COLUMN_NAMES_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
primaryKeyColumnNames() - Method in class io.debezium.relational.NoOpTableEditorImpl
 
primaryKeyColumnNames() - Method in interface io.debezium.relational.Table
The list of column names that make up the primary key for this table.
primaryKeyColumnNames() - Method in interface io.debezium.relational.TableEditor
The list of column names that make up the primary key for this table.
primaryKeyColumnNames() - Method in class io.debezium.relational.TableEditorImpl
 
primaryKeyColumnNames() - Method in class io.debezium.relational.TableImpl
 
primaryKeyColumns() - Method in interface io.debezium.relational.Table
Get the columns that make up the primary key for this table.
PRIME - Static variable in class io.debezium.util.HashCode
 
print(ResultSet) - Method in class io.debezium.jdbc.JdbcConnection
 
print(ResultSet, Consumer<String>) - Method in class io.debezium.jdbc.JdbcConnection
 
printSimpleValue(Object, Object) - Method in class io.debezium.pipeline.source.spi.EventFormatter
 
printStackTrace() - Method in exception io.debezium.text.MultipleParsingExceptions
 
printStackTrace(PrintStream) - Method in exception io.debezium.text.MultipleParsingExceptions
 
printStackTrace(PrintWriter) - Method in exception io.debezium.text.MultipleParsingExceptions
 
printStruct(Struct) - Method in class io.debezium.pipeline.source.spi.EventFormatter
 
priority - Variable in enum io.debezium.relational.SystemVariables.DefaultScope
 
priority() - Method in enum io.debezium.relational.SystemVariables.DefaultScope
 
priority() - Method in interface io.debezium.relational.SystemVariables.Scope
 
process() - Method in class io.debezium.pipeline.signal.SignalProcessor
 
process(Struct) - Method in class io.debezium.pipeline.signal.channels.SourceSignalChannel
Used in streaming flow to add signals from signaling table
processFilteredEvent(P, OffsetContext) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
processHeartbeat(P, OffsetContext) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
processMessage(Partition, DataCollectionId, Object, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.SignalBasedIncrementalSnapshotChangeEventSource
 
processMessage(P, DataCollectionId, Object, OffsetContext) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
processSchemaChange(P, OffsetContext, DataCollectionId) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
processSchemaChange(P, OffsetContext, DataCollectionId) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
processSignal(SignalRecord) - Method in class io.debezium.pipeline.signal.SignalProcessor
 
processSignal(ConsumerRecord<String, String>) - Method in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
processSourceSignal() - Method in class io.debezium.pipeline.signal.SignalProcessor
 
processTransactionCommittedEvent(P, OffsetContext) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
processTransactionStartedEvent(P, OffsetContext) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
producerException - Variable in class io.debezium.connector.base.ChangeEventQueue
 
producerException(RuntimeException) - Method in class io.debezium.connector.base.ChangeEventQueue
 
producerThrowable - Variable in class io.debezium.pipeline.ErrorHandler
 
progressListener - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
PROPAGATE_COLUMN_SOURCE_TYPE - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
PROPAGATE_DATATYPE_SOURCE_TYPE - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
propagateSourceTypeToSchemaParameter(String, String) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
 
PropagateSourceTypeToSchemaParameter - Class in io.debezium.relational.mapping
PropagateSourceTypeToSchemaParameter() - Constructor for class io.debezium.relational.mapping.PropagateSourceTypeToSchemaParameter
 
propagateSourceTypeToSchemaParameterByDatatype(String, String) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
 
propertiesOf(String, String) - Static method in class io.debezium.util.Collect
 
propertiesOf(String, String, String, String) - Static method in class io.debezium.util.Collect
 
propertiesOf(String, String, String, String, String, String) - Static method in class io.debezium.util.Collect
 
propertiesOf(String, String, String, String, String, String, String, String) - Static method in class io.debezium.util.Collect
 
propertiesOf(String, String, String, String, String, String, String, String, String, String) - Static method in class io.debezium.util.Collect
 
propertiesOf(String, String, String, String, String, String, String, String, String, String, String, String) - Static method in class io.debezium.util.Collect
 
props - Variable in class io.debezium.config.Configuration.Builder
 
props - Variable in class io.debezium.transforms.tracing.DebeziumTextMap
 
propsWithMaskedPassword(Properties) - Static method in class io.debezium.jdbc.JdbcConnection
 
PROVIDE_TRANSACTION_METADATA - Static variable in class io.debezium.config.CommonConnectorConfig
 
providers - Static variable in class io.debezium.converters.CloudEventsConverter
 
pruneStack(Set<BoundedConcurrentHashMap.HashEntry<K, V>>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
Prunes HIR blocks in the bottom of the stack until an HOT block sits in the stack bottom.
PUBID_CHARACTER - Static variable in class io.debezium.text.XmlCharacters
 
PURPOSE - Static variable in class io.debezium.transforms.ExtractNewRecordState
 
put(TableId, Table) - Method in class io.debezium.relational.Tables.TablesById
 
put(TableId, TableSchema) - Method in class io.debezium.relational.RelationalDatabaseSchema.SchemasByTableId
 
put(String, String) - Method in class io.debezium.transforms.tracing.DebeziumTextMap
 
put(K, int, V, boolean) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
put(K, V) - Method in class io.debezium.util.BoundedConcurrentHashMap
Maps the specified key to the specified value in this table.
put(K, V) - Method in class io.debezium.util.LRUCacheMap
 
putAll(Tables.TablesById) - Method in class io.debezium.relational.Tables.TablesById
 
putAll(Iterable<Array.Entry>) - Method in interface io.debezium.document.Array
Sets on this object all key/value pairs from the supplied map.
putAll(Iterable<Document.Field>) - Method in class io.debezium.document.BasicDocument
 
putAll(Iterable<Document.Field>) - Method in interface io.debezium.document.Document
Sets on this object all name/value pairs from the supplied object.
putAll(Iterable<Document.Field>, Predicate<CharSequence>) - Method in interface io.debezium.document.Document
Attempts to copy all of the acceptable fields from the source and set on this document, overwriting any existing values.
putAll(Iterator<Document.Field>) - Method in interface io.debezium.document.Document
Sets on this object all name/value pairs from the supplied object.
putAll(Map<? extends CharSequence, ?>) - Method in interface io.debezium.document.Document
Sets on this object all key/value pairs from the supplied map.
putAll(Map<? extends K, ? extends V>) - Method in class io.debezium.util.BoundedConcurrentHashMap
Copies all of the mappings from the specified map to this one.
putIfAbsent(K, V) - Method in class io.debezium.util.BoundedConcurrentHashMap

Q

query(String, JdbcConnection.ResultSetConsumer) - Method in class io.debezium.jdbc.JdbcConnection
Execute a SQL query.
query(String, JdbcConnection.StatementFactory, JdbcConnection.ResultSetConsumer) - Method in class io.debezium.jdbc.JdbcConnection
Execute a SQL query.
QUERY_FETCH_SIZE - Static variable in class io.debezium.config.CommonConnectorConfig
 
queryAndMap(String, JdbcConnection.ResultSetMapper<T>) - Method in class io.debezium.jdbc.JdbcConnection
Execute a SQL query and map the result set into an expected type.
queryAndMap(String, JdbcConnection.StatementFactory, JdbcConnection.ResultSetMapper<T>) - Method in class io.debezium.jdbc.JdbcConnection
Execute a SQL query and map the result set into an expected type.
queryFetchSize - Variable in class io.debezium.config.CommonConnectorConfig
 
querySingleValue(Connection, String, JdbcConnection.StatementPreparer, JdbcConnection.ResultSetExtractor<T>) - Static method in class io.debezium.jdbc.JdbcConnection
 
queryWithBlockingConsumer(String, JdbcConnection.StatementFactory, JdbcConnection.BlockingResultSetConsumer) - Method in class io.debezium.jdbc.JdbcConnection
 
queue - Variable in class io.debezium.connector.base.ChangeEventQueue
 
queue - Variable in class io.debezium.pipeline.ErrorHandler
 
queue - Variable in class io.debezium.pipeline.EventDispatcher
 
queueEnd() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
Returns the entry at the end of the queue.
queueFront() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
Returns the entry at the front of the queue.
QueueMetricsMXBean - Interface in io.debezium.pipeline.metrics.traits
Exposes queue metrics.
quote(String, char) - Static method in class io.debezium.relational.TableId
Quotes the given identifier part, e.g.
quotedColumnIdString(String) - Method in class io.debezium.jdbc.JdbcConnection
Prepares qualified column names with appropriate quote character as per the specific database's rules.
quotedTableIdString(TableId) - Method in class io.debezium.jdbc.JdbcConnection
Converts a table id into a string with all components of the id quoted so non-alphanumeric characters are properly handled.
quotingChar - Variable in class io.debezium.relational.TableIdParser.ParsingContext
 

R

randomlySelect(T...) - Static method in class io.debezium.util.Sequences
Obtain a supplier function that randomly selects from the given values.
randomlySelect(T, T...) - Static method in class io.debezium.util.Sequences
Obtain a supplier function that randomly selects from the given values.
RangeValidator(Number, Number) - Constructor for class io.debezium.config.Field.RangeValidator
 
read() - Method in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
read() - Method in class io.debezium.pipeline.signal.channels.jmx.JmxSignalChannel
 
read() - Method in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
read() - Method in interface io.debezium.pipeline.signal.channels.SignalChannelReader
 
read() - Method in class io.debezium.pipeline.signal.channels.SourceSignalChannel
 
read(byte[]) - Method in interface io.debezium.document.DocumentReader
Read a document from the supplied bytes.
read(byte[]) - Method in class io.debezium.document.JacksonReader
 
read(File) - Method in interface io.debezium.document.DocumentReader
Read a document from the supplied file.
read(File) - Method in class io.debezium.document.JacksonReader
 
read(File) - Static method in class io.debezium.util.IoUtil
Read and return the entire contents of the supplied File.
read(InputStream) - Method in interface io.debezium.document.DocumentReader
Read a document from the supplied stream.
read(InputStream) - Method in class io.debezium.document.JacksonReader
 
read(InputStream) - Static method in class io.debezium.util.IoUtil
Read and return the entire contents of the supplied InputStream.
read(InputStream, String) - Static method in class io.debezium.util.IoUtil
Read and return the entire contents of the supplied InputStream.
read(Reader) - Method in interface io.debezium.document.DocumentReader
Read a document from the supplied Reader.
read(Reader) - Method in class io.debezium.document.JacksonReader
 
read(Reader) - Static method in class io.debezium.util.IoUtil
Read and return the entire contents of the supplied Reader.
read(Object, Struct, Instant) - Method in class io.debezium.data.Envelope
Generate a read message with the given information.
read(Runnable) - Method in class io.debezium.util.FunctionalReadWriteLock
Obtain a read lock, perform the operation, and release the lock.
read(String) - Method in interface io.debezium.document.DocumentReader
Read a document from the supplied JSON-formatted string.
read(String) - Method in class io.debezium.document.JacksonReader
 
read(URL) - Method in interface io.debezium.document.DocumentReader
Read a document from the content at the given URL.
read(URL) - Method in class io.debezium.document.JacksonReader
 
read(Supplier<T>) - Method in class io.debezium.util.FunctionalReadWriteLock
Obtain a read lock, perform the operation, and release the read lock.
READ - Enum constant in enum io.debezium.data.Envelope.Operation
The operation that read the current state of a record, most typically during snapshots.
readAllCatalogNames() - Method in class io.debezium.jdbc.JdbcConnection
Get the names of all of the catalogs.
readAllSchemaNames(Predicate<String>) - Method in class io.debezium.jdbc.JdbcConnection
Get the names of all of the schemas, optionally applying a filter.
readAllTableNames(String[]) - Method in class io.debezium.jdbc.JdbcConnection
Get the identifiers of all available tables.
readArray(byte[]) - Method in interface io.debezium.document.ArrayReader
Read an array from the supplied bytes.
readArray(File) - Method in interface io.debezium.document.ArrayReader
Read an array from the supplied file.
readArray(File) - Method in class io.debezium.document.JacksonReader
 
readArray(InputStream) - Method in interface io.debezium.document.ArrayReader
Read an array from the supplied stream.
readArray(InputStream) - Method in class io.debezium.document.JacksonReader
 
readArray(Reader) - Method in interface io.debezium.document.ArrayReader
Read an array from the supplied Reader.
readArray(Reader) - Method in class io.debezium.document.JacksonReader
 
readArray(String) - Method in interface io.debezium.document.ArrayReader
Read an array from the supplied JSON-formatted string.
readArray(String) - Method in class io.debezium.document.JacksonReader
 
readArray(URL) - Method in interface io.debezium.document.ArrayReader
Read an array from the content at the given URL.
readArray(URL) - Method in class io.debezium.document.JacksonReader
 
readBytes(File) - Static method in class io.debezium.util.IoUtil
Read and return the entire contents of the supplied file.
readBytes(InputStream) - Static method in class io.debezium.util.IoUtil
Read and return the entire contents of the supplied stream.
readChunk(P, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
readClassPathResource(String) - Static method in class io.debezium.util.IoUtil
Read a resource on classpath as a String
reader - Variable in class io.debezium.connector.common.OffsetReader
 
reader - Variable in class io.debezium.serde.json.JsonSerde
 
readKey(JsonNode) - Method in class io.debezium.serde.json.JsonSerde.JsonDeserializer
 
readLines(InputStream, Consumer<String>) - Static method in class io.debezium.util.IoUtil
Read the lines from the supplied stream.
readLines(InputStream, Consumer<String>, Charset) - Static method in class io.debezium.util.IoUtil
Read the lines from the supplied stream.
readLines(String, ClassLoader, Class<?>, Consumer<String>) - Static method in class io.debezium.util.IoUtil
Read the lines from the content of the resource file at the given path on the classpath.
readLines(Path, Consumer<String>) - Static method in class io.debezium.util.IoUtil
Read the lines from the supplied stream.
readObject(ObjectInputStream) - Method in class io.debezium.util.BoundedConcurrentHashMap
Reconstitute the ConcurrentHashMap instance from a stream (i.e., deserialize it).
readOnly(Iterable<T>) - Static method in class io.debezium.util.Iterators
 
readOnly(Iterable<V>, Function<V, T>) - Static method in class io.debezium.util.Iterators
 
readOnly(Iterator<? extends V>, Function<V, T>) - Static method in class io.debezium.util.Iterators
 
readOnly(Iterator<T>) - Static method in class io.debezium.util.Iterators
 
ReadOnly - Annotation Type in io.debezium.annotation
Annotation that can be used to specify that the target field, method, constructor, package or type is read-only.
readOnlyIterable(Iterable<? extends V>, Function<V, T>) - Static method in class io.debezium.util.Iterators
 
readOnlyIterable(Iterable<T>) - Static method in class io.debezium.util.Iterators
 
readPrimaryKeyNames(DatabaseMetaData, TableId) - Method in class io.debezium.jdbc.JdbcConnection
 
readPrimaryKeyOrUniqueIndexNames(DatabaseMetaData, TableId) - Method in class io.debezium.jdbc.JdbcConnection
 
readSchema() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
readSchema(Tables, String, String, Tables.TableFilter, Tables.ColumnNameFilter, boolean) - Method in class io.debezium.jdbc.JdbcConnection
Create definitions for each tables in the database, given the catalog name, schema pattern, table filter, and column filter.
readSignalString(String) - Method in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
readTableChunkStatement(String) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
readTableColumn(ResultSet, TableId, Tables.ColumnNameFilter) - Method in class io.debezium.jdbc.JdbcConnection
Returns a ColumnEditor representing the current record of the given result set of column metadata, if included in column.include.list.
readTableNames(String, String, String, String[]) - Method in class io.debezium.jdbc.JdbcConnection
Get the identifiers of the tables.
readTablePreparedStatement(CommonConnectorConfig, String, OptionalLong) - Method in class io.debezium.jdbc.JdbcConnection
Allow per-connector prepared query creation to override for best database performance depending on the table size.
readTableStatement(CommonConnectorConfig, OptionalLong) - Method in class io.debezium.jdbc.JdbcConnection
Allow per-connector query creation to override for best database performance depending on the table size.
readTableStatement(JdbcConnection, OptionalLong) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Allow per-connector query creation to override for best database performance depending on the table size.
readTableStructure(ChangeEventSource.ChangeEventSourceContext, RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>, O) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Reads the structure of all the captured tables, writing it to RelationalSnapshotChangeEventSource.RelationalSnapshotContext.tables.
readTableUniqueIndices(DatabaseMetaData, TableId) - Method in class io.debezium.jdbc.JdbcConnection
 
readValue(JsonNode) - Method in class io.debezium.serde.json.JsonSerde.JsonDeserializer
 
readValueUnderLock(BoundedConcurrentHashMap.HashEntry<K, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
Reads value field of an entry under lock.
Recency() - Constructor for enum io.debezium.util.BoundedConcurrentHashMap.Recency
 
recommender - Variable in class io.debezium.config.Field
 
recommender() - Method in class io.debezium.config.Field
Get the Field.Recommender for this field.
reconvertData(String, byte[], SerializerType, Boolean) - Method in class io.debezium.converters.CloudEventsConverter
 
record - Variable in class io.debezium.converters.spi.RecordParser
 
record - Variable in class io.debezium.pipeline.DataChangeEvent
 
record(SchemaChangeEvent, TableChanges) - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
Records the given schema change event in the persistent history.
record(Map<String, ?>, Map<String, ?>, String, String) - Method in class io.debezium.relational.history.AbstractSchemaHistory
 
record(Map<String, ?>, Map<String, ?>, String, String) - Method in interface io.debezium.relational.history.SchemaHistory
Record a change to the schema of the named database, and store it in the schema storage.
record(Map<String, ?>, Map<String, ?>, String, String, String, TableChanges, Instant) - Method in class io.debezium.relational.history.AbstractSchemaHistory
 
record(Map<String, ?>, Map<String, ?>, String, String, String, TableChanges, Instant) - Method in interface io.debezium.relational.history.SchemaHistory
 
RECORD_ENVELOPE_KEY_SCHEMA_NAME_SUFFIX - Static variable in class io.debezium.transforms.SmtManager
 
recordParser - Variable in class io.debezium.converters.spi.CloudEventsMaker
 
RecordParser - Class in io.debezium.converters.spi
An abstract parser of change records.
RecordParser(Schema, Struct, String...) - Constructor for class io.debezium.converters.spi.RecordParser
 
records - Variable in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
records - Variable in class io.debezium.relational.history.MemorySchemaHistory
 
RecordWriter() - Constructor for class io.debezium.data.SchemaUtil.RecordWriter
 
recover(Offsets<?, ?>) - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
recover(Offsets<?, ?>) - Method in interface io.debezium.schema.HistorizedDatabaseSchema
 
recover(Offsets<?, ?>, Tables, DdlParser) - Method in interface io.debezium.relational.history.SchemaHistory
Recover the database schema to a known point in its history.
recover(Partition, OffsetContext) - Method in interface io.debezium.schema.HistorizedDatabaseSchema
 
recover(Map<String, ?>, Map<String, ?>, Tables, DdlParser) - Method in interface io.debezium.relational.history.SchemaHistory
recover(Map<Map<String, ?>, Map<String, ?>>, Tables, DdlParser) - Method in class io.debezium.relational.history.AbstractSchemaHistory
 
recover(Map<Map<String, ?>, Map<String, ?>>, Tables, DdlParser) - Method in interface io.debezium.relational.history.SchemaHistory
recoveredTables - Variable in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
RECOVERING - Enum constant in enum io.debezium.relational.history.SchemaHistoryMetrics.SchemaHistoryStatus
 
recoverRecords(Consumer<HistoryRecord>) - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
recoverRecords(Consumer<HistoryRecord>) - Method in class io.debezium.relational.history.AbstractSchemaHistory
 
recoverRecords(Consumer<HistoryRecord>) - Method in class io.debezium.relational.history.MemorySchemaHistory
 
recoveryStarted() - Method in interface io.debezium.relational.history.SchemaHistoryListener
 
recoveryStarted() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
recoveryStartTime - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
recoveryStopped() - Method in interface io.debezium.relational.history.SchemaHistoryListener
 
recoveryStopped() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
reentrant() - Static method in class io.debezium.util.FunctionalReadWriteLock
Create a read-write lock that supports reentrancy.
REFERENCE_SIZE - Static variable in class io.debezium.util.ApproximateStructSizeCalculator
 
refresh(Table) - Method in class io.debezium.relational.RelationalDatabaseSchema
Refreshes the schema content with a table constructed externally
refreshRow() - Method in class io.debezium.jdbc.CancellableResultSet
 
refreshSchema(TableId) - Method in class io.debezium.relational.RelationalDatabaseSchema
 
refreshTableSchema(Table) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
regexRouter - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
RegExSplitter() - Constructor for class io.debezium.util.Strings.RegExSplitter
 
register() - Method in class io.debezium.metrics.Metrics
Registers a metrics MBean into the platform MBean server.
register() - Method in interface io.debezium.pipeline.metrics.ChangeEventSourceMetrics
 
registerConverterFor(TableId, Column, Object) - Method in class io.debezium.relational.CustomConverterRegistry
Create and register a converter for a given database column.
registered - Variable in class io.debezium.metrics.Metrics
 
registerMXBean(Object, CommonConnectorConfig, String, String) - Static method in class io.debezium.pipeline.JmxUtils
 
registerMXBean(ObjectName, Object) - Static method in class io.debezium.pipeline.JmxUtils
 
registerSignalAction(String, SignalAction<P>) - Method in class io.debezium.pipeline.signal.SignalProcessor
 
REGISTRATION_RETRIES - Static variable in class io.debezium.pipeline.JmxUtils
 
REGISTRATION_RETRY_DELAY - Static variable in class io.debezium.pipeline.JmxUtils
 
rehash() - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
RelationalBaseSourceConnector - Class in io.debezium.connector.common
Base class for Debezium's relational CDC SourceConnector implementations.
RelationalBaseSourceConnector() - Constructor for class io.debezium.connector.common.RelationalBaseSourceConnector
 
RelationalChangeRecordEmitter<P extends Partition> - Class in io.debezium.relational
Base class for ChangeRecordEmitter implementations based on a relational database.
RelationalChangeRecordEmitter(P, OffsetContext, Clock, RelationalDatabaseConnectorConfig) - Constructor for class io.debezium.relational.RelationalChangeRecordEmitter
 
RelationalDatabaseConnectorConfig - Class in io.debezium.relational
Configuration options shared across the relational CDC connectors.
RelationalDatabaseConnectorConfig(Configuration, Tables.TableFilter, Selectors.TableIdToStringMapper, int, ColumnFilterMode, boolean) - Constructor for class io.debezium.relational.RelationalDatabaseConnectorConfig
 
RelationalDatabaseConnectorConfig.DecimalHandlingMode - Enum in io.debezium.relational
The set of predefined DecimalHandlingMode options or aliases.
RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder - Enum in io.debezium.relational
The set of predefined DecimalHandlingMode options or aliases.
RelationalDatabaseSchema - Class in io.debezium.relational
A DatabaseSchema of a relational database such as Postgres.
RelationalDatabaseSchema(RelationalDatabaseConnectorConfig, TopicNamingStrategy<TableId>, Tables.TableFilter, Tables.ColumnNameFilter, TableSchemaBuilder, boolean, Key.KeyMapper) - Constructor for class io.debezium.relational.RelationalDatabaseSchema
 
RelationalDatabaseSchema.SchemasByTableId - Class in io.debezium.relational
A map of schemas by table id.
RelationalSnapshotChangeEventSource<P extends Partition,O extends OffsetContext> - Class in io.debezium.relational
Base class for SnapshotChangeEventSource for relational databases with or without a schema history.
RelationalSnapshotChangeEventSource(RelationalDatabaseConnectorConfig, MainConnectionProvidingConnectionFactory<? extends JdbcConnection>, RelationalDatabaseSchema, EventDispatcher<P, TableId>, Clock, SnapshotProgressListener<P>) - Constructor for class io.debezium.relational.RelationalSnapshotChangeEventSource
 
RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P extends Partition,O extends OffsetContext> - Class in io.debezium.relational
Mutable context which is populated in the course of snapshotting.
RelationalSnapshotContext(P, String) - Constructor for class io.debezium.relational.RelationalSnapshotChangeEventSource.RelationalSnapshotContext
 
RelationalTableFilters - Class in io.debezium.relational
 
RelationalTableFilters(Configuration, Tables.TableFilter, Selectors.TableIdToStringMapper, boolean) - Constructor for class io.debezium.relational.RelationalTableFilters
 
relative(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
releaseDataSnapshotLocks(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Releases all locks established in order to create a consistent data snapshot.
releaseSchemaSnapshotLocks(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
Releases all locks established in order to create a consistent schema snapshot.
remaining() - Method in interface io.debezium.util.Threads.Timer
 
remainingCapacity() - Method in class io.debezium.connector.base.ChangeEventQueue
 
remainingCapacity() - Method in interface io.debezium.connector.base.ChangeEventQueueMetrics
 
remainingTables - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
remove() - Method in class io.debezium.util.BoundedConcurrentHashMap.HashIterator
 
remove() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Removes this entry from the cache.
remove(int) - Method in interface io.debezium.document.Array
Remove the specified entry from this array
remove(int) - Method in class io.debezium.document.BasicArray
 
remove(TableId) - Method in class io.debezium.relational.RelationalDatabaseSchema.SchemasByTableId
 
remove(TableId) - Method in class io.debezium.relational.Tables.TablesById
 
remove(CharSequence) - Method in class io.debezium.document.BasicDocument
 
remove(CharSequence) - Method in interface io.debezium.document.Document
Remove the field with the supplied name, and return the value.
remove(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap.EntrySet
 
remove(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap.KeySet
 
remove(Object) - Method in class io.debezium.util.BoundedConcurrentHashMap
Removes the key (and its corresponding value) from this map.
remove(Object, int, Object) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
Remove; match on key only if value null, else match both.
remove(Object, Object) - Method in class io.debezium.util.BoundedConcurrentHashMap
remove(Optional<? extends CharSequence>) - Method in interface io.debezium.document.Document
If the supplied name is provided, then remove the field with the supplied name and return the value.
remove(K) - Method in class io.debezium.util.LRUCacheMap
 
removeAll() - Method in interface io.debezium.document.Array
Remove all entries from this array.
removeAll() - Method in class io.debezium.document.BasicArray
 
removeAll() - Method in class io.debezium.document.BasicDocument
 
removeAll() - Method in interface io.debezium.document.Document
Remove all fields from this document.
removeAttribute(String) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
removeAttribute(String) - Method in interface io.debezium.relational.TableEditor
Remove an attribute from this table.
removeAttribute(String) - Method in class io.debezium.relational.TableEditorImpl
 
removeColumn(String) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
removeColumn(String) - Method in interface io.debezium.relational.TableEditor
Remove the column with the given name.
removeColumn(String) - Method in class io.debezium.relational.TableEditorImpl
 
removeDataCollectionFromSnapshot(String) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
removeDataCollectionFromSnapshot(String) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
removedDelegate - Variable in class io.debezium.transforms.ExtractNewRecordState
 
removeDelimiter() - Method in class io.debezium.pipeline.source.spi.EventFormatter
 
removeEldestEntry(Map.Entry<BoundedConcurrentHashMap.HashEntry<K, V>, V>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
removeFromQueue() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Removes this entry from the queue.
removeFromSegment(Set<BoundedConcurrentHashMap.HashEntry<K, V>>) - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
removeFromStack() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Removes this entry from the stack.
removeHeaders(Headers) - Method in class io.debezium.transforms.HeaderToValue
 
removeLineFeeds(String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Removes line feeds from input string.
removes - Variable in class io.debezium.crdt.StateBasedPNCounter
 
removeSchema(TableId) - Method in class io.debezium.relational.RelationalDatabaseSchema
 
removeTable(TableId) - Method in class io.debezium.relational.Tables
Remove the definition of the identified table.
removeTablesForDatabase(String) - Method in class io.debezium.relational.Tables
 
removeTablesForDatabase(String, String) - Method in class io.debezium.relational.Tables
 
rename(Table, TableId) - Method in class io.debezium.relational.history.TableChanges
 
renameColumn(String, String) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
renameColumn(String, String) - Method in interface io.debezium.relational.TableEditor
Rename the column with the given name to the new specified name.
renameColumn(String, String) - Method in class io.debezium.relational.TableEditorImpl
 
renameTable(TableId, TableId) - Method in class io.debezium.relational.Tables
Rename an existing table.
reorderColumn(String, String) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
reorderColumn(String, String) - Method in interface io.debezium.relational.TableEditor
Reorder the column with the given name to be positioned after the designated column.
reorderColumn(String, String) - Method in class io.debezium.relational.TableEditorImpl
 
repeat(char) - Static method in class io.debezium.relational.TableId
 
replace(char) - Method in class io.debezium.schema.FieldNameUnderscoreReplacementFunction
 
replace(char) - Method in class io.debezium.schema.UnicodeReplacementFunction
 
replace(K, int, V) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
replace(K, int, V, V) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
replace(K, V) - Method in class io.debezium.util.BoundedConcurrentHashMap
replace(K, V, V) - Method in class io.debezium.util.BoundedConcurrentHashMap
replacement - Variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
REPLACEMENT_CHAR - Static variable in class io.debezium.schema.TopicSelector.TopicNameSanitizer
Deprecated.
 
replaceVariables(String, Function<String, String>) - Static method in class io.debezium.util.Strings
Look in the supplied value for variables and replace them with values from the supplied lookup function.
replaceVariablesWith(Function<String, String>) - Static method in class io.debezium.util.Strings
Obtain a function that will replace variables in the supplied value with values from the supplied lookup function.
requireContextField - Variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
required() - Method in class io.debezium.config.Field
 
rereadChunk(P, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
reset() - Method in interface io.debezium.crdt.DeltaCounter
Start a new interval and reset the DeltaCount.getChanges() to initial values.
reset() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
reset() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
reset() - Method in class io.debezium.pipeline.meters.ConnectionMeter
 
reset() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
reset() - Method in class io.debezium.pipeline.meters.StreamingMeter
 
reset() - Method in interface io.debezium.pipeline.metrics.ChangeEventSourceMetricsMXBean
 
reset() - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
reset() - Method in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
reset() - Method in class io.debezium.pipeline.metrics.PipelineMetrics
 
reset() - Method in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
reset() - Method in interface io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannelMXBean
 
reset() - Method in class io.debezium.pipeline.txmetadata.TransactionContext
 
reset() - Method in class io.debezium.relational.ddl.DataTypeBuilder
 
reset() - Method in class io.debezium.relational.ddl.DdlChanges
Clear all accumulated changes.
reset() - Method in interface io.debezium.util.Threads.TimeSince
Reset the elapsed time to 0.
reset(Object) - Method in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
reset(Object) - Method in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
reset(T) - Method in interface io.debezium.pipeline.signal.channels.SignalChannelReader
 
resetChunk() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
resetHeartbeat() - Method in class io.debezium.heartbeat.HeartbeatImpl
 
resetOffset(P) - Method in class io.debezium.pipeline.spi.Offsets
 
resetRetries() - Method in class io.debezium.pipeline.ErrorHandler
 
resolveCatalogName(String) - Method in class io.debezium.jdbc.JdbcConnection
 
resolveJdbcType(int, int) - Method in class io.debezium.jdbc.JdbcConnection
Resolves the supplied metadata JDBC type to a final JDBC type.
resolveNativeType(String) - Method in class io.debezium.jdbc.JdbcConnection
Provides a native type for the given type name.
resolveOpenTracingApiAvailable() - Static method in class io.debezium.transforms.tracing.ActivateTracingSpan
 
resolveTableId(String, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Create a TableId from the supplied schema and table names.
restartDelay - Variable in class io.debezium.connector.common.BaseSourceTask
 
RESTARTING - Enum constant in enum io.debezium.connector.common.BaseSourceTask.State
 
restore() - Method in class io.debezium.util.LoggingContext.PreviousContext
Restore this logging context.
ResultReceiver - Interface in io.debezium.jdbc
This interface allows the code to optionally pass a value between two parts of the application.
resultSet - Variable in class io.debezium.jdbc.CancellableResultSet
 
resultSet - Variable in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
RESUMED - Enum constant in enum io.debezium.pipeline.notification.IncrementalSnapshotNotificationService.SnapshotStatus
 
ResumeIncrementalSnapshot<P extends Partition> - Class in io.debezium.pipeline.signal.actions.snapshotting
 
ResumeIncrementalSnapshot(EventDispatcher<P, ? extends DataCollectionId>) - Constructor for class io.debezium.pipeline.signal.actions.snapshotting.ResumeIncrementalSnapshot
 
resumeSnapshot() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
resumeSnapshot() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
resumeSnapshot(P, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
resumeSnapshot(P, OffsetContext) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
RETRIABLE_RESTART_WAIT - Static variable in class io.debezium.config.CommonConnectorConfig
 
retriableRestartWait - Variable in class io.debezium.config.CommonConnectorConfig
 
retriableRestartWait - Variable in class io.debezium.connector.common.BaseSourceTask
 
retries - Variable in class io.debezium.pipeline.ErrorHandler
 
RETRIES_BEFORE_LOCK - Static variable in class io.debezium.util.BoundedConcurrentHashMap
Number of unsynchronized retries in size and containsValue methods before resorting to locking.
RETRIES_DISABLED - Static variable in class io.debezium.pipeline.ErrorHandler
 
RETRIES_UNLIMITED - Static variable in class io.debezium.pipeline.ErrorHandler
 
retrieveColumnNames() - Method in interface io.debezium.relational.Table
The list of column names that make up this table.
retrieveColumnNames() - Method in class io.debezium.relational.TableImpl
 
RETURN_CONTROL_INTERVAL - Static variable in class io.debezium.config.ConfigurationDefaults
The maximum wait time before poll() return control back to Connect when no events are available.
reusable() - Static method in class io.debezium.util.Stopwatch
Create a new Stopwatch that can be reused.
revertChunk() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
revertChunk() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
rewind() - Method in class io.debezium.text.TokenStream
Method to allow tokens to be re-used from the start without re-tokenizing content.
rewind(TokenStream.Marker) - Method in class io.debezium.text.TokenStream
Reset the stream back to the position described by the supplied marker.
REWRITE - Enum constant in enum io.debezium.transforms.ExtractNewRecordStateConfigDefinition.DeleteHandling
 
RIGHT - Enum constant in enum io.debezium.util.Strings.Justify
 
rollback() - Method in class io.debezium.jdbc.JdbcConnection
 
rollbackTransaction(Connection) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
root() - Static method in interface io.debezium.document.Path
Get the zero-length path.
ROOT_FIELD_NAME - Static variable in class io.debezium.transforms.HeaderToValue
 
RootPath() - Constructor for class io.debezium.document.Paths.RootPath
 
ROUTE_BY_FIELD - Static variable in class io.debezium.transforms.ExtractNewRecordStateConfigDefinition
 
ROUTE_BY_FIELD - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
ROUTE_TOMBSTONE_ON_EMPTY_PAYLOAD - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
ROUTE_TOPIC_REGEX - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
ROUTE_TOPIC_REPLACEMENT - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
routeByField - Variable in class io.debezium.transforms.ExtractNewRecordState
 
routeByField - Variable in class io.debezium.transforms.outbox.EventRouterDelegate.DefaultConfigurationProvider
 
routeTombstoneOnEmptyPayload - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
row - Variable in class io.debezium.relational.SnapshotChangeRecordEmitter
 
rowCountForTable(TableId) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
If connector is able to provide statistics-based number of records per table.
rowDeleted() - Method in class io.debezium.jdbc.CancellableResultSet
 
rowInserted() - Method in class io.debezium.jdbc.CancellableResultSet
 
rowsScanned - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
rowsScanned(TableId, long) - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
rowsScanned(P, TableId, long) - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
rowsScanned(P, TableId, long) - Method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
rowToArray(Table, ResultSet, ColumnUtils.ColumnArray) - Method in class io.debezium.jdbc.JdbcConnection
Converts a ResultSet row to an array of Objects
rowUpdated() - Method in class io.debezium.jdbc.CancellableResultSet
 
rules - Variable in class io.debezium.relational.mapping.ColumnMappers.Builder
 
rules - Variable in class io.debezium.relational.mapping.ColumnMappers
 
running - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
running - Variable in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
RUNNING - Enum constant in enum io.debezium.connector.common.BaseSourceTask.State
 
RUNNING - Enum constant in enum io.debezium.relational.history.SchemaHistoryMetrics.SchemaHistoryStatus
 

S

salt - Variable in class io.debezium.relational.mapping.MaskStrings.HashValueConverter
 
sanitizedTopicName(String) - Method in class io.debezium.schema.AbstractTopicNamingStrategy
 
sb - Variable in class io.debezium.data.SchemaUtil.RecordWriter
 
scale - Variable in class io.debezium.relational.ColumnEditorImpl
 
scale - Variable in class io.debezium.relational.ColumnImpl
 
scale - Variable in class io.debezium.relational.ddl.DataType
 
scale - Variable in class io.debezium.relational.ddl.DataTypeBuilder
 
scale() - Method in interface io.debezium.relational.Column
Get the scale of the column.
scale() - Method in interface io.debezium.relational.ColumnEditor
Get the scale of the column.
scale() - Method in class io.debezium.relational.ColumnEditorImpl
 
scale() - Method in class io.debezium.relational.ColumnImpl
 
scale() - Method in class io.debezium.relational.ddl.DataType
 
scale(int) - Method in class io.debezium.relational.ddl.DataTypeBuilder
 
scale(Integer) - Method in interface io.debezium.relational.ColumnEditor
Set the scale of the column.
scale(Integer) - Method in class io.debezium.relational.ColumnEditorImpl
 
SCALE_FIELD - Static variable in class io.debezium.data.VariableScaleDecimal
 
SCALE_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
schema - Variable in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
 
schema - Variable in class io.debezium.data.Envelope
 
schema - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
schema - Variable in class io.debezium.pipeline.EventDispatcher
 
schema - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
schema - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
schema - Variable in class io.debezium.schema.SchemaChangeEvent
 
schema() - Method in class io.debezium.connector.AbstractSourceInfo
Returns the schema of specific sub-types.
schema() - Method in interface io.debezium.connector.SourceInfoStructMaker
Returns the schema of the source info.
schema() - Method in class io.debezium.data.Envelope
Get the Schema describing the message envelopes and their content.
schema() - Static method in class io.debezium.data.geometry.Geometry
Returns a SchemaBuilder for a Geometry field, with all other default Schema settings.
schema() - Static method in class io.debezium.data.Json
Returns a SchemaBuilder for a JSON field, with all other default Schema settings.
schema() - Static method in class io.debezium.data.Uuid
Returns a SchemaBuilder for a Uuid field, with all other default Schema settings.
schema() - Static method in class io.debezium.data.VariableScaleDecimal
Returns a Schema for a VariableScaleDecimal but with all other default Schema settings.
schema() - Static method in class io.debezium.data.Xml
Returns a SchemaBuilder for an XML field, with all other default Schema settings.
schema() - Method in class io.debezium.relational.ColumnId
Get the name of the JDBC schema.
schema() - Method in class io.debezium.relational.TableId
Get the name of the JDBC schema.
schema() - Static method in class io.debezium.time.Date
Returns a Schema for a Date but with all other default Schema settings.
schema() - Static method in class io.debezium.time.Interval
Returns a Schema for a Interval but with all other default Schema settings.
schema() - Static method in class io.debezium.time.MicroDuration
Returns a Schema for a MicroDuration but with all other default Schema settings.
schema() - Static method in class io.debezium.time.MicroTime
Returns a Schema for a MicroTime but with all other default Schema settings.
schema() - Static method in class io.debezium.time.MicroTimestamp
Returns a Schema for a MicroTimestamp but with all other default Schema settings.
schema() - Static method in class io.debezium.time.NanoDuration
Returns a Schema for a NanoDuration but with all other default Schema settings.
schema() - Static method in class io.debezium.time.NanoTime
Returns a Schema for a NanoTime but with all other default Schema settings.
schema() - Static method in class io.debezium.time.NanoTimestamp
Returns a Schema for a NanoTimestamp but with all other default Schema settings.
schema() - Static method in class io.debezium.time.Time
Returns a Schema for a Time but with all other default Schema settings.
schema() - Static method in class io.debezium.time.Timestamp
Returns a Schema for a Timestamp but with all other default Schema settings.
schema() - Static method in class io.debezium.time.Year
Returns a Schema for a Year but with all other default Schema settings.
schema() - Static method in class io.debezium.time.ZonedTime
Returns a Schema for a ZonedTime but with all other default Schema settings.
schema() - Static method in class io.debezium.time.ZonedTimestamp
Returns a Schema for a ZonedTimestamp but with all other default Schema settings.
schema(int) - Static method in class io.debezium.data.Bits
Returns a Schema for a Bits but with all other default Schema settings.
schema(String) - Static method in class io.debezium.data.Enum
Returns a SchemaBuilder for an enumeration, with all other default Schema settings.
schema(String) - Static method in class io.debezium.data.EnumSet
Returns a Schema for a set of enumerated values, with all other default Schema settings.
schema(List<String>) - Static method in class io.debezium.data.Enum
Returns a SchemaBuilder for an enumeration, with all other default Schema settings.
schema(List<String>) - Static method in class io.debezium.data.EnumSet
Returns a Schema for a set of enumerated values, with all other default Schema settings.
SCHEMA - Enum constant in enum io.debezium.relational.ColumnFilterMode
 
SCHEMA_CACHE_SIZE - Static variable in class io.debezium.transforms.ExtractNewRecordState
 
SCHEMA_EXCLUDE_LIST - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
A comma-separated list of regular expressions that match schema names to be excluded from monitoring.
SCHEMA_EXCLUDE_LIST_NAME - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
SCHEMA_FIELD_NAME - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
Schema and payload within event data
SCHEMA_FIELD_NAME - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
SCHEMA_HISTORY - Static variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
The database schema history class is hidden in the #configDef() since that is designed to work with a user interface, and in these situations using Kafka is the only way to go.
SCHEMA_HISTORY_CHANGE_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_HISTORY_CHANGE_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_HISTORY_COLUMN_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_HISTORY_COLUMN_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_HISTORY_CONNECTOR_KEY_SCHEMA_NAME_SUFFIX - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_HISTORY_CONNECTOR_KEY_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_HISTORY_CONNECTOR_SCHEMA_NAME_PREFIX - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_HISTORY_CONNECTOR_VALUE_SCHEMA_NAME_SUFFIX - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_HISTORY_CONNECTOR_VALUE_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_HISTORY_TABLE_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_HISTORY_TABLE_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
SCHEMA_INCLUDE_LIST - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
A comma-separated list of regular expressions that match schema names to be monitored.
SCHEMA_INCLUDE_LIST_ALREADY_SPECIFIED_ERROR_MSG - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
SCHEMA_INCLUDE_LIST_NAME - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
SCHEMA_NAME - Static variable in class io.debezium.relational.history.HistoryRecord.Fields
 
SCHEMA_NAME - Static variable in class io.debezium.time.Date
 
SCHEMA_NAME - Static variable in class io.debezium.time.Interval
 
SCHEMA_NAME - Static variable in class io.debezium.time.MicroDuration
 
SCHEMA_NAME - Static variable in class io.debezium.time.MicroTime
 
SCHEMA_NAME - Static variable in class io.debezium.time.MicroTimestamp
 
SCHEMA_NAME - Static variable in class io.debezium.time.NanoDuration
 
SCHEMA_NAME - Static variable in class io.debezium.time.NanoTime
 
SCHEMA_NAME - Static variable in class io.debezium.time.NanoTimestamp
 
SCHEMA_NAME - Static variable in class io.debezium.time.Time
 
SCHEMA_NAME - Static variable in class io.debezium.time.Timestamp
 
SCHEMA_NAME - Static variable in class io.debezium.time.Year
 
SCHEMA_NAME - Static variable in class io.debezium.time.ZonedTime
 
SCHEMA_NAME - Static variable in class io.debezium.time.ZonedTimestamp
 
SCHEMA_NAME_ADJUSTMENT_MODE - Static variable in class io.debezium.config.CommonConnectorConfig
 
SCHEMA_NAME_ADJUSTMENT_MODE - Static variable in class io.debezium.transforms.ByLogicalTableRouter
 
SCHEMA_NAME_KEY - Static variable in class io.debezium.connector.AbstractSourceInfo
 
SCHEMA_NAME_SUFFIX - Static variable in class io.debezium.data.Envelope
A suffix appended to each schema name representing Envelope
SCHEMA_URL_PATH - Static variable in class io.debezium.converters.spi.CloudEventsMaker
 
SCHEMA_VERSION - Static variable in class io.debezium.data.Bits
 
SCHEMA_VERSION - Static variable in class io.debezium.data.Enum
 
SCHEMA_VERSION - Static variable in class io.debezium.data.EnumSet
 
SCHEMA_VERSION - Static variable in class io.debezium.data.Envelope
 
SCHEMA_VERSION - Static variable in class io.debezium.data.Json
 
SCHEMA_VERSION - Static variable in class io.debezium.data.Uuid
 
SCHEMA_VERSION - Static variable in class io.debezium.data.VariableScaleDecimal
 
SCHEMA_VERSION - Static variable in class io.debezium.data.Xml
 
schemaBuilder - Variable in class io.debezium.relational.RelationalDatabaseSchema
 
schemaBuilder(Column) - Method in class io.debezium.jdbc.JdbcValueConverters
 
schemaBuilder(Column) - Method in interface io.debezium.relational.ValueConverterProvider
Returns a SchemaBuilder for a Schema describing literal values of the given JDBC type.
schemaChangeEvent(SchemaChangeEvent) - Method in class io.debezium.pipeline.EventDispatcher.SchemaChangeEventReceiver
 
schemaChangeEvent(SchemaChangeEvent) - Method in interface io.debezium.pipeline.spi.SchemaChangeEventEmitter.Receiver
 
SchemaChangeEvent - Class in io.debezium.schema
Represents a structural change to a database schema.
SchemaChangeEvent(Map<String, ?>, Map<String, ?>, Struct, String, String, String, Table, SchemaChangeEvent.SchemaChangeEventType, boolean, TableId) - Constructor for class io.debezium.schema.SchemaChangeEvent
 
SchemaChangeEvent(Map<String, ?>, Map<String, ?>, Struct, String, String, String, Set<Table>, SchemaChangeEvent.SchemaChangeEventType, boolean, Instant, TableId) - Constructor for class io.debezium.schema.SchemaChangeEvent
 
SchemaChangeEvent.SchemaChangeEventType - Enum in io.debezium.schema
Type describing the content of the event.
SchemaChangeEventEmitter - Interface in io.debezium.pipeline.spi
Emits one or more change records - specific to a given DataCollectionSchema.
SchemaChangeEventEmitter.Receiver - Interface in io.debezium.pipeline.spi
 
SchemaChangeEventReceiver() - Constructor for class io.debezium.pipeline.EventDispatcher.SchemaChangeEventReceiver
 
SchemaChangeEventType() - Constructor for enum io.debezium.schema.SchemaChangeEvent.SchemaChangeEventType
 
schemaChangeKeySchema - Variable in class io.debezium.pipeline.EventDispatcher
 
schemaChangeRecordKey(SchemaChangeEvent) - Method in class io.debezium.pipeline.EventDispatcher.SchemaChangeEventReceiver
 
schemaChangeRecordValue(SchemaChangeEvent) - Method in class io.debezium.pipeline.EventDispatcher.SchemaChangeEventReceiver
 
SchemaChanges<P extends Partition> - Class in io.debezium.pipeline.signal.actions
 
SchemaChanges(EventDispatcher<P, ? extends DataCollectionId>, boolean) - Constructor for class io.debezium.pipeline.signal.actions.SchemaChanges
 
schemaChangeTopic() - Method in class io.debezium.schema.AbstractTopicNamingStrategy
 
schemaChangeValueSchema - Variable in class io.debezium.pipeline.EventDispatcher
 
schemaExcludeList() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
schemaExclusions - Variable in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
 
SchemaFactory - Class in io.debezium.schema
A factory for creating SchemaBuilder structs.
SchemaFactory() - Constructor for class io.debezium.schema.SchemaFactory
 
schemaFactoryObject - Static variable in class io.debezium.schema.SchemaFactory
 
schemaFilter - Variable in class io.debezium.relational.RelationalTableFilters
 
schemaFilter() - Method in class io.debezium.relational.RelationalTableFilters
 
schemaFor(I) - Method in interface io.debezium.schema.DatabaseSchema
 
schemaFor(TableId) - Method in class io.debezium.relational.RelationalDatabaseSchema
Get the Schema information for the table with the given identifier, if that table exists and is included by the filter configuration.
schemaHistory - Variable in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
SchemaHistory - Interface in io.debezium.relational.history
A history of the database schema described by a Tables.
schemaHistoryChangeSchema(SchemaNameAdjuster) - Method in class io.debezium.schema.SchemaFactory
 
schemaHistoryColumnSchema(SchemaNameAdjuster) - Method in class io.debezium.schema.SchemaFactory
 
schemaHistoryConnectorKeySchema(SchemaNameAdjuster, CommonConnectorConfig) - Method in class io.debezium.schema.SchemaFactory
 
schemaHistoryConnectorValueSchema(SchemaNameAdjuster, CommonConnectorConfig, ConnectTableChangeSerializer) - Method in class io.debezium.schema.SchemaFactory
 
SchemaHistoryException - Exception in io.debezium.relational.history
 
SchemaHistoryException(String) - Constructor for exception io.debezium.relational.history.SchemaHistoryException
 
SchemaHistoryException(String, Throwable) - Constructor for exception io.debezium.relational.history.SchemaHistoryException
 
SchemaHistoryException(String, Throwable, boolean, boolean) - Constructor for exception io.debezium.relational.history.SchemaHistoryException
 
SchemaHistoryException(Throwable) - Constructor for exception io.debezium.relational.history.SchemaHistoryException
 
schemaHistoryIsUpToDate() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
Verifies that in-memory representation of the table’s schema is up to date with the table's schema in the database.
SchemaHistoryListener - Interface in io.debezium.relational.history
Listener receiving lifecycle and data events from SchemaHistory.
SchemaHistoryMetrics - Class in io.debezium.relational.history
Implementation of DatabaseSchema metrics.
SchemaHistoryMetrics(CommonConnectorConfig, boolean) - Constructor for class io.debezium.relational.history.SchemaHistoryMetrics
 
SchemaHistoryMetrics.SchemaHistoryStatus - Enum in io.debezium.relational.history
 
SchemaHistoryMXBean - Interface in io.debezium.relational.history
Metrics describing SchemaHistory use.
SchemaHistoryStatus() - Constructor for enum io.debezium.relational.history.SchemaHistoryMetrics.SchemaHistoryStatus
 
schemaHistoryTableSchema(SchemaNameAdjuster) - Method in class io.debezium.schema.SchemaFactory
 
schemaIncludeList() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
schemaInclusions - Variable in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
 
SchemaMetricsMXBean - Interface in io.debezium.pipeline.metrics.traits
Exposes schema metrics.
schemaName - Variable in class io.debezium.relational.TableId
 
schemaName() - Method in class io.debezium.relational.history.HistoryRecord
 
schemaName(String) - Static method in class io.debezium.data.Envelope
Converts an event type name into envelope schema name
schemaNameAdjuster - Variable in class io.debezium.converters.CloudEventsConverter
 
schemaNameAdjuster - Variable in class io.debezium.heartbeat.HeartbeatFactory
 
schemaNameAdjuster - Variable in class io.debezium.relational.TableSchemaBuilder
 
schemaNameAdjuster - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
schemaNameAdjuster() - Method in class io.debezium.config.CommonConnectorConfig
 
SchemaNameAdjuster - Interface in io.debezium.schema
A adjuster for the names of change data message schemas and for the names of the fiields in the schemas.
SchemaNameAdjuster.ReplacementOccurred - Interface in io.debezium.schema
Function used to report that an original value was replaced with an Avro-compatible string.
schemaNameAdjustmentMode - Variable in class io.debezium.config.CommonConnectorConfig
 
schemaNameAdjustmentMode() - Method in class io.debezium.converters.CloudEventsConverterConfig
Return which adjustment mode is used to build message schema names.
SchemaNameAdjustmentMode(String) - Constructor for enum io.debezium.config.CommonConnectorConfig.SchemaNameAdjustmentMode
 
schemaParts() - Method in class io.debezium.relational.TableId
 
SchemaRegexTopicNamingStrategy - Class in io.debezium.schema
Implement a regex expression strategy to determine data event topic names using DataCollectionId.schemaParts().
SchemaRegexTopicNamingStrategy(Properties) - Constructor for class io.debezium.schema.SchemaRegexTopicNamingStrategy
 
schemaRegistryUrls - Variable in class io.debezium.converters.CloudEventsConverter
 
schemasByTableId - Variable in class io.debezium.relational.RelationalDatabaseSchema
 
SchemasByTableId(boolean) - Constructor for class io.debezium.relational.RelationalDatabaseSchema.SchemasByTableId
 
schemaSnapshotFilter - Variable in class io.debezium.relational.RelationalTableFilters
Evaluate whether the table is eligible for schema snapshotting or not.
SchemaTopicNamingStrategy - Class in io.debezium.schema
Determine data event topic names using DataCollectionId.schemaParts().
SchemaTopicNamingStrategy(Properties) - Constructor for class io.debezium.schema.SchemaTopicNamingStrategy
 
SchemaTopicNamingStrategy(Properties, boolean) - Constructor for class io.debezium.schema.SchemaTopicNamingStrategy
 
SchemaUnicodeTopicNamingStrategy - Class in io.debezium.schema
Implement a unicode converter strategy to determine data event topic names using DataCollectionId.schemaParts().
SchemaUnicodeTopicNamingStrategy(Properties) - Constructor for class io.debezium.schema.SchemaUnicodeTopicNamingStrategy
 
schemaUpdateCache - Variable in class io.debezium.transforms.ExtractNewRecordState
 
schemaUpdateCache - Variable in class io.debezium.transforms.HeaderToValue
 
SchemaUtil - Class in io.debezium.data
Utilities for obtaining JSON string representations of Schema, Struct, and Field objects.
SchemaUtil() - Constructor for class io.debezium.data.SchemaUtil
 
SchemaUtil.RecordWriter - Class in io.debezium.data
 
schemaVerificationPassed - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
SECONDS_PER_DAY - Static variable in class io.debezium.time.Conversions
 
seek(long) - Method in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
segment - Variable in class io.debezium.document.Paths.ChildPath
 
segment - Variable in class io.debezium.document.Paths.SingleSegmentPath
 
segment - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRS
The owning segment
segment - Variable in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
segment(int) - Method in interface io.debezium.document.Path
Get the segment at the given index.
segment(int) - Method in class io.debezium.document.Paths.ChildPath
 
segment(int) - Method in class io.debezium.document.Paths.MultiSegmentPath
 
segment(int) - Method in class io.debezium.document.Paths.RootPath
 
segment(int) - Method in class io.debezium.document.Paths.SingleSegmentPath
 
Segment(int, int, float, BoundedConcurrentHashMap.Eviction, BoundedConcurrentHashMap.EvictionListener<K, V>) - Constructor for class io.debezium.util.BoundedConcurrentHashMap.Segment
 
segmentFor(int) - Method in class io.debezium.util.BoundedConcurrentHashMap
Returns the segment that should be used for key with given hash
segmentMask - Variable in class io.debezium.util.BoundedConcurrentHashMap
Mask value for indexing into segments.
segments - Variable in class io.debezium.document.Paths.MultiSegmentPath
 
segments - Variable in class io.debezium.util.BoundedConcurrentHashMap
The segments, each of which is a specialized hash table
segmentShift - Variable in class io.debezium.util.BoundedConcurrentHashMap
Shift value for indexing within segments.
SELECT_ALL_PATTERN - Static variable in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
Selectors - Class in io.debezium.relational
Define predicates determines whether tables or columns should be used.
Selectors() - Constructor for class io.debezium.relational.Selectors
 
Selectors.DatabaseSelectionPredicateBuilder - Class in io.debezium.relational
A builder of a database predicate.
Selectors.TableIdToStringMapper - Interface in io.debezium.relational
Implementations convert given TableIds to strings, so regular expressions can be applied to them for the purpose of table filtering.
Selectors.TableSelectionPredicateBuilder - Class in io.debezium.relational
A builder of a table predicate.
semaphore - Variable in class io.debezium.pipeline.signal.SignalProcessor
 
SEMAPHORE_WAIT_TIME - Static variable in class io.debezium.pipeline.signal.SignalProcessor
 
send(Notification) - Method in class io.debezium.pipeline.notification.channels.jmx.JmxNotificationChannel
 
send(Notification) - Method in class io.debezium.pipeline.notification.channels.LogNotificationChannel
 
send(Notification) - Method in interface io.debezium.pipeline.notification.channels.NotificationChannel
 
send(Notification) - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
send(Notification, Offsets<P, O>) - Method in interface io.debezium.pipeline.notification.channels.ConnectChannel
 
send(Notification, Offsets<P, O>) - Method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
sender - Variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
sendEvent(Object[]) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
sendEvent(Object[]) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
sendEvent(P, EventDispatcher<P, T>, OffsetContext, Object[]) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
sendWindowEvents(P, OffsetContext) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
SEPARATOR - Static variable in class io.debezium.relational.TableIdParser
 
sequence() - Method in class io.debezium.connector.AbstractSourceInfo
Returns extra sequencing metadata about a change event formatted as a stringified JSON array.
SEQUENCE_KEY - Static variable in class io.debezium.connector.AbstractSourceInfo
 
Sequences - Class in io.debezium.util
Utility methods for obtaining streams of integers.
Sequences() - Constructor for class io.debezium.util.Sequences
 
serialize(TableChanges) - Method in class io.debezium.relational.history.ConnectTableChangeSerializer
 
serialize(TableChanges) - Method in class io.debezium.relational.history.JsonTableChangeSerializer
 
serialize(TableChanges) - Method in interface io.debezium.relational.history.TableChanges.TableChangesSerializer
 
serialize(String, Array) - Method in class io.debezium.document.ArraySerdes
 
serialize(String, Document) - Method in class io.debezium.document.DocumentSerdes
 
serialize(String, T) - Method in class io.debezium.serde.json.JsonSerde.JsonSerializer
 
serializedStringToArray(String, String) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
serializer - Variable in class io.debezium.pipeline.signal.actions.SchemaChanges
 
serializer() - Method in class io.debezium.serde.json.JsonSerde
 
SerializerType - Enum in io.debezium.converters.spi
A set of available serializer types for CloudEvents or the data attribute of CloudEvents.
SerializerType() - Constructor for enum io.debezium.converters.spi.SerializerType
 
serialVersionUID - Static variable in class io.debezium.data.SpecialValueDecimal
 
serialVersionUID - Static variable in exception io.debezium.document.JacksonWriter.WritingError
 
serialVersionUID - Static variable in exception io.debezium.jdbc.JdbcConnectionException
 
serialVersionUID - Static variable in exception io.debezium.relational.history.SchemaHistoryException
 
serialVersionUID - Static variable in exception io.debezium.text.MultipleParsingExceptions
 
serialVersionUID - Static variable in exception io.debezium.text.ParsingException
 
serialVersionUID - Static variable in exception io.debezium.transforms.partitions.ComputePartitionException
Deprecated.
 
serialVersionUID - Static variable in class io.debezium.util.BoundedConcurrentHashMap.LRU
The serialVersionUID
serialVersionUID - Static variable in class io.debezium.util.BoundedConcurrentHashMap.Segment
 
serialVersionUID - Static variable in class io.debezium.util.BoundedConcurrentHashMap
 
serialVersionUID - Static variable in class io.debezium.util.BoundedConcurrentHashMap.WriteThroughEntry
 
serialVersionUID - Static variable in class io.debezium.util.VariableLatch.Sync
 
SERVER_NAME_KEY - Static variable in class io.debezium.connector.AbstractSourceInfo
 
SERVER_NAME_KEY - Static variable in class io.debezium.heartbeat.HeartbeatImpl
 
serverName - Variable in class io.debezium.connector.AbstractSourceInfoStructMaker
 
serverName - Variable in class io.debezium.connector.LegacyV1AbstractSourceInfoStructMaker
 
serverName() - Method in class io.debezium.connector.AbstractSourceInfo
 
serverNameKey(String) - Method in class io.debezium.heartbeat.HeartbeatImpl
Produce a key struct based on the server name and KEY_SCHEMA
set(Path, boolean, Value, Consumer<Path>) - Method in interface io.debezium.document.Document
Set the value at the given path resolved against this document, optionally adding any missing intermediary documents or arrays based upon the format of the path segments.
set(CharSequence, Object) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to be a binary value.
set(List<T>, int, T, T) - Static method in class io.debezium.util.Collect
Set the value at the given position in the list, expanding the list as required to accommodate the new position.
Set() - Constructor for class io.debezium.config.Field.Set
 
Set(Collection<Field>) - Constructor for class io.debezium.config.Field.Set
 
SET_VARIABLE - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
setArray(int) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to be a new, empty array.
setArray(int, Array) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to be the supplied array.
setArray(int, Value...) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to be the supplied array.
setArray(CharSequence) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to be a new, empty array.
setArray(CharSequence, Array) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to be the supplied array.
setArray(CharSequence, Object...) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to be the supplied array.
setAutoCommit(boolean) - Method in class io.debezium.jdbc.JdbcConnection
 
setBinary(int, byte[]) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to be a binary value.
setBinary(CharSequence, byte[]) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to be a binary value.
setBoolean(int, boolean) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to the supplied boolean value.
setBoolean(CharSequence, boolean) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to the supplied boolean value.
setColumns(Column...) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
setColumns(Column...) - Method in interface io.debezium.relational.TableEditor
Set this table's column definitions.
setColumns(Column...) - Method in class io.debezium.relational.TableEditorImpl
 
setColumns(Iterable<Column>) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
setColumns(Iterable<Column>) - Method in interface io.debezium.relational.TableEditor
Set this table's column definitions.
setColumns(Iterable<Column>) - Method in class io.debezium.relational.TableEditorImpl
 
setComment(String) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
setComment(String) - Method in interface io.debezium.relational.TableEditor
Set the comment of the table
setComment(String) - Method in class io.debezium.relational.TableEditorImpl
 
setContext(IncrementalSnapshotContext<T>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
setContext(O) - Method in class io.debezium.pipeline.signal.SignalProcessor
 
setCurrentDatabase(String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
setCurrentDatabase(String) - Method in interface io.debezium.relational.ddl.DdlParser
 
setCurrentSchema(String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
setCurrentSchema(String) - Method in interface io.debezium.relational.ddl.DdlParser
Set the name of the current schema.
setDefaultCharsetName(String) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
setDefaultCharsetName(String) - Method in interface io.debezium.relational.TableEditor
Set the name of the character set that should be used by default in the columns that require a character set but have not defined one.
setDefaultCharsetName(String) - Method in class io.debezium.relational.TableEditorImpl
 
setDocument(int) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to be a new, empty Document.
setDocument(int, Document) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to be the supplied Document.
setDocument(CharSequence) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to be a new, empty Document.
setDocument(CharSequence, Document) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to be the supplied Document.
setEventListener(DataChangeEventListener<P>) - Method in class io.debezium.pipeline.EventDispatcher
Provide a listener that is invoked for every incoming event to be processed.
setFetchDirection(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
setFetchSize(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
setIncrementalSnapshotChangeEventSource(Optional<IncrementalSnapshotChangeEventSource<P, ? extends DataCollectionId>>) - Method in class io.debezium.pipeline.EventDispatcher
Enable support for incremental snapshotting.
setLength(String, int, char) - Static method in class io.debezium.util.Strings
Set the length of the string, padding with the supplied character if the supplied string is shorter than desired, or truncating the string if it is longer than desired.
setNull(int) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to be a null value.
setNull(CharSequence) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to be a null value.
setNumber(int, double) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to the supplied double value.
setNumber(int, float) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to the supplied float value.
setNumber(int, int) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to the supplied integer value.
setNumber(int, long) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to the supplied long value.
setNumber(int, BigDecimal) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to the supplied big integer value.
setNumber(int, BigInteger) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to the supplied big integer value.
setNumber(CharSequence, double) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to the supplied double value.
setNumber(CharSequence, float) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to the supplied float value.
setNumber(CharSequence, int) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to the supplied integer value.
setNumber(CharSequence, long) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to the supplied long value.
setNumber(CharSequence, BigDecimal) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to the supplied big integer value.
setNumber(CharSequence, BigInteger) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to the supplied big integer value.
setOf(Field...) - Static method in class io.debezium.config.Field
Create a set of fields.
setOf(Iterable<Field>) - Static method in class io.debezium.config.Field
Create a set of fields.
setOf(String, char, Function<String, T>) - Static method in class io.debezium.util.Strings
Generate the set of values that are included in the list delimited by the given delimiter.
setOf(String, Function<String, String[]>, Function<String, T>) - Static method in class io.debezium.util.Strings
Generate the set of values that are included in the list.
setOf(String, Function<String, T>) - Static method in class io.debezium.util.Strings
Generate the set of values that are included in the list separated by commas.
setOfRegex(String) - Static method in class io.debezium.util.Strings
Generate the set of regular expression Patterns that are specified in the string containing comma-separated regular expressions.
setOfRegex(String, int) - Static method in class io.debezium.util.Strings
Generate the set of regular expression Patterns that are specified in the string containing comma-separated regular expressions.
setPrimaryKeyNames(String...) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
setPrimaryKeyNames(String...) - Method in interface io.debezium.relational.TableEditor
Set the columns that make up this table's primary key.
setPrimaryKeyNames(String...) - Method in class io.debezium.relational.TableEditorImpl
 
setPrimaryKeyNames(List<String>) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
setPrimaryKeyNames(List<String>) - Method in interface io.debezium.relational.TableEditor
Set the columns that make up this table's primary key.
setPrimaryKeyNames(List<String>) - Method in class io.debezium.relational.TableEditorImpl
 
setProducerThrowable(Throwable) - Method in class io.debezium.pipeline.ErrorHandler
 
setRequireContextField(boolean) - Method in class io.debezium.transforms.tracing.ActivateTracingSpan
 
setSchema(Table) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
setSchema(Table) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
setSchemaVerificationPassed(boolean) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
setSchemaVerificationPassed(boolean) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
setSnapshot(SnapshotRecord) - Method in class io.debezium.connector.common.BaseSourceInfo
 
setSnapshotMarker(OffsetContext, boolean, boolean, boolean, boolean) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
setSourceTable(Table) - Method in class io.debezium.relational.ChangeTable
 
setString(int, String) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to the supplied string value.
setString(CharSequence, String) - Method in interface io.debezium.document.Document
Set the value for the field with the given name to the supplied string value.
setTable(BoundedConcurrentHashMap.HashEntry<K, V>[]) - Method in class io.debezium.util.BoundedConcurrentHashMap.Segment
Sets table to new HashEntry array.
setTaskState(BaseSourceTask.State) - Method in class io.debezium.connector.common.BaseSourceTask
Sets the new state for the task.
setTopic(String, R) - Method in class io.debezium.transforms.ExtractNewRecordState
 
setTypeInfoForConstant(String, ColumnEditor) - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
setUniqueValues() - Method in class io.debezium.relational.NoOpTableEditorImpl
 
setUniqueValues() - Method in interface io.debezium.relational.TableEditor
Sets this table's primary key to contain all columns, ensuring that all values are unique within the table.
setUniqueValues() - Method in class io.debezium.relational.TableEditorImpl
 
setValue(int, Value) - Method in interface io.debezium.document.Array
Set the value for the field with the given name to be a value.
setValue(int, Value) - Method in class io.debezium.document.BasicArray
 
setValue(Document.Field) - Method in interface io.debezium.document.Document
Set the field on this document.
setValue(CharSequence, Value) - Method in class io.debezium.document.BasicDocument
 
setValue(CharSequence, Value) - Method in interface io.debezium.document.Document
Set the value for the field with the given name.
setValue(V) - Method in class io.debezium.util.BoundedConcurrentHashMap.WriteThroughEntry
Set our entry's value and write through to the map.
setVariable(SystemVariables.Scope, String, String) - Method in class io.debezium.relational.SystemVariables
Set the variable with the specified scope.
SetVariableEvent(String, String, String, int, String) - Constructor for class io.debezium.relational.ddl.DdlParserListener.SetVariableEvent
 
SHORT_FALSE - Static variable in class io.debezium.util.NumberConversions
 
SHORT_TRUE - Static variable in class io.debezium.util.NumberConversions
 
shouldProvideTransactionMetadata - Variable in class io.debezium.config.CommonConnectorConfig
 
shouldProvideTransactionMetadata() - Method in class io.debezium.config.CommonConnectorConfig
 
shouldSkipSnapshot() - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshottingTask
Whether to skip the snapshot phase.
SHUTDOWN_WAIT_TIMEOUT - Static variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
Waiting period for the polling loop to finish.
SHUTDOWN_WAIT_TIMEOUT - Static variable in class io.debezium.pipeline.signal.SignalProcessor
Waiting period for the polling loop to finish.
signal(String, String, String) - Method in class io.debezium.pipeline.signal.channels.jmx.JmxSignalChannel
 
signal(String, String, String) - Method in interface io.debezium.pipeline.signal.channels.jmx.JmxSignalChannelMXBean
 
SIGNAL_DATA_COLLECTION - Static variable in class io.debezium.config.CommonConnectorConfig
 
SIGNAL_ENABLED_CHANNELS - Static variable in class io.debezium.config.CommonConnectorConfig
 
SIGNAL_FILE - Static variable in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
SIGNAL_POLL_INTERVAL_MS - Static variable in class io.debezium.config.CommonConnectorConfig
 
SIGNAL_POLL_TIMEOUT_MS - Static variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
SIGNAL_TOPIC - Static variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
SignalAction<P extends Partition> - Interface in io.debezium.pipeline.signal.actions
 
signalActions - Variable in class io.debezium.pipeline.signal.SignalProcessor
 
signalAlterDatabase(String, String, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal an alter database event to ddl changes listener.
signalAlterTable(TableId, TableId, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal an alter table event to ddl changes listener.
signalAlterView(TableId, TableId, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal an alter view event to ddl changes listener.
SignalBasedIncrementalSnapshotChangeEventSource<P extends Partition,T extends DataCollectionId> - Class in io.debezium.pipeline.source.snapshot.incremental
 
SignalBasedIncrementalSnapshotChangeEventSource(RelationalDatabaseConnectorConfig, JdbcConnection, EventDispatcher<P, T>, DatabaseSchema<?>, Clock, SnapshotProgressListener<P>, DataChangeEventListener<P>, NotificationService<P, ? extends OffsetContext>) - Constructor for class io.debezium.pipeline.source.snapshot.incremental.SignalBasedIncrementalSnapshotChangeEventSource
 
SignalBasedIncrementalSnapshotContext<T> - Class in io.debezium.pipeline.source.snapshot.incremental
A class describing current state of incremental snapshot
SignalBasedIncrementalSnapshotContext() - Constructor for class io.debezium.pipeline.source.snapshot.incremental.SignalBasedIncrementalSnapshotContext
 
SignalBasedIncrementalSnapshotContext(boolean) - Constructor for class io.debezium.pipeline.source.snapshot.incremental.SignalBasedIncrementalSnapshotContext
 
signalChangeEvent(DdlParserListener.Event) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal an event to ddl changes listener.
SignalChannelReader - Interface in io.debezium.pipeline.signal.channels
This interface is used to provide custom read channels for the Debezium signaling feature: Implementations must: define the name of the reader in SignalChannelReader.name(), initialize specific configuration/variables/connections in the SignalChannelReader.init(CommonConnectorConfig connectorConfig) method, implement reset logic for specific channel in the SignalChannelReader.reset(Object) method if you need to reset already processed signals, provide a list of signal record in the SignalChannelReader.read() method.
signalChannelReaders - Variable in class io.debezium.pipeline.signal.SignalProcessor
 
signalCreateDatabase(String, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal a create database event to ddl changes listener.
signalCreateIndex(String, TableId, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal a create index event to ddl changes listener.
signalCreateTable(TableId, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal a create table event to ddl changes listener.
signalCreateView(TableId, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal a create view event to ddl changes listener.
signalDropDatabase(String, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal a drop database event to ddl changes listener.
signalDropIndex(String, TableId, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal a drop index event to ddl changes listener.
signalDropTable(TableId, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal a drop table event to ddl changes listener.
signalDropView(TableId, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal a drop view event to ddl changes listener.
signalEnabledChannels - Variable in class io.debezium.config.CommonConnectorConfig
 
signalFile - Variable in class io.debezium.pipeline.signal.channels.FileSignalChannel
 
signalingDataCollection - Variable in class io.debezium.config.CommonConnectorConfig
 
SignalPayload<P extends Partition> - Class in io.debezium.pipeline.signal
 
SignalPayload(P, String, String, Document, OffsetContext, Map<String, Object>) - Constructor for class io.debezium.pipeline.signal.SignalPayload
 
signalPollInterval - Variable in class io.debezium.config.CommonConnectorConfig
 
signalProcessor - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
signalProcessor - Variable in class io.debezium.pipeline.EventDispatcher
 
SignalProcessor<P extends Partition,O extends OffsetContext> - Class in io.debezium.pipeline.signal
This class permits to process signals coming from the different channels.
SignalProcessor(Class<? extends SourceConnector>, CommonConnectorConfig, Map<String, SignalAction<P>>, List<SignalChannelReader>, DocumentReader, Offsets<P, O>) - Constructor for class io.debezium.pipeline.signal.SignalProcessor
 
signalProcessorExecutor - Variable in class io.debezium.pipeline.signal.SignalProcessor
 
SignalRecord - Class in io.debezium.pipeline.signal
The class represent the signal sent on a channel: id STRING - the unique identifier of the signal sent, usually UUID, can be used for deduplication type STRING - the unique logical name of the code executing the signal data STRING - the data in JSON format that are passed to the signal code
SignalRecord(String, String, String, Map<String, Object>) - Constructor for class io.debezium.pipeline.signal.SignalRecord
 
SIGNALS - Static variable in class io.debezium.pipeline.signal.channels.jmx.JmxSignalChannel
 
SIGNALS - Static variable in class io.debezium.pipeline.signal.channels.SourceSignalChannel
 
signalsConsumer - Variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
signalSetVariable(String, String, int, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
signalTruncateTable(TableId, String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
Signal a truncate table event to ddl changes listener.
signalUseDatabase(String) - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
signalWindowStatement - Variable in class io.debezium.pipeline.source.snapshot.incremental.SignalBasedIncrementalSnapshotChangeEventSource
 
SIGNED_UNSIGNED_ZEROFILL_PATTERN - Static variable in class io.debezium.relational.ddl.DataTypeBuilder
 
SINGLE_QUOTED_STRING - Static variable in class io.debezium.text.TokenStream.BasicTokenizer
The token type for tokens that consist of all the characters within single-quotes.
SINGLE_QUOTES - Static variable in class io.debezium.relational.TableIdParser
 
SingleDuration() - Constructor for class io.debezium.util.Stopwatch.SingleDuration
 
singleResultMapper(JdbcConnection.ResultSetExtractor<T>, String) - Method in class io.debezium.jdbc.JdbcConnection
 
SingleSegmentPath(String) - Constructor for class io.debezium.document.Paths.SingleSegmentPath
 
SingleThreadAccess - Annotation Type in io.debezium.annotation
Denotes that the annotated element of a class that's meant for multi-threaded usage is accessed only by single thread and thus doesn't need to be guarded via synchronization or similar.
SinkNotificationChannel - Class in io.debezium.pipeline.notification.channels
 
SinkNotificationChannel() - Constructor for class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
SinkNotificationChannel.EmptyOffsetContext - Class in io.debezium.pipeline.notification.channels
 
size - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRS
The number of LIRS entries in a segment
size() - Method in interface io.debezium.document.Array
Return the number of name-value fields in this object.
size() - Method in class io.debezium.document.BasicArray
 
size() - Method in class io.debezium.document.BasicDocument
 
size() - Method in interface io.debezium.document.Document
Return the number of name-value fields in this object.
size() - Method in interface io.debezium.document.Path
Get the number of segments in the path.
size() - Method in class io.debezium.document.Paths.ChildPath
 
size() - Method in class io.debezium.document.Paths.MultiSegmentPath
 
size() - Method in class io.debezium.document.Paths.RootPath
 
size() - Method in class io.debezium.document.Paths.SingleSegmentPath
 
size() - Method in class io.debezium.relational.Tables
Get the number of tables that are in this object.
size() - Method in class io.debezium.relational.Tables.TablesById
 
size() - Method in class io.debezium.util.BoundedConcurrentHashMap.EntrySet
 
size() - Method in class io.debezium.util.BoundedConcurrentHashMap.KeySet
 
size() - Method in class io.debezium.util.BoundedConcurrentHashMap
Returns the number of key-value mappings in this map.
size() - Method in class io.debezium.util.BoundedConcurrentHashMap.Values
 
size() - Method in class io.debezium.util.LRUCacheMap
 
Sizeable - Interface in io.debezium.pipeline
Calculates or estimates the size of the object
sizeInBytesQueue - Variable in class io.debezium.connector.base.ChangeEventQueue
 
SKIP - Enum constant in enum io.debezium.config.CommonConnectorConfig.EventProcessingFailureHandlingMode
Problematic events will be skipped.
SKIP_AND_ERROR - Enum constant in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.InvalidOperationBehavior
 
SKIP_AND_WARN - Enum constant in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.InvalidOperationBehavior
 
SKIP_MESSAGES_WITHOUT_CHANGE - Static variable in class io.debezium.config.CommonConnectorConfig
Specifies whether to skip messages containing no updates in included columns
SKIP_UNPARSEABLE_DDL_STATEMENTS - Static variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
SKIP_UNPARSEABLE_DDL_STATEMENTS - Static variable in interface io.debezium.relational.history.SchemaHistory
 
skipComments - Variable in class io.debezium.relational.ddl.AbstractDdlParser
 
skipComments() - Method in class io.debezium.relational.ddl.AbstractDdlParser
Determine whether parsing should exclude comments from the token stream.
skipEmptyMessages() - Method in class io.debezium.relational.RelationalChangeRecordEmitter
Whether empty data messages should be ignored.
skipMessagesWithoutChange - Variable in class io.debezium.config.CommonConnectorConfig
 
skipMessagesWithoutChange() - Method in class io.debezium.config.CommonConnectorConfig
 
skipMessagesWithoutChange() - Method in class io.debezium.pipeline.AbstractChangeRecordEmitter
 
skipped(O) - Static method in class io.debezium.pipeline.spi.SnapshotResult
 
SKIPPED - Enum constant in enum io.debezium.pipeline.spi.SnapshotResult.SnapshotResultStatus
 
SKIPPED_OPERATIONS - Static variable in class io.debezium.config.CommonConnectorConfig
 
skippedOperations - Variable in class io.debezium.config.CommonConnectorConfig
 
skippedOperations - Variable in class io.debezium.pipeline.EventDispatcher
 
skipRecord(String) - Method in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
skipSchemaChangeEvent(SchemaChangeEvent) - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
skipUnparseableDDL - Variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
skipUnparseableDDL - Variable in class io.debezium.relational.history.AbstractSchemaHistory
 
skipUnparseableDdlStatements() - Method in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
skipUnparseableDdlStatements() - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
skipUnparseableDdlStatements() - Method in interface io.debezium.schema.HistorizedDatabaseSchema
 
skipViews - Variable in class io.debezium.relational.ddl.AbstractDdlParser
 
sleeper(Duration, Clock) - Static method in interface io.debezium.util.Metronome
Create a new metronome that starts ticking immediately and that uses Thread.sleep(long) to wait.
sleepWhen(boolean) - Method in interface io.debezium.util.DelayStrategy
Attempt to sleep when the specified criteria is met.
sleepWhen(BooleanSupplier) - Method in interface io.debezium.util.DelayStrategy
Attempt to sleep when the specified criteria is met.
smtManager - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
smtManager - Variable in class io.debezium.transforms.ExtractChangedRecordState
 
smtManager - Variable in class io.debezium.transforms.ExtractNewRecordState
 
smtManager - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
smtManager - Variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
smtManager - Variable in class io.debezium.transforms.partitions.PartitionRouting
 
smtManager - Variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
SmtManager<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.transforms
A class used by all Debezium supplied SMTs to centralize common logic.
SmtManager(Configuration) - Constructor for class io.debezium.transforms.SmtManager
 
snapshot() - Method in class io.debezium.connector.AbstractSourceInfo
 
snapshot() - Method in class io.debezium.connector.common.BaseSourceInfo
 
SNAPSHOT_DELAY_MS - Static variable in class io.debezium.config.CommonConnectorConfig
 
SNAPSHOT_FETCH_SIZE - Static variable in class io.debezium.config.CommonConnectorConfig
 
SNAPSHOT_FULL_COLUMN_SCAN_FORCE - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
SNAPSHOT_KEY - Static variable in class io.debezium.connector.AbstractSourceInfo
 
SNAPSHOT_LOCK_TIMEOUT_MS - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
SNAPSHOT_MAX_THREADS - Static variable in class io.debezium.config.CommonConnectorConfig
 
SNAPSHOT_MODE_TABLES - Static variable in class io.debezium.config.CommonConnectorConfig
 
SNAPSHOT_RECORD_SCHEMA - Static variable in class io.debezium.connector.AbstractSourceInfoStructMaker
 
SNAPSHOT_SELECT_STATEMENT_OVERRIDES_BY_TABLE - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
SNAPSHOT_TABLES_ORDER_BY_ROW_COUNT - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
snapshotAborted - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
snapshotAborted() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
snapshotAborted(P) - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
snapshotAborted(P) - Method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
SnapshotChangeEventSource<P extends Partition,O extends OffsetContext> - Interface in io.debezium.pipeline.source.spi
A change event source that emits events for taking a consistent snapshot of the captured tables, which may include schema and data information.
SnapshotChangeEventSourceMetrics<P extends Partition> - Interface in io.debezium.pipeline.metrics
Metrics related to the snapshot phase of a connector.
SnapshotChangeEventSourceMetricsMXBean - Interface in io.debezium.pipeline.metrics
 
SnapshotChangeRecordEmitter<P extends Partition> - Class in io.debezium.relational
Emits change data based on a single row read via JDBC.
SnapshotChangeRecordEmitter(P, OffsetContext, Object[], Clock, RelationalDatabaseConnectorConfig) - Constructor for class io.debezium.relational.SnapshotChangeRecordEmitter
 
snapshotCompleted - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
snapshotCompleted() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
snapshotCompleted(P) - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
snapshotCompleted(P) - Method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
SnapshotContext(P) - Constructor for class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshotContext
 
snapshotData - Variable in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshottingTask
 
snapshotData() - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshottingTask
Whether data (rows in captured tables) should be snapshotted.
snapshotDelay - Variable in class io.debezium.config.CommonConnectorConfig
 
snapshotFetchSize - Variable in class io.debezium.config.CommonConnectorConfig
 
snapshotLockTimeout() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
snapshotMaxThreads - Variable in class io.debezium.config.CommonConnectorConfig
 
snapshotMeter - Variable in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
SnapshotMeter - Class in io.debezium.pipeline.meters
Carries snapshot metrics.
SnapshotMeter(Clock) - Constructor for class io.debezium.pipeline.meters.SnapshotMeter
 
snapshotMetrics - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
SnapshotMetricsMXBean - Interface in io.debezium.pipeline.metrics.traits
Exposes snapshot metrics.
snapshotOrderByRowCount - Variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
snapshotOrderByRowCount() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
snapshotPaused - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
snapshotPaused() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
snapshotPaused(P) - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
snapshotPaused(P) - Method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
snapshotProgressListener - Variable in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource
 
snapshotProgressListener - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
SnapshotProgressListener<P extends Partition> - Interface in io.debezium.pipeline.source.spi
Invoked whenever an important event or change of state happens during the snapshot phase.
snapshotRecord - Variable in class io.debezium.connector.common.BaseSourceInfo
 
SnapshotRecord - Enum in io.debezium.connector
Describes whether the change record comes from snapshot and if it is the last one
SnapshotRecord() - Constructor for enum io.debezium.connector.SnapshotRecord
 
SnapshotResult<O extends OffsetContext> - Class in io.debezium.pipeline.spi
 
SnapshotResult(SnapshotResult.SnapshotResultStatus, O) - Constructor for class io.debezium.pipeline.spi.SnapshotResult
 
SnapshotResult.SnapshotResultStatus - Enum in io.debezium.pipeline.spi
 
SnapshotResultStatus() - Constructor for enum io.debezium.pipeline.spi.SnapshotResult.SnapshotResultStatus
 
snapshotResumed() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
snapshotResumed(P) - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
snapshotResumed(P) - Method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
snapshotRunning - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
snapshotRunning() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
snapshotRunning() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
snapshotSchema - Variable in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshottingTask
 
snapshotSchema() - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshottingTask
Whether the schema of captured tables should be snapshotted.
snapshotStarted() - Method in class io.debezium.pipeline.meters.SnapshotMeter
 
snapshotStarted(P) - Method in class io.debezium.pipeline.metrics.DefaultSnapshotChangeEventSourceMetrics
 
snapshotStarted(P) - Method in interface io.debezium.pipeline.source.spi.SnapshotProgressListener
 
SnapshotStatus() - Constructor for enum io.debezium.pipeline.notification.IncrementalSnapshotNotificationService.SnapshotStatus
 
SnapshotTablesRowCountOrder(String) - Constructor for enum io.debezium.relational.RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder
 
SnapshottingTask(boolean, boolean) - Constructor for class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshottingTask
 
SnapshotType() - Constructor for enum io.debezium.pipeline.signal.actions.AbstractSnapshotSignal.SnapshotType
 
sortedColumns - Variable in class io.debezium.relational.TableEditorImpl
 
source - Variable in class io.debezium.converters.spi.RecordParser
 
source - Variable in class io.debezium.schema.SchemaChangeEvent
 
source() - Method in class io.debezium.converters.spi.RecordParser
Get the value of the source field in the record.
source() - Method in class io.debezium.relational.history.HistoryRecord
 
SOURCE - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
 
SOURCE - Static variable in class io.debezium.data.Envelope.FieldName
The origin field is used to store the information about the source of a record, including the Kafka Connect partition and offset information.
SOURCE - Static variable in class io.debezium.relational.history.HistoryRecord.Fields
 
SOURCE_FIELDS - Static variable in class io.debezium.converters.spi.RecordParser
 
sourceEventPosition - Variable in class io.debezium.pipeline.meters.StreamingMeter
 
sourceField - Variable in class io.debezium.serde.json.JsonSerdeConfig
 
sourceField() - Method in class io.debezium.serde.json.JsonSerdeConfig
 
sourceInfo - Variable in class io.debezium.pipeline.CommonOffsetContext
 
sourceInfoSchema - Variable in class io.debezium.relational.TableSchemaBuilder
 
sourceInfoStructMaker - Variable in class io.debezium.config.CommonConnectorConfig
 
SourceInfoStructMaker<T extends AbstractSourceInfo> - Interface in io.debezium.connector
Converts the connector SourceInfo into publicly visible source field of the message.
sourcePosition - Variable in class io.debezium.pipeline.source.spi.EventFormatter
 
sourcePosition(Map<String, String>) - Method in class io.debezium.pipeline.source.spi.EventFormatter
 
sourceSignalChannel - Variable in class io.debezium.pipeline.EventDispatcher
 
SourceSignalChannel - Class in io.debezium.pipeline.signal.channels
The class responsible for processing of signals delivered to Debezium via a dedicated signaling table.
SourceSignalChannel() - Constructor for class io.debezium.pipeline.signal.channels.SourceSignalChannel
 
sourceTable - Variable in class io.debezium.relational.ChangeTable
The table from which the changes are captured
sourceTableColumns - Variable in class io.debezium.util.ColumnUtils.MappedColumns
 
sourceTableId - Variable in class io.debezium.relational.ChangeTable
 
SPACE - Static variable in class io.debezium.config.Field
 
SPACE_CHARACTER - Static variable in class io.debezium.text.XmlCharacters
 
spanContextField - Variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
specialValue - Variable in class io.debezium.data.SpecialValueDecimal
 
SpecialValue() - Constructor for enum io.debezium.data.SpecialValueDecimal.SpecialValue
 
SpecialValueDecimal - Class in io.debezium.data
Extension of plain a BigDecimal type that adds support for new features like special values handling - NaN, infinity;
SpecialValueDecimal(SpecialValueDecimal.SpecialValue) - Constructor for class io.debezium.data.SpecialValueDecimal
 
SpecialValueDecimal(BigDecimal) - Constructor for class io.debezium.data.SpecialValueDecimal
 
SpecialValueDecimal.SpecialValue - Enum in io.debezium.data
Special values for floating-point and numeric types
SPECVERSION - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
 
split(String) - Static method in class io.debezium.util.Strings.RegExSplitter
 
split(String, String) - Static method in class io.debezium.util.Strings
Split a string into pieces based on delimiters.
splitLines(String) - Static method in class io.debezium.util.Strings
Split the supplied content into lines, returning each line as an element in the returned list.
SQLSERVER_CONNECTOR - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
sqlState - Variable in exception io.debezium.jdbc.JdbcConnectionException
 
SRID_FIELD - Static variable in class io.debezium.data.geometry.Geometry
 
stackBottom() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
Returns the entry at the bottom of the stack.
start() - Method in class io.debezium.pipeline.signal.SignalProcessor
 
start() - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
start() - Method in class io.debezium.relational.history.AbstractSchemaHistory
 
start() - Method in interface io.debezium.relational.history.SchemaHistory
Start the history.
start() - Method in class io.debezium.text.TokenStream
Begin the token stream, including (if required) the tokenization of the input content.
start() - Method in class io.debezium.util.Stopwatch
Start the stopwatch.
start(Configuration) - Method in class io.debezium.connector.common.BaseSourceTask
Called when starting this source task.
start(CdcSourceTaskContext, ChangeEventQueueMetrics, EventMetadataProvider) - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
start(Map<String, String>) - Method in class io.debezium.connector.common.BaseSourceTask
 
started() - Method in interface io.debezium.relational.history.SchemaHistoryListener
 
started() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
STARTED - Enum constant in enum io.debezium.pipeline.notification.IncrementalSnapshotNotificationService.SnapshotStatus
 
startIfNeededAndPossible() - Method in class io.debezium.connector.common.BaseSourceTask
Starts this connector in case it has been stopped after a retriable error, and the backoff period has passed.
startIndex - Variable in class io.debezium.text.TokenStream.CaseSensitiveToken
 
startIndex() - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
startIndex() - Method in interface io.debezium.text.TokenStream.Token
Get the index in the raw stream for the first character in the token.
startNewChunk() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
startNewChunk() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
startOfLastToken - Variable in class io.debezium.relational.TableIdParser.ParsingContext
 
startPauseTime - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
startsWithIgnoreCase(String, String) - Static method in class io.debezium.util.Strings
Whether the given string begins with the given prefix, ignoring casing.
startTime - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
state - Variable in class io.debezium.connector.common.BaseSourceTask
 
state - Variable in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
 
State() - Constructor for enum io.debezium.connector.common.BaseSourceTask.State
 
State() - Constructor for class io.debezium.util.MurmurHash3.State
 
StateBasedGCounter - Class in io.debezium.crdt
 
StateBasedGCounter() - Constructor for class io.debezium.crdt.StateBasedGCounter
 
StateBasedGCounter(long) - Constructor for class io.debezium.crdt.StateBasedGCounter
 
StateBasedPNCounter - Class in io.debezium.crdt
 
StateBasedPNCounter() - Constructor for class io.debezium.crdt.StateBasedPNCounter
 
StateBasedPNCounter(long, long) - Constructor for class io.debezium.crdt.StateBasedPNCounter
 
StateBasedPNDeltaCounter - Class in io.debezium.crdt
 
StateBasedPNDeltaCounter() - Constructor for class io.debezium.crdt.StateBasedPNDeltaCounter
 
StateBasedPNDeltaCounter(long, long, long, long) - Constructor for class io.debezium.crdt.StateBasedPNDeltaCounter
 
stateLock - Variable in class io.debezium.connector.common.BaseSourceTask
Used to ensure that start(), stop() and commitRecord() calls are serialized.
statement - Variable in class io.debezium.relational.ddl.DdlParserListener.Event
 
statement() - Method in class io.debezium.relational.ddl.DdlParserListener.Event
Get the DDL statement associated with this event.
STATEMENT_CACHE_CAPACITY - Static variable in class io.debezium.jdbc.JdbcConnection
 
STATEMENT_DELIMITER - Static variable in class io.debezium.jdbc.JdbcConnection
 
statementCache - Variable in class io.debezium.jdbc.JdbcConnection
 
statistics() - Method in interface io.debezium.util.Stopwatch.Durations
Get the statistics for the durations in nanoseconds.
statistics() - Method in class io.debezium.util.Stopwatch.MultipleDurations
 
statistics() - Method in class io.debezium.util.Stopwatch.SingleDuration
 
stats - Variable in class io.debezium.util.Stopwatch.SingleDuration
 
status - Variable in class io.debezium.pipeline.spi.SnapshotResult
 
status - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
step(Clock, Duration, BooleanSupplier, Duration) - Static method in interface io.debezium.util.ElapsedTimeStrategy
Create a strategy whose time periods start out at one length but then change to another length after another period has elapsed.
stop() - Method in class io.debezium.connector.common.BaseSourceTask
 
stop() - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
Stops this coordinator.
stop() - Method in class io.debezium.pipeline.notification.NotificationService
 
stop() - Method in class io.debezium.pipeline.signal.SignalProcessor
 
stop() - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
stop() - Method in class io.debezium.relational.history.AbstractSchemaHistory
 
stop() - Method in interface io.debezium.relational.history.SchemaHistory
Stop recording history and release any resources acquired since SchemaHistory.configure(Configuration, HistoryRecordComparator, SchemaHistoryListener, boolean).
stop() - Method in class io.debezium.util.Stopwatch
Stop the stopwatch.
stop(boolean) - Method in class io.debezium.connector.common.BaseSourceTask
 
stopPauseTime - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
stopped() - Method in interface io.debezium.relational.history.SchemaHistoryListener
 
stopped() - Method in class io.debezium.relational.history.SchemaHistoryMetrics
 
STOPPED - Enum constant in enum io.debezium.connector.common.BaseSourceTask.State
 
STOPPED - Enum constant in enum io.debezium.relational.history.SchemaHistoryMetrics.SchemaHistoryStatus
 
stopSnapshot() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
stopSnapshot() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
stopSnapshot(P, OffsetContext, Map<String, Object>, List<String>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
stopSnapshot(P, OffsetContext, Map<String, Object>, List<String>) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotChangeEventSource
 
StopSnapshot<P extends Partition> - Class in io.debezium.pipeline.signal.actions.snapshotting
The action to stop an ad-hoc snapshot.
StopSnapshot(EventDispatcher<P, ? extends DataCollectionId>) - Constructor for class io.debezium.pipeline.signal.actions.snapshotting.StopSnapshot
 
stopTime - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
Stopwatch - Class in io.debezium.util
A stopwatch for measuring durations.
Stopwatch() - Constructor for class io.debezium.util.Stopwatch
 
Stopwatch.BaseDurations - Class in io.debezium.util
Abstract base class for Stopwatch.Durations implementations.
Stopwatch.Durations - Interface in io.debezium.util
The average and total durations as measured by one or more stopwatches.
Stopwatch.MultipleDurations - Class in io.debezium.util
A Stopwatch.Durations implementation that accumulates all added durations.
Stopwatch.SingleDuration - Class in io.debezium.util
A Stopwatch.Durations implementation that only remembers the most recently added duration.
Stopwatch.Statistics - Interface in io.debezium.util
The timing statistics for a recorded set of samples.
Stopwatch.StopwatchSet - Interface in io.debezium.util
A set of stopwatches whose durations are combined.
storageExists() - Method in class io.debezium.relational.history.MemorySchemaHistory
 
storageExists() - Method in interface io.debezium.relational.history.SchemaHistory
Determines if the underlying storage exists (e.g.
store(Map<String, Object>) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
store(Map<String, Object>) - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
store(Map<String, Object>) - Method in class io.debezium.pipeline.txmetadata.TransactionContext
 
STORE_ONLY_CAPTURED_DATABASES_DDL - Static variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
STORE_ONLY_CAPTURED_DATABASES_DDL - Static variable in interface io.debezium.relational.history.SchemaHistory
 
STORE_ONLY_CAPTURED_TABLES_DDL - Static variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
STORE_ONLY_CAPTURED_TABLES_DDL - Static variable in interface io.debezium.relational.history.SchemaHistory
 
storeOnlyCapturedDatabases() - Method in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
storeOnlyCapturedDatabases() - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
storeOnlyCapturedDatabases() - Method in interface io.debezium.schema.HistorizedDatabaseSchema
 
storeOnlyCapturedDatabasesDdl - Variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
storeOnlyCapturedTables() - Method in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
storeOnlyCapturedTables() - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
storeOnlyCapturedTables() - Method in interface io.debezium.schema.HistorizedDatabaseSchema
 
storeOnlyCapturedTablesDdl - Variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
storeRecord(HistoryRecord) - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
storeRecord(HistoryRecord) - Method in class io.debezium.relational.history.AbstractSchemaHistory
 
storeRecord(HistoryRecord) - Method in class io.debezium.relational.history.MemorySchemaHistory
 
strategy() - Method in interface io.debezium.util.BoundedConcurrentHashMap.EvictionPolicy
Returns type of eviction algorithm (strategy).
strategy() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
strategy() - Method in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
strategy() - Method in class io.debezium.util.BoundedConcurrentHashMap.NullEvictionPolicy
 
stream() - Method in interface io.debezium.document.Document
Returns a sequential Stream with this array as its source.
streamEntries() - Method in interface io.debezium.document.Array
Returns a sequential Stream with this array as its source.
streamEvents(ChangeEventSource.ChangeEventSourceContext, P, O) - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
StreamingChangeEventSource<P extends Partition,O extends OffsetContext> - Interface in io.debezium.pipeline.source.spi
A change event source that emits events from a DB log, such as MySQL's binlog or similar.
StreamingChangeEventSourceMetrics<P extends Partition> - Interface in io.debezium.pipeline.metrics
Metrics related to the streaming phase of a connector.
StreamingChangeEventSourceMetricsMXBean - Interface in io.debezium.pipeline.metrics
Metrics specific to streaming change event sources
StreamingChangeRecordReceiver() - Constructor for class io.debezium.pipeline.EventDispatcher.StreamingChangeRecordReceiver
 
streamingConnected(boolean) - Method in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
streamingMeter - Variable in class io.debezium.pipeline.metrics.DefaultStreamingChangeEventSourceMetrics
 
StreamingMeter - Class in io.debezium.pipeline.meters
Carries streaming metrics.
StreamingMeter(CdcSourceTaskContext, EventMetadataProvider) - Constructor for class io.debezium.pipeline.meters.StreamingMeter
 
streamingMetrics - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
StreamingMetricsMXBean - Interface in io.debezium.pipeline.metrics.traits
Exposes streaming metrics.
StreamingProgressListener - Interface in io.debezium.pipeline.source.spi
Invoked whenever an important event or change of state happens during the streaming phase.
streamingReceiver - Variable in class io.debezium.pipeline.EventDispatcher
Change event receiver for events dispatched from a streaming change event source.
streamingSource - Variable in class io.debezium.pipeline.ChangeEventSourceCoordinator
 
streamValues() - Method in interface io.debezium.document.Array
Returns a sequential Stream with this array as its source.
string - Variable in class io.debezium.pipeline.source.spi.EventFormatter
 
STRING - Enum constant in enum io.debezium.document.Value.Type
 
STRING - Enum constant in enum io.debezium.jdbc.JdbcValueConverters.DecimalMode
 
STRING - Enum constant in enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
Represent DECIMAL and NUMERIC values as a string values.
Strings - Class in io.debezium.util
String-related utility methods.
Strings() - Constructor for class io.debezium.util.Strings
 
Strings.CharacterPredicate - Interface in io.debezium.util
Represents a predicate (boolean-valued function) of one character argument.
Strings.Justify - Enum in io.debezium.util
 
Strings.RegExSplitter - Class in io.debezium.util
A tokenization class used to split a comma-separated list of regular expressions.
stringToDataCollections(String) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
struct - Variable in class io.debezium.transforms.ExtractNewRecordState.FieldReference
The struct ("source", "transaction") hosting the given field, or null for "op" and "ts_ms".
struct() - Method in class io.debezium.connector.AbstractSourceInfo
Returns the source struct representing this source info.
struct(T) - Method in interface io.debezium.connector.SourceInfoStructMaker
Converts the connector's source info into the struct to be included in the message as the source field.
StructGenerator - Interface in io.debezium.relational
A function that converts one change event row (from a snapshot select, or from before/after state of a log event) into the corresponding Kafka Connect key or value Struct.
structMaker() - Method in class io.debezium.connector.AbstractSourceInfo
 
SUBJECT - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
 
subpath(int) - Method in interface io.debezium.document.Path
Get a portion of this path that has a specified number of segments.
subpath(int) - Method in class io.debezium.document.Paths.ChildPath
 
subpath(int) - Method in class io.debezium.document.Paths.MultiSegmentPath
 
subpath(int) - Method in class io.debezium.document.Paths.RootPath
 
subpath(int) - Method in class io.debezium.document.Paths.SingleSegmentPath
 
subset(Tables.TableFilter) - Method in class io.debezium.relational.Tables
 
subset(String, boolean) - Method in interface io.debezium.config.Configuration
Return a new Configuration that contains only the subset of keys that match the given prefix.
substring(int, int) - Method in class io.debezium.text.TokenStream.CharacterArrayStream
 
substring(int, int) - Method in interface io.debezium.text.TokenStream.CharacterStream
Get the content from the start position to the end position.
suffix - Variable in class io.debezium.relational.ddl.DataTypeBuilder
 
supportedTableTypes() - Method in class io.debezium.jdbc.JdbcConnection
 
supportsLargeTimeValues() - Method in class io.debezium.jdbc.JdbcValueConverters
 
supportsOperationFiltering() - Method in class io.debezium.config.CommonConnectorConfig
Whether a particular connector supports an optimized way for implementing operation skipping, or not.
supportsSchemaChangesDuringIncrementalSnapshot() - Method in class io.debezium.config.CommonConnectorConfig
 
surrogateKey - Variable in class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
SYMBOL - Static variable in class io.debezium.text.TokenStream.BasicTokenizer
The token type for tokens that consist of an individual "symbol" character.
sync - Variable in class io.debezium.util.VariableLatch
 
Sync(int) - Constructor for class io.debezium.util.VariableLatch.Sync
 
system() - Static method in interface io.debezium.util.Clock
Get the Clock instance that uses the System methods.
SYSTEM - Static variable in interface io.debezium.util.Clock
The Clock instance that uses the System methods.
systemVariables - Variable in class io.debezium.relational.ddl.AbstractDdlParser
 
systemVariables - Variable in class io.debezium.relational.SystemVariables
 
systemVariables() - Method in class io.debezium.relational.ddl.AbstractDdlParser
 
systemVariables() - Method in interface io.debezium.relational.ddl.DdlParser
 
SystemVariables - Class in io.debezium.relational
Encapsulates a set of a database's system variables.
SystemVariables() - Constructor for class io.debezium.relational.SystemVariables
Create an instance.
SystemVariables(SystemVariables.Scope[]) - Constructor for class io.debezium.relational.SystemVariables
 
SystemVariables(List<SystemVariables.Scope>) - Constructor for class io.debezium.relational.SystemVariables
 
SystemVariables.DefaultScope - Enum in io.debezium.relational
 
SystemVariables.Scope - Interface in io.debezium.relational
Interface that is used for enums defining the customized scope values for specific DBMSs.

T

table - Variable in class io.debezium.relational.history.TableChanges.TableChange
 
table - Variable in class io.debezium.relational.Key.Builder
 
table - Variable in class io.debezium.relational.Key
 
table - Variable in class io.debezium.util.BoundedConcurrentHashMap.Segment
The per-segment table.
table() - Method in class io.debezium.relational.ColumnId
Get the name of the table.
table() - Method in class io.debezium.relational.TableId
Get the name of the table.
Table - Interface in io.debezium.relational
An immutable definition of a table.
TABLE_CHANGES - Static variable in class io.debezium.relational.history.HistoryRecord.Fields
 
TABLE_EXCLUDE_LIST - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
A comma-separated list of regular expressions that match the fully-qualified names of tables to be excluded from monitoring.
TABLE_EXCLUDE_LIST_NAME - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
TABLE_FIELD_NAME - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
TABLE_IGNORE_BUILTIN - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
TABLE_INCLUDE_LIST - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
A comma-separated list of regular expressions that match the fully-qualified names of tables to be monitored.
TABLE_INCLUDE_LIST_ALREADY_SPECIFIED_ERROR_MSG - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
TABLE_INCLUDE_LIST_NAME - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
TABLE_JSON_PAYLOAD_NULL_BEHAVIOR - Static variable in class io.debezium.transforms.outbox.EventRouterConfigDefinition
 
TABLE_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
TABLE_MAXIMUM_KEY - Static variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
TABLE_NAME_KEY - Static variable in class io.debezium.connector.AbstractSourceInfo
 
TABLE_SCAN_COMPLETED - Enum constant in enum io.debezium.pipeline.notification.IncrementalSnapshotNotificationService.SnapshotStatus
 
TABLE_SPLIT - Static variable in class io.debezium.relational.Key.CustomKeyMapper
 
TableAlteredEvent(TableId, TableId, String, boolean) - Constructor for class io.debezium.relational.ddl.DdlParserListener.TableAlteredEvent
 
TableChange(TableChanges.TableChangeType, Table) - Constructor for class io.debezium.relational.history.TableChanges.TableChange
 
TableChange(TableChanges.TableChangeType, Table, TableId) - Constructor for class io.debezium.relational.history.TableChanges.TableChange
 
tableChanges - Variable in class io.debezium.schema.SchemaChangeEvent
 
tableChanges() - Method in class io.debezium.relational.history.HistoryRecord
 
TableChanges - Class in io.debezium.relational.history
An abstract representation of one or more changes to the structure to the tables of a relational database.
TableChanges() - Constructor for class io.debezium.relational.history.TableChanges
 
TableChanges.TableChange - Class in io.debezium.relational.history
 
TableChanges.TableChangesSerializer<T> - Interface in io.debezium.relational.history
The interface that defines conversion of TableChanges into a serialized format for persistent storage or delivering as a message.
TableChanges.TableChangeType - Enum in io.debezium.relational.history
 
tableChangesSerializer - Variable in class io.debezium.pipeline.EventDispatcher
 
tableChangesSerializer - Variable in class io.debezium.relational.history.AbstractSchemaHistory
 
tableChangesSerializer - Static variable in class io.debezium.relational.history.HistoryRecord
 
TableChangeType() - Constructor for enum io.debezium.relational.history.TableChanges.TableChangeType
 
tableCharsetName - Variable in class io.debezium.relational.ColumnEditorImpl
 
TableCreatedEvent(TableId, String, boolean) - Constructor for class io.debezium.relational.ddl.DdlParserListener.TableCreatedEvent
 
TableDroppedEvent(TableId, String, boolean) - Constructor for class io.debezium.relational.ddl.DdlParserListener.TableDroppedEvent
 
TableEditor - Interface in io.debezium.relational
An editor for Table instances, normally obtained from a Tables instance.
TableEditorImpl - Class in io.debezium.relational
 
TableEditorImpl() - Constructor for class io.debezium.relational.TableEditorImpl
 
TableEvent(DdlParserListener.EventType, TableId, String, boolean) - Constructor for class io.debezium.relational.ddl.DdlParserListener.TableEvent
 
tableExcludeList() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
tableExclusions - Variable in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
 
tableFilter - Variable in class io.debezium.relational.RelationalDatabaseSchema
 
tableFilter - Variable in class io.debezium.relational.RelationalTableFilters
 
tableFilters - Variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
tableFor(TableId) - Method in class io.debezium.relational.RelationalDatabaseSchema
Get the Table meta-data for the table with the given identifier, if that table exists and is included by the filter configuration
tableFrom - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
tableId - Variable in class io.debezium.relational.ColumnId
 
tableId - Variable in class io.debezium.relational.ddl.DdlParserListener.TableEvent
 
tableId - Variable in class io.debezium.relational.ddl.DdlParserListener.TableIndexEvent
 
tableId() - Method in class io.debezium.relational.ColumnId
Get the identifier for the table that owns this column.
tableId() - Method in class io.debezium.relational.ddl.DdlParserListener.TableEvent
Get the identifier of the primary table affected by this event.
tableId() - Method in class io.debezium.relational.ddl.DdlParserListener.TableIndexEvent
Get the identifier of the table to which the index applies.
tableId() - Method in class io.debezium.relational.NoOpTableEditorImpl
 
tableId() - Method in interface io.debezium.relational.TableEditor
Get the identifier for this table.
tableId() - Method in class io.debezium.relational.TableEditorImpl
 
tableId(TableId) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
tableId(TableId) - Method in interface io.debezium.relational.TableEditor
Set the table identifier.
tableId(TableId) - Method in class io.debezium.relational.TableEditorImpl
 
tableId(String, String, String) - Static method in class io.debezium.relational.TableId
 
TableId - Class in io.debezium.relational
Unique identifier for a database table.
TableId(String, String, String) - Constructor for class io.debezium.relational.TableId
Create a new table identifier.
TableId(String, String, String, Selectors.TableIdToStringMapper) - Constructor for class io.debezium.relational.TableId
Create a new table identifier.
tableIdCaseInsensitive - Variable in class io.debezium.relational.RelationalDatabaseSchema.SchemasByTableId
 
tableIdCaseInsensitive - Variable in class io.debezium.relational.Tables
 
tableIdCaseInsensitive - Variable in class io.debezium.relational.Tables.TableIds
 
tableIdCaseInsensitive - Variable in class io.debezium.relational.Tables.TablesById
 
tableIdMapper - Variable in class io.debezium.relational.mapping.ColumnMappers.Builder
 
tableIdMapper - Variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
TableIdParser - Class in io.debezium.relational
Parses identifiers into the corresponding parts of a TableId.
TableIdParser() - Constructor for class io.debezium.relational.TableIdParser
 
TableIdParser.ParsingContext - Class in io.debezium.relational
 
TableIdParser.ParsingState - Enum in io.debezium.relational
 
TableIdParser.TableIdTokenizer - Class in io.debezium.relational
 
TableIdPredicates - Interface in io.debezium.relational
Collection of predicate methods used for parsing TableId.
tableIds() - Method in class io.debezium.relational.RelationalDatabaseSchema
Returns the set of table ids included in the current filter configuration.
tableIds() - Method in class io.debezium.relational.Tables
Get the set of TableIds for which there is a Schema.
TableIds(boolean) - Constructor for class io.debezium.relational.Tables.TableIds
 
TableIdTokenizer(String, TableIdPredicates) - Constructor for class io.debezium.relational.TableIdParser.TableIdTokenizer
 
TableImpl - Class in io.debezium.relational
 
TableImpl(Table) - Constructor for class io.debezium.relational.TableImpl
 
TableImpl(TableId, List<Column>, List<String>, String, String, List<Attribute>) - Constructor for class io.debezium.relational.TableImpl
 
tableIncludeList() - Method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
tableInclusions - Variable in class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
 
TableIndexCreatedEvent(String, TableId, String) - Constructor for class io.debezium.relational.ddl.DdlParserListener.TableIndexCreatedEvent
 
TableIndexDroppedEvent(String, TableId, String) - Constructor for class io.debezium.relational.ddl.DdlParserListener.TableIndexDroppedEvent
 
TableIndexEvent(DdlParserListener.EventType, String, TableId, String) - Constructor for class io.debezium.relational.ddl.DdlParserListener.TableIndexEvent
 
tableInformationComplete() - Method in class io.debezium.relational.HistorizedRelationalDatabaseSchema
 
tableInformationComplete() - Method in class io.debezium.relational.RelationalDatabaseSchema
 
tableInformationComplete() - Method in interface io.debezium.schema.DatabaseSchema
Indicates whether or not table names are guaranteed to be fully present, regardless of whether or not a snapshot has been performed.
tableName - Variable in class io.debezium.relational.TableId
 
tableNames - Variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 
tables - Variable in class io.debezium.relational.RelationalDatabaseSchema
 
tables - Variable in class io.debezium.relational.RelationalSnapshotChangeEventSource.RelationalSnapshotContext
 
tables - Variable in class io.debezium.schema.SchemaChangeEvent
 
tables() - Method in class io.debezium.relational.RelationalDatabaseSchema
 
Tables - Class in io.debezium.relational
Structural definitions for a set of tables in a JDBC database.
Tables() - Constructor for class io.debezium.relational.Tables
Create case sensitive empty set of definitions.
Tables(boolean) - Constructor for class io.debezium.relational.Tables
Create an empty set of definitions.
Tables(Tables, boolean) - Constructor for class io.debezium.relational.Tables
 
Tables.ColumnNameFilter - Interface in io.debezium.relational
A filter for columns.
Tables.ColumnNameFilterFactory - Class in io.debezium.relational
 
Tables.TableFilter - Interface in io.debezium.relational
A filter for tables.
Tables.TableIds - Class in io.debezium.relational
A set of table ids.
Tables.TablesById - Class in io.debezium.relational
A map of tables by id.
TablesById(boolean) - Constructor for class io.debezium.relational.Tables.TablesById
 
tablesByTableId - Variable in class io.debezium.relational.Tables
 
tableScanCompleted(P) - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
tableSchema - Variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
TableSchema - Class in io.debezium.relational
Defines the Kafka Connect Schema functionality associated with a given table definition, and which can be used to send rows of data that match the table definition to Kafka Connect.
TableSchema(TableId, Schema, StructGenerator, Envelope, Schema, StructGenerator) - Constructor for class io.debezium.relational.TableSchema
Create an instance with the specified Schemas for the keys and values, and the functions that generate the key and value for a given row of data.
TableSchemaBuilder - Class in io.debezium.relational
Builder that constructs TableSchema instances for Table definitions.
TableSchemaBuilder(ValueConverterProvider, DefaultValueConverter, SchemaNameAdjuster, CustomConverterRegistry, Schema, FieldNameSelector.FieldNamer<Column>, boolean) - Constructor for class io.debezium.relational.TableSchemaBuilder
Create a new instance of the builder.
TableSchemaBuilder(ValueConverterProvider, SchemaNameAdjuster, CustomConverterRegistry, Schema, FieldNameSelector.FieldNamer<Column>, boolean) - Constructor for class io.debezium.relational.TableSchemaBuilder
Create a new instance of the builder.
TableSelectionPredicateBuilder() - Constructor for class io.debezium.relational.Selectors.TableSelectionPredicateBuilder
 
tableSelector() - Static method in class io.debezium.relational.Selectors
Obtain a new builder for a table selection predicate.
tableTo - Variable in class io.debezium.pipeline.meters.SnapshotMeter
 
TableTruncatedEvent(TableId, String, boolean) - Constructor for class io.debezium.relational.ddl.DdlParserListener.TableTruncatedEvent
 
tableTypes() - Method in class io.debezium.jdbc.JdbcConnection
 
TASK_ID - Static variable in class io.debezium.config.CommonConnectorConfig
 
TASK_ID - Static variable in class io.debezium.util.LoggingContext
The key for the task id MDC property.
taskContext - Variable in class io.debezium.pipeline.meters.StreamingMeter
 
taskContext - Variable in class io.debezium.pipeline.metrics.PipelineMetrics
 
taskId - Variable in class io.debezium.config.CommonConnectorConfig
 
taskId - Variable in class io.debezium.connector.common.CdcSourceTaskContext
 
temporalPrecisionMode - Variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
TemporalPrecisionMode - Enum in io.debezium.jdbc
The set of predefined TemporalPrecisionMode options.
TemporalPrecisionMode(String) - Constructor for enum io.debezium.jdbc.TemporalPrecisionMode
 
Temporals - Class in io.debezium.time
Misc.
Temporals() - Constructor for class io.debezium.time.Temporals
 
temporarilyForConnector(String, String, String, Runnable) - Static method in class io.debezium.util.LoggingContext
Run the supplied function in the temporary connector MDC context, and when complete always return the MDC context to its state before this method was called.
temporaryLoggingContext(CommonConnectorConfig, String, Runnable) - Method in class io.debezium.connector.common.CdcSourceTaskContext
Run the supplied function in the temporary connector MDC context, and when complete always return the MDC context to its state before this method was called.
tempRemoveFromQueue() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Temporarily removes this entry from the queue, fixing up neighbor links.
tempRemoveFromStack() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Temporarily removes this entry from the stack, fixing up neighbor links.
test(char) - Method in interface io.debezium.util.Strings.CharacterPredicate
Evaluates this predicate on the given character argument.
threadFactory(Class<? extends SourceConnector>, String, String, boolean, boolean) - Static method in class io.debezium.util.Threads
Returns a thread factory that creates threads conforming to Debezium thread naming pattern debezium-<connector class>-<connector-id>-<thread-name>.
threadFactory(Class<? extends SourceConnector>, String, String, boolean, boolean, Consumer<Thread>) - Static method in class io.debezium.util.Threads
Returns a thread factory that creates threads conforming to Debezium thread naming pattern debezium-<connector class>-<connector-id>-<thread-name>.
Threads - Class in io.debezium.util
Utilities related to threads and threading.
Threads() - Constructor for class io.debezium.util.Threads
 
Threads.Timer - Interface in io.debezium.util
Expires after defined time period.
Threads.TimeSince - Interface in io.debezium.util
Measures the amount time that has elapsed since the last reset.
ThreadSafe - Annotation Type in io.debezium.annotation
Denotes that the annotated type is safe for concurrent access from multiple threads.
threshold - Variable in class io.debezium.util.BoundedConcurrentHashMap.Segment
The table is rehashed when its size exceeds this threshold.
thresholdExpired() - Method in interface io.debezium.util.BoundedConcurrentHashMap.EvictionPolicy
Returns true if batching threshold has expired, false otherwise.
thresholdExpired() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRS
 
thresholdExpired() - Method in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
thresholdExpired() - Method in class io.debezium.util.BoundedConcurrentHashMap.NullEvictionPolicy
 
Throwables - Class in io.debezium.util
Functionality for dealing with Throwables.
Throwables() - Constructor for class io.debezium.util.Throwables
 
throwNoMoreContent() - Method in class io.debezium.text.TokenStream
 
throwProducerExceptionIfPresent() - Method in class io.debezium.connector.base.ChangeEventQueue
 
time(int, Runnable) - Method in interface io.debezium.util.Stopwatch.StopwatchSet
Time the given function multiple times.
time(int, Callable<T>, Consumer<T>) - Method in interface io.debezium.util.Stopwatch.StopwatchSet
Time the given function multiple times.
time(Runnable) - Method in interface io.debezium.util.Stopwatch.StopwatchSet
Time the given function.
time(Callable<T>) - Method in interface io.debezium.util.Stopwatch.StopwatchSet
Time the given function.
Time - Class in io.debezium.time
A utility for converting various Java time representations into the INT32 number of milliseconds since midnight, and for defining a Kafka Connect Schema for time values with no date or timezone information.
Time() - Constructor for class io.debezium.time.Time
 
TIME - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
 
TIME_PATTERN - Static variable in class io.debezium.util.Strings
 
TIME_PRECISION_MODE - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
timeout(String, long, TimeUnit, long, TimeUnit, Threads.TimeSince, Runnable) - Static method in class io.debezium.util.Threads
Create a thread that will call the supplied function when the elapsed time has exceeded the specified amount.
timeout(String, long, TimeUnit, long, TimeUnit, LongSupplier, Runnable, Runnable) - Static method in class io.debezium.util.Threads
Create a thread that will call the supplied function when the elapsed time has exceeded the specified amount.
timeout(String, long, TimeUnit, Threads.TimeSince, Runnable) - Static method in class io.debezium.util.Threads
Create a thread that will call the supplied function when the elapsed time has exceeded the specified amount.
timer(Clock, Duration) - Static method in class io.debezium.util.Threads
Obtain a Threads.Timer that uses the given clock to indicate that a pre-defined time period expired.
times(int) - Static method in class io.debezium.util.Sequences
Create a stream of number monotonically increasing numbers starting at 0, useful when performing an operation number times.
timeSince(Clock) - Static method in class io.debezium.util.Threads
Obtain a Threads.TimeSince that uses the given clock to record the time elapsed.
timestamp - Variable in class io.debezium.schema.SchemaChangeEvent
 
timestamp() - Method in class io.debezium.connector.AbstractSourceInfo
 
timestamp() - Method in class io.debezium.relational.history.HistoryRecord
 
Timestamp - Class in io.debezium.time
A utility for converting various Java time representations into the signed INT64 number of milliseconds past epoch, and for defining a Kafka Connect Schema for timestamp values with no timezone information.
Timestamp() - Constructor for class io.debezium.time.Timestamp
 
TIMESTAMP - Static variable in class io.debezium.data.Envelope.FieldName
The ts_ms field is used to store the information about the local time at which the connector processed/generated the event.
TIMESTAMP - Static variable in class io.debezium.relational.history.HistoryRecord.Fields
 
TIMESTAMP_KEY - Static variable in class io.debezium.connector.AbstractSourceInfo
 
toArray(ByteBuffer, int, int) - Static method in class io.debezium.util.ApproximateStructSizeCalculator
 
toArray(ResultSet, Table) - Static method in class io.debezium.util.ColumnUtils
 
toBigDecimal(Column, Field, Object) - Method in class io.debezium.jdbc.JdbcValueConverters
 
toBitSet(Schema, byte[]) - Static method in class io.debezium.data.Bits
 
toByte(char[], int) - Static method in class io.debezium.util.HexConverter
 
toByteArray(char[]) - Method in class io.debezium.jdbc.JdbcValueConverters
 
toByteArray(Serializable) - Method in enum io.debezium.relational.mapping.MaskStrings.HashingByteArrayStrategy
 
toByteBuffer(char[]) - Method in class io.debezium.jdbc.JdbcValueConverters
 
toByteBuffer(Column, byte[]) - Method in class io.debezium.jdbc.JdbcValueConverters
Converts the given byte array value into a byte buffer as preferred by Kafka Connect.
toByteBuffer(String) - Method in class io.debezium.jdbc.JdbcValueConverters
 
toConnectData(JsonNode, Schema) - Method in class io.debezium.transforms.outbox.JsonSchemaData
Convert a Jackson JsonNode into a new Struct according the schema.
toConnectData(String, byte[]) - Method in class io.debezium.converters.BinaryDataConverter
 
toConnectData(String, byte[]) - Method in class io.debezium.converters.ByteArrayConverter
 
toConnectData(String, byte[]) - Method in class io.debezium.converters.CloudEventsConverter
 
toConnectHeader(String, String, byte[]) - Method in class io.debezium.converters.BinaryDataConverter
 
toConnectHeader(String, String, byte[]) - Method in class io.debezium.converters.ByteArrayConverter
 
toConnectSchema(String, JsonNode) - Method in class io.debezium.transforms.outbox.JsonSchemaData
Build a new connect Schema inferring structure and types from Json node.
toConnectSchemaWithCycles(String, ArrayNode) - Method in class io.debezium.transforms.outbox.JsonSchemaData
 
toDocument(Attribute) - Method in class io.debezium.relational.history.JsonTableChangeSerializer
 
toDocument(Column) - Method in class io.debezium.relational.history.JsonTableChangeSerializer
 
toDocument(TableChanges.TableChange) - Method in class io.debezium.relational.history.JsonTableChangeSerializer
 
toDocument(Table) - Method in class io.debezium.relational.history.JsonTableChangeSerializer
 
toDouble() - Method in class io.debezium.data.SpecialValueDecimal
 
toDoubleQuoted() - Method in class io.debezium.relational.TableId
Returns a new TableId with all parts of the identifier using " character.
toDoubleQuotedString() - Method in class io.debezium.relational.TableId
Returns a dot-separated String representation of this identifier, quoting all name parts with the " char.
toEpochDay(Object, TemporalAdjuster) - Static method in class io.debezium.time.Date
Get the number of epoch days of the given LocalDateTime, LocalDate, LocalTime, Date, Date, Time, or Timestamp, ignoring any time portions of the supplied value.
toEpochMicros(Object, TemporalAdjuster) - Static method in class io.debezium.time.MicroTimestamp
Get the number of microseconds past epoch of the given LocalDateTime, LocalDate, LocalTime, Date, Date, Time, or Timestamp.
toEpochMicros(Instant) - Static method in class io.debezium.time.Conversions
 
toEpochMillis(Object, TemporalAdjuster) - Static method in class io.debezium.time.Timestamp
Get the number of milliseconds past epoch of the given LocalDateTime, LocalDate, LocalTime, Date, Date, Time, or Timestamp.
toEpochNanos(Object, TemporalAdjuster) - Static method in class io.debezium.time.NanoTimestamp
Get the number of nanoseconds past epoch of the given LocalDateTime, LocalDate, LocalTime, Date, Date, Time, or Timestamp.
toEpochNanos(LocalDate) - Static method in class io.debezium.time.NanoTimestamp
Get the number of nanoseconds past epoch of the given LocalDate.
toEpochNanos(LocalDateTime) - Static method in class io.debezium.time.NanoTimestamp
Get the number of nanoseconds past epoch of the given LocalDateTime.
toHash(Serializable) - Method in class io.debezium.relational.mapping.MaskStrings.HashValueConverter
 
toHistoryRecord(InputStream) - Method in class io.debezium.relational.history.AbstractFileBasedSchemaHistory
 
toInstantFromMicros(long) - Static method in class io.debezium.time.Conversions
 
toInstantFromMillis(long) - Static method in class io.debezium.time.Conversions
 
toIsoString(int, int, int, int, int, BigDecimal) - Static method in class io.debezium.time.Interval
Converts a number of time units to a ISO formatted string.
toIsoString(Object, ZoneId, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTime
Get the ISO 8601 formatted representation of the given LocalDateTime, LocalDate, LocalTime, Date, Date, Time, Timestamp, OffsetTime, or OffsetDateTime, ignoring any date portions of the supplied value.
toIsoString(Object, ZoneId, TemporalAdjuster, Integer) - Static method in class io.debezium.time.ZonedTimestamp
Get the ISO 8601 formatted representation of the given LocalDateTime, LocalDate, LocalTime, Date, Date, Time, Timestamp, OffsetTime, or OffsetDateTime, ignoring any date portions of the supplied value.
toIsoString(Date, ZoneId, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTime
Get the ISO 8601 formatted representation of the given Date, which contains a date but no time or timezone information.
toIsoString(Date, ZoneId, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTimestamp
Get the ISO 8601 formatted representation of the given Date, which contains a date but no time or timezone information.
toIsoString(Time, ZoneId, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTime
Get the ISO 8601 formatted representation of the given Time, which contains time but no date or timezone information.
toIsoString(Time, ZoneId, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTimestamp
Get the ISO 8601 formatted representation of the given Time, which contains time but no date or timezone information.
toIsoString(Timestamp, ZoneId, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTime
Get the ISO 8601 formatted representation of the given Timestamp, which contains a date and time but has no timezone information.
toIsoString(Timestamp, ZoneId, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTimestamp
Get the ISO 8601 formatted representation of the given Timestamp, which contains a date and time but has no timezone information.
toIsoString(OffsetDateTime, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTime
Get the ISO 8601 formatted representation of the given OffsetDateTime.
toIsoString(OffsetDateTime, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTimestamp
Get the ISO 8601 formatted representation of the given OffsetDateTime.
toIsoString(OffsetTime, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTime
Get the ISO 8601 formatted representation of the given OffsetTime.
toIsoString(OffsetTime, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTimestamp
Get the ISO 8601 formatted representation of the given OffsetTime.
toIsoString(ZonedDateTime, TemporalAdjuster, Integer) - Static method in class io.debezium.time.ZonedTimestamp
Get the ISO 8601 formatted representation of the given ZonedDateTime.
toIsoString(Date, ZoneId, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTime
Get the ISO 8601 formatted representation of the given Date or one of its JDBC subclasses, using the supplied timezone information.
toIsoString(Date, ZoneId, TemporalAdjuster) - Static method in class io.debezium.time.ZonedTimestamp
Get the ISO 8601 formatted representation of the given Date or one of its JDBC subclasses, using the supplied timezone information.
toIterable(Iterator<T>) - Static method in class io.debezium.util.Iterators
Get an Iterable from an Iterator.
TokenFactory() - Constructor for class io.debezium.text.TokenStream.TokenFactory
 
tokenIndex - Variable in class io.debezium.text.TokenStream.Marker
 
tokenIterator - Variable in class io.debezium.text.TokenStream
This class navigates the Token objects using this iterator.
tokenize(TokenStream.CharacterStream, TokenStream.Tokens) - Method in class io.debezium.relational.TableIdParser.TableIdTokenizer
 
tokenize(TokenStream.CharacterStream, TokenStream.Tokens) - Method in class io.debezium.text.TokenStream.BasicTokenizer
 
tokenize(TokenStream.CharacterStream, TokenStream.Tokens) - Method in interface io.debezium.text.TokenStream.Tokenizer
Process the supplied characters and construct the appropriate TokenStream.Token objects.
tokenize(TokenStream.CharacterStream, TokenStream.Tokens) - Method in class io.debezium.util.Strings.RegExSplitter
 
tokenizer - Variable in class io.debezium.text.TokenStream
 
tokens - Variable in class io.debezium.relational.TableIdParser.ParsingContext
 
tokens - Variable in class io.debezium.text.TokenStream.TokenFactory
 
tokens - Variable in class io.debezium.text.TokenStream
 
TokenStream - Class in io.debezium.text
A foundation for basic parsers that tokenize input content and allows parsers to easily access and use those tokens.
TokenStream(String, TokenStream.Tokenizer, boolean) - Constructor for class io.debezium.text.TokenStream
 
TokenStream.BasicTokenizer - Class in io.debezium.text
A basic TokenStream.Tokenizer implementation that ignores whitespace but includes tokens for individual symbols, the period ('.'), single-quoted strings, double-quoted strings, whitespace-delimited words, and optionally comments.
TokenStream.CaseInsensitiveToken - Class in io.debezium.text
 
TokenStream.CaseInsensitiveTokenFactory - Class in io.debezium.text
 
TokenStream.CaseSensitiveToken - Class in io.debezium.text
An immutable TokenStream.Token that implements matching using case-sensitive logic.
TokenStream.CaseSensitiveTokenFactory - Class in io.debezium.text
 
TokenStream.CharacterArrayStream - Class in io.debezium.text
An implementation of TokenStream.CharacterStream that works with a single character array.
TokenStream.CharacterStream - Interface in io.debezium.text
Interface used by a TokenStream.Tokenizer to iterate through the characters in the content input to the TokenStream.
TokenStream.Marker - Class in io.debezium.text
An opaque marker for a position within the token stream.
TokenStream.Token - Interface in io.debezium.text
The interface defining a token, which references the characters in the actual input character stream.
TokenStream.TokenFactory - Class in io.debezium.text
 
TokenStream.Tokenizer - Interface in io.debezium.text
Interface for a Tokenizer component responsible for processing the characters in a TokenStream.CharacterStream and constructing the appropriate TokenStream.Token objects.
TokenStream.Tokens - Interface in io.debezium.text
A factory for Token objects, used by a TokenStream.Tokenizer to create tokens in the correct order.
toLocalDate(Object) - Static method in class io.debezium.time.Conversions
 
toLocalDateTime(Object) - Static method in class io.debezium.time.Conversions
 
toLocalTime(Object) - Static method in class io.debezium.time.Conversions
 
toLogical(Struct) - Static method in class io.debezium.data.VariableScaleDecimal
Decodes the encoded value - see VariableScaleDecimal.fromLogical(Schema, BigDecimal) for encoding format
toLowercase() - Method in class io.debezium.relational.TableId
 
toLowerCaseIfNeeded(TableId) - Method in class io.debezium.relational.RelationalDatabaseSchema.SchemasByTableId
 
toLowerCaseIfNeeded(TableId) - Method in class io.debezium.relational.Tables.TableIds
 
toLowerCaseIfNeeded(TableId) - Method in class io.debezium.relational.Tables.TablesById
 
toMap(Table) - Static method in class io.debezium.util.ColumnUtils
 
TOMBSTONES_ON_DELETE - Static variable in class io.debezium.config.CommonConnectorConfig
 
toMicroOfDay(Object, boolean) - Static method in class io.debezium.time.MicroTime
Get the number of microseconds past midnight of the given Duration.
toMilliOfDay(Object, boolean) - Static method in class io.debezium.time.Time
Get the number of milliseconds past midnight of the given Duration.
toNanoOfDay(Object, boolean) - Static method in class io.debezium.time.NanoTime
Get the number of nanoseconds past midnight of the given Duration.
TOPIC_CACHE_SIZE - Static variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
TOPIC_DELIMITER - Static variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
TOPIC_HEARTBEAT_PREFIX - Static variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
TOPIC_KEY_ENFORCE_UNIQUENESS - Static variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
TOPIC_KEY_FIELD_NAME - Static variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
TOPIC_KEY_FIELD_REGEX - Static variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
TOPIC_KEY_FIELD_REPLACEMENT - Static variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
TOPIC_NAME_PATTERN - Static variable in class io.debezium.config.CommonConnectorConfig
 
TOPIC_NAMING_STRATEGY - Static variable in class io.debezium.config.CommonConnectorConfig
 
TOPIC_PARTITION_NUM_FIELD - Static variable in class io.debezium.transforms.partitions.PartitionRouting
 
TOPIC_PREFIX - Static variable in class io.debezium.config.CommonConnectorConfig
 
TOPIC_REGEX - Static variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
TOPIC_REGEX - Static variable in class io.debezium.transforms.ByLogicalTableRouter
 
TOPIC_REPLACEMENT - Static variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
TOPIC_REPLACEMENT - Static variable in class io.debezium.transforms.ByLogicalTableRouter
 
TOPIC_TRANSACTION - Static variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
topicName - Variable in class io.debezium.heartbeat.HeartbeatImpl
 
topicName - Variable in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
topicName - Variable in class io.debezium.pipeline.signal.channels.KafkaSignalChannel
 
topicName - Variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
TopicNameCache(TopicSelector.DataCollectionTopicNamer<I>) - Constructor for class io.debezium.schema.TopicSelector.TopicNameCache
Deprecated.
 
topicNameFor(I) - Method in class io.debezium.schema.TopicSelector
Deprecated.
Returns the name of the Kafka topic for a given data collection identifier
topicNameFor(I, String, String) - Method in interface io.debezium.schema.TopicSelector.DataCollectionTopicNamer
Deprecated.
 
topicNameFor(I, String, String) - Method in class io.debezium.schema.TopicSelector.TopicNameCache
Deprecated.
 
topicNameFor(I, String, String) - Method in class io.debezium.schema.TopicSelector.TopicNameSanitizer
Deprecated.
 
topicNames - Variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
topicNames - Variable in class io.debezium.schema.TopicSelector.TopicNameCache
Deprecated.
 
TopicNameSanitizer(TopicSelector.DataCollectionTopicNamer<I>) - Constructor for class io.debezium.schema.TopicSelector.TopicNameSanitizer
Deprecated.
 
topicNamingStrategy - Variable in class io.debezium.heartbeat.HeartbeatFactory
 
topicNamingStrategy - Variable in class io.debezium.pipeline.EventDispatcher
 
topicNamingStrategy - Variable in class io.debezium.relational.RelationalDatabaseSchema
 
topicRegex - Variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
topicRegex - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
topicRegexReplaceCache - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
topicReplacement - Variable in class io.debezium.schema.AbstractRegexTopicNamingStrategy
 
topicReplacement - Variable in class io.debezium.transforms.ByLogicalTableRouter
 
TopicSelector<I extends DataCollectionId> - Class in io.debezium.schema
Deprecated.
Use TopicNamingStrategy instead.
TopicSelector(String, String, String, TopicSelector.DataCollectionTopicNamer<I>) - Constructor for class io.debezium.schema.TopicSelector
Deprecated.
 
TopicSelector.DataCollectionTopicNamer<I extends DataCollectionId> - Interface in io.debezium.schema
Deprecated.
Implementations determine the topic name corresponding to a given data collection.
TopicSelector.TopicNameCache<I extends DataCollectionId> - Class in io.debezium.schema
Deprecated.
A topic namer that caches names it has obtained from a delegate.
TopicSelector.TopicNameSanitizer<I extends DataCollectionId> - Class in io.debezium.schema
Deprecated.
A topic namer that replaces any characters invalid in a topic name with _.
toQuoted(char) - Method in class io.debezium.relational.TableId
Returns a new TableId that has all parts of the identifier quoted.
toQuotedString(char) - Method in class io.debezium.relational.TableId
Returns a dot-separated String representation of this identifier, quoting all name parts with the given quoting char.
toRelativePath() - Method in interface io.debezium.document.Path
Obtain the representation of this path as a relative path without the leading '/'.
toRelativePath() - Method in class io.debezium.document.Paths.ChildPath
 
toRelativePath() - Method in class io.debezium.document.Paths.MultiSegmentPath
 
toRelativePath() - Method in class io.debezium.document.Paths.RootPath
 
toRelativePath() - Method in class io.debezium.document.Paths.SingleSegmentPath
 
toSchemaChangeEventType(TableChanges.TableChangeType) - Static method in class io.debezium.schema.SchemaChangeEvent
 
toSet() - Method in class io.debezium.relational.Tables.TableIds
 
toSource(Struct) - Method in enum io.debezium.connector.SnapshotRecord
 
toString() - Method in class io.debezium.config.Field.RangeValidator
 
toString() - Method in class io.debezium.config.Field
 
toString() - Method in class io.debezium.crdt.StateBasedGCounter
 
toString() - Method in class io.debezium.crdt.StateBasedPNCounter
 
toString() - Method in class io.debezium.crdt.StateBasedPNDeltaCounter
 
toString() - Method in class io.debezium.data.SchemaUtil.RecordWriter
 
toString() - Method in class io.debezium.data.SpecialValueDecimal
Converts a value from its logical format (BigDecimal/special) to its string representation
toString() - Method in class io.debezium.document.BasicArray
 
toString() - Method in class io.debezium.document.BasicDocument
 
toString() - Method in class io.debezium.document.BasicEntry
 
toString() - Method in class io.debezium.document.BasicField
 
toString() - Method in class io.debezium.document.BinaryValue
 
toString() - Method in class io.debezium.document.ComparableValue
 
toString() - Method in class io.debezium.document.ConvertingValue
 
toString() - Method in class io.debezium.document.NullValue
 
toString() - Method in class io.debezium.document.Paths.ChildPath
 
toString() - Method in class io.debezium.document.Paths.MultiSegmentPath
 
toString() - Method in class io.debezium.document.Paths.RootPath
 
toString() - Method in class io.debezium.document.Paths.SingleSegmentPath
 
toString() - Method in class io.debezium.pipeline.DataChangeEvent
 
toString() - Method in class io.debezium.pipeline.notification.Notification
 
toString() - Method in class io.debezium.pipeline.signal.SignalPayload
 
toString() - Method in class io.debezium.pipeline.signal.SignalRecord
 
toString() - Method in class io.debezium.pipeline.source.AbstractSnapshotChangeEventSource.SnapshottingTask
 
toString() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
toString() - Method in class io.debezium.pipeline.source.snapshot.incremental.DataCollection
 
toString() - Method in class io.debezium.pipeline.source.spi.ChangeTableResultSet
 
toString() - Method in class io.debezium.pipeline.source.spi.EventFormatter
 
toString() - Method in class io.debezium.pipeline.spi.SnapshotResult
 
toString() - Method in class io.debezium.pipeline.txmetadata.TransactionContext
 
toString() - Method in class io.debezium.relational.AttributeEditorImpl
 
toString() - Method in class io.debezium.relational.AttributeImpl
 
toString() - Method in class io.debezium.relational.ChangeTable
 
toString() - Method in class io.debezium.relational.ColumnEditorImpl
 
toString() - Method in class io.debezium.relational.ColumnId
 
toString() - Method in class io.debezium.relational.ColumnImpl
 
toString() - Method in class io.debezium.relational.ddl.DataType
 
toString() - Method in class io.debezium.relational.ddl.DdlChanges
 
toString() - Method in class io.debezium.relational.ddl.DdlParserListener.DatabaseAlteredEvent
 
toString() - Method in class io.debezium.relational.ddl.DdlParserListener.DatabaseEvent
 
toString() - Method in class io.debezium.relational.ddl.DdlParserListener.SetVariableEvent
 
toString() - Method in class io.debezium.relational.ddl.DdlParserListener.TableAlteredEvent
 
toString() - Method in class io.debezium.relational.ddl.DdlParserListener.TableEvent
 
toString() - Method in class io.debezium.relational.ddl.DdlParserListener.TableIndexEvent
 
toString() - Method in class io.debezium.relational.history.HistoryRecord
 
toString() - Method in class io.debezium.relational.history.MemorySchemaHistory
 
toString() - Method in class io.debezium.relational.history.TableChanges.TableChange
 
toString() - Method in class io.debezium.relational.history.TableChanges
 
toString() - Method in class io.debezium.relational.NoOpTableEditorImpl
 
toString() - Method in class io.debezium.relational.TableEditorImpl
 
toString() - Method in class io.debezium.relational.TableId
 
toString() - Method in class io.debezium.relational.TableImpl
 
toString() - Method in class io.debezium.relational.Tables
 
toString() - Method in class io.debezium.relational.TableSchema
 
toString() - Method in class io.debezium.schema.SchemaChangeEvent
 
toString() - Method in exception io.debezium.text.MultipleParsingExceptions
 
toString() - Method in class io.debezium.text.Position
 
toString() - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
toString() - Method in class io.debezium.text.TokenStream.Marker
 
toString() - Method in class io.debezium.text.TokenStream
 
toString() - Method in enum io.debezium.transforms.HeaderToValue.Operation
 
toString() - Method in class io.debezium.util.LRUCacheMap
 
toString() - Method in class io.debezium.util.MurmurHash3
 
toString() - Method in class io.debezium.util.Stopwatch.BaseDurations
 
toString() - Method in class io.debezium.util.VariableLatch
Returns a string identifying this latch, as well as its state.
toString(TableId) - Method in interface io.debezium.relational.Selectors.TableIdToStringMapper
 
toString(StringBuilder, String) - Method in class io.debezium.relational.TableImpl
 
toStruct(Column) - Method in class io.debezium.relational.history.ConnectTableChangeSerializer
 
toStruct(TableChanges.TableChange) - Method in class io.debezium.relational.history.ConnectTableChangeSerializer
 
toStruct(Table) - Method in class io.debezium.relational.history.ConnectTableChangeSerializer
 
toSummaryString(DataCollectionId, OffsetContext, Object, Struct) - Method in interface io.debezium.pipeline.source.spi.EventMetadataProvider
 
toTableIds(Set<TableId>, Pattern) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
TOTAL_ROWS_SCANNED - Static variable in class io.debezium.pipeline.notification.IncrementalSnapshotNotificationService
 
totalCapacity() - Method in class io.debezium.connector.base.ChangeEventQueue
 
totalCapacity() - Method in interface io.debezium.connector.base.ChangeEventQueueMetrics
 
totalChangesApplied - Variable in class io.debezium.relational.history.SchemaHistoryMetrics
 
totalEventCount - Variable in class io.debezium.pipeline.txmetadata.TransactionContext
 
totalNumberOfCreateEventsSeen - Variable in class io.debezium.pipeline.meters.CommonEventMeter
 
totalNumberOfDeleteEventsSeen - Variable in class io.debezium.pipeline.meters.CommonEventMeter
 
totalNumberOfEventsSeen - Variable in class io.debezium.pipeline.meters.CommonEventMeter
 
totalNumberOfUpdateEventsSeen - Variable in class io.debezium.pipeline.meters.CommonEventMeter
 
totalRowsScanned - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
toValue(String, Struct) - Method in class io.debezium.transforms.partitions.PartitionRouting
 
traceRecord(R, Struct, Struct, Struct, String) - Method in class io.debezium.transforms.tracing.ActivateTracingSpan
 
TRACING_COMPONENT - Static variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
TRACING_CONTEXT_FIELD_REQUIRED - Static variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
TRACING_OPERATION_NAME - Static variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
TRACING_SPAN_CONTEXT_FIELD - Static variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
tracingSmt - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
transaction - Variable in class io.debezium.converters.spi.RecordParser
 
transaction - Variable in class io.debezium.schema.AbstractTopicNamingStrategy
 
transaction() - Method in class io.debezium.converters.spi.RecordParser
Get the value of the transaction field in the record.
TRANSACTION - Static variable in class io.debezium.data.Envelope.FieldName
The optional metadata information associated with transaction - like transaction id.
TRANSACTION_BLOCK_SCHEMA - Static variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
TRANSACTION_BLOCK_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
TRANSACTION_BLOCK_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
TRANSACTION_EVENT_COUNT_COLLECTION_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
TRANSACTION_EVENT_COUNT_COLLECTION_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
TRANSACTION_METADATA_KEY_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
TRANSACTION_METADATA_KEY_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
TRANSACTION_METADATA_VALUE_SCHEMA_NAME - Static variable in class io.debezium.schema.SchemaFactory
 
TRANSACTION_METADATA_VALUE_SCHEMA_VERSION - Static variable in class io.debezium.schema.SchemaFactory
 
transactionBlockSchema() - Method in class io.debezium.schema.SchemaFactory
 
transactionComittedEvent(Partition, OffsetContext, Instant) - Method in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
TransactionContext - Class in io.debezium.pipeline.txmetadata
The context holds internal state necessary for book-keeping of events in active transaction.
TransactionContext() - Constructor for class io.debezium.pipeline.txmetadata.TransactionContext
 
transactionEvent(OffsetContext, DataCollectionId, Struct) - Method in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
transactionEventCountPerDataCollectionSchema() - Method in class io.debezium.schema.SchemaFactory
 
transactionId - Variable in class io.debezium.pipeline.txmetadata.TransactionContext
 
transactionKeySchema - Variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
transactionKeySchema(SchemaNameAdjuster) - Method in class io.debezium.schema.SchemaFactory
 
transactionMonitor - Variable in class io.debezium.pipeline.EventDispatcher
 
TransactionMonitor - Class in io.debezium.pipeline.txmetadata
The class has externalized its state in TransactionContext context class so it can be stored in and recovered from offsets.
TransactionMonitor(CommonConnectorConfig, EventMetadataProvider, SchemaNameAdjuster, BlockingConsumer<SourceRecord>, String) - Constructor for class io.debezium.pipeline.txmetadata.TransactionMonitor
 
transactionStartedEvent(Partition, String, OffsetContext, Instant) - Method in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
TransactionStatus - Enum in io.debezium.pipeline.txmetadata
Describes the transition of transaction from start to end.
TransactionStatus() - Constructor for enum io.debezium.pipeline.txmetadata.TransactionStatus
 
transactionTopic() - Method in class io.debezium.schema.AbstractTopicNamingStrategy
 
transactionValueSchema - Variable in class io.debezium.pipeline.txmetadata.TransactionMonitor
 
transactionValueSchema(SchemaNameAdjuster) - Method in class io.debezium.schema.SchemaFactory
 
transform(F) - Method in interface io.debezium.util.Iterators.TransformedIterator
 
transform(BiFunction<CharSequence, Value, Value>) - Method in interface io.debezium.document.Document
Transform all of the field values using the supplied transformer function.
transform(BiFunction<Integer, Value, Value>) - Method in interface io.debezium.document.Array
Transform all of the field values using the supplied transformer function.
transform(Iterator<F>, Function<? super F, ? extends T>) - Static method in class io.debezium.util.Iterators
Transform an iterator from a given type to super types.
trim(String) - Static method in class io.debezium.util.Strings
Trim away any leading or trailing whitespace characters.
trim(String, Strings.CharacterPredicate) - Static method in class io.debezium.util.Strings
Trim away any leading or trailing characters that satisfy the supplied predicate
trimDownSize - Variable in class io.debezium.util.BoundedConcurrentHashMap.LRU
 
TRUE - Enum constant in enum io.debezium.connector.SnapshotRecord
Record is from snapshot is not the last one.
truncate(Struct, Instant) - Method in class io.debezium.data.Envelope
Generate an truncate message with the given information.
TRUNCATE - Enum constant in enum io.debezium.data.Envelope.Operation
An operation that resulted in an existing table being truncated in the source.
TRUNCATE - Enum constant in enum io.debezium.schema.SchemaChangeEvent.SchemaChangeEventType
 
TRUNCATE_COLUMN - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
TRUNCATE_TABLE - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
truncateStrings(String, int) - Method in class io.debezium.relational.mapping.ColumnMappers.Builder
Truncate to a maximum length the string values for each of the columns with the fully-qualified names.
TruncateStrings - Class in io.debezium.relational.mapping
A ColumnMapper implementation that ensures that string values longer than a specified length will be truncated.
TruncateStrings(int) - Constructor for class io.debezium.relational.mapping.TruncateStrings
Create a ColumnMapper that truncates string values to a maximum length.
TruncateStrings.TruncatingValueConverter - Class in io.debezium.relational.mapping
 
TruncatingValueConverter(int) - Constructor for class io.debezium.relational.mapping.TruncateStrings.TruncatingValueConverter
 
tryAcquireShared(int) - Method in class io.debezium.util.VariableLatch.Sync
 
tryReleaseShared(int) - Method in class io.debezium.util.VariableLatch.Sync
 
tryStartingSnapshot(RelationalSnapshotChangeEventSource.RelationalSnapshotContext<P, O>) - Method in class io.debezium.relational.RelationalSnapshotChangeEventSource
 
ts_ms - Variable in class io.debezium.converters.spi.RecordParser
 
ts_ms() - Method in class io.debezium.converters.spi.RecordParser
Get the value of the ts_ms field in the record.
ts_msSchema - Variable in class io.debezium.converters.spi.RecordParser
 
ts_msSchema() - Method in class io.debezium.converters.spi.RecordParser
Get the schema of the ts_ms field in the record.
TX_ATTRIBUTE_PREFIX - Static variable in class io.debezium.converters.CloudEventsConverter
 
TX_LOG_WRITE_OPERATION_NAME - Static variable in class io.debezium.transforms.tracing.ActivateTracingSpan
 
txExtensionName(String) - Static method in class io.debezium.converters.CloudEventsConverter
 
type - Variable in class io.debezium.config.ConfigDefinition
 
type - Variable in class io.debezium.config.ConfigDefinitionEditor
 
type - Variable in class io.debezium.config.Field
 
type - Variable in class io.debezium.pipeline.notification.Notification.Builder
 
type - Variable in class io.debezium.pipeline.notification.Notification
 
type - Variable in class io.debezium.pipeline.signal.SignalPayload
 
type - Variable in class io.debezium.pipeline.signal.SignalRecord
 
type - Variable in class io.debezium.relational.ddl.DdlParserListener.Event
 
type - Variable in class io.debezium.relational.history.TableChanges.TableChange
 
type - Variable in class io.debezium.schema.SchemaChangeEvent
 
type - Variable in class io.debezium.text.TokenStream.CaseSensitiveToken
 
type() - Method in class io.debezium.config.ConfigDefinition
 
type() - Method in class io.debezium.config.Field
Get the type of this field.
type() - Method in class io.debezium.relational.ddl.DdlParserListener.Event
Get the type of event.
type() - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
type() - Method in interface io.debezium.text.TokenStream.Token
Get the type of the token.
type(Field...) - Method in class io.debezium.config.ConfigDefinitionEditor
 
type(String) - Method in interface io.debezium.relational.ColumnEditor
Set the database-specific name of the column's data type.
type(String) - Method in class io.debezium.relational.ColumnEditorImpl
 
type(String, String) - Method in interface io.debezium.relational.ColumnEditor
Set the database-specific name of the column's data type.
type(String, String) - Method in class io.debezium.relational.ColumnEditorImpl
 
Type() - Constructor for enum io.debezium.document.Value.Type
 
TYPE - Static variable in class io.debezium.converters.spi.CloudEventsMaker.FieldName
 
TYPE - Static variable in class io.debezium.pipeline.notification.Notification
 
TYPE_EXPRESSION_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
TYPE_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
TYPE_LENGTH_PARAMETER_KEY - Static variable in class io.debezium.relational.mapping.PropagateSourceTypeToSchemaParameter
 
TYPE_NAME_KEY - Static variable in class io.debezium.relational.history.ConnectTableChangeSerializer
 
TYPE_NAME_PARAMETER_KEY - Static variable in class io.debezium.relational.mapping.PropagateSourceTypeToSchemaParameter
 
TYPE_SCALE_PARAMETER_KEY - Static variable in class io.debezium.relational.mapping.PropagateSourceTypeToSchemaParameter
 
typeExpression - Variable in class io.debezium.relational.ColumnEditorImpl
 
typeExpression - Variable in class io.debezium.relational.ColumnImpl
 
typeExpression() - Method in interface io.debezium.relational.Column
Get the database-specific complete expression defining the column's data type, including dimensions, length, precision, character sets, constraints, etc.
typeExpression() - Method in interface io.debezium.relational.ColumnEditor
Get the database-specific complete expression defining the column's data type, including dimensions, length, precision, character sets, constraints, etc.
typeExpression() - Method in class io.debezium.relational.ColumnEditorImpl
 
typeExpression() - Method in class io.debezium.relational.ColumnImpl
 
typeForValue(Value) - Static method in class io.debezium.document.ComparableValue
 
typeName - Variable in class io.debezium.relational.ColumnEditorImpl
 
typeName - Variable in class io.debezium.relational.ColumnImpl
 
typeName() - Method in interface io.debezium.relational.Column
Get the database-specific name of the column's data type.
typeName() - Method in interface io.debezium.relational.ColumnEditor
Get the database-specific name of the column's data type.
typeName() - Method in class io.debezium.relational.ColumnEditorImpl
 
typeName() - Method in class io.debezium.relational.ColumnImpl
 
TYPES_BY_CLASS - Static variable in class io.debezium.document.ComparableValue
 
typeUsesCharset() - Method in interface io.debezium.relational.Column
Determine whether this column has a Column.typeName() or Column.jdbcType() to which a character set applies.

U

UNAVAILABLE_VALUE_PLACEHOLDER - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
unchangedSchema - Variable in class io.debezium.transforms.ExtractChangedRecordState
 
unexpectedBinary(Object, Field) - Method in class io.debezium.jdbc.JdbcValueConverters
Handle the unexpected value from a row with a column type of Types.BLOB, Types.BINARY, Types.VARBINARY, Types.LONGVARBINARY.
UnicodeReplacementFunction - Class in io.debezium.schema
An unicode replacement implementation of ReplacementFunction
UnicodeReplacementFunction() - Constructor for class io.debezium.schema.UnicodeReplacementFunction
 
uniqueValues - Variable in class io.debezium.relational.NoOpTableEditorImpl
 
uniqueValues - Variable in class io.debezium.relational.TableEditorImpl
 
UNKNOWN_PROPERTIES_IGNORED - Static variable in class io.debezium.serde.json.JsonSerdeConfig
 
unknownPropertiesIgnored - Variable in class io.debezium.serde.json.JsonSerdeConfig
 
unlimitedRetries() - Method in class io.debezium.pipeline.ErrorHandler
 
unmodifiableSet(Collection<T>) - Static method in class io.debezium.util.Collect
 
unmodifiableSet(Function<V, T>, Collection<V>) - Static method in class io.debezium.util.Collect
 
unmodifiableSet(Function<V, T>, V...) - Static method in class io.debezium.util.Collect
 
unmodifiableSet(Iterator<T>) - Static method in class io.debezium.util.Collect
 
unmodifiableSet(Set<T>) - Static method in class io.debezium.util.Collect
 
unmodifiableSet(Set<T>, T...) - Static method in class io.debezium.util.Collect
 
unmodifiableSet(T...) - Static method in class io.debezium.util.Collect
 
unquoteIdentifierPart(String) - Static method in class io.debezium.util.Strings
Unquotes the given identifier part (e.g.
unregister() - Method in class io.debezium.metrics.Metrics
Unregisters a metrics MBean from the platform MBean server.
unregister() - Method in interface io.debezium.pipeline.metrics.ChangeEventSourceMetrics
 
unregisterMXBean(CommonConnectorConfig, String, String) - Static method in class io.debezium.pipeline.JmxUtils
 
unregisterMXBean(ObjectName) - Static method in class io.debezium.pipeline.JmxUtils
 
UNSET_INT_VALUE - Static variable in interface io.debezium.relational.Column
 
unsetCorrelationId() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
unsetCorrelationId() - Method in interface io.debezium.pipeline.source.snapshot.incremental.IncrementalSnapshotContext
 
unsetDefaultValueExpression() - Method in interface io.debezium.relational.ColumnEditor
Unsets the default value expression of the column, reverting the editor to the state where {@link #defaultValueExpression(String))} has never been called
unsetDefaultValueExpression() - Method in class io.debezium.relational.ColumnEditorImpl
 
unwrap(Class<T>) - Method in class io.debezium.jdbc.CancellableResultSet
 
update(Object, Struct, Struct, Instant) - Method in class io.debezium.data.Envelope
Generate an update message with the given information.
UPDATE - Enum constant in enum io.debezium.data.Envelope.Operation
An operation that resulted in an existing record being updated in the source.
updateArray(int, Array) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateArray(String, Array) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateAsciiStream(int, InputStream) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateAsciiStream(int, InputStream, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateAsciiStream(int, InputStream, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateAsciiStream(String, InputStream) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateAsciiStream(String, InputStream, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateAsciiStream(String, InputStream, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBigDecimal(int, BigDecimal) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBigDecimal(String, BigDecimal) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBinaryStream(int, InputStream) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBinaryStream(int, InputStream, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBinaryStream(int, InputStream, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBinaryStream(String, InputStream) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBinaryStream(String, InputStream, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBinaryStream(String, InputStream, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBlob(int, InputStream) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBlob(int, InputStream, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBlob(int, Blob) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBlob(String, InputStream) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBlob(String, InputStream, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBlob(String, Blob) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBoolean(int, boolean) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBoolean(String, boolean) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateByte(int, byte) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateByte(String, byte) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBytes(int, byte[]) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateBytes(String, byte[]) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateCharacterStream(int, Reader) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateCharacterStream(int, Reader, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateCharacterStream(int, Reader, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateCharacterStream(String, Reader) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateCharacterStream(String, Reader, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateCharacterStream(String, Reader, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateClob(int, Reader) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateClob(int, Reader, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateClob(int, Clob) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateClob(String, Reader) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateClob(String, Reader, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateClob(String, Clob) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateColumn(Column) - Method in class io.debezium.relational.NoOpTableEditorImpl
 
updateColumn(Column) - Method in interface io.debezium.relational.TableEditor
Update the column with the given name.
updateColumn(Column) - Method in class io.debezium.relational.TableEditorImpl
 
updateCommonEventMetrics() - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
updateCommonEventMetrics(Envelope.Operation) - Method in class io.debezium.pipeline.meters.CommonEventMeter
 
updateDate(int, Date) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateDate(String, Date) - Method in class io.debezium.jdbc.CancellableResultSet
 
updatedDelegate - Variable in class io.debezium.transforms.ExtractNewRecordState
 
updateDouble(int, double) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateDouble(String, double) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateEnvelope(Schema, Struct) - Method in class io.debezium.transforms.ByLogicalTableRouter
 
updateEnvelopeSchema(Schema, String) - Method in class io.debezium.transforms.ByLogicalTableRouter
 
updateFloat(int, float) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateFloat(String, float) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateInt(int, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateInt(String, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateKey(Schema, Struct, String) - Method in class io.debezium.transforms.ByLogicalTableRouter
 
updateKeySchema(Schema, String) - Method in class io.debezium.transforms.ByLogicalTableRouter
 
updateLastOffset(Map<String, ?>, Map<String, ?>) - Method in class io.debezium.connector.common.BaseSourceTask
 
updateLong(int, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateLong(String, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNCharacterStream(int, Reader) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNCharacterStream(int, Reader, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNCharacterStream(String, Reader) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNCharacterStream(String, Reader, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNClob(int, Reader) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNClob(int, Reader, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNClob(int, NClob) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNClob(String, Reader) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNClob(String, Reader, long) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNClob(String, NClob) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNString(int, String) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNString(String, String) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNull(int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateNull(String) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateObject(int, Object) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateObject(int, Object, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateObject(int, Object, SQLType) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateObject(int, Object, SQLType, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateObject(String, Object) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateObject(String, Object, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateObject(String, Object, SQLType) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateObject(String, Object, SQLType, int) - Method in class io.debezium.jdbc.CancellableResultSet
 
updatePositions() - Method in class io.debezium.relational.TableEditorImpl
 
updatePrimaryKeys() - Method in class io.debezium.relational.TableEditorImpl
 
updateRef(int, Ref) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateRef(String, Ref) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateRow() - Method in class io.debezium.jdbc.CancellableResultSet
 
updateRowId(int, RowId) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateRowId(String, RowId) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateSchema(ExtractNewRecordState.FieldReference, SchemaBuilder, Schema) - Method in class io.debezium.transforms.ExtractNewRecordState
 
updateShort(int, short) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateShort(String, short) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateSQLXML(int, SQLXML) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateSQLXML(String, SQLXML) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateString(int, String) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateString(String, String) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateTable(TableId, Function<Table, Table>) - Method in class io.debezium.relational.Tables
Add or update the definition for the identified table.
updateTime(int, Time) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateTime(String, Time) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateTimestamp(int, Timestamp) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateTimestamp(String, Timestamp) - Method in class io.debezium.jdbc.CancellableResultSet
 
updateValue(ExtractNewRecordState.FieldReference, Struct, Struct) - Method in class io.debezium.transforms.ExtractNewRecordState
 
updateValue(Schema, Struct) - Method in class io.debezium.transforms.ByLogicalTableRouter
 
USE_DATABASE - Enum constant in enum io.debezium.relational.ddl.DdlParserListener.EventType
 
useCatalogBeforeSchema - Variable in class io.debezium.pipeline.signal.actions.SchemaChanges
 
useCatalogBeforeSchema - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
useCatalogBeforeSchema - Variable in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
useCatalogBeforeSchema - Variable in class io.debezium.relational.history.AbstractSchemaHistory
 
useCatalogBeforeSchema() - Method in class io.debezium.relational.HistorizedRelationalDatabaseConnectorConfig
 
useComments - Variable in class io.debezium.text.TokenStream.BasicTokenizer
 
USER - Static variable in interface io.debezium.jdbc.JdbcConfiguration
A field for the user of the database.
USER - Static variable in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
userDefinedType(String) - Static method in class io.debezium.relational.ddl.DataType
Obtain the data type for a user-defined or fully-qualified type name.
username() - Method in class io.debezium.jdbc.JdbcConnection
Returns the username for this connection
Uuid - Class in io.debezium.data
A semantic type for a Uuid string.
Uuid() - Constructor for class io.debezium.data.Uuid
 

V

V1 - Enum constant in enum io.debezium.config.CommonConnectorConfig.Version
 
V1 - Enum constant in enum io.debezium.relational.mapping.MaskStrings.HashingByteArrayStrategy
 
V2 - Enum constant in enum io.debezium.config.CommonConnectorConfig.Version
 
V2 - Enum constant in enum io.debezium.relational.mapping.MaskStrings.HashingByteArrayStrategy
 
VALID_CHARACTER - Static variable in class io.debezium.text.XmlCharacters
 
validate(Configuration, Field.Set) - Method in class io.debezium.transforms.SmtManager
Validates the supplied Configuration based on the given fields and throws an exception in the event that there are any validation errors.
validate(Configuration, Field.ValidationOutput) - Method in class io.debezium.config.Field
Validate the supplied value for this field, and report any problems to the designated consumer.
validate(Configuration, Field, Field.ValidationOutput) - Method in class io.debezium.config.Field.EnumRecommender
 
validate(Configuration, Field, Field.ValidationOutput) - Method in class io.debezium.config.Field.RangeValidator
 
validate(Configuration, Field, Field.ValidationOutput) - Method in interface io.debezium.config.Field.Validator
Validate the supplied value for the field, and report any problems to the designated consumer.
validate(Configuration, Function<String, Field>, Map<String, ConfigValue>) - Method in class io.debezium.config.Field
Validate this field in the supplied configuration, updating the ConfigValue for the field with the results.
validate(Field.Set) - Method in interface io.debezium.config.Configuration
Validate the supplied fields in this configuration.
validate(Iterable<Field>, Field.ValidationOutput) - Method in class io.debezium.config.CommonConnectorConfig
Validates the supplied fields in this configuration.
validate(Iterable<Field>, Field.ValidationOutput) - Method in interface io.debezium.config.Configuration
Validate the supplied fields in this configuration.
validate(Map<String, String>) - Method in class io.debezium.connector.common.RelationalBaseSourceConnector
 
validateAllFields(Configuration) - Method in class io.debezium.connector.common.RelationalBaseSourceConnector
 
validateAndRecord(Iterable<Field>, Consumer<String>) - Method in class io.debezium.config.CommonConnectorConfig
Validate the supplied fields in this configuration.
validateAndRecord(Iterable<Field>, Consumer<String>) - Method in interface io.debezium.config.Configuration
Validate the supplied fields in this configuration.
validateColumnExcludeList(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
validateConfiguration() - Method in class io.debezium.transforms.HeaderToValue
 
validateConnection(Map<String, ConfigValue>, Configuration) - Method in class io.debezium.connector.common.RelationalBaseSourceConnector
Validates connection to database.
validateDatabaseExcludeList(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
validateHostname(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
validateIncomingRowToInternalMetadata(int[], Field[], ValueConverter[], Object[], int) - Method in class io.debezium.relational.TableSchemaBuilder
 
validateKeyFieldReplacement(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.schema.AbstractRegexTopicNamingStrategy
If TOPIC_KEY_FIELD_REGEX has a value that is really a regex, then the TOPIC_KEY_FIELD_REPLACEMENT must be a non-empty value.
validateKeyFieldReplacement(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.transforms.ByLogicalTableRouter
If KEY_FIELD_REGEX has a value that is really a regex, then the KEY_FIELD_REPLACEMENT must be a non-empty value.
validateMaxQueueSize(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.CommonConnectorConfig
 
validateMessageKeyColumnsField(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
validateNotificationTopicName(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
validateSchemaExcludeList(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
validateSkippedOperation(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.CommonConnectorConfig
 
validateTableBlacklist(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
validateTableExcludeList(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.relational.RelationalDatabaseConnectorConfig
 
validateTopicName(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.config.CommonConnectorConfig
 
validateTopicReplacement(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.schema.AbstractRegexTopicNamingStrategy
If TOPIC_REGEX has a value that is really a regex, then the TOPIC_REPLACEMENT must be a non-empty value.
validationOutput(Field, String) - Static method in class io.debezium.config.Field
 
validator - Variable in class io.debezium.config.Field
 
validator() - Method in class io.debezium.config.Field
Get the validator for this field.
validatorForType(ConfigDef.Type) - Static method in class io.debezium.config.Field
 
validFullname(String) - Static method in interface io.debezium.schema.SchemaNameAdjuster
Convert the proposed string to a valid Avro fullname, replacing all invalid characters with the underscore ('_') character.
validFullname(String, ReplacementFunction) - Static method in interface io.debezium.schema.SchemaNameAdjuster
Convert the proposed string to a valid Avro fullname, using the supplied function to replace all invalid characters.
validFullname(String, ReplacementFunction, SchemaNameAdjuster.ReplacementOccurred) - Static method in interface io.debezium.schema.SchemaNameAdjuster
Convert the proposed string to a valid Avro fullname, using the supplied function to replace all invalid characters.
validFullname(String, String) - Static method in interface io.debezium.schema.SchemaNameAdjuster
Convert the proposed string to a valid Avro fullname, replacing all invalid characters with the supplied string.
validValues - Variable in class io.debezium.config.Field.EnumRecommender
 
validValues(Field, Configuration) - Method in class io.debezium.config.Field.EnumRecommender
 
validValues(Field, Configuration) - Method in class io.debezium.config.Field.InvisibleRecommender
 
validValues(Field, Configuration) - Method in class io.debezium.config.Field.OneOfRecommender
 
validValues(Field, Configuration) - Method in interface io.debezium.config.Field.Recommender
Return a set of recommended (and valid) values for the field given the current configuration values.
value - Variable in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
 
value - Variable in enum io.debezium.config.CommonConnectorConfig.EventProcessingFailureHandlingMode
 
value - Variable in enum io.debezium.config.CommonConnectorConfig.FieldNameAdjustmentMode
 
value - Variable in enum io.debezium.config.CommonConnectorConfig.SchemaNameAdjustmentMode
 
value - Variable in enum io.debezium.config.CommonConnectorConfig.Version
 
value - Variable in class io.debezium.document.BasicEntry
 
value - Variable in class io.debezium.document.BasicField
 
value - Variable in class io.debezium.document.BinaryValue
 
value - Variable in class io.debezium.document.ComparableValue
 
value - Variable in class io.debezium.document.ConvertingValue
 
value - Variable in enum io.debezium.jdbc.TemporalPrecisionMode
 
value - Variable in class io.debezium.pipeline.source.spi.EventFormatter
 
value - Variable in class io.debezium.relational.AttributeEditorImpl
 
value - Variable in class io.debezium.relational.AttributeImpl
 
value - Variable in class io.debezium.relational.ddl.DdlParserListener.SetVariableEvent
 
value - Variable in enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
 
value - Variable in enum io.debezium.relational.RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder
 
value - Variable in enum io.debezium.transforms.ExtractNewRecordStateConfigDefinition.DeleteHandling
 
value - Variable in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalFieldPlacement
 
value - Variable in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.InvalidOperationBehavior
 
value - Variable in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.JsonPayloadNullFieldBehavior
 
value - Variable in class io.debezium.util.BoundedConcurrentHashMap.HashEntry
 
value() - Element in annotation type io.debezium.annotation.GuardedBy
 
value() - Element in annotation type io.debezium.annotation.SingleThreadAccess
Describes the thread accessing the annotated element.
value() - Method in interface io.debezium.relational.Attribute
The attribute value.
value() - Method in interface io.debezium.relational.AttributeEditor
Get the value of the attribute.
value() - Method in class io.debezium.relational.AttributeEditorImpl
 
value() - Method in class io.debezium.relational.AttributeImpl
 
value() - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
value() - Method in interface io.debezium.text.TokenStream.Token
Get the value of the token, in actual case.
value(Object) - Method in interface io.debezium.relational.AttributeEditor
Set the value of the attribute.
value(Object) - Method in class io.debezium.relational.AttributeEditorImpl
 
value(Struct) - Method in class io.debezium.pipeline.source.spi.EventFormatter
 
Value - Interface in io.debezium.document
A value in a Document or Array.
VALUE_FIELD - Static variable in class io.debezium.data.VariableScaleDecimal
 
Value.NullHandler - Interface in io.debezium.document
 
Value.Type - Enum in io.debezium.document
 
ValueConversionCallback - Interface in io.debezium.jdbc
Invoked to convert incoming SQL column values into Kafka Connect values.
ValueConverter - Interface in io.debezium.relational
A function that converts from a column data value into another value.
valueConverterProvider - Variable in class io.debezium.relational.TableSchemaBuilder
 
ValueConverterProvider - Interface in io.debezium.relational
A provider of ValueConverter functions and the SchemaBuilder used to describe them.
valueFromColumnData(Object[]) - Method in class io.debezium.relational.TableSchema
Convert the specified row of values into a Kafka Connect value.
valueGenerator - Variable in class io.debezium.relational.TableSchema
 
ValueIterator() - Constructor for class io.debezium.util.BoundedConcurrentHashMap.ValueIterator
 
valueOf(String) - Static method in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.config.CommonConnectorConfig.EventProcessingFailureHandlingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.config.CommonConnectorConfig.FieldNameAdjustmentMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.config.CommonConnectorConfig.SchemaNameAdjustmentMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.config.CommonConnectorConfig.Version
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.config.Field.Group
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.connector.common.BaseSourceTask.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.connector.SnapshotRecord
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.converters.spi.SerializerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.data.Envelope.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.data.SpecialValueDecimal.SpecialValue
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class io.debezium.data.SpecialValueDecimal
Factory method for creating instances from numbers in string format
valueOf(String) - Static method in enum io.debezium.document.Value.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.jdbc.JdbcValueConverters.BigIntUnsignedMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.jdbc.JdbcValueConverters.DecimalMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.jdbc.TemporalPrecisionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.pipeline.notification.IncrementalSnapshotNotificationService.SnapshotStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.pipeline.signal.actions.AbstractSnapshotSignal.SnapshotType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.pipeline.spi.SnapshotResult.SnapshotResultStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.pipeline.txmetadata.TransactionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.relational.ColumnFilterMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.relational.ddl.DdlParserListener.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.relational.history.SchemaHistoryMetrics.SchemaHistoryStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.relational.history.TableChanges.TableChangeType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.relational.mapping.MaskStrings.HashingByteArrayStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.relational.SystemVariables.DefaultScope
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.relational.TableIdParser.ParsingState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.schema.SchemaChangeEvent.SchemaChangeEventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.transforms.ExtractNewRecordStateConfigDefinition.DeleteHandling
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.transforms.HeaderToValue.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalFieldPlacement
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.InvalidOperationBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.JsonPayloadNullFieldBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.transforms.partitions.PartitionRouting.HashFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.util.BoundedConcurrentHashMap.Eviction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.util.BoundedConcurrentHashMap.Recency
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.util.Strings.Justify
Returns the enum constant of this type with the specified name.
values - Variable in class io.debezium.document.BasicArray
 
values - Variable in class io.debezium.relational.RelationalDatabaseSchema.SchemasByTableId
 
values - Variable in class io.debezium.relational.Tables.TableIds
 
values - Variable in class io.debezium.relational.Tables.TablesById
 
values - Variable in class io.debezium.util.BoundedConcurrentHashMap
 
values() - Static method in enum io.debezium.config.CommonConnectorConfig.BinaryHandlingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.config.CommonConnectorConfig.EventProcessingFailureHandlingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.config.CommonConnectorConfig.FieldNameAdjustmentMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.config.CommonConnectorConfig.SchemaNameAdjustmentMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.config.CommonConnectorConfig.Version
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.config.Field.Group
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.connector.common.BaseSourceTask.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.connector.SnapshotRecord
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.converters.spi.SerializerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.data.Envelope.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.data.SpecialValueDecimal.SpecialValue
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface io.debezium.document.Array
 
values() - Method in class io.debezium.document.BasicArray
 
values() - Static method in enum io.debezium.document.Value.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.jdbc.JdbcValueConverters.BigIntUnsignedMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.jdbc.JdbcValueConverters.DecimalMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.jdbc.TemporalPrecisionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.pipeline.notification.IncrementalSnapshotNotificationService.SnapshotStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.pipeline.signal.actions.AbstractSnapshotSignal.SnapshotType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.pipeline.spi.SnapshotResult.SnapshotResultStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.pipeline.txmetadata.TransactionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.relational.ColumnFilterMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.relational.ddl.DdlParserListener.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.relational.history.SchemaHistoryMetrics.SchemaHistoryStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.relational.history.TableChanges.TableChangeType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.relational.mapping.MaskStrings.HashingByteArrayStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.DecimalHandlingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.relational.RelationalDatabaseConnectorConfig.SnapshotTablesRowCountOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.relational.SystemVariables.DefaultScope
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.relational.TableIdParser.ParsingState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.schema.SchemaChangeEvent.SchemaChangeEventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.transforms.ExtractNewRecordStateConfigDefinition.DeleteHandling
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.transforms.HeaderToValue.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.AdditionalFieldPlacement
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.InvalidOperationBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.transforms.outbox.EventRouterConfigDefinition.JsonPayloadNullFieldBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.transforms.partitions.PartitionRouting.HashFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.util.BoundedConcurrentHashMap.Eviction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.util.BoundedConcurrentHashMap.Recency
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class io.debezium.util.BoundedConcurrentHashMap
Returns a Collection view of the values contained in this map.
values() - Method in class io.debezium.util.LRUCacheMap
 
values() - Static method in enum io.debezium.util.Strings.Justify
Returns an array containing the constants of this enum type, in the order they are declared.
Values() - Constructor for class io.debezium.util.BoundedConcurrentHashMap.Values
 
VALUES_FIELD - Static variable in class io.debezium.data.Enum
 
VALUES_FIELD - Static variable in class io.debezium.data.EnumSet
 
valueSchema - Variable in class io.debezium.heartbeat.HeartbeatImpl
 
valueSchema - Variable in class io.debezium.pipeline.notification.channels.SinkNotificationChannel
 
valueSchema - Variable in class io.debezium.relational.TableSchema
 
valueSchema() - Method in class io.debezium.relational.TableSchema
Get the Schema that represents the table's columns, excluding those that make up the TableSchema.keySchema().
ValueWrapper<T> - Interface in io.debezium.data
Provides the access to the original encapsulated value obtained for example from JDBC.
VAR_DELIM - Static variable in class io.debezium.util.Strings
 
VariableLatch - Class in io.debezium.util
A latch that works similarly to CountDownLatch except that it can also increase the count dynamically.
VariableLatch(int) - Constructor for class io.debezium.util.VariableLatch
Constructs a CountDownLatch initialized with the given count.
VariableLatch.Sync - Class in io.debezium.util
Synchronization control For CountDownLatch.
variableName - Variable in class io.debezium.relational.ddl.DdlParserListener.SetVariableEvent
 
variableName() - Method in class io.debezium.relational.ddl.DdlParserListener.SetVariableEvent
Get the name of the variable that was set.
variableName(String) - Method in class io.debezium.relational.SystemVariables
 
VariableScaleDecimal - Class in io.debezium.data
An arbitrary precision decimal value with variable scale.
VariableScaleDecimal() - Constructor for class io.debezium.data.VariableScaleDecimal
 
variableValue() - Method in class io.debezium.relational.ddl.DdlParserListener.SetVariableEvent
Get the value of the variable that was set.
verifySchemaUnchanged() - Method in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
Verifies that table's schema in the database has not changed since it was captured in the previous window
version - Variable in class io.debezium.connector.AbstractSourceInfoStructMaker
 
version - Variable in class io.debezium.connector.LegacyV1AbstractSourceInfoStructMaker
 
version - Variable in class io.debezium.metadata.ConnectorDescriptor
 
Version(String) - Constructor for enum io.debezium.config.CommonConnectorConfig.Version
 
versionedValueSchema - Variable in class io.debezium.transforms.outbox.EventRouterDelegate
 
viewPerTableEventCount - Variable in class io.debezium.pipeline.txmetadata.TransactionContext
 
visible(Field, Configuration) - Method in class io.debezium.config.Field.EnumRecommender
 
visible(Field, Configuration) - Method in class io.debezium.config.Field.InvisibleRecommender
 
visible(Field, Configuration) - Method in class io.debezium.config.Field.OneOfRecommender
 
visible(Field, Configuration) - Method in interface io.debezium.config.Field.Recommender
Set the visibility of the field given the current configuration values.
VisibleForTesting - Annotation Type in io.debezium.annotation
Indicates that visibility of the annotated element is raised for the purposes of testing (e.g.
VITESS_CONNECTOR - Static variable in class io.debezium.transforms.partitions.ComputePartition
Deprecated.
 

W

WAIT_FOR_CLOSE_SECONDS - Static variable in class io.debezium.jdbc.JdbcConnection
 
warmupMiss() - Method in class io.debezium.util.BoundedConcurrentHashMap.LIRSHashEntry
Records a miss when the hot entry set is not full.
WARN - Enum constant in enum io.debezium.config.CommonConnectorConfig.EventProcessingFailureHandlingMode
The position of problematic events will be logged and events will be skipped.
wasNull() - Method in class io.debezium.jdbc.CancellableResultSet
 
width - Variable in class io.debezium.config.Field
 
width() - Method in class io.debezium.config.Field
Get the width of this field.
window - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotChangeEventSource
 
windowOpened - Variable in class io.debezium.pipeline.source.snapshot.incremental.AbstractIncrementalSnapshotContext
 
with(Configuration) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Add all of the fields in the supplied Configuration object.
with(Field...) - Method in class io.debezium.config.Field.Set
Get a new set that contains the fields in this set and those supplied.
with(Field, boolean) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the key of the specified field.
with(Field, double) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the key of the specified field.
with(Field, float) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the key of the specified field.
with(Field, int) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the key of the specified field.
with(Field, long) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the key of the specified field.
with(Field, EnumeratedValue) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the key of the specified field.
with(Field, Class<?>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given class name value with the specified field.
with(Field, Object) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the key of the specified field.
with(Field, String) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the key of the specified field.
with(Iterable<Field>) - Method in class io.debezium.config.Field.Set
Get a new set that contains the fields in this set and those supplied.
with(String, boolean) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the specified key.
with(String, double) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the specified key.
with(String, float) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the specified key.
with(String, int) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the specified key.
with(String, long) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the specified key.
with(String, EnumeratedValue) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the specified key.
with(String, Class<?>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given class name value with the specified key.
with(String, Object) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the specified key.
with(String, String) - Method in class io.debezium.config.Configuration.Builder
 
with(String, String) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Associate the given value with the specified key.
with(T) - Static method in class io.debezium.util.Iterators
 
with(T[]) - Static method in class io.debezium.util.Iterators
 
with(T, T) - Static method in class io.debezium.util.Iterators
 
with(T, T, T) - Static method in class io.debezium.util.Iterators
 
with(T, T, T, T...) - Static method in class io.debezium.util.Iterators
 
withAdditionalData(Map<String, String>) - Method in class io.debezium.pipeline.notification.Notification.Builder
 
withAggregateType(String) - Method in class io.debezium.pipeline.notification.Notification.Builder
 
withAllowedValues(Set<?>) - Method in class io.debezium.config.Field
 
withConnectionFactoryClass(String) - Method in interface io.debezium.jdbc.JdbcConfiguration.Builder
Use the given connection factory class in the resulting configuration.
withConnectionTimeoutMs(int) - Method in interface io.debezium.jdbc.JdbcConfiguration.Builder
Use the given connection timeout in the resulting configuration.
withDatabase(String) - Method in interface io.debezium.jdbc.JdbcConfiguration.Builder
Use the given database name in the resulting configuration.
withDefault(boolean) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given default value.
withDefault(int) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given default value.
withDefault(long) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given default value.
withDefault(Configuration) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If any of the fields in the supplied Configuration object do not exist, then add them.
withDefault(Field, boolean) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If the field does not have a value, then associate the given value with the key of the specified field.
withDefault(Field, double) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If the field does not have a value, then associate the given value with the key of the specified field.
withDefault(Field, float) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If the field does not have a value, then associate the given value with the key of the specified field.
withDefault(Field, int) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If the field does not have a value, then associate the given value with the key of the specified field.
withDefault(Field, long) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If the field does not have a value, then associate the given value with the key of the specified field.
withDefault(Field, Class<?>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If the field does not have a value, then associate the given value with the key of the specified field.
withDefault(Field, Object) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If the field does not have a value, then associate the given value with the key of the specified field.
withDefault(Field, String) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If the field does not have a value, then associate the given value with the key of the specified field.
withDefault(String) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given default value.
withDefault(String, boolean) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If there is no field with the specified key, then associate the given value with the specified key.
withDefault(String, double) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If there is no field with the specified key, then associate the given value with the specified key.
withDefault(String, float) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If there is no field with the specified key, then associate the given value with the specified key.
withDefault(String, int) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If there is no field with the specified key, then associate the given value with the specified key.
withDefault(String, long) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If there is no field with the specified key, then associate the given value with the specified key.
withDefault(String, EnumeratedValue) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If there is no field with the specified key, then associate the given value with the specified key.
withDefault(String, Class<?>) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If there is no field with the specified key, then associate the given class name value with the specified key.
withDefault(String, Object) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If there is no field with the specified key, then associate the given value with the specified key.
withDefault(String, String) - Method in class io.debezium.config.Configuration.Builder
 
withDefault(String, String) - Method in interface io.debezium.config.Configuration.ConfigBuilder
If there is no field with the specified key, then associate the given value with the specified key.
withDefault(BooleanSupplier) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given default value.
withDefault(IntSupplier) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given default value.
withDefault(LongSupplier) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given default value.
withDependents(String...) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given display name.
withDescription(String) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given description.
withDisplayName(String) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given display name.
withDoc(String) - Method in interface io.debezium.data.Envelope.Builder
Define the documentation for the schema.
withEnum(Class<T>) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but has a type of Schema.Type.STRING, a recommender that returns a list of Enum names as valid values, and a validator that verifies values are valid enumeration names.
withEnum(Class<T>, T) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but has a type of Schema.Type.STRING, a recommender that returns a list of Enum names as valid values, and a validator that verifies values are valid enumeration names.
withGroup(Field.GroupEntry) - Method in class io.debezium.config.Field
 
withHostname(String) - Method in interface io.debezium.jdbc.JdbcConfiguration.Builder
Use the given host in the resulting configuration.
withId(String) - Method in class io.debezium.pipeline.notification.Notification.Builder
 
withImportance(ConfigDef.Importance) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given importance.
withInvisibleRecommender() - Method in class io.debezium.config.Field
 
withMasked(String) - Method in interface io.debezium.config.Configuration
Return a new Configuration that contains all of the same fields as this configuration, except with masked values for all keys that match the specified pattern.
withMasked(Pattern) - Method in interface io.debezium.config.Configuration
Return a new Configuration that contains all of the same fields as this configuration, except with masked values for all keys that match the specified pattern.
withMaskedPasswords() - Method in interface io.debezium.config.Configuration
Return a new Configuration that contains all of the same fields as this configuration, except with masked values for all keys that end in "password".
withMaskedSensitiveOptions(Configuration) - Method in class io.debezium.connector.common.BaseSourceTask
 
withName(String) - Method in interface io.debezium.converters.CloudEventsConverter.CESchemaBuilder
 
withName(String) - Static method in enum io.debezium.converters.spi.SerializerType
 
withName(String) - Method in interface io.debezium.data.Envelope.Builder
Define the name for the schema.
withNoValidation() - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but that uses no validation.
without(String) - Method in class io.debezium.config.Configuration.Builder
 
without(String) - Method in interface io.debezium.config.Configuration.ConfigBuilder
Remove the value associated with the specified key.
withoutKnownFields() - Method in interface io.debezium.jdbc.JdbcConfiguration
Get a view of this configuration that does not contain the known fields.
withoutQuotes(String) - Static method in class io.debezium.relational.ddl.AbstractDdlParser
Cut out the string surrounded with single, double and reversed quotes.
withPassword(String) - Method in interface io.debezium.jdbc.JdbcConfiguration.Builder
Use the given password in the resulting configuration.
withPort(int) - Method in interface io.debezium.jdbc.JdbcConfiguration.Builder
Use the given port in the resulting configuration.
withRecommender(Field.Recommender) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given recommender.
withRecord(Schema) - Method in interface io.debezium.data.Envelope.Builder
Define the Schema used in the Envelope.FieldName.BEFORE and Envelope.FieldName.AFTER fields.
withReplacedVariables(Function<String, String>) - Method in interface io.debezium.config.Configuration
Return a new Configuration that contains all of the same fields as this configuration, except with all variables in the fields replaced with values from the supplied function.
withScaleAdjustedIfNeeded(Column, BigDecimal) - Method in class io.debezium.jdbc.JdbcValueConverters
 
withSchema(String, Schema) - Method in interface io.debezium.converters.CloudEventsConverter.CESchemaBuilder
 
withSchema(Schema, String...) - Method in interface io.debezium.data.Envelope.Builder
Define the Schema used for an arbitrary field in the envelope.
withSource(Schema) - Method in interface io.debezium.data.Envelope.Builder
Define the Schema used in the Envelope.FieldName.SOURCE field.
withSystemProperties(String) - Method in interface io.debezium.config.Configuration
Return a copy of this configuration except where acceptable system properties are used to overwrite properties copied from this configuration.
withSystemProperties(Function<String, String>) - Method in interface io.debezium.config.Configuration
Return a copy of this configuration except where acceptable system properties are used to overwrite properties copied from this configuration.
withType(int) - Method in class io.debezium.text.TokenStream.CaseInsensitiveToken
 
withType(int) - Method in class io.debezium.text.TokenStream.CaseSensitiveToken
 
withType(int) - Method in interface io.debezium.text.TokenStream.Token
Bitmask ORed with existing type value.
withType(String) - Method in class io.debezium.pipeline.notification.Notification.Builder
 
withType(ConfigDef.Type) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given type.
withUser(String) - Method in interface io.debezium.jdbc.JdbcConfiguration.Builder
Use the given user in the resulting configuration.
withValidation(Field.Validator...) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but that in addition to existing validation the supplied validation function(s) are also used.
withValue(String, Object) - Method in interface io.debezium.converters.CloudEventsConverter.CEValueBuilder
 
withValue(Schema) - Static method in class io.debezium.converters.CloudEventsConverter
 
withWidth(ConfigDef.Width) - Method in class io.debezium.config.Field
Create and return a new Field instance that is a copy of this field but with the given width.
WKB_FIELD - Static variable in class io.debezium.data.geometry.Geometry
 
WKB_POINT - Static variable in class io.debezium.data.geometry.Point
 
WKB_POINT_SIZE - Static variable in class io.debezium.data.geometry.Point
 
WORD - Static variable in class io.debezium.text.TokenStream.BasicTokenizer
The token type for tokens that represent an unquoted string containing a character sequence made up of non-whitespace and non-symbol characters.
wrapInMappingConverterIfNeeded(ColumnMappers, TableId, Column, ValueConverter) - Method in class io.debezium.relational.TableSchemaBuilder
 
wrapped - Variable in exception io.debezium.document.JacksonWriter.WritingError
 
wrapped() - Method in exception io.debezium.document.JacksonWriter.WritingError
 
write(Array) - Method in interface io.debezium.document.ArrayWriter
Write the supplied array to a string using UTF-8.
write(Array) - Method in class io.debezium.document.JacksonWriter
 
write(Array, OutputStream) - Method in interface io.debezium.document.ArrayWriter
Write the supplied array to bytes using UTF-8.
write(Array, OutputStream) - Method in class io.debezium.document.JacksonWriter
 
write(Array, Writer) - Method in interface io.debezium.document.ArrayWriter
Write the supplied array to bytes using UTF-8.
write(Array, Writer) - Method in class io.debezium.document.JacksonWriter
 
write(Document) - Method in interface io.debezium.document.DocumentWriter
Write the supplied document to a string using UTF-8.
write(Document) - Method in class io.debezium.document.JacksonWriter
 
write(Document, OutputStream) - Method in interface io.debezium.document.DocumentWriter
Write the supplied document to bytes using UTF-8.
write(Document, OutputStream) - Method in class io.debezium.document.JacksonWriter
 
write(Document, Writer) - Method in interface io.debezium.document.DocumentWriter
Write the supplied document to bytes using UTF-8.
write(Document, Writer) - Method in class io.debezium.document.JacksonWriter
 
write(Runnable) - Method in class io.debezium.util.FunctionalReadWriteLock
Obtain an exclusive write lock, perform the operation, and release the lock.
write(Supplier<T>) - Method in class io.debezium.util.FunctionalReadWriteLock
Obtain an exclusive write lock, perform the operation, and release the lock.
writeArray(Array, JsonGenerator) - Method in class io.debezium.document.JacksonWriter
 
writeAsBytes(Array) - Method in interface io.debezium.document.ArrayWriter
Write the supplied array to bytes using UTF-8.
writeAsBytes(Document) - Method in interface io.debezium.document.DocumentWriter
Write the supplied array to bytes using UTF-8.
writeAsBytes(Document) - Method in class io.debezium.document.JacksonWriter
 
writeDocument(Document, JsonGenerator) - Method in class io.debezium.document.JacksonWriter
 
writeObject(ObjectOutputStream) - Method in class io.debezium.util.BoundedConcurrentHashMap
Save the state of the ConcurrentHashMap instance to a stream (i.e., serialize it).
WriteThroughEntry(K, V) - Constructor for class io.debezium.util.BoundedConcurrentHashMap.WriteThroughEntry
 
writeValue(Value, JsonGenerator) - Method in class io.debezium.document.JacksonWriter
 
WritingError(IOException) - Constructor for exception io.debezium.document.JacksonWriter.WritingError
 

X

X_FIELD - Static variable in class io.debezium.data.geometry.Point
 
Xml - Class in io.debezium.data
A semantic type for an XML string.
Xml() - Constructor for class io.debezium.data.Xml
 
XmlCharacters - Class in io.debezium.text
A utility class for determining the validity of various XML names, per the XML 1.0 Specification.
XmlCharacters() - Constructor for class io.debezium.text.XmlCharacters
 

Y

Y_FIELD - Static variable in class io.debezium.data.geometry.Point
 
Year - Class in io.debezium.time
A utility for defining a Kafka Connect Schema that represents year values.
Year() - Constructor for class io.debezium.time.Year
 

Z

ZERO - Static variable in class io.debezium.data.SpecialValueDecimal
 
ZERO - Static variable in class io.debezium.data.VariableScaleDecimal
 
ZonedTime - Class in io.debezium.time
A utility for converting various Java time representations into the STRING representation of the time in a particular time zone, and for defining a Kafka Connect Schema for zoned time values.
ZonedTime() - Constructor for class io.debezium.time.ZonedTime
 
ZonedTimestamp - Class in io.debezium.time
A utility for converting various Java time representations into the STRING representation of the time and date in a particular time zone, and for defining a Kafka Connect Schema for zoned timestamp values.
ZonedTimestamp() - Constructor for class io.debezium.time.ZonedTimestamp
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form