Uses of Interface
org.apache.flink.table.factories.DynamicTableFactory.Context
-
-
Uses of DynamicTableFactory.Context in org.apache.flink.connector.base.table
Constructors in org.apache.flink.connector.base.table with parameters of type DynamicTableFactory.Context Constructor Description AsyncDynamicSinkContext(AsyncDynamicTableSinkFactory factory, DynamicTableFactory.Context context)
-
Uses of DynamicTableFactory.Context in org.apache.flink.connector.blackhole.table
Methods in org.apache.flink.connector.blackhole.table with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DynamicTableSink
BlackHoleTableSinkFactory. createDynamicTableSink(DynamicTableFactory.Context context)
-
Uses of DynamicTableFactory.Context in org.apache.flink.connector.datagen.table
Methods in org.apache.flink.connector.datagen.table with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DynamicTableSource
DataGenTableSourceFactory. createDynamicTableSource(DynamicTableFactory.Context context)
-
Uses of DynamicTableFactory.Context in org.apache.flink.connector.file.table
Methods in org.apache.flink.connector.file.table with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DynamicTableSink
FileSystemTableFactory. createDynamicTableSink(DynamicTableFactory.Context context)
DynamicTableSource
FileSystemTableFactory. createDynamicTableSource(DynamicTableFactory.Context context)
protected <I,F extends DecodingFormatFactory<I>>
DecodingFormat<I>FileSystemTableFactory. discoverDecodingFormat(DynamicTableFactory.Context context, Class<F> formatFactoryClass)
-
Uses of DynamicTableFactory.Context in org.apache.flink.connector.file.table.factories
Methods in org.apache.flink.connector.file.table.factories with parameters of type DynamicTableFactory.Context Modifier and Type Method Description BulkDecodingFormat<RowData>
BulkReaderFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Creates aBulkDecodingFormat
from the given context and format options. -
Uses of DynamicTableFactory.Context in org.apache.flink.connector.print.table
Methods in org.apache.flink.connector.print.table with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DynamicTableSink
PrintTableSinkFactory. createDynamicTableSink(DynamicTableFactory.Context context)
-
Uses of DynamicTableFactory.Context in org.apache.flink.connector.upserttest.table
Methods in org.apache.flink.connector.upserttest.table with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DynamicTableSink
UpsertTestDynamicTableSinkFactory. createDynamicTableSink(DynamicTableFactory.Context context)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.avro
Methods in org.apache.flink.formats.avro with parameters of type DynamicTableFactory.Context Modifier and Type Method Description BulkDecodingFormat<RowData>
AvroFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DecodingFormat<DeserializationSchema<RowData>>
AvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
AvroFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
AvroFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.avro.registry.confluent
Methods in org.apache.flink.formats.avro.registry.confluent with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
RegistryAvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
RegistryAvroFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.avro.registry.confluent.debezium
Methods in org.apache.flink.formats.avro.registry.confluent.debezium with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
DebeziumAvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
DebeziumAvroFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.csv
Methods in org.apache.flink.formats.csv with parameters of type DynamicTableFactory.Context Modifier and Type Method Description BulkDecodingFormat<RowData>
CsvFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DecodingFormat<DeserializationSchema<RowData>>
CsvFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
CsvFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
CsvFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.json
Methods in org.apache.flink.formats.json with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
JsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
JsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.json.canal
Methods in org.apache.flink.formats.json.canal with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
CanalJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
CanalJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.json.debezium
Methods in org.apache.flink.formats.json.debezium with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
DebeziumJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
DebeziumJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.json.maxwell
Methods in org.apache.flink.formats.json.maxwell with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
MaxwellJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
MaxwellJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.json.ogg
Methods in org.apache.flink.formats.json.ogg with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
OggJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
OggJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.parquet
Methods in org.apache.flink.formats.parquet with parameters of type DynamicTableFactory.Context Modifier and Type Method Description BulkDecodingFormat<RowData>
ParquetFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
ParquetFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.protobuf
Methods in org.apache.flink.formats.protobuf with parameters of type DynamicTableFactory.Context Modifier and Type Method Description BulkDecodingFormat<RowData>
PbFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DecodingFormat<DeserializationSchema<RowData>>
PbFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
PbFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
PbFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.formats.raw
Methods in org.apache.flink.formats.raw with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
RawFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
RawFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.orc
Methods in org.apache.flink.orc with parameters of type DynamicTableFactory.Context Modifier and Type Method Description BulkDecodingFormat<RowData>
OrcFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
OrcFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of DynamicTableFactory.Context in org.apache.flink.table.examples.java.connectors
Methods in org.apache.flink.table.examples.java.connectors with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
ChangelogCsvFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DynamicTableSource
SocketDynamicTableFactory. createDynamicTableSource(DynamicTableFactory.Context context)
-
Uses of DynamicTableFactory.Context in org.apache.flink.table.factories
Classes in org.apache.flink.table.factories that implement DynamicTableFactory.Context Modifier and Type Class Description static class
FactoryUtil.DefaultDynamicTableContext
Default implementation ofDynamicTableFactory.Context
.Methods in org.apache.flink.table.factories with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DecodingFormat<I>
DecodingFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Creates a format from the given context and format options.DynamicTableSink
DynamicTableSinkFactory. createDynamicTableSink(DynamicTableFactory.Context context)
Creates aDynamicTableSink
instance from aCatalogTable
and additional context information.DynamicTableSource
DynamicTableSourceFactory. createDynamicTableSource(DynamicTableFactory.Context context)
Creates aDynamicTableSource
instance from aCatalogTable
and additional context information.EncodingFormat<I>
EncodingFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Creates a format from the given context and format options.static FactoryUtil.TableFactoryHelper
FactoryUtil. createTableFactoryHelper(DynamicTableFactory factory, DynamicTableFactory.Context context)
Creates a utility that helps in discovering formats, merging options withgetEnrichmentOptions()
and validating them all for aDynamicTableFactory
.Map<String,String>
ManagedTableFactory. enrichOptions(DynamicTableFactory.Context context)
Deprecated.Enrich options from catalog and session information.Map<String,String>
ManagedTableFactory. onCompactTable(DynamicTableFactory.Context context, CatalogPartitionSpec partitionSpec)
Deprecated.Notifies the listener that a table compaction occurred.void
ManagedTableFactory. onCreateTable(DynamicTableFactory.Context context, boolean ignoreIfExists)
Deprecated.Notifies the listener that a table creation occurred.void
ManagedTableFactory. onDropTable(DynamicTableFactory.Context context, boolean ignoreIfNotExists)
Deprecated.Notifies the listener that a table drop occurred. -
Uses of DynamicTableFactory.Context in org.apache.flink.table.file.testutils
Methods in org.apache.flink.table.file.testutils with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DynamicTableSink
TestFileSystemTableFactory. createDynamicTableSink(DynamicTableFactory.Context context)
DynamicTableSource
TestFileSystemTableFactory. createDynamicTableSource(DynamicTableFactory.Context context)
-
Uses of DynamicTableFactory.Context in org.apache.flink.table.toolbox
Methods in org.apache.flink.table.toolbox with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DynamicTableSource
TestScanTableSourceWithWatermarkPushDownFactory. createDynamicTableSource(DynamicTableFactory.Context context)
-
Uses of DynamicTableFactory.Context in org.apache.flink.table.utils.python
Methods in org.apache.flink.table.utils.python with parameters of type DynamicTableFactory.Context Modifier and Type Method Description DynamicTableSource
PythonDynamicTableFactory. createDynamicTableSource(DynamicTableFactory.Context context)
-