A B C D E F G H I J K L M N O P Q R S T U V W 
All Classes All Packages

A

AbstractMysqlFieldReader - Class in io.debezium.connector.mysql
Abstract class for decode MySQL return value according to different protocols.
AbstractMysqlFieldReader() - Constructor for class io.debezium.connector.mysql.AbstractMysqlFieldReader
 
AbstractReader - Class in io.debezium.connector.mysql.legacy
A component that performs a snapshot of a MySQL server, and records the schema changes in MySqlSchema.
AbstractReader(String, MySqlTaskContext, HaltingPredicate) - Constructor for class io.debezium.connector.mysql.legacy.AbstractReader
Create a snapshot reader.
AbstractReader.AcceptAllPredicate - Class in io.debezium.connector.mysql.legacy
A predicate that returns true for all sourceRecords
acceptableDatabase(String) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
AcceptAllPredicate() - Constructor for class io.debezium.connector.mysql.legacy.AbstractReader.AcceptAllPredicate
 
acceptAndContinue - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
accepts(SourceRecord) - Method in interface io.debezium.connector.mysql.HaltingPredicate
Whether this record should be processed by the calling reader or not.
accepts(SourceRecord) - Method in class io.debezium.connector.mysql.legacy.AbstractReader.AcceptAllPredicate
 
accepts(SourceRecord) - Method in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader.ParallelHaltingPredicate
 
accepts(SourceRecord) - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader.OffsetLimitPredicate
 
add(Event) - Method in class io.debezium.connector.mysql.EventBuffer
An entry point to the buffer that should be used by BinlogReader to push events.
add(Event) - Method in class io.debezium.connector.mysql.legacy.EventBuffer
An entry point to the buffer that should be used by BinlogReader to push events.
addColumnFromTable(TableEditor, String, String, Table) - Method in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
addReader(Reader) - Method in class io.debezium.connector.mysql.legacy.ChainedReader.Builder
 
addSchemaEvent(RelationalSnapshotChangeEventSource.RelationalSnapshotContext, String, String) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
addToBuffer(Event) - Method in class io.debezium.connector.mysql.EventBuffer
Adds an event to the buffer if there is a space available.
addToBuffer(Event) - Method in class io.debezium.connector.mysql.legacy.EventBuffer
Adds an event to the buffer if there is a space available.
adjustTemporal(Temporal) - Static method in class io.debezium.connector.mysql.MySqlValueConverters
A utility method that adjusts ambiguous 2-digit year values of DATETIME, DATE, and TIMESTAMP types using these MySQL-specific rules: Year values in the range 00-69 are converted to 2000-2069. Year values in the range 70-99 are converted to 1970-1999.
after - Variable in class io.debezium.connector.mysql.MySqlChangeRecordEmitter
 
ALL_FIELDS - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
The set of Fields defined as part of this configuration.
AlterTableParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL ALTER TABLE statements.
AlterTableParserListener(MySqlAntlrDdlParser, List<ParseTreeListener>) - Constructor for class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
AlterViewParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL ALTER VIEW statements.
AlterViewParserListener(MySqlAntlrDdlParser, List<ParseTreeListener>) - Constructor for class io.debezium.connector.mysql.antlr.listener.AlterViewParserListener
 
appendCreateTableStatement(StringBuilder, Table) - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
 
appendCreateTableStatement(StringBuilder, Table) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
appendDropTableStatement(StringBuilder, TableId) - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
 
appendDropTableStatement(StringBuilder, TableId) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
appendToDdlStatement(String, StringBuilder) - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext.DatabaseLocales
 
apply(R) - Method in class io.debezium.connector.mysql.transforms.ReadToInsertEvent
 
applyDdl(SourceInfo, String, String, DdlChanges.DatabaseStatementStringConsumer) - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Apply the supplied DDL statements to this database schema and record the history.
applySchemaChange(SchemaChangeEvent) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
aReaderLeading - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
asBigIntUnsignedMode() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.BigIntUnsignedHandlingMode
 
asIntervalBeginning() - Method in class io.debezium.connector.mysql.GtidSet.UUIDSet
 
assign(long, TableId) - Method in class io.debezium.connector.mysql.legacy.RecordMakers
Assign the given table number to the table with the specified table ID.
assignTableNumber(long, TableId) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
Assign the given table number to the table with the specified table ID.
availableBinlogFiles() - Method in class io.debezium.connector.mysql.MySqlConnection
Query the database server to get the list of the binlog files availble.

B

before - Variable in class io.debezium.connector.mysql.MySqlChangeRecordEmitter
 
beginTransaction(Event) - Method in class io.debezium.connector.mysql.EventBuffer
 
beginTransaction(Event) - Method in class io.debezium.connector.mysql.legacy.EventBuffer
 
bigEndianLong(byte[], int, int) - Static method in class io.debezium.connector.mysql.RowDeserializers
Read a big-endian long value.
BIGINT_CORRECTION - Static variable in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
 
BIGINT_MAX_VALUE - Static variable in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
 
BIGINT_UNSIGNED_HANDLING_MODE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
BigIntUnsignedHandlingMode(String) - Constructor for enum io.debezium.connector.mysql.MySqlConnectorConfig.BigIntUnsignedHandlingMode
 
binaryLogClient - Variable in class io.debezium.connector.mysql.MySqlTaskContext
 
binaryLogClientThreads - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
binaryLogClientThreads - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
BINLOG_FILENAME_OFFSET_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
BINLOG_FILENAME_OFFSET_KEY - Static variable in class io.debezium.connector.mysql.SourceInfo
 
BINLOG_POSITION_OFFSET_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
BINLOG_POSITION_OFFSET_KEY - Static variable in class io.debezium.connector.mysql.SourceInfo
 
BINLOG_ROW_IN_EVENT_OFFSET_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
BINLOG_ROW_IN_EVENT_OFFSET_KEY - Static variable in class io.debezium.connector.mysql.SourceInfo
 
binlogFilename() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Get the name of the MySQL binary log file that has last been processed.
binlogFilename() - Method in class io.debezium.connector.mysql.SourceInfo
Get the name of the MySQL binary log file that has last been processed.
binlogPosition() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Get the position within the MySQL binary log file of the next event to be processed.
binlogPosition() - Method in class io.debezium.connector.mysql.SourceInfo
Get the position within the MySQL binary log file of the next event to be processed.
BinlogPosition(String, long) - Constructor for class io.debezium.connector.mysql.legacy.BinlogReader.BinlogPosition
 
BinlogPosition(String, long) - Constructor for class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.BinlogPosition
 
BinlogReader - Class in io.debezium.connector.mysql.legacy
A component that reads the binlog of a MySQL server, and records any schema changes in MySqlSchema.
BinlogReader(String, MySqlTaskContext, HaltingPredicate) - Constructor for class io.debezium.connector.mysql.legacy.BinlogReader
Create a binlog reader.
BinlogReader(String, MySqlTaskContext, HaltingPredicate, long) - Constructor for class io.debezium.connector.mysql.legacy.BinlogReader
Create a binlog reader.
BinlogReader.BinlogPosition - Class in io.debezium.connector.mysql.legacy
 
BinlogReader.ReaderThreadLifecycleListener - Class in io.debezium.connector.mysql.legacy
 
binlogReaderA - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
binlogReaderB - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
BinlogReaderMetrics - Class in io.debezium.connector.mysql.legacy
 
BinlogReaderMetrics(BinaryLogClient, MySqlTaskContext, String, ChangeEventQueueMetrics) - Constructor for class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
BinlogReaderMetricsMXBean - Interface in io.debezium.connector.mysql.legacy
 
bitSlice(long, int, int, int) - Static method in class io.debezium.connector.mysql.RowDeserializers
Slice an integer out of a portion of long value.
BlockingReader - Class in io.debezium.connector.mysql.legacy
A component that blocks doing nothing until the connector task is stopped
BlockingReader(String, String) - Constructor for class io.debezium.connector.mysql.legacy.BlockingReader
 
booleanOffsetValue(Map<String, ?>, String) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
buffer - Variable in class io.debezium.connector.mysql.EventBuffer
 
buffer - Variable in class io.debezium.connector.mysql.legacy.EventBuffer
 
BUFFER_SIZE_FOR_BINLOG_READER - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
bufferSizeForBinlogReader() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
bufferSizeForStreamingChangeEventSource() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
build() - Method in class io.debezium.connector.mysql.legacy.ChainedReader.Builder
 
build() - Method in class io.debezium.connector.mysql.legacy.Filters.Builder
Build the filters.
Builder() - Constructor for class io.debezium.connector.mysql.legacy.ChainedReader.Builder
 
Builder(Configuration) - Constructor for class io.debezium.connector.mysql.legacy.Filters.Builder
Create a Builder for a filter.
BUILT_IN_DB_NAMES - Static variable in class io.debezium.connector.mysql.legacy.Filters
 
BUILT_IN_DB_NAMES - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
byteOrderOfBitType() - Method in class io.debezium.connector.mysql.MySqlValueConverters
 

C

capacity - Variable in class io.debezium.connector.mysql.EventBuffer
 
capacity - Variable in class io.debezium.connector.mysql.legacy.EventBuffer
 
capturedTablesAsStringArray() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Get all table names for all databases that are monitored whose events are captured by Debezium
capturedTablesAsStringArray() - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
Get all table names for all databases that are monitored whose events are captured by Debezium
cause - Variable in class io.debezium.connector.mysql.EventDataDeserializationExceptionData
 
ChainedReader - Class in io.debezium.connector.mysql.legacy
A Reader implementation that runs one or more other Readers in a consistently, completely, and sequentially.
ChainedReader(List<Reader>, String) - Constructor for class io.debezium.connector.mysql.legacy.ChainedReader
Create a new chained reader.
ChainedReader.Builder - Class in io.debezium.connector.mysql.legacy
 
changeEventCompleted() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
changeEventCompleted() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
changeEventQueueMetrics - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
changeEventSourceContext - Variable in class io.debezium.connector.mysql.EventBuffer
 
charset - Variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext.DatabaseLocales
 
CHARSET_NAME_CLIENT - Static variable in class io.debezium.connector.mysql.MySqlSystemVariables
 
CHARSET_NAME_CONNECTION - Static variable in class io.debezium.connector.mysql.MySqlSystemVariables
 
CHARSET_NAME_DATABASE - Static variable in class io.debezium.connector.mysql.MySqlSystemVariables
The system variable name fo the name for the character set that the current database uses.
CHARSET_NAME_RESULT - Static variable in class io.debezium.connector.mysql.MySqlSystemVariables
 
CHARSET_NAME_SERVER - Static variable in class io.debezium.connector.mysql.MySqlSystemVariables
The system variable name for the name of the character set that the server uses by default.
charsetFor(Column) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Return the Charset instance with the MySQL-specific character set name used by the given column.
charsetForTable(TableId) - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
Get the name of the character set for the give table name.
charsetNameForDatabase - Variable in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
charsetNameForDatabase() - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
Provides a map of default character sets by database/schema name.
checkLaggingLeadingInfo() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
cleanTimestamp(String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Clean input timestamp to yyyy-mm-dd hh:mm:ss[.fffffffff] format
cleanupResources() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
This method is normally called by AbstractReader.poll() when there this reader finishes normally and all generated records are consumed prior to being stopped.
clear() - Method in class io.debezium.connector.mysql.EventBuffer
Cleans-up the buffer after the transaction is either thrown away or streamed into a Kafka topic
clear() - Method in class io.debezium.connector.mysql.legacy.EventBuffer
Cleans-up the buffer after the transaction is either thrown away or streamed into a Kafka topic
clear() - Method in class io.debezium.connector.mysql.legacy.RecordMakers
Clear all of the cached record makers.
clearTableMappings() - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
Clear all of the table mappings.
client - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
client - Variable in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
client - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
client - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
clock - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
clock - Variable in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
clock - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
close() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
close() - Method in class io.debezium.connector.mysql.MySqlConnection
 
close() - Method in class io.debezium.connector.mysql.transforms.ReadToInsertEvent
 
collation - Variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext.DatabaseLocales
 
columnDefinitionListener - Variable in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
columnDefinitionListener - Variable in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
ColumnDefinitionParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing column definition part of MySQL statements.
ColumnDefinitionParserListener(TableEditor, ColumnEditor, MySqlAntlrDdlParser, List<ParseTreeListener>) - Constructor for class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
ColumnDefinitionParserListener(TableEditor, ColumnEditor, MySqlAntlrDdlParser, List<ParseTreeListener>, boolean) - Constructor for class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
columnEditor - Variable in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
columnEditor - Variable in class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
 
columnEditors - Variable in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
columnFilter - Variable in class io.debezium.connector.mysql.legacy.Filters.Builder
 
columnFilter - Variable in class io.debezium.connector.mysql.legacy.Filters
 
columnFilter() - Method in class io.debezium.connector.mysql.legacy.Filters
 
commitTransaction() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
commitTransaction() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
compareTo(GtidSet.Interval) - Method in class io.debezium.connector.mysql.GtidSet.Interval
 
complete(AbstractSnapshotChangeEventSource.SnapshotContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
completed - Variable in class io.debezium.connector.mysql.legacy.ChainedReader
 
completed - Variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
completed - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
completeEvent() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Capture that we're starting a new event.
completeEvent() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Capture that we're starting a new event.
completeReaders() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
When the task is stopped, the readers may have additional work to perform before they actually stop and before all their records have been consumed via the BaseSourceTask.poll() method.
completeSnapshot() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Denote that a snapshot has completed successfully.
completeSuccessfully() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
Call this method only when the reader has successfully completed all of its work, signaling that subsequent calls to AbstractReader.poll() should forever return null and that this reader should transition from Reader.State.STOPPING to Reader.State.STOPPED.
completeSuccessfully() - Method in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
completeSuccessfully() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
completeTransaction(boolean, Event) - Method in class io.debezium.connector.mysql.EventBuffer
Sends all events from the buffer int a final handler.
completeTransaction(boolean, Event) - Method in class io.debezium.connector.mysql.legacy.EventBuffer
Sends all events from the buffer int a final handler.
completionMessage - Variable in class io.debezium.connector.mysql.legacy.ChainedReader.Builder
 
completionMessage - Variable in class io.debezium.connector.mysql.legacy.ChainedReader
 
completionMessage(String) - Method in class io.debezium.connector.mysql.legacy.ChainedReader.Builder
Set the message that should be logged when all of the readers have completed their work.
config - Variable in class io.debezium.connector.mysql.legacy.Filters.Builder
 
config - Variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
config - Variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
config - Variable in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
config - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
config() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
config() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
config() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
config() - Method in class io.debezium.connector.mysql.MySqlConnector
 
config() - Method in class io.debezium.connector.mysql.transforms.ReadToInsertEvent
 
CONFIG_DEFINITION - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
configDef() - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
configuration - Variable in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
configure(Map<String, ?>) - Method in class io.debezium.connector.mysql.transforms.ReadToInsertEvent
 
configure(Properties) - Method in class io.debezium.connector.mysql.converters.TinyIntOneToBooleanConverter
 
configuredServerId - Variable in class io.debezium.connector.mysql.legacy.MySqlConnectorTask.ServerIdGenerator
 
connection - Variable in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
connection - Variable in class io.debezium.connector.mysql.MySqlConnectorTask
 
connection - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
connection - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
connection(boolean) - Method in class io.debezium.connector.mysql.MySqlConnection
 
CONNECTION_TIMEOUT_MS - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
connectionConfig - Variable in class io.debezium.connector.mysql.MySqlConnection
 
connectionContext - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
connectionContext - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
connectionContext - Variable in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
connectionContext - Variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
connectionCreated(RelationalSnapshotChangeEventSource.RelationalSnapshotContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
connectionMetricHandledByCoordinator() - Method in class io.debezium.connector.mysql.MySqlChangeEventSourceMetricsFactory
 
connectionString() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
connectionString() - Method in class io.debezium.connector.mysql.MySqlConnection
 
connectionTimeout - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
connectorConfig - Variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
connectorConfig - Variable in class io.debezium.connector.mysql.MySqlOffsetContext.Loader
 
connectorConfig - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
connectorConfig - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
connectorName() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
consumeEvent(Event) - Method in class io.debezium.connector.mysql.EventBuffer
 
consumeEvent(Event) - Method in class io.debezium.connector.mysql.legacy.EventBuffer
 
consumer - Variable in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
 
containsZeroValuesInDatePart(String, Column, Table) - Static method in class io.debezium.connector.mysql.MySqlValueConverters
 
context - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
CONTEXT_NAME - Static variable in class io.debezium.connector.mysql.MySqlConnectorTask
 
contextName() - Static method in class io.debezium.connector.mysql.Module
 
convert(Column, String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Converts a default value from the expected format to a logical object acceptable by the main JDBC converter.
convertDefault - Variable in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
Whether to convert the column's default value into the corresponding schema type or not.
convertDefault - Variable in class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
Whether to convert the column's default value into the corresponding schema type or not.
convertDefaultValue(boolean) - Method in class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
 
convertDefaultValueToSchemaType(ColumnEditor) - Method in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
convertDefaultValueToSchemaType(ColumnEditor) - Method in class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
 
convertDurationToMicroseconds(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Converts a value object for an expected type of Duration to Long values that represents the time in microseconds.
converted - Variable in class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
 
convertEnumToString(List<String>, Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Converts a value object for a MySQL ENUM, which is represented in the binlog events as an integer value containing the index of the enum option.
converter - Variable in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
 
converter(Column, Field) - Method in class io.debezium.connector.mysql.MySqlValueConverters
 
converterFor(RelationalColumn, CustomConverter.ConverterRegistration<SchemaBuilder>) - Method in class io.debezium.connector.mysql.converters.TinyIntOneToBooleanConverter
 
converters - Variable in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
converters - Variable in class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
convertersByTableNumber - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
convertGeometry(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Convert the a value representing a GEOMETRY byte[] value to a Geometry value used in a SourceRecord.
convertJson(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Convert the String byte[] value to a string value used in a SourceRecord.
convertPoint(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Convert the a value representing a POINT byte[] value to a Point value used in a SourceRecord.
convertSetToString(List<String>, Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Converts a value object for a MySQL SET, which is represented in the binlog events contain a long number in which every bit corresponds to a different option.
convertSetValue(Column, long, List<String>) - Method in class io.debezium.connector.mysql.MySqlValueConverters
 
convertString(Column, Field, Charset, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Convert the String or byte[] value to a string value used in a SourceRecord.
convertTimestampToLocalDateTime(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
 
convertToBit(String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
convertToBits(Column, String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Converts a string object for an expected JDBC type of Types.BIT.
convertToBits(String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
convertToBoolean(String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Converts a string object for an expected JDBC type of Types.BOOLEAN.
convertToDecimal(Column, String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Converts a string object for an expected JDBC type of Types.DECIMAL.
convertToDouble(String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Converts a string object for an expected JDBC type of Types.DOUBLE.
convertToDuration(Column, String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Converts a string object for an object type of Duration.
convertToLocalDate(Column, String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Converts a string object for an object type of LocalDate or LocalDateTime in case of MySql Date type.
convertToLocalDateTime(Column, String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Converts a string object for an object type of LocalDateTime.
convertToTimestamp(Column, String) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Converts a string object for an object type of Timestamp.
convertUnsignedBigint(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Convert the a value representing a Unsigned BIGINT value to the correct Unsigned INT representation.
convertUnsignedBigint(BigDecimal) - Static method in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
Convert original value insertion of type 'BIGINT' into the correct BIGINT UNSIGNED representation Note: Unsigned BIGINT (16-bit) is represented in 'BigDecimal' data type.
convertUnsignedInt(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Convert the a value representing a Unsigned INT value to the correct Unsigned INT representation.
convertUnsignedInteger(long) - Static method in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
Convert original value insertion of type 'INT' into the correct INT UNSIGNED representation Note: Unsigned INT (32-bit) is represented in 'Long' 64-bit data type.
convertUnsignedMediumint(int) - Static method in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
Convert original value insertion of type 'MEDIUMINT' into the correct MEDIUMINT UNSIGNED representation Note: Unsigned MEDIUMINT (32-bit) is represented in 'Integer' 32-bit data type since the MAX value of Unsigned MEDIUMINT 16777215 < Max value of Integer 2147483647
convertUnsignedMediumint(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Convert the a value representing a Unsigned MEDIUMINT value to the correct Unsigned SMALLINT representation.
convertUnsignedSmallint(int) - Static method in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
Convert original value insertion of type 'SMALLINT' into the correct SMALLINT UNSIGNED representation Note: Unsigned SMALLINT (16-bit) is represented in 'Integer' 32-bit data type.
convertUnsignedSmallint(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Convert the a value representing a Unsigned SMALLINT value to the correct Unsigned SMALLINT representation.
convertUnsignedTinyint(short) - Static method in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
Convert original value insertion of type 'TINYINT' into the correct TINYINT UNSIGNED representation Note: Unsigned TINYINT (8-bit) is represented in 'Short' 16-bit data type.
convertUnsignedTinyint(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Convert the a value representing a Unsigned TINYINT value to the correct Unsigned TINYINT representation.
convertYearToInt(Column, Field, Object) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Converts a value object for a MySQL YEAR, which appear in the binlog as an integer though returns from the MySQL JDBC driver as either a short or a Date.
counter - Variable in class io.debezium.connector.mysql.legacy.MySqlConnectorTask.ServerIdGenerator
 
create(Object[], Instant) - Method in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
Produce a create record for the row.
create(Object[], Instant, int, int) - Method in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
Produce a create record for the row.
CreateAndAlterDatabaseParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL CREATE DATABASE and ALTER DATABASE statements, to get default character sets for database.
CreateAndAlterDatabaseParserListener(MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.CreateAndAlterDatabaseParserListener
 
createAndStartTaskContext(Configuration, Filters) - Static method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
createDocumentFromOffset(Map<String, ?>) - Static method in class io.debezium.connector.mysql.legacy.SourceInfo
Create a Document from the given offset.
createDocumentFromOffset(Map<String, ?>) - Static method in class io.debezium.connector.mysql.SourceInfo
Create a Document from the given offset.
createEmpty() - Static method in class io.debezium.connector.mysql.MySqlGeometry
Create a GEOMETRYCOLLECTION EMPTY MySqlGeometry
createNewLexerInstance(CharStream) - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
createNewParserInstance(CommonTokenStream) - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
createNewSystemVariablesInstance() - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
createParseTreeWalkerListener() - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
createReconcilingBinlogReader(BinlogReader) - Method in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
Create and return a ReconcilingBinlogReader for the two binlog readers contained in this ParallelSnapshotReader.
createSchemaChangeEventsForTables(ChangeEventSource.ChangeEventSourceContext, RelationalSnapshotChangeEventSource.RelationalSnapshotContext, AbstractSnapshotChangeEventSource.SnapshottingTask) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
createSchemaEventsForTables(RelationalSnapshotChangeEventSource.RelationalSnapshotContext, Collection<TableId>, boolean) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
createStatement(Connection) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
createStatementWithLargeResultSet() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
Create a JDBC statement that can be used for large result sets.
createStatementWithLargeResultSet(Connection) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
Create a JDBC statement that can be used for large result sets.
CreateTableParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL CREATE TABLE statements.
CreateTableParserListener(MySqlAntlrDdlParser, List<ParseTreeListener>) - Constructor for class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
CreateUniqueIndexParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL CREATE UNIQUE INDEX statements, that will be used as a primary key if it's not already defined for the table.
CreateUniqueIndexParserListener(MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.CreateUniqueIndexParserListener
 
CreateViewParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL CREATE VIEW statements.
CreateViewParserListener(MySqlAntlrDdlParser, List<ParseTreeListener>) - Constructor for class io.debezium.connector.mysql.antlr.listener.CreateViewParserListener
 
currentBinlogFilename - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
currentBinlogFilename - Variable in class io.debezium.connector.mysql.SourceInfo
 
currentBinlogPosition - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
currentBinlogPosition - Variable in class io.debezium.connector.mysql.SourceInfo
 
currentDatabaseCharset() - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
Get the name of the character set for the current database, via the "character_set_database" system property.
currentEventLengthInBytes - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
currentEventLengthInBytes - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
currentGtid - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
currentGtid - Variable in class io.debezium.connector.mysql.SourceInfo
 
currentGtidSet - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
currentGtidSet - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
currentQuery - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
currentQuery - Variable in class io.debezium.connector.mysql.SourceInfo
 
currentReader - Variable in class io.debezium.connector.mysql.legacy.ChainedReader
 
currentRowNumber - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
currentRowNumber - Variable in class io.debezium.connector.mysql.SourceInfo
 

D

database() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
database() - Method in class io.debezium.connector.mysql.SourceInfo
 
DATABASE_BLACKLIST_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
DATABASE_EXCLUDE_LIST_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
DATABASE_HISTORY - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
The database history class is hidden in the MySqlConnectorConfig.configDef() since that is designed to work with a user interface, and in these situations using Kafka is the only way to go.
DATABASE_INCLUDE_LIST_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
DATABASE_WHITELIST_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
databaseEvent(String) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
databaseEvent(String) - Method in class io.debezium.connector.mysql.SourceInfo
 
databaseEvent(String, Instant) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
databaseExcludeList - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
databaseFilter() - Method in class io.debezium.connector.mysql.legacy.Filters
 
databaseIncludeList - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
DatabaseLocales(String, String) - Constructor for class io.debezium.connector.mysql.legacy.MySqlJdbcContext.DatabaseLocales
 
databaseName - Variable in class io.debezium.connector.mysql.antlr.listener.CreateAndAlterDatabaseParserListener
 
databaseName - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
databaseName - Variable in class io.debezium.connector.mysql.SourceInfo
 
databaseSchema - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
dataTypeResolver - Variable in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
DATE_FIELD_PATTERN - Static variable in class io.debezium.connector.mysql.MySqlValueConverters
Used to parse values of DATE columns.
dbFilter - Variable in class io.debezium.connector.mysql.legacy.Filters.Builder
 
dbFilter - Variable in class io.debezium.connector.mysql.legacy.Filters
 
dbHistory - Variable in class io.debezium.connector.mysql.legacy.MySqlSchema
 
dbSchema - Variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
dbSchema() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
ddlChanges - Variable in class io.debezium.connector.mysql.legacy.MySqlSchema
 
ddlChanges - Variable in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
ddlFilter - Variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
ddlFilter - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
ddlFilter() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
Get the predicate function that will return true if a DDL has to be skipped over and left out of the schema history or false when it should be processed.
ddlParser - Variable in class io.debezium.connector.mysql.legacy.MySqlSchema
 
ddlParser - Variable in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
DEFAULT_BINLOG_BUFFER_SIZE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
Default size of the binlog buffer used for examining transactions and deciding whether to propagate them or not.
DEFAULT_MIN_HALTING_DURATION - Static variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader.ParallelHaltingPredicate
 
DEFAULT_PORT - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
DEFAULT_SNAPSHOT_FETCH_SIZE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
Minimum value used for fetch size hint.
defaultParsingErrorHandler(String, Exception) - Static method in class io.debezium.connector.mysql.MySqlValueConverters
 
defaultSelector(MySqlConnectorConfig) - Static method in class io.debezium.connector.mysql.MySqlTopicSelector
 
defaultSelector(String, String) - Static method in class io.debezium.connector.mysql.MySqlTopicSelector
Deprecated.
defaultValueColumnEditor - Variable in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
defaultValueConverter - Variable in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
defaultValueConverter - Variable in class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
 
defaultValueListener - Variable in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
defaultValueListener - Variable in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
DefaultValueParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing default value definition part of MySQL statements.
DefaultValueParserListener(ColumnEditor, MySqlValueConverters, AtomicReference<Boolean>, boolean) - Constructor for class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
 
delayedSchemaSnapshotTables - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
delete(SourceInfo, Object[], int, int, BitSet, Instant, BlockingConsumer<SourceRecord>) - Method in interface io.debezium.connector.mysql.legacy.RecordMakers.Converter
 
delete(Object[], Instant) - Method in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
Produce a delete record for the row.
delete(Object[], Instant, int, int) - Method in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
Produce a delete record for the row.
DeleteRowsDeserializer(Map<Long, TableMapEventData>) - Constructor for class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserialize(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.StopEventDataDeserializer
 
deserializeDate(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserializeDate(ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Converts a MySQL DATE value to a LocalDate.
deserializeDate(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
deserializeDate(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
deserializeDatetime(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserializeDatetime(ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Converts a MySQL DATETIME value without fractional seconds to a LocalDateTime.
deserializeDatetime(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
deserializeDatetime(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
deserializeDatetimeV2(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserializeDatetimeV2(int, ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Converts a MySQL DATETIME value with fractional seconds to a LocalDateTime.
deserializeDatetimeV2(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
deserializeDatetimeV2(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
deserializeFractionalSecondsInNanos(int, ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Read the binary input stream to obtain the number of nanoseconds given the fractional seconds precision, or fsp.
deserializeFractionalSecondsInNanosNegative(int, ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Read the binary input stream to obtain the number of nanoseconds given the fractional seconds precision, or fsp.
deserializeString(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserializeString(int, ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Converts a MySQL string to a byte[].
deserializeString(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
deserializeString(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
deserializeTime(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserializeTime(ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Converts a MySQL TIME value without fractional seconds to a Duration.
deserializeTime(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
deserializeTime(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
deserializeTimestamp(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserializeTimestamp(ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Converts a MySQL TIMESTAMP value without fractional seconds to a OffsetDateTime.
deserializeTimestamp(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
deserializeTimestamp(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
deserializeTimestampV2(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserializeTimestampV2(int, ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Converts a MySQL TIMESTAMP value with fractional seconds to a OffsetDateTime.
deserializeTimestampV2(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
deserializeTimestampV2(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
deserializeTimeV2(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserializeTimeV2(int, ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Converts a MySQL TIME value with fractional seconds to a Duration.
deserializeTimeV2(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
deserializeTimeV2(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
deserializeVarString(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserializeVarString(int, ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Converts a MySQL string to a byte[].
deserializeVarString(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
deserializeVarString(int, ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
deserializeYear(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.DeleteRowsDeserializer
 
deserializeYear(ByteArrayInputStream) - Static method in class io.debezium.connector.mysql.RowDeserializers
Converts a MySQL YEAR value to a Year object.
deserializeYear(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
deserializeYear(ByteArrayInputStream) - Method in class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
destroy() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
 
destroy() - Method in class io.debezium.connector.mysql.legacy.ChainedReader
 
destroy() - Method in interface io.debezium.connector.mysql.legacy.Reader
After the reader has stopped, there may still be some resources we want left available until the connector task is destroyed.
determineLeadingReader() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
determineSnapshotOffset(RelationalSnapshotChangeEventSource.RelationalSnapshotContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
DISABLED - io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
Establish an unencrypted connection.
dispatcher - Variable in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
doCleanup() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
The reader has completed all processing and all enqueued records have been consumed, so this reader should clean up any resources that might remain.
doCleanup() - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
doCleanup() - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
doDestroy() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
The reader has been requested to de-initialize resources after stopping.
doDestroy() - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
doDestroy() - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
doInitialize() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
The reader has been requested to initialize resources prior to starting.
doInitialize() - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
doInitialize() - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
doPoll() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
doPoll() - Method in class io.debezium.connector.mysql.MySqlConnectorTask
 
doStart() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
The reader has been requested to start, so initialize any un-initialized resources required by the reader.
doStart() - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
doStart() - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
Start the snapshot and return immediately.
doStop() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
The reader has been requested to stop, so perform any work required to stop the reader's resources that were previously started.
doStop() - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
doStop() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
doStop() - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
doStop() - Method in class io.debezium.connector.mysql.MySqlConnectorTask
 
DropDatabaseParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL DROP DATABASE statements.
DropDatabaseParserListener(MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.DropDatabaseParserListener
 
DropTableParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL DROP TABLE statements.
DropTableParserListener(MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.DropTableParserListener
 
DropViewParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL DROP VIEW statements.
DropViewParserListener(MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.DropViewParserListener
 

E

EARLIEST - io.debezium.connector.mysql.MySqlConnectorConfig.GtidNewChannelPosition
This mode will start reading new gtid channel from earliest available position in server.
earliestBinlogFilename() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
Determine the earliest binlog filename that is still available in the server.
earliestBinlogFilename() - Method in class io.debezium.connector.mysql.MySqlConnection
Determine the earliest binlog filename that is still available in the server.
emit(TableId, T) - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSource.BinlogChangeEmitter
 
emitChangeEvent(MySqlOffsetContext, List<SchemaChangeEvent>, String, DdlParserListener.Event, TableId, SchemaChangeEvent.SchemaChangeEventType, boolean) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
emitTombstoneOnDelete - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
ENABLE_TIME_ADJUSTER - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
end - Variable in class io.debezium.connector.mysql.GtidSet.Interval
 
enqueueRecord(SourceRecord) - Method in class io.debezium.connector.mysql.legacy.AbstractReader
Enqueue a record so that it can be obtained when this reader is polled.
enqueueSchemaChanges(String, Set<TableId>, String) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
enterAlterByAddColumn(MySqlParser.AlterByAddColumnContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterByAddColumns(MySqlParser.AlterByAddColumnsContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterByAddPrimaryKey(MySqlParser.AlterByAddPrimaryKeyContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterByAddUniqueKey(MySqlParser.AlterByAddUniqueKeyContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterByChangeColumn(MySqlParser.AlterByChangeColumnContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterByChangeDefault(MySqlParser.AlterByChangeDefaultContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterByDropColumn(MySqlParser.AlterByDropColumnContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterByDropPrimaryKey(MySqlParser.AlterByDropPrimaryKeyContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterByModifyColumn(MySqlParser.AlterByModifyColumnContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterByRename(MySqlParser.AlterByRenameContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterByRenameColumn(MySqlParser.AlterByRenameColumnContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterSimpleDatabase(MySqlParser.AlterSimpleDatabaseContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateAndAlterDatabaseParserListener
 
enterAlterTable(MySqlParser.AlterTableContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
enterAlterView(MySqlParser.AlterViewContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterViewParserListener
 
enterAutoIncrementColumnConstraint(MySqlParser.AutoIncrementColumnConstraintContext) - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
enterColumnCreateTable(MySqlParser.ColumnCreateTableContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
enterColumnDeclaration(MySqlParser.ColumnDeclarationContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
enterColumnDefinition(MySqlParser.ColumnDefinitionContext) - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
enterCreateDatabase(MySqlParser.CreateDatabaseContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateAndAlterDatabaseParserListener
 
enterCreateDatabaseOption(MySqlParser.CreateDatabaseOptionContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateAndAlterDatabaseParserListener
 
enterCreateIndex(MySqlParser.CreateIndexContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateUniqueIndexParserListener
 
enterCreateView(MySqlParser.CreateViewContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateViewParserListener
 
enterDefaultValue(MySqlParser.DefaultValueContext) - Method in class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
 
enterDropDatabase(MySqlParser.DropDatabaseContext) - Method in class io.debezium.connector.mysql.antlr.listener.DropDatabaseParserListener
 
enterDropTable(MySqlParser.DropTableContext) - Method in class io.debezium.connector.mysql.antlr.listener.DropTableParserListener
 
enterDropView(MySqlParser.DropViewContext) - Method in class io.debezium.connector.mysql.antlr.listener.DropViewParserListener
 
enterEveryRule(ParserRuleContext) - Method in class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
 
enterNullNotnull(MySqlParser.NullNotnullContext) - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
enterPrimaryKeyColumnConstraint(MySqlParser.PrimaryKeyColumnConstraintContext) - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
enterPrimaryKeyTableConstraint(MySqlParser.PrimaryKeyTableConstraintContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
enterRenameTableClause(MySqlParser.RenameTableClauseContext) - Method in class io.debezium.connector.mysql.antlr.listener.RenameTableParserListener
 
enterRoutineBody(MySqlParser.RoutineBodyContext) - Method in class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
 
enterSerialDefaultColumnConstraint(MySqlParser.SerialDefaultColumnConstraintContext) - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
enterSetCharset(MySqlParser.SetCharsetContext) - Method in class io.debezium.connector.mysql.antlr.listener.SetStatementParserListener
 
enterSetNames(MySqlParser.SetNamesContext) - Method in class io.debezium.connector.mysql.antlr.listener.SetStatementParserListener
 
enterSetVariable(MySqlParser.SetVariableContext) - Method in class io.debezium.connector.mysql.antlr.listener.SetStatementParserListener
 
enterTableOptionCharset(MySqlParser.TableOptionCharsetContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
enterTruncateTable(MySqlParser.TruncateTableContext) - Method in class io.debezium.connector.mysql.antlr.listener.TruncateTableParserListener
 
enterUniqueKeyColumnConstraint(MySqlParser.UniqueKeyColumnConstraintContext) - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
enterUniqueKeyTableConstraint(MySqlParser.UniqueKeyTableConstraintContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
enterUseStatement(MySqlParser.UseStatementContext) - Method in class io.debezium.connector.mysql.antlr.listener.UseStatementParserListener
 
EPOCH_DATE - Static variable in class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
EPOCH_EQUIVALENT_DATE - Static variable in class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
EPOCH_EQUIVALENT_TIMESTAMP - Static variable in class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
EPOCH_TIMESTAMP - Static variable in class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
equals(Object) - Method in class io.debezium.connector.mysql.GtidSet
 
equals(Object) - Method in class io.debezium.connector.mysql.GtidSet.Interval
 
equals(Object) - Method in class io.debezium.connector.mysql.GtidSet.UUIDSet
 
equals(Object) - Method in class io.debezium.connector.mysql.legacy.BinlogReader.BinlogPosition
 
equals(Object) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.BinlogPosition
 
error(String, Exception) - Method in interface io.debezium.connector.mysql.MySqlValueConverters.ParsingErrorHandler
 
errorHandler - Variable in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
errorHandler - Variable in class io.debezium.connector.mysql.MySqlConnectorTask
 
errorHandler - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
errors - Variable in class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
Collection of catched exceptions.
escapeOption(String) - Static method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
event(DataCollectionId, Instant) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
EVENT_DESERIALIZATION_FAILURE_HANDLING_MODE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
EventBuffer - Class in io.debezium.connector.mysql
This class represents a look-ahead buffer that allows Debezium to accumulate binlog events and decide if the last event in transaction is either ROLLBACK or COMMIT.
EventBuffer - Class in io.debezium.connector.mysql.legacy
This class represents a look-ahead buffer that allows Debezium to accumulate binlog events and decide if the last event in transaction is either ROLLBACK or COMMIT.
EventBuffer(int, BinlogReader) - Constructor for class io.debezium.connector.mysql.legacy.EventBuffer
 
EventBuffer(int, MySqlStreamingChangeEventSource, ChangeEventSource.ChangeEventSourceContext) - Constructor for class io.debezium.connector.mysql.EventBuffer
 
EventDataDeserializationExceptionData - Class in io.debezium.connector.mysql
Event data for an event of type EventType.INCIDENT representing a failure to deserialize a binlog event.
EventDataDeserializationExceptionData(EventDataDeserializationException) - Constructor for class io.debezium.connector.mysql.EventDataDeserializationExceptionData
 
eventDeserializationFailureHandlingMode - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
eventDeserializationFailureHandlingMode - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
eventDispatcher - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
eventHandlers - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
eventHandlers - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
eventProcessingFailureHandlingMode() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
eventProcessingFailureHandlingMode() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
EVENTS_TO_SKIP_OFFSET_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
EVENTS_TO_SKIP_OFFSET_KEY - Static variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
eventsToSkipUponRestart() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Get the number of events after the last transaction BEGIN that we've already processed.
eventsToSkipUponRestart() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Get the number of events after the last transaction BEGIN that we've already processed.
eventTimestamp - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
excludeAllTables(Filters) - Method in class io.debezium.connector.mysql.legacy.Filters.Builder
Exclude all those tables included by the given filter.
excludeDatabases(Predicate<String>) - Method in class io.debezium.connector.mysql.legacy.Filters.Builder
Exclude all the databases that the given predicate tests as true for.
excludeTables(Predicate<TableId>) - Method in class io.debezium.connector.mysql.legacy.Filters.Builder
Exclude all the tables that the given predicate tests as true for.
execute() - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
Perform the snapshot using the same logic as the "mysqldump" utility.
execute(ChangeEventSource.ChangeEventSourceContext) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
executorService - Variable in class io.debezium.connector.mysql.legacy.SnapshotReader
 
exitAlterByAddColumn(MySqlParser.AlterByAddColumnContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
exitAlterByAddColumns(MySqlParser.AlterByAddColumnsContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
exitAlterByChangeColumn(MySqlParser.AlterByChangeColumnContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
exitAlterByChangeDefault(MySqlParser.AlterByChangeDefaultContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
exitAlterByModifyColumn(MySqlParser.AlterByModifyColumnContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
exitAlterByRenameColumn(MySqlParser.AlterByRenameColumnContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
exitAlterTable(MySqlParser.AlterTableContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
exitAlterView(MySqlParser.AlterViewContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterViewParserListener
 
exitAtomTableItem(MySqlParser.AtomTableItemContext) - Method in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
exitColumnCreateTable(MySqlParser.ColumnCreateTableContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
exitColumnDeclaration(MySqlParser.ColumnDeclarationContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
exitColumnDefinition(MySqlParser.ColumnDefinitionContext) - Method in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
exitColumnDefinition(MySqlParser.ColumnDefinitionContext) - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
exitCopyCreateTable(MySqlParser.CopyCreateTableContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
exitCreateDatabase(MySqlParser.CreateDatabaseContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateAndAlterDatabaseParserListener
 
exitCreateView(MySqlParser.CreateViewContext) - Method in class io.debezium.connector.mysql.antlr.listener.CreateViewParserListener
 
exitEveryRule(ParserRuleContext) - Method in class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
 
exitQuerySpecification(MySqlParser.QuerySpecificationContext) - Method in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
exitQuerySpecificationNointo(MySqlParser.QuerySpecificationNointoContext) - Method in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
exitSubqueryTableItem(MySqlParser.SubqueryTableItemContext) - Method in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
EXPOSED_FIELDS - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
EXTENDED - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
This mode will block all writes for the entire duration of the snapshot.
extractCharset(MySqlParser.CharsetNameContext, MySqlParser.CollationNameContext) - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
Obtains the charset name either form charset if present or from collation.
extractEnumAndSetOptions(Column) - Method in class io.debezium.connector.mysql.MySqlValueConverters
 
extractEnumAndSetOptions(List<String>) - Static method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
Extracts the enumeration values properly parsed and escaped.
extractEnumAndSetOptionsAsString(Column) - Method in class io.debezium.connector.mysql.MySqlValueConverters
 

F

factory - Variable in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
factory() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
FACTORY - Static variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
failed(Throwable) - Method in class io.debezium.connector.mysql.legacy.AbstractReader
Call this method only when the reader has failed, that a subsequent call to AbstractReader.poll() should throw this error, and that AbstractReader.doCleanup() can be called at any time.
failed(Throwable, String) - Method in class io.debezium.connector.mysql.legacy.AbstractReader
Call this method only when the reader has failed, that a subsequent call to AbstractReader.poll() should throw this error, and that AbstractReader.doCleanup() can be called at any time.
failure - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
failureException - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
FALLBACK - Static variable in class io.debezium.connector.mysql.converters.TinyIntOneToBooleanConverter
 
filename - Variable in class io.debezium.connector.mysql.legacy.BinlogReader.BinlogPosition
 
filename - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.BinlogPosition
 
filterGtidSet(GtidSet, GtidSet) - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
Apply the include/exclude GTID source filters to the current GTID set and merge them onto the currently available GTID set from a MySQL server.
filterGtidSet(GtidSet, GtidSet) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Apply the include/exclude GTID source filters to the current GTID set and merge them onto the currently available GTID set from a MySQL server.
filters - Variable in class io.debezium.connector.mysql.legacy.MySqlSchema
 
filters - Variable in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
filters - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
filters() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Get the database and table filters defined by the configuration.
Filters - Class in io.debezium.connector.mysql.legacy
A utility that is contains various filters for acceptable database names, TableIds, and columns.
Filters(Predicate<String>, Predicate<TableId>, Predicate<String>, Predicate<TableId>, Predicate<TableId>, Tables.ColumnNameFilter) - Constructor for class io.debezium.connector.mysql.legacy.Filters
 
Filters.Builder - Class in io.debezium.connector.mysql.legacy
 
forScope(SystemVariables.Scope) - Method in class io.debezium.connector.mysql.MySqlSystemVariables
 
forServerWithId(String) - Method in class io.debezium.connector.mysql.GtidSet
Find the GtidSet.UUIDSet for the server with the specified Uuid.
forTable(long, BitSet, BlockingConsumer<SourceRecord>) - Method in class io.debezium.connector.mysql.legacy.RecordMakers
Obtain the record maker for the given table, using the specified columns and sending records to the given consumer.
forTable(TableId, BitSet, BlockingConsumer<SourceRecord>) - Method in class io.debezium.connector.mysql.legacy.RecordMakers
Obtain the record maker for the given table, using the specified columns and sending records to the given consumer.
forwardTillPosition - Variable in class io.debezium.connector.mysql.EventBuffer
Contains the position of the last event belonging to the transaction that has not fit into the buffer.
forwardTillPosition - Variable in class io.debezium.connector.mysql.legacy.EventBuffer
Contains the position of the last event belonging to the transaction that has not fit into the buffer.
fromBytes(byte[]) - Static method in class io.debezium.connector.mysql.MySqlGeometry
Create a MySqlGeometry from the original byte array from MySQL binlog event

G

generateReadEvents() - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
Set this reader's execution to produce a Envelope.Operation.READ event for each row.
getAllConfigurationFields() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
getAllConfigurationFields() - Method in class io.debezium.connector.mysql.MySqlConnectorTask
 
getAllFilters(Configuration) - Static method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
Get the filters representing all tables represented by the config.
getAllTableIds(RelationalSnapshotChangeEventSource.RelationalSnapshotContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
getBinaryLogClient() - Method in class io.debezium.connector.mysql.MySqlTaskContext
 
getBinlogClient() - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
getBinlogFilename() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getBinlogFilename() - Method in interface io.debezium.connector.mysql.legacy.BinlogReaderMetricsMXBean
Name of the current MySQL binlog file being read by underlying mysql-binlog-client.
getBinlogFilename() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getBinlogFilename() - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetricsMXBean
Name of the current MySQL binlog file being read by underlying mysql-binlog-client.
getBinlogPosition() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getBinlogPosition() - Method in interface io.debezium.connector.mysql.legacy.BinlogReaderMetricsMXBean
Current MySQL binlog offset position being read by underlying mysql-binlog-client.
getBinlogPosition() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getBinlogPosition() - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetricsMXBean
Current MySQL binlog offset position being read by underlying mysql-binlog-client.
getBinlogSslSocketFactory(MySqlJdbcContext) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
getBinlogSslSocketFactory(MySqlConnectorConfig, MySqlConnection) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
getBinlogTimestampSeconds() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getBinlogTimestampSeconds() - Method in class io.debezium.connector.mysql.SourceInfo
 
getCapturedTables() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getCapturedTables() - Method in interface io.debezium.connector.mysql.legacy.ReaderMetricsMXBean
 
getCapturedTables() - Method in class io.debezium.connector.mysql.legacy.SnapshotReaderMetrics
 
getCapturedTables() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSourceMetrics
 
getCapturedTables() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getCause() - Method in class io.debezium.connector.mysql.EventDataDeserializationExceptionData
 
getColumn() - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
getColumnEditor() - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
getColumnExcludeNameFilter(String) - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getColumnIncludeNameFilter(String) - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getColumnValue(ResultSet, int, Column, Table, T) - Method in class io.debezium.connector.mysql.MySqlConnection
 
getConfiguredServerId() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask.ServerIdGenerator
 
getConnectionContext() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
getConnectionTimeout() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
getConnectionTimeout() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getConnectorConfig() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
getConnectorName() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getContextName() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getConverters() - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
getCreateTableEvent(RelationalSnapshotChangeEventSource.RelationalSnapshotContext, Table) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
getCreateTableFilters(Filters) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
Get the filters for table creation.
getCurrentBinlogFilename() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getCurrentBinlogFilename() - Method in class io.debezium.connector.mysql.SourceInfo
 
getCurrentBinlogPosition() - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
getCurrentBinlogPosition() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getCurrentBinlogPosition() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
getCurrentBinlogPosition() - Method in class io.debezium.connector.mysql.SourceInfo
 
getCurrentGtid() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getCurrentGtid() - Method in class io.debezium.connector.mysql.SourceInfo
 
getCurrentRowNumber() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getCurrentRowNumber() - Method in class io.debezium.connector.mysql.SourceInfo
 
getDatabaseExcludeList() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getDatabaseIncludeList() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getDdlFilter() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getDdlParser() - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
getEnd() - Method in class io.debezium.connector.mysql.GtidSet.Interval
Get the ending transaction number in this interval.
getErrors() - Method in class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
Returns all caught errors during tree walk.
getEstimatedTableSize(TableId) - Method in class io.debezium.connector.mysql.MySqlConnection
 
getEventSourcePosition(DataCollectionId, OffsetContext, Object, Struct) - Method in class io.debezium.connector.mysql.MySqlEventMetadataProvider
 
getEventTimestamp(DataCollectionId, OffsetContext, Object, Struct) - Method in class io.debezium.connector.mysql.MySqlEventMetadataProvider
 
getFilename() - Method in class io.debezium.connector.mysql.legacy.BinlogReader.BinlogPosition
 
getFilename() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.BinlogPosition
 
getGtidSet() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getGtidSet() - Method in interface io.debezium.connector.mysql.legacy.BinlogReaderMetricsMXBean
Current MySQL Gtid being read by underlying mysql-binlog-client.
getGtidSet() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getGtidSet() - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetricsMXBean
Current MySQL Gtid being read by underlying mysql-binlog-client.
getGtidSetBeginning() - Method in class io.debezium.connector.mysql.GtidSet
Returns a copy with all intervals set to beginning
getHistoryRecordComparator() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getHoldingGlobalLock() - Method in class io.debezium.connector.mysql.legacy.SnapshotReaderMetrics
 
getHoldingGlobalLock() - Method in interface io.debezium.connector.mysql.legacy.SnapshotReaderMetricsMXBean
 
getHoldingGlobalLock() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSourceMetrics
 
getHoldingGlobalLock() - Method in interface io.debezium.connector.mysql.MySqlSnapshotChangeEventSourceMetricsMXBean
 
getIncrementalSnapshotChangeEventSource(OffsetContext, SnapshotProgressListener, DataChangeEventListener) - Method in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
getIncrementalSnapshotContext() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
getIntervals() - Method in class io.debezium.connector.mysql.GtidSet.UUIDSet
Get the intervals of transaction numbers.
getIsGtidModeEnabled() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getIsGtidModeEnabled() - Method in interface io.debezium.connector.mysql.legacy.BinlogReaderMetricsMXBean
Tracks if the connector is running using Gtids to track current offset.
getIsGtidModeEnabled() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getIsGtidModeEnabled() - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetricsMXBean
Tracks if the connector is running using Gtids to track current offset.
getLaggingReader() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
getLastEvent() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getLastEvent() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getLastOffset() - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
getLastTransactionId() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getLastTransactionId() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getLeadingReader() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
getLockStatement() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
Determine which flavour of MySQL locking to use.
getMetrics() - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
getMetrics() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
getMilliSecondsBehindSource() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getMilliSecondsBehindSource() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getMilliSecondsSinceLastEvent() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getMilliSecondsSinceLastEvent() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getMonitoredTables() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
Deprecated.
Superseded by the 'Captured Tables' metric. Use BinlogReaderMetrics.getCapturedTables(). Scheduled for removal in a future release.
getMonitoredTables() - Method in interface io.debezium.connector.mysql.legacy.ReaderMetricsMXBean
Deprecated.
Superseded by the 'Captured Tables' metric. Use ReaderMetricsMXBean.getCapturedTables(). Scheduled for removal in a future release.
getMonitoredTables() - Method in class io.debezium.connector.mysql.legacy.SnapshotReaderMetrics
 
getMonitoredTables() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSourceMetrics
 
getMonitoredTables() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getNewColumnValues() - Method in class io.debezium.connector.mysql.MySqlChangeRecordEmitter
 
getNewFilters(Map<String, ?>, Configuration) - Static method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
Get the filters representing the tables that have been newly added to the config, but not those that previously existed in the config.
getNextServerId() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask.ServerIdGenerator
 
getNumberOfCommittedTransactions() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getNumberOfCommittedTransactions() - Method in interface io.debezium.connector.mysql.legacy.BinlogReaderMetricsMXBean
Tracks the number of committed transactions.
getNumberOfCommittedTransactions() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getNumberOfCommittedTransactions() - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetricsMXBean
Tracks the number of committed transactions.
getNumberOfDisconnects() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getNumberOfDisconnects() - Method in interface io.debezium.connector.mysql.legacy.BinlogReaderMetricsMXBean
Tracks the number of times the underlying mysql-binlog-client has been disconnected from MySQL.
getNumberOfDisconnects() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getNumberOfDisconnects() - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetricsMXBean
Tracks the number of times the underlying mysql-binlog-client has been disconnected from MySQL.
getNumberOfLargeTransactions() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getNumberOfLargeTransactions() - Method in interface io.debezium.connector.mysql.legacy.BinlogReaderMetricsMXBean
Tracks the number of transaction which contains events that contained more entries than could be contained within the connectors {@see io.debezium.connector.mysql.EventBuffer} instance.
getNumberOfLargeTransactions() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getNumberOfLargeTransactions() - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetricsMXBean
Tracks the number of transaction which contains events that contained more entries than could be contained within the connectors {@see io.debezium.connector.mysql.EventBuffer} instance.
getNumberOfNotWellFormedTransactions() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getNumberOfNotWellFormedTransactions() - Method in interface io.debezium.connector.mysql.legacy.BinlogReaderMetricsMXBean
Tracks the number of transactions which are not well-formed.
getNumberOfNotWellFormedTransactions() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getNumberOfNotWellFormedTransactions() - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetricsMXBean
Tracks the number of transactions which are not well-formed.
getNumberOfRolledBackTransactions() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getNumberOfRolledBackTransactions() - Method in interface io.debezium.connector.mysql.legacy.BinlogReaderMetricsMXBean
Tracks the number of rolled back transactions.
getNumberOfRolledBackTransactions() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getNumberOfRolledBackTransactions() - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetricsMXBean
Tracks the number of rolled back transactions.
getNumberOfSkippedEvents() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getNumberOfSkippedEvents() - Method in interface io.debezium.connector.mysql.legacy.BinlogReaderMetricsMXBean
Tracks the number of events skipped by underlying mysql-binlog-client, generally due to the client being unable to properly deserialize the event.
getNumberOfSkippedEvents() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getNumberOfSkippedEvents() - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetricsMXBean
Tracks the number of events skipped by underlying mysql-binlog-client, generally due to the client being unable to properly deserialize the event.
getOffset() - Method in class io.debezium.connector.mysql.MySqlChangeRecordEmitter
 
getOffset() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
getOldColumnValues() - Method in class io.debezium.connector.mysql.MySqlChangeRecordEmitter
 
getOldFilters(Map<String, ?>, Configuration) - Static method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
Get the filters representing those tables that previously existed in the config, but not those newly added to the config.
getOperation() - Method in class io.debezium.connector.mysql.MySqlChangeRecordEmitter
 
getPartition() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Get the Kafka Connect detail about the source "partition", which describes the portion of the source that we are consuming.
getPartition() - Method in class io.debezium.connector.mysql.MySqlOffsetContext.Loader
 
getPosition() - Method in class io.debezium.connector.mysql.legacy.BinlogReader.BinlogPosition
 
getPosition() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.BinlogPosition
 
getQuery() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getQuery() - Method in class io.debezium.connector.mysql.SourceInfo
 
getRestartOffset(Map<String, ?>) - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
Get the offset to restart the connector from.
getRows(E) - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSource.RowsProvider
 
getSchema() - Method in class io.debezium.connector.mysql.MySqlTaskContext
 
getSelectedColumns() - Method in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
getServerId() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getServerId() - Method in class io.debezium.connector.mysql.SourceInfo
 
getSessionVariableForSslVersion() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
Read the Ssl Version session variable.
getSessionVariableForSslVersion() - Method in class io.debezium.connector.mysql.MySqlConnection
Read the Ssl Version session variable.
getSnapshotChangeEventSource(OffsetContext, SnapshotProgressListener) - Method in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
getSnapshotLockingMode() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getSnapshotMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider) - Method in class io.debezium.connector.mysql.MySqlChangeEventSourceMetricsFactory
 
getSnapshotMode() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getSnapshotNewTables() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getSnapshotSelect(RelationalSnapshotChangeEventSource.RelationalSnapshotContext, TableId) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
Generate a valid sqlserver query string for the specified table
getSnapshottingTask(OffsetContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
getSource() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
getSourceEventPosition() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getSourceEventPosition() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getSourceInfo() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
getSourceInfoSchema() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
getSourceInfoStructMaker() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getSourceInfoStructMaker(CommonConnectorConfig.Version) - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getSourceRecordOffset(Map<String, Object>) - Method in class io.debezium.connector.mysql.legacy.RecordMakers
 
getSrid() - Method in class io.debezium.connector.mysql.MySqlGeometry
Returns the coordinate reference system identifier (SRID)
getStart() - Method in class io.debezium.connector.mysql.GtidSet.Interval
Get the starting transaction number in this interval.
getStreamingChangeEventSource(OffsetContext) - Method in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
getStreamingMetrics(T, ChangeEventQueueMetrics, EventMetadataProvider) - Method in class io.debezium.connector.mysql.MySqlChangeEventSourceMetricsFactory
 
getTableExcludeList() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getTableFilter() - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
getTableId(long) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
Return the table id associated with MySQL-specific table number.
getTableId(E) - Method in interface io.debezium.connector.mysql.MySqlStreamingChangeEventSource.TableIdProvider
 
getTableId(DdlParserListener.Event) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
getTableIdFromTableNumber(long) - Method in class io.debezium.connector.mysql.legacy.RecordMakers
Converts table number back to table id
getTableIncludeList() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getTableSourceItemContext(MySqlParser.TableSourceContext) - Method in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
getTemporalPrecisionMode() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
getThreadId() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
getThreadId() - Method in class io.debezium.connector.mysql.SourceInfo
 
getTopicSelector() - Method in class io.debezium.connector.mysql.MySqlTaskContext
 
getTotalNumberOfEventsSeen() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
getTotalNumberOfEventsSeen() - Method in class io.debezium.connector.mysql.legacy.SnapshotReaderMetrics
 
getTotalNumberOfEventsSeen() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSourceMetrics
 
getTotalNumberOfEventsSeen() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
getTransactionContext() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
getTransactionId() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
getTransactionId(DataCollectionId, OffsetContext, Object, Struct) - Method in class io.debezium.connector.mysql.MySqlEventMetadataProvider
 
getUUID() - Method in class io.debezium.connector.mysql.GtidSet.UUIDSet
Get the Uuid for the server that generated the GTIDs.
getUUIDSets() - Method in class io.debezium.connector.mysql.GtidSet
Get an immutable collection of the range of GTIDs for a single server.
getValue() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.BigIntUnsignedHandlingMode
 
getValue() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.GtidNewChannelPosition
 
getValue() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
 
getValue() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
 
getValue() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
 
getValue() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotNewTables
 
getValueConverters(MySqlConnectorConfig) - Static method in class io.debezium.connector.mysql.legacy.MySqlSchema
 
getValueConverters(MySqlConnectorConfig) - Method in class io.debezium.connector.mysql.MySqlConnectorTask
 
getWkb() - Method in class io.debezium.connector.mysql.MySqlGeometry
Returns the standard well-known binary representation of the MySQL byte
gitIdNewChannelPosition - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
GLOBAL - io.debezium.connector.mysql.MySqlSystemVariables.MySqlScope
 
globalLock() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
globalLockAcquired() - Method in class io.debezium.connector.mysql.legacy.SnapshotReaderMetrics
 
globalLockAcquired() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSourceMetrics
 
globalLockAcquiredAt - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
globalLockReleased() - Method in class io.debezium.connector.mysql.legacy.SnapshotReaderMetrics
 
globalLockReleased() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSourceMetrics
 
globalUnlock() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
GTID_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
GTID_KEY - Static variable in class io.debezium.connector.mysql.SourceInfo
 
GTID_NEW_CHANNEL_POSITION - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
If set to 'latest', connector when encountering new GTID channel after job restart will start reading it from the latest executed position (default).
GTID_SET_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
GTID_SET_KEY - Static variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
GTID_SOURCE_EXCLUDES - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
A comma-separated list of regular expressions that match source UUIDs in the GTID set used to find the binlog position in the MySQL server.
GTID_SOURCE_FILTER_DML_EVENTS - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
If set to true, we will only produce DML events into Kafka for transactions that were written on MySQL servers with UUIDs matching the filters defined by the MySqlConnectorConfig.GTID_SOURCE_INCLUDES or MySqlConnectorConfig.GTID_SOURCE_EXCLUDES configuration options, if they are specified.
GTID_SOURCE_INCLUDES - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
A comma-separated list of regular expressions that match source UUIDs in the GTID set used to find the binlog position in the MySQL server.
gtidDmlSourceFilter - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
gtidDmlSourceFilter - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
gtidFilter - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader.OffsetLimitPredicate
 
gtidNewChannelPosition() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
GtidNewChannelPosition(String) - Constructor for enum io.debezium.connector.mysql.MySqlConnectorConfig.GtidNewChannelPosition
 
gtidSet - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
gtidSet - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
gtidSet() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Get the string representation of the GTID range for the MySQL binary log file.
gtidSet() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Get the string representation of the GTID range for the MySQL binary log file.
GtidSet - Class in io.debezium.connector.mysql
A set of MySQL GTIDs.
GtidSet(String) - Constructor for class io.debezium.connector.mysql.GtidSet
 
GtidSet(Map<String, GtidSet.UUIDSet>) - Constructor for class io.debezium.connector.mysql.GtidSet
 
GtidSet.Interval - Class in io.debezium.connector.mysql
 
GtidSet.UUIDSet - Class in io.debezium.connector.mysql
A range of GTIDs for a single server with a specific Uuid.
gtidSourceFilter - Variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
gtidSourceFilter - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
gtidSourceFilter - Variable in class io.debezium.connector.mysql.MySqlHistoryRecordComparator
 
gtidSourceFilter() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
Get the predicate function that will return true if a GTID source is to be included, or false if a GTID source is to be excluded.
gtidSourceFilter() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
Get the predicate function that will return true if a GTID source is to be included, or false if a GTID source is to be excluded.

H

HaltingPredicate - Interface in io.debezium.connector.mysql
A predicate invoked by Reader implementations in order to determine whether they should continue with processing records or not.
handleChange(Event, String, Class<T>, MySqlStreamingChangeEventSource.TableIdProvider<T>, MySqlStreamingChangeEventSource.RowsProvider<T, U>, MySqlStreamingChangeEventSource.BinlogChangeEmitter<U>) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
handleDelete(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Generate source records for the supplied event with an DeleteRowsEventData.
handleDelete(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Generate source records for the supplied event with an DeleteRowsEventData.
handleEvent(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
handleEvent(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
handleGtidEvent(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Handle the supplied event with a GtidEventData that signals the beginning of a GTID transaction.
handleGtidEvent(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Handle the supplied event with a GtidEventData that signals the beginning of a GTID transaction.
handleInsert(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Generate source records for the supplied event with an WriteRowsEventData.
handleInsert(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Generate source records for the supplied event with an WriteRowsEventData.
handleQueryEvent(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Handle the supplied event with an QueryEventData by possibly recording the DDL statements as changes in the MySQL schemas.
handleQueryEvent(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Handle the supplied event with an QueryEventData by possibly recording the DDL statements as changes in the MySQL schemas.
handleRotateLogsEvent(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Handle the supplied event with a RotateEventData that signals the logs are being rotated.
handleRotateLogsEvent(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Handle the supplied event with a RotateEventData that signals the logs are being rotated.
handleRowsQuery(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Handle the supplied event with an RowsQueryEventData by recording the original SQL query that generated the event.
handleRowsQuery(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Handle the supplied event with an RowsQueryEventData by recording the original SQL query that generated the event.
handleServerHeartbeat(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Handle the supplied event that is sent by a primary to a replica to let the replica know that the primary is still alive.
handleServerHeartbeat(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Handle the supplied event that is sent by a primary to a replica to let the replica know that the primary is still alive.
handleServerIncident(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Handle the supplied event that signals that an out of the ordinary event that occurred on the master.
handleServerIncident(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Handle the supplied event that signals that an out of the ordinary event that occurred on the master.
handleServerStop(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Handle the supplied event that signals that mysqld has stopped.
handleServerStop(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Handle the supplied event that signals that mysqld has stopped.
handleTransactionCompletion(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
handleTransactionCompletion(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
handleUpdate(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Generate source records for the supplied event with an UpdateRowsEventData.
handleUpdate(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Generate source records for the supplied event with an UpdateRowsEventData.
handleUpdateTableMetadata(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Handle a change in the table metadata.
handleUpdateTableMetadata(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Handle a change in the table metadata.
hasFilterInfo() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
hashCode() - Method in class io.debezium.connector.mysql.GtidSet
 
hashCode() - Method in class io.debezium.connector.mysql.GtidSet.Interval
 
hashCode() - Method in class io.debezium.connector.mysql.GtidSet.UUIDSet
 
hashCode() - Method in class io.debezium.connector.mysql.legacy.BinlogReader.BinlogPosition
 
hashCode() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.BinlogPosition
 
hasTable(TableId) - Method in class io.debezium.connector.mysql.legacy.RecordMakers
Determine if there is a record maker for the given table.
heartbeat - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
heartbeatIntervalFactor - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
heartbeatIntervalFactor - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
historyComparator - Variable in class io.debezium.connector.mysql.legacy.MySqlSchema
 
historyComparator() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
 
historyExists() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Return true if the database history entity exists
historyExists() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
Return true if the database history entity exists
historyExists() - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
Return true if the database history entity exists
historyLocation() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Get the information about where the DDL statement history is recorded.
holdingGlobalLock - Variable in class io.debezium.connector.mysql.legacy.SnapshotReaderMetrics
 
holdingGlobalLock - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSourceMetrics
 
hostname() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
hostname() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
hostname() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 

I

IGNORED_TABLE_NAMES - Static variable in class io.debezium.connector.mysql.legacy.Filters
A list of tables that are always ignored.
ignoreDmlEventByGtidSource - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
ignoreDmlEventByGtidSource - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
ignoredQueryStatements - Variable in class io.debezium.connector.mysql.legacy.MySqlSchema
 
ignoredQueryStatements - Variable in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
ignoredTableFilter() - Method in class io.debezium.connector.mysql.legacy.Filters
 
ignoreEvent(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
ignoreEvent(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
IMPLEMENTATION_PROP - Static variable in class io.debezium.connector.mysql.MySqlConnector
 
INCLUDE_SQL_QUERY - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
includeData - Variable in class io.debezium.connector.mysql.legacy.SnapshotReader
 
includeData - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
 
includeData() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Whether this snapshotting mode should include the actual data or just the schema of captured tables.
includeDatabases(Predicate<String>) - Method in class io.debezium.connector.mysql.legacy.Filters.Builder
Include all the databases that the given predicate tests as true for.
includedColumns - Variable in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
 
includeSchema - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
 
includeSchema() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Whether this snapshotting mode should include the schema.
includeSchemaChangeRecords() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
includeSchemaChangeRecords() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
includeSqlQuery() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
includeSqlQuery() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
includeTables(Predicate<TableId>) - Method in class io.debezium.connector.mysql.legacy.Filters.Builder
Include the tables that the given predicate tests as true for.
INCONSISTENT_SCHEMA_HANDLING_MODE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
inconsistentSchemaFailureHandlingMode - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
inconsistentSchemaFailureHandlingMode() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
inconsistentSchemaHandlingMode - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
inconsistentSchemaHandlingMode - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
inconsistentSchemaHandlingMode() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
inconsistentSchemaHandlingMode() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
incrementalSnapshotContext - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
incrementalSnapshotEvents() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
INFO - Static variable in class io.debezium.connector.mysql.Module
 
informAboutUnknownTableIfRequired(Event, TableId, String) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
If we receive an event for a table that is monitored but whose metadata we don't know, either ignore that event or raise a warning or error as per the MySqlConnectorConfig.INCONSISTENT_SCHEMA_HANDLING_MODE configuration.
informAboutUnknownTableIfRequired(Event, TableId, String) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
If we receive an event for a table that is monitored but whose metadata we don't know, either ignore that event or raise a warning or error as per the MySqlConnectorConfig.INCONSISTENT_SCHEMA_HANDLING_MODE configuration.
initial(MySqlConnectorConfig) - Static method in class io.debezium.connector.mysql.MySqlOffsetContext
 
INITIAL - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Perform a snapshot only upon initial startup of a connector.
INITIAL_ONLY - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Perform a snapshot and then stop before attempting to read the binlog.
INITIAL_POLL_PERIOD_IN_MILLIS - Static variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
initialEventsToSkip - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
initialEventsToSkip - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
initialize() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
 
initialize() - Method in class io.debezium.connector.mysql.legacy.ChainedReader
 
initialize() - Method in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
initialize() - Method in interface io.debezium.connector.mysql.legacy.Reader
Perform any initialization of the reader before being started.
initializeDataTypeResolver() - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
initializeHistory() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
Initialize the database history with any server-specific information.
initializeHistoryStorage() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
Initialize permanent storage for database history
initializeStorage() - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
insert(SourceInfo, Object[], int, int, BitSet, Instant, BlockingConsumer<SourceRecord>) - Method in interface io.debezium.connector.mysql.legacy.RecordMakers.Converter
 
INT_CORRECTION - Static variable in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
 
INT_MAX_VALUE - Static variable in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
 
Interval(long, long) - Constructor for class io.debezium.connector.mysql.GtidSet.Interval
 
intervals - Variable in class io.debezium.connector.mysql.GtidSet.UUIDSet
 
intializeHistoryStorage() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Initialize permanent storage for database history
inTransaction - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
inTransaction - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
io.debezium.connector.mysql - package io.debezium.connector.mysql
 
io.debezium.connector.mysql.antlr - package io.debezium.connector.mysql.antlr
 
io.debezium.connector.mysql.antlr.listener - package io.debezium.connector.mysql.antlr.listener
 
io.debezium.connector.mysql.converters - package io.debezium.connector.mysql.converters
 
io.debezium.connector.mysql.legacy - package io.debezium.connector.mysql.legacy
 
io.debezium.connector.mysql.transforms - package io.debezium.connector.mysql.transforms
 
isBinlogAvailable() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
Determine whether the binlog position as set on the SourceInfo is available in the server.
isBinlogAvailable(MySqlConnectorConfig, MySqlOffsetContext) - Method in class io.debezium.connector.mysql.MySqlConnectorTask
Determine whether the binlog position as set on the SourceInfo is available in the server.
isBinlogFormatRow() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
Determine whether the MySQL server has the row-level binlog enabled.
isBinlogFormatRow() - Method in class io.debezium.connector.mysql.MySqlConnection
Determine whether the MySQL server has the row-level binlog enabled.
isBinlogRowImageFull() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
Determine whether the MySQL server has the binlog_row_image set to 'FULL'.
isBinlogRowImageFull() - Method in class io.debezium.connector.mysql.MySqlConnection
Determine whether the MySQL server has the binlog_row_image set to 'FULL'.
isBuiltInDatabase(String) - Static method in class io.debezium.connector.mysql.legacy.Filters
 
isBuiltInDatabase(String) - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
isBuiltInDb - Variable in class io.debezium.connector.mysql.legacy.Filters.Builder
 
isBuiltInDb - Variable in class io.debezium.connector.mysql.legacy.Filters
 
isBuiltInTable - Variable in class io.debezium.connector.mysql.legacy.Filters.Builder
 
isBuiltInTable - Variable in class io.debezium.connector.mysql.legacy.Filters
 
isBuiltInTable(TableId) - Static method in class io.debezium.connector.mysql.legacy.Filters
 
isConnected() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
isConnected() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
isContainedWithin(GtidSet) - Method in class io.debezium.connector.mysql.GtidSet
Determine if the GTIDs represented by this object are contained completely within the supplied set of GTIDs.
isContainedWithin(GtidSet.Interval) - Method in class io.debezium.connector.mysql.GtidSet.Interval
Determine if this interval is completely within the supplied interval.
isContainedWithin(GtidSet.UUIDSet) - Method in class io.debezium.connector.mysql.GtidSet.UUIDSet
Determine if the set of transaction numbers from this server is completely within the set of transaction numbers from the set of transaction numbers in the supplied set.
isGeometryCollection(String) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Determine if the uppercase form of a column's type is geometry collection independent of JDBC driver or server version.
isGloballyLocked() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
isGlobalSetVariableStatement(String, String) - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
 
isGlobalSetVariableStatement(String, String) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
isGrammarInUpperCase() - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
isGtidModeEnabled - Variable in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
isGtidModeEnabled - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
isGtidModeEnabled() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
Determine whether the MySQL server has GTIDs enabled.
isGtidModeEnabled() - Method in class io.debezium.connector.mysql.MySqlConnection
Determine whether the MySQL server has GTIDs enabled.
isIgnoredTable - Variable in class io.debezium.connector.mysql.legacy.Filters.Builder
 
isIgnoredTable - Variable in class io.debezium.connector.mysql.legacy.Filters
 
isIgnoredTable(TableId) - Static method in class io.debezium.connector.mysql.legacy.Filters
 
isInBufferFullMode() - Method in class io.debezium.connector.mysql.EventBuffer
 
isInBufferFullMode() - Method in class io.debezium.connector.mysql.legacy.EventBuffer
 
isInitialSnapshotOnly() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
isLastSnapshot() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
isLastSnapshot() - Method in class io.debezium.connector.mysql.SourceInfo
Deprecated.
isLegacy(String) - Static method in class io.debezium.connector.mysql.MySqlConnector
 
isNotBuiltInTable(TableId) - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
ISO_LOCAL_DATE_WITH_OPTIONAL_TIME - Static variable in class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
isPoint() - Method in class io.debezium.connector.mysql.MySqlGeometry
Returns whether this geometry is a 2D POINT type.
isPositionAtOrBefore(Document, Document) - Method in class io.debezium.connector.mysql.MySqlHistoryRecordComparator
Determine whether the first offset is at or before the point in time of the second offset, where the offsets are given in JSON representation of the maps returned by #offset().
isPositionAtOrBefore(Document, Document, Predicate<String>) - Static method in class io.debezium.connector.mysql.legacy.SourceInfo
Determine whether the first offset is at or before the point in time of the second offset, where the offsets are given in JSON representation of the maps returned by SourceInfo.offset().
isReplayingEventsBeyondBufferCapacity() - Method in class io.debezium.connector.mysql.EventBuffer
Whether we are replaying TX events from binlog that have not fit into the buffer before
isReplayingEventsBeyondBufferCapacity() - Method in class io.debezium.connector.mysql.legacy.EventBuffer
Whether we are replaying TX events from binlog that have not fit into the buffer before
isRetriable(Throwable) - Method in class io.debezium.connector.mysql.MySqlErrorHandler
 
isRunning() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
 
isSchemaOnlyRecoverySnapshot() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
isSchemaOnlySnapshot() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
isSnapshotAllowedWhenNeeded() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
isSnapshotCompleted() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
isSnapshotInEffect() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Determine whether a snapshot is currently in effect.
isSnapshotNeverAllowed() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
isSnapshotRunning() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
isStorageInitializationExecuted() - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
isStoreOnlyCapturedTablesDdl() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
 
isTableCaptured(TableId) - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Decide whether events should be captured for a given table
isTableIdCaseInsensitive() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
isTableIdCaseSensitive() - Method in class io.debezium.connector.mysql.MySqlConnection
 
isTablesLocked() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 

J

jdbc - Variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
jdbc() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
JDBC_DRIVER - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
JDBC_PROPERTY_LEGACY_DATETIME - Static variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
JDBC_PROPERTY_LEGACY_DATETIME - Static variable in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
jdbcConfig - Variable in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 

K

KEEP_ALIVE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
KEEP_ALIVE_INTERVAL_MS - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
KEEPALIVE_THREAD_NAME - Static variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
KEEPALIVE_THREAD_NAME - Static variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
knownGtidSet() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
Determine the executed GTID set for MySQL.
knownGtidSet() - Method in class io.debezium.connector.mysql.MySqlConnection
Determine the executed GTID set for MySQL.

L

largeTxNotBufferedPosition - Variable in class io.debezium.connector.mysql.EventBuffer
Contains the position of the first event that has not fit into the buffer.
largeTxNotBufferedPosition - Variable in class io.debezium.connector.mysql.legacy.EventBuffer
Contains the position of the first event that has not fit into the buffer.
lastEventProcessor - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
lastOffset - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
lastOffset - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
lastSnapshot - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
lastSnapshotRecord(RelationalSnapshotChangeEventSource.RelationalSnapshotContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
lastTransactionId - Variable in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
lastTransactionId - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
LATEST - io.debezium.connector.mysql.MySqlConnectorConfig.GtidNewChannelPosition
This mode will start reading new gtid channel from mysql servers last_executed position
leadingReaderFinalOffsetDocument - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader.OffsetLimitPredicate
 
legacy - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
legacy() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
LEGACY_IMPLEMENTATION - Static variable in class io.debezium.connector.mysql.MySqlConnector
 
LegacyV1MySqlSourceInfoStructMaker - Class in io.debezium.connector.mysql.legacy
 
LegacyV1MySqlSourceInfoStructMaker - Class in io.debezium.connector.mysql
 
LegacyV1MySqlSourceInfoStructMaker(String, String, CommonConnectorConfig) - Constructor for class io.debezium.connector.mysql.legacy.LegacyV1MySqlSourceInfoStructMaker
 
LegacyV1MySqlSourceInfoStructMaker(String, String, CommonConnectorConfig) - Constructor for class io.debezium.connector.mysql.LegacyV1MySqlSourceInfoStructMaker
 
listeners - Variable in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
listeners - Variable in class io.debezium.connector.mysql.antlr.listener.AlterViewParserListener
 
listeners - Variable in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
listeners - Variable in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
listeners - Variable in class io.debezium.connector.mysql.antlr.listener.CreateViewParserListener
 
listeners - Variable in class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
Collection of listeners for delegation of events.
load(Map<String, ?>) - Method in class io.debezium.connector.mysql.MySqlOffsetContext.Loader
 
Loader(MySqlConnectorConfig) - Constructor for class io.debezium.connector.mysql.MySqlOffsetContext.Loader
 
loadHistory(SourceInfo) - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Load the database schema information using the previously-recorded history, and stop reading the history when the the history reaches the supplied starting point.
loadHistory(SourceInfo) - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
Load the database schema information using the previously-recorded history, and stop reading the history when the the history reaches the supplied starting point.
LOCAL - io.debezium.connector.mysql.MySqlSystemVariables.MySqlScope
 
lockTablesForSchemaSnapshot(ChangeEventSource.ChangeEventSourceContext, RelationalSnapshotChangeEventSource.RelationalSnapshotContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
LOG - Static variable in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
LOG - Static variable in class io.debezium.connector.mysql.antlr.listener.CreateUniqueIndexParserListener
 
LOG - Static variable in class io.debezium.connector.mysql.antlr.listener.RenameTableParserListener
 
logEvent(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
logEvent(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
logger - Variable in class io.debezium.connector.mysql.AbstractMysqlFieldReader
 
logger - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
logger - Variable in class io.debezium.connector.mysql.legacy.BlockingReader
 
logger - Variable in class io.debezium.connector.mysql.legacy.ChainedReader
 
logger - Variable in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
logger - Static variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
logger - Static variable in class io.debezium.connector.mysql.legacy.MySqlSchema
 
logger - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
logger - Variable in class io.debezium.connector.mysql.legacy.TimedBlockingReader
 
logger() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
LOGGER - Static variable in class io.debezium.connector.mysql.converters.TinyIntOneToBooleanConverter
 
LOGGER - Static variable in class io.debezium.connector.mysql.EventBuffer
 
LOGGER - Static variable in class io.debezium.connector.mysql.legacy.EventBuffer
 
LOGGER - Static variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
LOGGER - Static variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
LOGGER - Static variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader.ParallelHaltingPredicate
 
LOGGER - Static variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
LOGGER - Static variable in class io.debezium.connector.mysql.MySqlConnection
 
LOGGER - Static variable in class io.debezium.connector.mysql.MySqlConnector
 
LOGGER - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
LOGGER - Static variable in class io.debezium.connector.mysql.MySqlConnectorTask
 
LOGGER - Static variable in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
LOGGER - Static variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
LOGGER - Static variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
LOGGER - Static variable in class io.debezium.connector.mysql.MySqlValueConverters
 
LOGGER - Static variable in class io.debezium.connector.mysql.transforms.ReadToInsertEvent
 
logReaderState() - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
logReaderState(Level) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
logRolesForCurrentUser(JdbcConnection) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
logServerInformation(JdbcConnection) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
logStreamingSourceState() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
logStreamingSourceState(Level) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
LONG - io.debezium.connector.mysql.MySqlConnectorConfig.BigIntUnsignedHandlingMode
Represent BIGINT UNSIGNED values as precise long values.
longOffsetValue(Map<String, ?>, String) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
longOffsetValue(Map<String, ?>, String) - Method in class io.debezium.connector.mysql.MySqlOffsetContext.Loader
 
LOWER_CASE_TABLE_NAMES - Static variable in class io.debezium.connector.mysql.MySqlSystemVariables
The system variable name to see if the MySQL tables are stored and looked-up in case sensitive way.

M

makeRecord() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
markLastSnapshot(Configuration) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Denote that a snapshot will be complete after one last record.
markLastSnapshotRecord() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
MASK_10_BITS - Static variable in class io.debezium.connector.mysql.RowDeserializers
 
MASK_6_BITS - Static variable in class io.debezium.connector.mysql.RowDeserializers
 
matches(String, String) - Method in class io.debezium.connector.mysql.MySqlValueConverters
Determine if the uppercase form of a column's type exactly matches or begins with the specified prefix.
MAX_POLL_PERIOD_IN_MILLIS - Static variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
maxBatchSize - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
maybeSetFilterDataFromConfig(Configuration) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Set filter data from config if and only if parallel snapshotting of new tables is turned on
MEDIUMINT_CORRECTION - Static variable in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
 
MEDIUMINT_MAX_VALUE - Static variable in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
 
metrics - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
metrics - Variable in class io.debezium.connector.mysql.legacy.SnapshotReader
 
metrics - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
metrics - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
metronome - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
metronome - Variable in class io.debezium.connector.mysql.legacy.BlockingReader
 
milliSecondsBehindMaster - Variable in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
milliSecondsBehindMaster - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
minHaltingDuration - Variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader.ParallelHaltingPredicate
 
MINIMAL - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
The connector holds the global read lock for just the initial portion of the snapshot while the connector reads the database schemas and other metadata.
MINIMAL_PERCONA - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
The connector holds a (Percona-specific) backup lock for just the initial portion of the snapshot while the connector reads the database schemas and other metadata.
modifyAndFlushLastRecord(Function<SourceRecord, SourceRecord>) - Method in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
Module - Class in io.debezium.connector.mysql
Information about this module.
Module() - Constructor for class io.debezium.connector.mysql.Module
 
MYSQL_CONNECTION_URL - Static variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
MySqlAntlrDdlParser - Class in io.debezium.connector.mysql.antlr
An ANTLR based parser for MySQL DDL statements.
MySqlAntlrDdlParser() - Constructor for class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
MySqlAntlrDdlParser(boolean, boolean, MySqlValueConverters, Tables.TableFilter) - Constructor for class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
MySqlAntlrDdlParser(MySqlValueConverters) - Constructor for class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
MySqlAntlrDdlParser(MySqlValueConverters, Tables.TableFilter) - Constructor for class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
MySqlAntlrDdlParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener for MySQL column definition queries.
MySqlAntlrDdlParserListener(MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
 
MysqlBinaryProtocolFieldReader - Class in io.debezium.connector.mysql
Decode binary protocol value for MySQL.
MysqlBinaryProtocolFieldReader() - Constructor for class io.debezium.connector.mysql.MysqlBinaryProtocolFieldReader
 
MySqlChangeEventSourceFactory - Class in io.debezium.connector.mysql
 
MySqlChangeEventSourceFactory(MySqlConnectorConfig, MySqlConnection, ErrorHandler, EventDispatcher<TableId>, Clock, MySqlDatabaseSchema, MySqlTaskContext, MySqlStreamingChangeEventSourceMetrics, ChangeEventQueue<DataChangeEvent>) - Constructor for class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
MySqlChangeEventSourceMetricsFactory - Class in io.debezium.connector.mysql
 
MySqlChangeEventSourceMetricsFactory(MySqlStreamingChangeEventSourceMetrics) - Constructor for class io.debezium.connector.mysql.MySqlChangeEventSourceMetricsFactory
 
MySqlChangeRecordEmitter - Class in io.debezium.connector.mysql
Emits change data.
MySqlChangeRecordEmitter(OffsetContext, Clock, Envelope.Operation, Serializable[], Serializable[]) - Constructor for class io.debezium.connector.mysql.MySqlChangeRecordEmitter
 
MySqlConnection - Class in io.debezium.connector.mysql
JdbcConnection extension to be used with MySQL Server
MySqlConnection(MySqlConnection.MySqlConnectionConfiguration) - Constructor for class io.debezium.connector.mysql.MySqlConnection
Creates a new connection using the supplied configuration.
MySqlConnection(MySqlConnection.MySqlConnectionConfiguration, MysqlFieldReader) - Constructor for class io.debezium.connector.mysql.MySqlConnection
Creates a new connection using the supplied configuration.
MySqlConnection.MySqlConnectionConfiguration - Class in io.debezium.connector.mysql
 
MySqlConnectionConfiguration(Configuration) - Constructor for class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
MySqlConnector - Class in io.debezium.connector.mysql
A Kafka Connect source connector that creates tasks that read the MySQL binary log and generate the corresponding data change events.
MySqlConnector() - Constructor for class io.debezium.connector.mysql.MySqlConnector
 
MySqlConnectorConfig - Class in io.debezium.connector.mysql
The configuration properties.
MySqlConnectorConfig(Configuration) - Constructor for class io.debezium.connector.mysql.MySqlConnectorConfig
 
MySqlConnectorConfig.BigIntUnsignedHandlingMode - Enum in io.debezium.connector.mysql
The set of predefined BigIntUnsignedHandlingMode options or aliases.
MySqlConnectorConfig.GtidNewChannelPosition - Enum in io.debezium.connector.mysql
The set of predefined Gtid New Channel Position options.
MySqlConnectorConfig.SecureConnectionMode - Enum in io.debezium.connector.mysql
The set of predefined SecureConnectionMode options or aliases.
MySqlConnectorConfig.SnapshotLockingMode - Enum in io.debezium.connector.mysql
The set of predefined Snapshot Locking Mode options.
MySqlConnectorConfig.SnapshotMode - Enum in io.debezium.connector.mysql
The set of predefined SnapshotMode options or aliases.
MySqlConnectorConfig.SnapshotNewTables - Enum in io.debezium.connector.mysql
 
MySqlConnectorTask - Class in io.debezium.connector.mysql.legacy
A Kafka Connect source task reads the MySQL binary log and generate the corresponding data change events.
MySqlConnectorTask - Class in io.debezium.connector.mysql
The main task executing streaming from MySQL.
MySqlConnectorTask() - Constructor for class io.debezium.connector.mysql.legacy.MySqlConnectorTask
Create an instance of the log reader that uses Kafka to store database schema history and the default topic selector of "<serverName>.<databaseName>.<tableName>" for data and "<serverName>" for metadata.
MySqlConnectorTask() - Constructor for class io.debezium.connector.mysql.MySqlConnectorTask
 
MySqlConnectorTask.ServerIdGenerator - Class in io.debezium.connector.mysql.legacy
 
MySqlDatabaseSchema - Class in io.debezium.connector.mysql
Component that records the schema history for databases hosted by a MySQL database server.
MySqlDatabaseSchema(MySqlConnectorConfig, MySqlValueConverters, TopicSelector<TableId>, SchemaNameAdjuster, boolean) - Constructor for class io.debezium.connector.mysql.MySqlDatabaseSchema
Create a schema component given the supplied MySQL connector configuration.
MySqlDefaultValueConverter - Class in io.debezium.connector.mysql
This class is used by a DDL parser to convert the string default value to a Java type recognized by value converters for a subset of types.
MySqlDefaultValueConverter(MySqlValueConverters) - Constructor for class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
MySqlErrorHandler - Class in io.debezium.connector.mysql
Error handler for SQL Server.
MySqlErrorHandler(String, ChangeEventQueue<?>) - Constructor for class io.debezium.connector.mysql.MySqlErrorHandler
 
MySqlEventMetadataProvider - Class in io.debezium.connector.mysql
 
MySqlEventMetadataProvider() - Constructor for class io.debezium.connector.mysql.MySqlEventMetadataProvider
 
mysqlFieldReader - Variable in class io.debezium.connector.mysql.legacy.SnapshotReader
 
mysqlFieldReader - Variable in class io.debezium.connector.mysql.MySqlConnection
 
MysqlFieldReader - Interface in io.debezium.connector.mysql
Decode MySQL return value according to different protocols.
MySqlGeometry - Class in io.debezium.connector.mysql
A parser API for MySQL Geometry types
MySqlGeometry(byte[], Integer) - Constructor for class io.debezium.connector.mysql.MySqlGeometry
Create a MySqlGeometry using the supplied wkb, note this should be the cleaned wkb for MySQL
MySqlHistoryRecordComparator - Class in io.debezium.connector.mysql
 
MySqlHistoryRecordComparator(Predicate<String>) - Constructor for class io.debezium.connector.mysql.MySqlHistoryRecordComparator
 
MySqlJdbcContext - Class in io.debezium.connector.mysql.legacy
A context for a JDBC connection to MySQL.
MySqlJdbcContext(MySqlConnectorConfig) - Constructor for class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
MySqlJdbcContext.DatabaseLocales - Class in io.debezium.connector.mysql.legacy
 
MySqlOffsetContext - Class in io.debezium.connector.mysql
 
MySqlOffsetContext(MySqlConnectorConfig, boolean, boolean, SourceInfo) - Constructor for class io.debezium.connector.mysql.MySqlOffsetContext
 
MySqlOffsetContext(MySqlConnectorConfig, boolean, boolean, TransactionContext, IncrementalSnapshotContext<TableId>, SourceInfo) - Constructor for class io.debezium.connector.mysql.MySqlOffsetContext
 
MySqlOffsetContext.Loader - Class in io.debezium.connector.mysql
 
MySqlSchema - Class in io.debezium.connector.mysql.legacy
Component that records the schema history for databases hosted by a MySQL database server.
MySqlSchema(MySqlConnectorConfig, Predicate<String>, boolean, TopicSelector<TableId>, Filters) - Constructor for class io.debezium.connector.mysql.legacy.MySqlSchema
Create a schema component given the supplied MySQL connector configuration.
MySqlScope(int) - Constructor for enum io.debezium.connector.mysql.MySqlSystemVariables.MySqlScope
 
MySqlSnapshotChangeEventSource - Class in io.debezium.connector.mysql
 
MySqlSnapshotChangeEventSource(MySqlConnectorConfig, MySqlOffsetContext, MySqlConnection, MySqlDatabaseSchema, EventDispatcher<TableId>, Clock, MySqlSnapshotChangeEventSourceMetrics, BlockingConsumer<Function<SourceRecord, SourceRecord>>) - Constructor for class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
MySqlSnapshotChangeEventSource.MySqlSnapshotContext - Class in io.debezium.connector.mysql
Mutable context which is populated in the course of snapshotting.
MySqlSnapshotChangeEventSourceMetrics - Class in io.debezium.connector.mysql
 
MySqlSnapshotChangeEventSourceMetrics(MySqlTaskContext, ChangeEventQueueMetrics, EventMetadataProvider) - Constructor for class io.debezium.connector.mysql.MySqlSnapshotChangeEventSourceMetrics
 
MySqlSnapshotChangeEventSourceMetricsMXBean - Interface in io.debezium.connector.mysql
 
MySqlSnapshotContext() - Constructor for class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource.MySqlSnapshotContext
 
MySqlSourceInfoStructMaker - Class in io.debezium.connector.mysql.legacy
 
MySqlSourceInfoStructMaker - Class in io.debezium.connector.mysql
 
MySqlSourceInfoStructMaker(String, String, CommonConnectorConfig) - Constructor for class io.debezium.connector.mysql.legacy.MySqlSourceInfoStructMaker
 
MySqlSourceInfoStructMaker(String, String, CommonConnectorConfig) - Constructor for class io.debezium.connector.mysql.MySqlSourceInfoStructMaker
 
MySqlStreamingChangeEventSource - Class in io.debezium.connector.mysql
 
MySqlStreamingChangeEventSource(MySqlConnectorConfig, MySqlOffsetContext, MySqlConnection, EventDispatcher<TableId>, ErrorHandler, Clock, MySqlTaskContext, MySqlStreamingChangeEventSourceMetrics) - Constructor for class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
MySqlStreamingChangeEventSource.BinlogChangeEmitter<T> - Interface in io.debezium.connector.mysql
 
MySqlStreamingChangeEventSource.BinlogPosition - Class in io.debezium.connector.mysql
 
MySqlStreamingChangeEventSource.ReaderThreadLifecycleListener - Class in io.debezium.connector.mysql
 
MySqlStreamingChangeEventSource.RowsProvider<E extends com.github.shyiko.mysql.binlog.event.EventData,​U> - Interface in io.debezium.connector.mysql
 
MySqlStreamingChangeEventSource.TableIdProvider<E extends com.github.shyiko.mysql.binlog.event.EventData> - Interface in io.debezium.connector.mysql
 
MySqlStreamingChangeEventSourceMetrics - Class in io.debezium.connector.mysql
 
MySqlStreamingChangeEventSourceMetrics(MySqlTaskContext, ChangeEventQueueMetrics, EventMetadataProvider) - Constructor for class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
MySqlStreamingChangeEventSourceMetricsMXBean - Interface in io.debezium.connector.mysql
 
MySqlSystemVariables - Class in io.debezium.connector.mysql
Custom class for MySQL SystemVariables, which defines MySQL scopes and constants of used variable names.
MySqlSystemVariables() - Constructor for class io.debezium.connector.mysql.MySqlSystemVariables
 
MySqlSystemVariables.MySqlScope - Enum in io.debezium.connector.mysql
 
MySqlTaskContext - Class in io.debezium.connector.mysql.legacy
A Kafka Connect source task reads the MySQL binary log and generate the corresponding data change events.
MySqlTaskContext - Class in io.debezium.connector.mysql
A state (context) associated with a MySQL task
MySqlTaskContext(Configuration, Filters) - Constructor for class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
MySqlTaskContext(Configuration, Filters, Boolean, Map<String, ?>) - Constructor for class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
MySqlTaskContext(Configuration, Filters, Map<String, ?>) - Constructor for class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
MySqlTaskContext(MySqlConnectorConfig, MySqlDatabaseSchema) - Constructor for class io.debezium.connector.mysql.MySqlTaskContext
 
MysqlTextProtocolFieldReader - Class in io.debezium.connector.mysql
Decode text protocol value for MySQL.
MysqlTextProtocolFieldReader() - Constructor for class io.debezium.connector.mysql.MysqlTextProtocolFieldReader
 
MySqlTopicSelector - Class in io.debezium.connector.mysql
Factory for this connector's TopicSelector.
MySqlTopicSelector() - Constructor for class io.debezium.connector.mysql.MySqlTopicSelector
 
MySqlUnsignedIntegerConverter - Class in io.debezium.connector.mysql
A converter API for MySQL Unsigned Integer types.
MySqlUnsignedIntegerConverter() - Constructor for class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
Private constructor
MySqlValueConverters - Class in io.debezium.connector.mysql
MySQL-specific customization of the conversions from JDBC values obtained from the MySQL binlog client library.
MySqlValueConverters(JdbcValueConverters.DecimalMode, TemporalPrecisionMode, JdbcValueConverters.BigIntUnsignedMode, CommonConnectorConfig.BinaryHandlingMode) - Constructor for class io.debezium.connector.mysql.MySqlValueConverters
Create a new instance that always uses UTC for the default time zone when_needed converting values without timezone information to values that require timezones.
MySqlValueConverters(JdbcValueConverters.DecimalMode, TemporalPrecisionMode, JdbcValueConverters.BigIntUnsignedMode, CommonConnectorConfig.BinaryHandlingMode, TemporalAdjuster, MySqlValueConverters.ParsingErrorHandler) - Constructor for class io.debezium.connector.mysql.MySqlValueConverters
Create a new instance that always uses UTC for the default time zone when converting values without timezone information to values that require timezones.
MySqlValueConverters.ParsingErrorHandler - Interface in io.debezium.connector.mysql
 

N

name - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
name - Variable in class io.debezium.connector.mysql.legacy.BlockingReader
 
name() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
 
name() - Method in class io.debezium.connector.mysql.legacy.BlockingReader
 
name() - Method in class io.debezium.connector.mysql.legacy.ChainedReader
 
name() - Method in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
name() - Method in interface io.debezium.connector.mysql.legacy.Reader
Get the name of this reader.
name() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
name() - Static method in class io.debezium.connector.mysql.Module
 
NEVER - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Never perform a snapshot and only read the binlog.
newTablesBinlogReader - Variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
newTablesInConfig() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
newTablesReader - Variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
nextSnapshot - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
NON_GTID_TRANSACTION_ID_FORMAT - Static variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
NONE - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
This mode will avoid using ANY table locks during the snapshot process.
numberOfCommittedTransactions - Variable in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
numberOfCommittedTransactions - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
numberOfLargeTransactions - Variable in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
numberOfLargeTransactions - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
numberOfNotWellFormedTransactions - Variable in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
numberOfNotWellFormedTransactions - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
numberOfRolledBackTransactions - Variable in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
numberOfRolledBackTransactions - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 

O

OFF - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotNewTables
Do not snapshot new tables
offset - Variable in class io.debezium.connector.mysql.legacy.MySqlConnectorTask.ServerIdGenerator
 
offset - Variable in class io.debezium.connector.mysql.MySqlChangeRecordEmitter
 
offset() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Get the Kafka Connect detail about the source "offset", which describes the position within the source where we last have last read.
offsetContext - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
offsetForRow(int, int) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Given the row number within a binlog event and the total number of rows in that event, compute and return the Kafka Connect offset that is be included in the produced change event describing the row.
OffsetLimitPredicate(Map<String, ?>, Predicate<String>) - Constructor for class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader.OffsetLimitPredicate
 
offsetsHaveFilterInfo(Map<String, ?>) - Static method in class io.debezium.connector.mysql.legacy.SourceInfo
 
offsetUsingPosition(long) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
offsetUsingPosition(long) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
oldTablesReader - Variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
ON_CONNECT_STATEMENTS - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
onCommittedTransaction() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
onCommittedTransaction() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
onCommunicationFailure(BinaryLogClient, Exception) - Method in class io.debezium.connector.mysql.legacy.BinlogReader.ReaderThreadLifecycleListener
 
onCommunicationFailure(BinaryLogClient, Exception) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.ReaderThreadLifecycleListener
 
onConnect(BinaryLogClient) - Method in class io.debezium.connector.mysql.legacy.BinlogReader.ReaderThreadLifecycleListener
 
onConnect(BinaryLogClient) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.ReaderThreadLifecycleListener
 
onDisconnect(BinaryLogClient) - Method in class io.debezium.connector.mysql.legacy.BinlogReader.ReaderThreadLifecycleListener
 
onDisconnect(BinaryLogClient) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.ReaderThreadLifecycleListener
 
onEvent(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
onEvent(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
onEventDeserializationFailure(BinaryLogClient, Exception) - Method in class io.debezium.connector.mysql.legacy.BinlogReader.ReaderThreadLifecycleListener
 
onEventDeserializationFailure(BinaryLogClient, Exception) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.ReaderThreadLifecycleListener
 
onGtidChange(String) - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
onGtidChange(String) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
onLargeTransaction() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
onLargeTransaction() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
onNotWellFormedTransaction() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
onNotWellFormedTransaction() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
onRolledBackTransaction() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
onRolledBackTransaction() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
operation - Variable in class io.debezium.connector.mysql.MySqlChangeRecordEmitter
 
optionalColumn - Variable in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
optionalColumn - Variable in class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
 
originalSystemProperties - Variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
originalSystemProperties - Variable in class io.debezium.connector.mysql.MySqlConnection
 
otherReaderNearEnd - Variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader.ParallelHaltingPredicate
 

P

PARALLEL - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotNewTables
Snapshot new tables in parallel to normal binlog reading.
ParallelHaltingPredicate(AtomicBoolean, AtomicBoolean) - Constructor for class io.debezium.connector.mysql.legacy.ParallelSnapshotReader.ParallelHaltingPredicate
 
ParallelHaltingPredicate(AtomicBoolean, AtomicBoolean, Duration) - Constructor for class io.debezium.connector.mysql.legacy.ParallelSnapshotReader.ParallelHaltingPredicate
 
ParallelSnapshotReader - Class in io.debezium.connector.mysql.legacy
A reader that runs a ChainedReader consisting of a SnapshotReader and a BinlogReader for all tables newly added to the config in parallel with a BinlogReader for all the tables previously in the config.
ParallelSnapshotReader(Configuration, MySqlTaskContext, Filters, MySqlConnectorTask.ServerIdGenerator) - Constructor for class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
Create a ParallelSnapshotReader.
ParallelSnapshotReader(BinlogReader, SnapshotReader, BinlogReader) - Constructor for class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
ParallelSnapshotReader.ParallelHaltingPredicate - Class in io.debezium.connector.mysql.legacy
A Halting Predicate for the parallel snapshot reader.
parse(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.BigIntUnsignedHandlingMode
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.GtidNewChannelPosition
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Determine if the supplied value is one of the predefined options.
parse(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotNewTables
Determine if the supplied value is one of the predefined options.
parse(String, String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.BigIntUnsignedHandlingMode
Determine if the supplied value is one of the predefined options.
parse(String, String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.GtidNewChannelPosition
Determine if the supplied value is one of the predefined options.
parse(String, String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
Determine if the supplied value is one of the predefined options.
parse(String, String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
Determine if the supplied value is one of the predefined options.
parse(String, String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Determine if the supplied value is one of the predefined options.
parse(String, String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotNewTables
Determine if the supplied value is one of the predefined options.
parseAtomTableItem(MySqlParser.TableSourceItemContext, Map<TableId, Table>) - Method in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
parseDdl(String, String, MySqlOffsetContext, Instant, boolean) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
parseName(MySqlParser.UidContext) - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
Parse a name from MySqlParser.UidContext.
parsePrimaryIndexColumnNames(MySqlParser.IndexColumnNamesContext, TableEditor) - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
Parse column names for primary index from MySqlParser.IndexColumnNamesContext.
parseQualifiedTableId(MySqlParser.FullIdContext) - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
Parse qualified table identification from MySqlParser.FullIdContext.
parseQuerySpecification(MySqlParser.SelectElementsContext) - Method in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.AlterViewParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.CreateAndAlterDatabaseParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.CreateUniqueIndexParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.CreateViewParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.DropDatabaseParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.DropTableParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.DropViewParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.RenameTableParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.SetStatementParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.TruncateTableParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.UseStatementParserListener
 
parser - Variable in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
parseSelectElements(MySqlParser.SelectElementsContext) - Method in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
parseSnapshotDdl(String, String, MySqlOffsetContext, Instant) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
parseStreamingDdl(String, String, MySqlOffsetContext, Instant) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
parseTree(MySqlParser) - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
parsingColumnIndex - Variable in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
parsingErrorHandler - Variable in class io.debezium.connector.mysql.MySqlValueConverters
 
partition - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
partition() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Get the Kafka Connect detail about the source "partition", which describes the portion of the source that we are consuming.
password() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
password() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
password() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
poll() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
 
poll() - Method in class io.debezium.connector.mysql.legacy.BlockingReader
Does nothing until the connector task is shut down, but regularly returns control back to Connect in order for being paused if requested.
poll() - Method in class io.debezium.connector.mysql.legacy.ChainedReader
 
poll() - Method in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
poll() - Method in interface io.debezium.connector.mysql.legacy.Reader
Poll for the next batch of source records.
poll() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
poll() - Method in class io.debezium.connector.mysql.legacy.TimedBlockingReader
 
pollComplete(List<SourceRecord>) - Method in class io.debezium.connector.mysql.legacy.AbstractReader
Method called when AbstractReader.poll() completes sending a non-zero-sized batch of records.
pollComplete(List<SourceRecord>) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
pollInterval - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
pollOutputDelay - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
port() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
port() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
port() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
PORT - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
position - Variable in class io.debezium.connector.mysql.legacy.BinlogReader.BinlogPosition
 
position - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.BinlogPosition
 
postSnapshot() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
postSnapshotCompletion() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
PRECISE - io.debezium.connector.mysql.MySqlConnectorConfig.BigIntUnsignedHandlingMode
Represent BIGINT UNSIGNED values as precise BigDecimal values, which are represented in change events in a binary form.
PREFERRED - io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
Establish a secure (encrypted) connection if the server supports secure connections.
prepare(ChangeEventSource.ChangeEventSourceContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
prepareTransaction(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Handle a EventType.XA_PREPARE event.
prepareTransaction(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Handle a EventType.XA_PREPARE event.
preSnapshotCompletion() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
preSnapshotStart() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
previousOffset - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
previousOutputMillis - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
priority - Variable in enum io.debezium.connector.mysql.MySqlSystemVariables.MySqlScope
 
priority() - Method in enum io.debezium.connector.mysql.MySqlSystemVariables.MySqlScope
 
properties - Variable in class io.debezium.connector.mysql.MySqlConnector
 
purgedGtidSet() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
Get the purged GTID values from MySQL (gtid_purged value)
purgedGtidSet() - Method in class io.debezium.connector.mysql.MySqlConnection
Get the purged GTID values from MySQL (gtid_purged value)

Q

QUERY_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
QUERY_KEY - Static variable in class io.debezium.connector.mysql.SourceInfo
 
querySystemVariables(String) - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
querySystemVariables(String) - Method in class io.debezium.connector.mysql.MySqlConnection
 
queue - Variable in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
queue - Variable in class io.debezium.connector.mysql.MySqlConnectorTask
 
quote(TableId) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
quote(TableId) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
quote(String) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
quote(String) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 

R

randomServerId() - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
read(SourceInfo, Object[], int, int, BitSet, Instant, BlockingConsumer<SourceRecord>) - Method in interface io.debezium.connector.mysql.legacy.RecordMakers.Converter
 
read(Object[], Instant) - Method in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
Produce a read record for the row.
read(Object[], Instant, int, int) - Method in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
Produce a read record for the row.
readBinlogPosition(int, SourceInfo, JdbcConnection, AtomicReference<String>) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
readDatabaseCollations() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
Read the MySQL default character sets for exisiting databases.
readDatabaseCollations() - Method in class io.debezium.connector.mysql.MySqlConnection
Read the MySQL default character sets for exisiting databases.
readDateField(ResultSet, int, Column, Table) - Method in class io.debezium.connector.mysql.AbstractMysqlFieldReader
 
readDateField(ResultSet, int, Column, Table) - Method in class io.debezium.connector.mysql.MysqlBinaryProtocolFieldReader
 
readDateField(ResultSet, int, Column, Table) - Method in class io.debezium.connector.mysql.MysqlTextProtocolFieldReader
In non-string mode the date field can contain zero in any of the date part which we need to handle as all-zero
reader - Variable in class io.debezium.connector.mysql.legacy.EventBuffer
 
Reader - Interface in io.debezium.connector.mysql.legacy
A component that reads a portion of the MySQL server history or current state.
Reader.State - Enum in io.debezium.connector.mysql.legacy
The possible states of a reader.
readerCompletedPolling() - Method in class io.debezium.connector.mysql.legacy.ChainedReader
Called when the previously-started reader has returned all of its records via polling.
ReaderMetricsMXBean - Interface in io.debezium.connector.mysql.legacy
Metrics that are common for both snapshot and binlog readers
readers - Variable in class io.debezium.connector.mysql.legacy.ChainedReader.Builder
 
readers - Variable in class io.debezium.connector.mysql.legacy.ChainedReader
 
readers - Variable in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
ReaderThreadLifecycleListener() - Constructor for class io.debezium.connector.mysql.legacy.BinlogReader.ReaderThreadLifecycleListener
 
ReaderThreadLifecycleListener() - Constructor for class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.ReaderThreadLifecycleListener
 
readField(ResultSet, int, Column, Table) - Method in class io.debezium.connector.mysql.AbstractMysqlFieldReader
 
readField(ResultSet, int, Column, Table) - Method in interface io.debezium.connector.mysql.MysqlFieldReader
read field from ResultSet according to different protocols
readMySqlCharsetSystemVariables() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
Read the MySQL charset-related system variables.
readMySqlCharsetSystemVariables() - Method in class io.debezium.connector.mysql.MySqlConnection
Read the MySQL charset-related system variables.
readMySqlSystemVariables() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
Read the MySQL system variables.
readMySqlSystemVariables() - Method in class io.debezium.connector.mysql.MySqlConnection
Read the MySQL system variables.
readTableSchema(AtomicReference<String>, JdbcConnection, MySqlSchema, SourceInfo, String, TableId) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
readTableStatement(OptionalLong) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
readTableStructure(ChangeEventSource.ChangeEventSourceContext, RelationalSnapshotChangeEventSource.RelationalSnapshotContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
readTimeField(ResultSet, int) - Method in class io.debezium.connector.mysql.AbstractMysqlFieldReader
 
readTimeField(ResultSet, int) - Method in class io.debezium.connector.mysql.MysqlBinaryProtocolFieldReader
 
readTimeField(ResultSet, int) - Method in class io.debezium.connector.mysql.MysqlTextProtocolFieldReader
As MySQL connector/J implementation is broken for MySQL type "TIME" we have to use a binary-ish workaround
readTimestampField(ResultSet, int, Column, Table) - Method in class io.debezium.connector.mysql.AbstractMysqlFieldReader
 
readTimestampField(ResultSet, int, Column, Table) - Method in class io.debezium.connector.mysql.MysqlBinaryProtocolFieldReader
 
readTimestampField(ResultSet, int, Column, Table) - Method in class io.debezium.connector.mysql.MysqlTextProtocolFieldReader
In non-string mode the time field can contain zero in any of the date part which we need to handle as all-zero
ReadToInsertEvent<R extends org.apache.kafka.connect.connector.ConnectRecord<R>> - Class in io.debezium.connector.mysql.transforms
This SMT allows the MySql connector to emit snapshot events as "c" operation type (CREATE) by changing the 'op' field of the records from "r" (default) to "c".
ReadToInsertEvent() - Constructor for class io.debezium.connector.mysql.transforms.ReadToInsertEvent
 
ReconcilingBinlogReader - Class in io.debezium.connector.mysql.legacy
A reader that unifies the binlog positions of two binlog readers.
ReconcilingBinlogReader(BinlogReader, BinlogReader, BinlogReader, long) - Constructor for class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
Create a reconciling Binlog Reader.
ReconcilingBinlogReader.OffsetLimitPredicate - Class in io.debezium.connector.mysql.legacy
A Predicate that returns false for any record beyond a given offset.
reconcilingReader - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
recordCounter - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
recorder - Variable in class io.debezium.connector.mysql.legacy.SnapshotReader
 
recordMakers - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
RecordMakers - Class in io.debezium.connector.mysql.legacy
A component that makes SourceRecords for tables.
RecordMakers(MySqlSchema, SourceInfo, TopicSelector<TableId>, boolean, Map<String, ?>) - Constructor for class io.debezium.connector.mysql.legacy.RecordMakers
Create the record makers using the supplied components.
RecordMakers.Converter - Interface in io.debezium.connector.mysql.legacy
 
RecordMakers.RecordsForTable - Class in io.debezium.connector.mysql.legacy
A SourceRecord factory for a specific table and consumer.
recordProcessor - Variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
recordRow(RecordMakers.RecordsForTable, Object[], Instant) - Method in interface io.debezium.connector.mysql.legacy.SnapshotReader.RecordRecorder
 
recordRowAsInsert(RecordMakers.RecordsForTable, Object[], Instant) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
recordRowAsRead(RecordMakers.RecordsForTable, Object[], Instant) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
 
records - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
recordSchemaChangesInSourceRecords - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
RecordsForTable(RecordMakers.Converter, BitSet, BlockingConsumer<SourceRecord>) - Constructor for class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
 
recoveredTables - Variable in class io.debezium.connector.mysql.legacy.MySqlSchema
 
refreshSchemas() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Discard any currently-cached schemas and rebuild them using the filters.
refreshSchemas() - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
Discard any currently-cached schemas and rebuild them using the filters.
regenerate() - Method in class io.debezium.connector.mysql.legacy.RecordMakers
Clear all of the cached record makers and generate new ones.
releaseDataSnapshotLocks(RelationalSnapshotChangeEventSource.RelationalSnapshotContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
releaseSchemaSnapshotLocks(RelationalSnapshotChangeEventSource.RelationalSnapshotContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
remainingReaders - Variable in class io.debezium.connector.mysql.legacy.ChainedReader
 
RenameTableParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL RENAME TABLE statements.
RenameTableParserListener(MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.RenameTableParserListener
 
replaceFirstNonNumericSubstring(String, int, char) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
Replace the first non-numeric substring
replaceOffsetAndSource(SourceRecord) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
Utility method to replace the offset and the source in the given record with the latest.
REQUIRED - io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
Establish a secure connection if the server supports secure connections.
reset() - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
reset() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
resetTransactionId() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
resolveColumnDataType(MySqlParser.DataTypeContext) - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
RESTART_PREFIX - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
restartBinlogFilename - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
restartBinlogFilename - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
restartBinlogPosition - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
restartBinlogPosition - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
restartBinlogPosition() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Get the position within the MySQL binary log file of the most recently processed event.
restartEventsToSkip - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
restartEventsToSkip - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
restartGtidSet - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
restartGtidSet - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
restartOffset - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
restartRowsToSkip - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
restartRowsToSkip - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
retainAll(Predicate<String>) - Method in class io.debezium.connector.mysql.GtidSet
Obtain a copy of this GtidSet except with only the GTID ranges that have server UUIDs that match the given predicate.
rewindBinaryLogClient(BinlogReader.BinlogPosition) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
rewindBinaryLogClient(ChangeEventSource.ChangeEventSourceContext, MySqlStreamingChangeEventSource.BinlogPosition) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
rollbackTransaction() - Method in class io.debezium.connector.mysql.EventBuffer
 
rollbackTransaction() - Method in class io.debezium.connector.mysql.legacy.EventBuffer
 
ROW_COUNT_FOR_STREAMING_RESULT_SETS - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
rowCountForLargeTable() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
rowCountForLargeTable() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
rowCountForTable(TableId) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
RowDeserializers - Class in io.debezium.connector.mysql
Custom deserializers for the MySQL Binlog Client library.
RowDeserializers() - Constructor for class io.debezium.connector.mysql.RowDeserializers
 
RowDeserializers.DeleteRowsDeserializer - Class in io.debezium.connector.mysql
A specialization of DeleteRowsEventDataDeserializer that converts MySQL DATE, TIME, DATETIME, and TIMESTAMP values to LocalDate, LocalTime, LocalDateTime, and OffsetDateTime objects, respectively.
RowDeserializers.UpdateRowsDeserializer - Class in io.debezium.connector.mysql
A specialization of UpdateRowsEventDataDeserializer that converts MySQL DATE, TIME, DATETIME, and TIMESTAMP values to LocalDate, LocalTime, LocalDateTime, and OffsetDateTime objects, respectively.
RowDeserializers.WriteRowsDeserializer - Class in io.debezium.connector.mysql
A specialization of WriteRowsEventDataDeserializer that converts MySQL DATE, TIME, DATETIME, and TIMESTAMP values to LocalDate, LocalTime, LocalDateTime, and OffsetDateTime objects, respectively.
rowsToSkipUponRestart() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Get the number of rows beyond the last completely processed event to be skipped upon restart.
rowsToSkipUponRestart() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Get the number of rows beyond the last completely processed event to be skipped upon restart.
runIfNotNull(Runnable, Object...) - Method in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
Runs a function if all given object are not null.
running - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
running - Variable in class io.debezium.connector.mysql.legacy.ChainedReader
 
running - Variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
running - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
RUNNING - io.debezium.connector.mysql.legacy.Reader.State
The reader is running and generated records.
runningLogMessage - Variable in class io.debezium.connector.mysql.legacy.BlockingReader
 

S

schema - Variable in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
schema - Variable in class io.debezium.connector.mysql.legacy.LegacyV1MySqlSourceInfoStructMaker
 
schema - Variable in class io.debezium.connector.mysql.legacy.MySqlSourceInfoStructMaker
 
schema - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
schema - Variable in class io.debezium.connector.mysql.legacy.SnapshotReaderMetrics
 
schema - Variable in class io.debezium.connector.mysql.LegacyV1MySqlSourceInfoStructMaker
 
schema - Variable in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
schema - Variable in class io.debezium.connector.mysql.MySqlConnectorTask
 
schema - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSourceMetrics
 
schema - Variable in class io.debezium.connector.mysql.MySqlSourceInfoStructMaker
 
schema - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
schema - Variable in class io.debezium.connector.mysql.MySqlTaskContext
 
schema() - Method in class io.debezium.connector.mysql.legacy.LegacyV1MySqlSourceInfoStructMaker
 
schema() - Method in class io.debezium.connector.mysql.legacy.MySqlSourceInfoStructMaker
 
schema() - Method in class io.debezium.connector.mysql.LegacyV1MySqlSourceInfoStructMaker
 
schema() - Method in class io.debezium.connector.mysql.MySqlSourceInfoStructMaker
 
SCHEMA_ONLY - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Perform a snapshot of only the database schemas (without data) and then begin reading the binlog.
SCHEMA_ONLY_RECOVERY - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Perform a snapshot of only the database schemas (without data) and then begin reading the binlog at the current binlog position.
schemaBuilder(Column) - Method in class io.debezium.connector.mysql.MySqlValueConverters
 
schemaChangeKeySchema - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
schemaChangeRecordKey(String) - Method in class io.debezium.connector.mysql.legacy.RecordMakers
 
schemaChangeRecordValue(String, Set<TableId>, String) - Method in class io.debezium.connector.mysql.legacy.RecordMakers
 
schemaChanges(String, Set<TableId>, String, BlockingConsumer<SourceRecord>) - Method in class io.debezium.connector.mysql.legacy.RecordMakers
Produce a schema change record for the given DDL statements.
schemaChangeValueSchema - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
schemaEvents - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
schemaNameAdjuster - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
SecureConnectionMode(String) - Constructor for enum io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
 
selectColumnsListener - Variable in class io.debezium.connector.mysql.antlr.listener.AlterViewParserListener
 
selectColumnsListener - Variable in class io.debezium.connector.mysql.antlr.listener.CreateViewParserListener
 
selector - Variable in class io.debezium.connector.mysql.converters.TinyIntOneToBooleanConverter
 
SELECTOR_PROPERTY - Static variable in class io.debezium.connector.mysql.converters.TinyIntOneToBooleanConverter
 
selectTableEditor - Variable in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
serialColumn() - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
serialVersionUID - Static variable in class io.debezium.connector.mysql.EventDataDeserializationExceptionData
 
serialVersionUID - Static variable in class io.debezium.connector.mysql.StopEventData
 
SERVER_ID - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SERVER_ID_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
SERVER_ID_KEY - Static variable in class io.debezium.connector.mysql.SourceInfo
 
SERVER_ID_OFFSET - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SERVER_NAME - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SERVER_PARTITION_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
SERVER_PARTITION_KEY - Static variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
serverId - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
serverId - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
serverId - Variable in class io.debezium.connector.mysql.SourceInfo
 
serverId() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
serverId() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
serverIdGenerator - Variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
ServerIdGenerator(long, long) - Constructor for class io.debezium.connector.mysql.legacy.MySqlConnectorTask.ServerIdGenerator
 
SESSION - io.debezium.connector.mysql.MySqlSystemVariables.MySqlScope
 
setBinlogPosition(String, long) - Method in class io.debezium.connector.mysql.SourceInfo
Set the position in the MySQL binlog where we will start reading.
setBinlogServerId(long) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Set the server ID as found within the MySQL binary log file.
setBinlogServerId(long) - Method in class io.debezium.connector.mysql.SourceInfo
Set the server ID as found within the MySQL binary log file.
setBinlogStartPoint(String, long) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Set the position in the MySQL binlog where we will start reading.
setBinlogStartPoint(String, long) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Set the position in the MySQL binlog where we will start reading.
setBinlogThread(long) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Set the identifier of the MySQL thread that generated the most recent event.
setBinlogThread(long) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
setBinlogThread(long) - Method in class io.debezium.connector.mysql.SourceInfo
Set the identifier of the MySQL thread that generated the most recent event.
setBinlogTimestampSeconds(long) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Set the number of seconds since Unix epoch (January 1, 1970) as found within the MySQL binary log file.
setBinlogTimestampSeconds(long) - Method in class io.debezium.connector.mysql.SourceInfo
Set the number of seconds since Unix epoch (January 1, 1970) as found within the MySQL binary log file.
setColumnDefaultValue(ColumnEditor) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
setColumnEditor(ColumnEditor) - Method in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
setCompletedGtidSet(String) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Set the GTID set that captures all of the GTID transactions that have been completely processed.
setCompletedGtidSet(String) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Set the GTID set that captures all of the GTID transactions that have been completely processed.
setEventPosition(long) - Method in class io.debezium.connector.mysql.SourceInfo
Set the position within the MySQL binary log file of the current event.
setEventPosition(long, long) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Set the position within the MySQL binary log file of the current event.
setEventPosition(long, long) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Set the position within the MySQL binary log file of the current event.
setFilterDataFromConfig(Configuration) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Set the filter data for the offset from the given Configuration
setFiltersFromFilters(Filters) - Method in class io.debezium.connector.mysql.legacy.Filters.Builder
Set the filter to match the given other filter.
setFiltersFromOffsets(Map<String, ?>) - Method in class io.debezium.connector.mysql.legacy.Filters.Builder
Completely reset the filter to match the filter info in the given offsets.
setFiltersFromStrings(String, String, String, String) - Method in class io.debezium.connector.mysql.legacy.Filters.Builder
 
setInitialSkips(long, int) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
setIsGtidModeEnabled(boolean) - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
setIsGtidModeEnabled(boolean) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
setMilliSecondsBehindSource(long) - Method in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
setMilliSecondsBehindSource(long) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
setOffset(Map<String, ?>) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Set the source offset, as read from Kafka Connect.
setQuery(String) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Set the original SQL query.
setQuery(String) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Set the original SQL query.
setQuery(String) - Method in class io.debezium.connector.mysql.SourceInfo
Set the original SQL query.
setRowNumber(int) - Method in class io.debezium.connector.mysql.SourceInfo
Given the row number within a binlog event and the total number of rows in that event, compute the Kafka Connect offset that is be included in the produced change event describing the row.
setRowNumber(int, int) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Given the row number within a binlog event and the total number of rows in that event, compute the Kafka Connect offset that is be included in the produced change event describing the row.
setSourceTime(Instant) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
setSourceTime(Instant) - Method in class io.debezium.connector.mysql.SourceInfo
 
setStatementFor(Map<String, String>) - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
setStatementFor(Map<String, String>) - Method in class io.debezium.connector.mysql.MySqlConnection
 
SetStatementParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL SET statements, for defining a system variables.
SetStatementParserListener(MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.SetStatementParserListener
 
setSystemProperty(String, Field, boolean) - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
setSystemProperty(String, Field, boolean) - Method in class io.debezium.connector.mysql.MySqlConnection
 
setSystemVariables(Map<String, String>) - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Set the system variables on the DDL parser.
setSystemVariables(Map<String, String>) - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
Set the system variables on the DDL parser.
setTransactionId() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
setupUnifiedReader() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
shouldRecordTableSchema(MySqlSchema, Filters, TableId) - Method in class io.debezium.connector.mysql.legacy.SnapshotReader
Whether DDL for the given table should be recorded.
shouldSnapshot() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Whether the snapshot should be executed.
shouldSnapshotOnDataError - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
 
shouldSnapshotOnDataError() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Whether the snapshot should be re-executed when there is a gap in data stream.
shouldSnapshotOnSchemaError - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
 
shouldSnapshotOnSchemaError() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Whether the schema can be recovered if database history is corrupted.
shouldStream - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
 
shouldStream() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Whether the snapshot mode is followed by streaming.
shutdown() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
shutdown() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Stop recording history and release any resources acquired since MySqlSchema.start().
shutdown() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
skipEvent - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
skipEvent - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
skipNodes - Variable in class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
Flag for skipping phase.
skippedNodesCount - Variable in class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
Count of skipped nodes.
skipUnparseableDDL - Variable in class io.debezium.connector.mysql.legacy.MySqlSchema
 
SMALLINT_CORRECTION - Static variable in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
 
SMALLINT_MAX_VALUE - Static variable in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
 
smtManager - Variable in class io.debezium.connector.mysql.transforms.ReadToInsertEvent
 
snapshot() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
SNAPSHOT_COMPLETED_KEY - Static variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
SNAPSHOT_LOCKING_MODE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SNAPSHOT_MODE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SNAPSHOT_NEW_TABLES - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
snapshotCompleted - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
snapshotLockingMode - Variable in class io.debezium.connector.mysql.legacy.SnapshotReader
 
snapshotLockingMode - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SnapshotLockingMode(String) - Constructor for enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
 
snapshotMode - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
snapshotMode() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
SnapshotMode(String, boolean, boolean, boolean, boolean, boolean) - Constructor for enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
 
snapshotNewTables - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SnapshotNewTables(String) - Constructor for enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotNewTables
 
SnapshotReader - Class in io.debezium.connector.mysql.legacy
A component that performs a snapshot of a MySQL server, and records the schema changes in MySqlSchema.
SnapshotReader(String, MySqlTaskContext) - Constructor for class io.debezium.connector.mysql.legacy.SnapshotReader
Create a snapshot reader.
SnapshotReader(String, MySqlTaskContext, boolean) - Constructor for class io.debezium.connector.mysql.legacy.SnapshotReader
Create a snapshot reader that can use global locking only optionally.
SnapshotReader.RecordRecorder - Interface in io.debezium.connector.mysql.legacy
 
SnapshotReaderMetrics - Class in io.debezium.connector.mysql.legacy
 
SnapshotReaderMetrics(MySqlTaskContext, MySqlSchema, ChangeEventQueueMetrics) - Constructor for class io.debezium.connector.mysql.legacy.SnapshotReaderMetrics
 
SnapshotReaderMetricsMXBean - Interface in io.debezium.connector.mysql.legacy
 
source - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
source - Variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
source - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
source() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
sourceInfo - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
SourceInfo - Class in io.debezium.connector.mysql.legacy
Information about the source of information, which includes the position in the source binary log we have previously processed.
SourceInfo - Class in io.debezium.connector.mysql
Information about the source of information, which includes the position in the source binary log we have previously processed.
SourceInfo(MySqlConnectorConfig) - Constructor for class io.debezium.connector.mysql.legacy.SourceInfo
 
SourceInfo(MySqlConnectorConfig) - Constructor for class io.debezium.connector.mysql.SourceInfo
 
sourceInfoSchema - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
sourceInfoStructMaker - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
sourcePartition - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
sourceTime - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
sourceTime - Variable in class io.debezium.connector.mysql.SourceInfo
 
split(long, int, int) - Static method in class io.debezium.connector.mysql.RowDeserializers
Split the integer into multiple integers.
SQL_SHOW_SESSION_VARIABLE_SSL_VERSION - Static variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
SQL_SHOW_SESSION_VARIABLE_SSL_VERSION - Static variable in class io.debezium.connector.mysql.MySqlConnection
 
SQL_SHOW_SYSTEM_VARIABLES - Static variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
SQL_SHOW_SYSTEM_VARIABLES - Static variable in class io.debezium.connector.mysql.MySqlConnection
 
SQL_SHOW_SYSTEM_VARIABLES_CHARACTER_SET - Static variable in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
SQL_SHOW_SYSTEM_VARIABLES_CHARACTER_SET - Static variable in class io.debezium.connector.mysql.MySqlConnection
 
srid - Variable in class io.debezium.connector.mysql.MySqlGeometry
Coordinate reference system identifier.
SSL_KEYSTORE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SSL_KEYSTORE_PASSWORD - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SSL_MODE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SSL_TRUSTSTORE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
SSL_TRUSTSTORE_PASSWORD - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
sslMode() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
sslMode() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
sslMode() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
sslModeEnabled() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
sslModeEnabled() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
sslModeEnabled() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
sslModeFor(MySqlConnectorConfig.SecureConnectionMode) - Static method in class io.debezium.connector.mysql.legacy.BinlogReader
 
sslModeFor(MySqlConnectorConfig.SecureConnectionMode) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
start - Variable in class io.debezium.connector.mysql.GtidSet.Interval
 
start() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
 
start() - Method in class io.debezium.connector.mysql.legacy.BlockingReader
 
start() - Method in class io.debezium.connector.mysql.legacy.ChainedReader
 
start() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
start() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Start by acquiring resources needed to persist the database history
start() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
start() - Method in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
start() - Method in interface io.debezium.connector.mysql.legacy.Reader
Start the reader and return immediately.
start() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
start() - Method in class io.debezium.connector.mysql.legacy.TimedBlockingReader
 
start(Configuration) - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
start(Configuration) - Method in class io.debezium.connector.mysql.MySqlConnectorTask
 
start(Map<String, String>) - Method in class io.debezium.connector.mysql.MySqlConnector
 
startGtid(String) - Method in class io.debezium.connector.mysql.SourceInfo
 
startGtid(String, String) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Record that a new GTID transaction has been started and has been included in the set of GTIDs known to the MySQL server.
startGtid(String, String) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
Record that a new GTID transaction has been started and has been included in the set of GTIDs known to the MySQL server.
STARTING_INDEX - Static variable in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
startingRowNumber - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
startingRowNumber - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
startNextReader() - Method in class io.debezium.connector.mysql.legacy.ChainedReader
Start the next reader.
startNextTransaction() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
startNextTransaction() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
startSnapshot() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Denote that a snapshot is being (or has been) started.
state - Variable in class io.debezium.connector.mysql.legacy.BlockingReader
 
state() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
 
state() - Method in class io.debezium.connector.mysql.legacy.BlockingReader
 
state() - Method in class io.debezium.connector.mysql.legacy.ChainedReader
 
state() - Method in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
state() - Method in interface io.debezium.connector.mysql.legacy.Reader
Get the current state of this reader.
state() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
State() - Constructor for enum io.debezium.connector.mysql.legacy.Reader.State
 
stats - Variable in class io.debezium.connector.mysql.legacy.BinlogReaderMetrics
 
stats - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSourceMetrics
 
stop() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
 
stop() - Method in class io.debezium.connector.mysql.legacy.BlockingReader
 
stop() - Method in class io.debezium.connector.mysql.legacy.ChainedReader
 
stop() - Method in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
stop() - Method in interface io.debezium.connector.mysql.legacy.Reader
Stop the reader from running and transition to the Reader.State.STOPPING state until all remaining records are consumed, at which point its state transitions to Reader.State.STOPPED.
stop() - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
stop() - Method in class io.debezium.connector.mysql.MySqlConnector
 
StopEventData - Class in io.debezium.connector.mysql
 
StopEventData() - Constructor for class io.debezium.connector.mysql.StopEventData
 
StopEventDataDeserializer - Class in io.debezium.connector.mysql
 
StopEventDataDeserializer() - Constructor for class io.debezium.connector.mysql.StopEventDataDeserializer
 
STOPPED - io.debezium.connector.mysql.legacy.Reader.State
The reader is stopped and static.
STOPPING - io.debezium.connector.mysql.legacy.Reader.State
The reader has completed its work or been explicitly stopped, but not all of the generated records have been consumed via polling.
storageInitialiationExecuted - Variable in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
storeOnlyCapturedTables() - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
storeOnlyCapturedTablesDdl - Variable in class io.debezium.connector.mysql.legacy.MySqlSchema
 
streamingChangeEventSource - Variable in class io.debezium.connector.mysql.EventBuffer
 
streamingMetrics - Variable in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
streamingMetrics - Variable in class io.debezium.connector.mysql.MySqlChangeEventSourceMetricsFactory
 
stringToDuration(String) - Static method in class io.debezium.connector.mysql.MySqlValueConverters
 
stringToLocalDate(String, Column, Table) - Static method in class io.debezium.connector.mysql.MySqlValueConverters
 
struct(SourceInfo) - Method in class io.debezium.connector.mysql.legacy.LegacyV1MySqlSourceInfoStructMaker
 
struct(SourceInfo) - Method in class io.debezium.connector.mysql.legacy.MySqlSourceInfoStructMaker
 
struct(SourceInfo) - Method in class io.debezium.connector.mysql.LegacyV1MySqlSourceInfoStructMaker
 
struct(SourceInfo) - Method in class io.debezium.connector.mysql.MySqlSourceInfoStructMaker
 
subtractGtidSet(GtidSet, GtidSet) - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
Determine the difference between two sets.
subtractGtidSet(GtidSet, GtidSet) - Method in class io.debezium.connector.mysql.MySqlConnection
Determine the difference between two sets.
success - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
supportsOperationFiltering() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
switchToBufferFullMode() - Method in class io.debezium.connector.mysql.EventBuffer
 
switchToBufferFullMode() - Method in class io.debezium.connector.mysql.legacy.EventBuffer
 
systemVariables() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
Get the system variables as known by the DDL parser.
systemVariables() - Method in class io.debezium.connector.mysql.MySqlDatabaseSchema
Get the system variables as known by the DDL parser.

T

table() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
Returns a string representation of the table(s) affected by the current event.
table() - Method in class io.debezium.connector.mysql.SourceInfo
Returns a string representation of the table(s) affected by the current event.
TABLE_BLACKLIST_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
TABLE_EXCLUDE_LIST_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
TABLE_INCLUDE_LIST_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
TABLE_WHITELIST_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
tableByAlias - Variable in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
tableEditor - Variable in class io.debezium.connector.mysql.antlr.listener.AlterTableParserListener
 
tableEditor - Variable in class io.debezium.connector.mysql.antlr.listener.AlterViewParserListener
 
tableEditor - Variable in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
tableEditor - Variable in class io.debezium.connector.mysql.antlr.listener.CreateTableParserListener
 
tableEditor - Variable in class io.debezium.connector.mysql.antlr.listener.CreateViewParserListener
 
tableEditor - Variable in class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
tableEvent(TableId) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
tableEvent(TableId) - Method in class io.debezium.connector.mysql.SourceInfo
 
tableEvent(String, Set<TableId>, Instant) - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
tableEvent(Set<TableId>) - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
tableEvent(Set<TableId>) - Method in class io.debezium.connector.mysql.SourceInfo
 
tableExcludeList - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
tableFilter - Variable in class io.debezium.connector.mysql.antlr.MySqlAntlrDdlParser
 
tableFilter - Variable in class io.debezium.connector.mysql.legacy.Filters.Builder
 
tableFilter - Variable in class io.debezium.connector.mysql.legacy.Filters
 
tableFilter() - Method in class io.debezium.connector.mysql.legacy.Filters
 
tableIdCaseInsensitive - Variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
Whether table ids are compared ignoring letter casing.
tableIds - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
tableIds - Variable in class io.debezium.connector.mysql.SourceInfo
 
tableIdsByTableNumber - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
tableIdsByTableNumber - Variable in class io.debezium.connector.mysql.MySqlDatabaseSchema
 
tableIncludeList - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
tableInformationComplete() - Method in class io.debezium.connector.mysql.legacy.MySqlSchema
 
tableLock(RelationalSnapshotChangeEventSource.RelationalSnapshotContext) - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
tableLockAcquiredAt - Variable in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
tableNumbersByTableId - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
TABLES_IGNORE_BUILTIN - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
tableUnlock() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
taskClass() - Method in class io.debezium.connector.mysql.MySqlConnector
 
taskConfigs(int) - Method in class io.debezium.connector.mysql.MySqlConnector
 
taskContext - Variable in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
taskContext - Variable in class io.debezium.connector.mysql.MySqlChangeEventSourceFactory
 
taskContext - Variable in class io.debezium.connector.mysql.MySqlConnectorTask
 
taskContext - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
temporalPrecisionMode - Variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
temporaryLoggingContext(String, Runnable) - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
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.
TEST_DISABLE_GLOBAL_LOCKING - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
It is not possible to test disabled global locking locally as regular MySQL build always provides global locking.
thisReaderNearEnd - Variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader.ParallelHaltingPredicate
 
THREAD_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
THREAD_KEY - Static variable in class io.debezium.connector.mysql.SourceInfo
 
threadId - Variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
threadId - Variable in class io.debezium.connector.mysql.SourceInfo
 
TIME_FIELD_PATTERN - Static variable in class io.debezium.connector.mysql.MySqlValueConverters
Used to parse values of TIME columns.
TIME_PRECISION_MODE - Static variable in class io.debezium.connector.mysql.MySqlConnectorConfig
 
TimedBlockingReader - Class in io.debezium.connector.mysql.legacy
A component that blocks doing nothing for a specified period of time or until the connector task is stopped
TimedBlockingReader(String, Duration) - Constructor for class io.debezium.connector.mysql.legacy.TimedBlockingReader
 
timeout - Variable in class io.debezium.connector.mysql.legacy.TimedBlockingReader
 
timer - Variable in class io.debezium.connector.mysql.legacy.TimedBlockingReader
 
timestamp() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
timestamp() - Method in class io.debezium.connector.mysql.SourceInfo
 
TIMESTAMP_FIELD_PATTERN - Static variable in class io.debezium.connector.mysql.MySqlValueConverters
Used to parse values of TIMESTAMP columns.
TIMESTAMP_KEY - Static variable in class io.debezium.connector.mysql.legacy.SourceInfo
 
TIMESTAMP_KEY - Static variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
timestampFormat(int) - Method in class io.debezium.connector.mysql.MySqlDefaultValueConverter
 
TINYINT_CORRECTION - Static variable in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
 
TINYINT_MAX_VALUE - Static variable in class io.debezium.connector.mysql.MySqlUnsignedIntegerConverter
Maximum values for Unsigned Integer Types.
TinyIntOneToBooleanConverter - Class in io.debezium.connector.mysql.converters
MySQL reports BOOLEAN values as TINYINT(1) in snapshot phase even as a result of DESCRIBE CREATE TABLE.
TinyIntOneToBooleanConverter() - Constructor for class io.debezium.connector.mysql.converters.TinyIntOneToBooleanConverter
 
toByteBuffer(Column, byte[]) - Method in class io.debezium.connector.mysql.MySqlValueConverters
 
topicSelector - Variable in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
topicSelector - Variable in class io.debezium.connector.mysql.legacy.RecordMakers
 
topicSelector - Variable in class io.debezium.connector.mysql.MySqlTaskContext
 
topicSelector() - Method in class io.debezium.connector.mysql.legacy.MySqlTaskContext
 
toString() - Method in class io.debezium.connector.mysql.EventDataDeserializationExceptionData
 
toString() - Method in class io.debezium.connector.mysql.GtidSet.Interval
 
toString() - Method in class io.debezium.connector.mysql.GtidSet
 
toString() - Method in class io.debezium.connector.mysql.GtidSet.UUIDSet
 
toString() - Method in class io.debezium.connector.mysql.legacy.AbstractReader
 
toString() - Method in class io.debezium.connector.mysql.legacy.BinlogReader.BinlogPosition
 
toString() - Method in class io.debezium.connector.mysql.legacy.SourceInfo
 
toString() - Method in class io.debezium.connector.mysql.MySqlOffsetContext
 
toString() - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource.BinlogPosition
 
toString() - Method in class io.debezium.connector.mysql.SourceInfo
 
toString() - Method in class io.debezium.connector.mysql.StopEventData
 
totalRecordCounter - Variable in class io.debezium.connector.mysql.legacy.BinlogReader
 
totalRecordCounter - Variable in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
transactionContext - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
transactionId - Variable in class io.debezium.connector.mysql.MySqlOffsetContext
 
TruncateTableParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL TRUNCATE TABLE statements.
TruncateTableParserListener(MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.TruncateTableParserListener
 
twoPhaseSchemaSnapshot() - Method in class io.debezium.connector.mysql.MySqlSnapshotChangeEventSource
 
txStarted - Variable in class io.debezium.connector.mysql.EventBuffer
 
txStarted - Variable in class io.debezium.connector.mysql.legacy.EventBuffer
 

U

unifiedReader - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
uniqueColumn - Variable in class io.debezium.connector.mysql.antlr.listener.ColumnDefinitionParserListener
 
unquote(String) - Method in class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
 
unquoteBinary(String) - Method in class io.debezium.connector.mysql.antlr.listener.DefaultValueParserListener
 
unwrapData(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
 
unwrapData(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
 
update(SourceInfo, Object[], Object[], int, int, BitSet, Instant, BlockingConsumer<SourceRecord>) - Method in interface io.debezium.connector.mysql.legacy.RecordMakers.Converter
 
update(Object[], Object[], Instant) - Method in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
Produce an update record for the row.
update(Object[], Object[], Instant, int, int) - Method in class io.debezium.connector.mysql.legacy.RecordMakers.RecordsForTable
Produce an update record for the row.
UpdateRowsDeserializer(Map<Long, TableMapEventData>) - Constructor for class io.debezium.connector.mysql.RowDeserializers.UpdateRowsDeserializer
 
uponCompletion - Variable in class io.debezium.connector.mysql.legacy.AbstractReader
 
uponCompletion - Variable in class io.debezium.connector.mysql.legacy.BlockingReader
 
uponCompletion - Variable in class io.debezium.connector.mysql.legacy.ChainedReader
 
uponCompletion - Variable in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
uponCompletion - Variable in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
uponCompletion(Runnable) - Method in class io.debezium.connector.mysql.legacy.AbstractReader
 
uponCompletion(Runnable) - Method in class io.debezium.connector.mysql.legacy.BlockingReader
 
uponCompletion(Runnable) - Method in class io.debezium.connector.mysql.legacy.ChainedReader
 
uponCompletion(Runnable) - Method in class io.debezium.connector.mysql.legacy.ParallelSnapshotReader
 
uponCompletion(Runnable) - Method in interface io.debezium.connector.mysql.legacy.Reader
Set the function that should be called when this reader transitions from the Reader.State.STOPPING to Reader.State.STOPPED state, which is after all generated records have been consumed via the poll method.
uponCompletion(Runnable) - Method in class io.debezium.connector.mysql.legacy.ReconcilingBinlogReader
 
URL_PATTERN - Static variable in class io.debezium.connector.mysql.MySqlConnection
 
useCursorFetch() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
useGlobalLock - Variable in class io.debezium.connector.mysql.legacy.SnapshotReader
 
useGlobalLock() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
Intended for testing only
userHasPrivileges(String) - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
Determine if the current user has the named privilege.
userHasPrivileges(String) - Method in class io.debezium.connector.mysql.MySqlConnection
Determine if the current user has the named privilege.
username() - Method in class io.debezium.connector.mysql.legacy.MySqlJdbcContext
 
username() - Method in class io.debezium.connector.mysql.MySqlConnection.MySqlConnectionConfiguration
 
username() - Method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
usesLocking() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
 
usesMinimalLocking() - Method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
 
UseStatementParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL USE statements that changes current database/schema on which all changes are applied.
UseStatementParserListener(MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.UseStatementParserListener
 
uuid - Variable in class io.debezium.connector.mysql.GtidSet.UUIDSet
 
UUIDSet(GtidSet.UUIDSet) - Constructor for class io.debezium.connector.mysql.GtidSet.UUIDSet
 
UUIDSet(String, GtidSet.Interval) - Constructor for class io.debezium.connector.mysql.GtidSet.UUIDSet
 
uuidSetsByServerId - Variable in class io.debezium.connector.mysql.GtidSet
 

V

validateAllFields(Configuration) - Method in class io.debezium.connector.mysql.MySqlConnector
 
validateAndLoadDatabaseHistory(MySqlConnectorConfig, MySqlOffsetContext, MySqlDatabaseSchema) - Method in class io.debezium.connector.mysql.MySqlConnectorTask
 
validateBinlogConfiguration(MySqlConnectorConfig) - Method in class io.debezium.connector.mysql.MySqlConnectorTask
 
validateConnection(Map<String, ConfigValue>, Configuration) - Method in class io.debezium.connector.mysql.MySqlConnector
 
validateEventDeserializationFailureHandlingModeNotSet(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
validateGtidNewChannelPositionNotSet(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
validateGtidSetExcludes(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
validateInconsistentSchemaHandlingModeNotIgnore(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
 
validateSnapshotFeasibility(MySqlConnectorConfig, MySqlOffsetContext) - Method in class io.debezium.connector.mysql.MySqlConnectorTask
 
validateSnapshotLockingMode(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
Validate the new snapshot.locking.mode configuration, which replaces snapshot.minimal.locking.
validateTimePrecisionMode(Configuration, Field, Field.ValidationOutput) - Static method in class io.debezium.connector.mysql.MySqlConnectorConfig
Validate the time.precision.mode configuration.
value - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.BigIntUnsignedHandlingMode
 
value - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.GtidNewChannelPosition
 
value - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
 
value - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
 
value - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
 
value - Variable in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotNewTables
 
valueOf(String) - Static method in enum io.debezium.connector.mysql.legacy.Reader.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.BigIntUnsignedHandlingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.GtidNewChannelPosition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotNewTables
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.debezium.connector.mysql.MySqlSystemVariables.MySqlScope
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.debezium.connector.mysql.legacy.Reader.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.mysql.MySqlConnectorConfig.BigIntUnsignedHandlingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.GtidNewChannelPosition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotLockingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotNewTables
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.debezium.connector.mysql.MySqlSystemVariables.MySqlScope
Returns an array containing the constants of this enum type, in the order they are declared.
VERIFY_CA - io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
Like REQUIRED, but additionally verify the server TLS certificate against the configured Certificate Authority (CA) certificates.
VERIFY_IDENTITY - io.debezium.connector.mysql.MySqlConnectorConfig.SecureConnectionMode
Like VERIFY_CA, but additionally verify that the server certificate matches the host to which the connection is attempted.
version() - Method in class io.debezium.connector.mysql.legacy.MySqlConnectorTask
 
version() - Static method in class io.debezium.connector.mysql.Module
 
version() - Method in class io.debezium.connector.mysql.MySqlConnector
 
version() - Method in class io.debezium.connector.mysql.MySqlConnectorTask
 
viewChange(Event) - Method in class io.debezium.connector.mysql.legacy.BinlogReader
Handle a EventType.VIEW_CHANGE event.
viewChange(Event) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Handle a EventType.VIEW_CHANGE event.
ViewSelectedColumnsParserListener - Class in io.debezium.connector.mysql.antlr.listener
Parser listener that is parsing MySQL SELECT statements used for definition of VIEW.
ViewSelectedColumnsParserListener(TableEditor, MySqlAntlrDdlParser) - Constructor for class io.debezium.connector.mysql.antlr.listener.ViewSelectedColumnsParserListener
 
visitErrorNode(ErrorNode) - Method in class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
 
visitTerminal(TerminalNode) - Method in class io.debezium.connector.mysql.antlr.listener.MySqlAntlrDdlParserListener
 

W

WHEN_NEEDED - io.debezium.connector.mysql.MySqlConnectorConfig.SnapshotMode
Perform a snapshot when it is needed.
with(GtidSet) - Method in class io.debezium.connector.mysql.GtidSet
Obtain a copy of this GtidSet except overwritten with all of the GTID ranges in the supplied GtidSet.
wkb - Variable in class io.debezium.connector.mysql.MySqlGeometry
Open Geospatial Consortium Well-Known-Binary representation of the Geometry.
WKB_EMPTY_GEOMETRYCOLLECTION - Static variable in class io.debezium.connector.mysql.MySqlGeometry
 
WKB_POINT_SIZE - Static variable in class io.debezium.connector.mysql.MySqlGeometry
 
wrap(Throwable) - Method in class io.debezium.connector.mysql.legacy.AbstractReader
Wraps the specified exception in a ConnectException, ensuring that all useful state is captured inside the new exception's message.
wrap(Throwable) - Method in class io.debezium.connector.mysql.MySqlStreamingChangeEventSource
Wraps the specified exception in a DebeziumException, ensuring that all useful state is captured inside the new exception's message.
WriteRowsDeserializer(Map<Long, TableMapEventData>) - Constructor for class io.debezium.connector.mysql.RowDeserializers.WriteRowsDeserializer
 
A B C D E F G H I J K L M N O P Q R S T U V W 
All Classes All Packages