A B C D E F G H I K L M N O P Q R S T U V 
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- add(TablePipeline) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamStatementSetImpl
 - add(TablePipeline) - Method in interface org.apache.flink.table.api.bridge.java.StreamStatementSet
 - addInsert(String, Table) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamStatementSetImpl
 - addInsert(String, Table) - Method in interface org.apache.flink.table.api.bridge.java.StreamStatementSet
 - addInsert(String, Table, boolean) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamStatementSetImpl
 - addInsert(String, Table, boolean) - Method in interface org.apache.flink.table.api.bridge.java.StreamStatementSet
 - addInsert(TableDescriptor, Table) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamStatementSetImpl
 - addInsert(TableDescriptor, Table) - Method in interface org.apache.flink.table.api.bridge.java.StreamStatementSet
 - addInsert(TableDescriptor, Table, boolean) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamStatementSetImpl
 - addInsert(TableDescriptor, Table, boolean) - Method in interface org.apache.flink.table.api.bridge.java.StreamStatementSet
 - addInsertSql(String) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamStatementSetImpl
 - addInsertSql(String) - Method in interface org.apache.flink.table.api.bridge.java.StreamStatementSet
 - AppendStreamTableSink<T> - Interface in org.apache.flink.legacy.table.sinks
 - 
Deprecated.This interface has been replaced by
DynamicTableSink. The new interface consumes internal data structures. See FLIP-95 for more information. - applyLimit(long) - Method in class org.apache.flink.connector.datagen.table.DataGenTableSource
 - AscendingTimestamps - Class in org.apache.flink.table.sources.wmstrategies
 - 
A watermark strategy for ascending rowtime attributes.
 - AscendingTimestamps() - Constructor for class org.apache.flink.table.sources.wmstrategies.AscendingTimestamps
 - asSummaryString() - Method in class org.apache.flink.connector.datagen.table.DataGenTableSource
 - attachAsDataStream() - Method in class org.apache.flink.table.api.bridge.java.internal.StreamStatementSetImpl
 - attachAsDataStream() - Method in interface org.apache.flink.table.api.bridge.java.StreamStatementSet
 - 
Optimizes all statements as one entity and adds them as transformations to the underlying
StreamExecutionEnvironment. 
B
- BlackHoleTableSinkFactory - Class in org.apache.flink.connector.blackhole.table
 - 
Black hole table sink factory swallowing all input records.
 - BlackHoleTableSinkFactory() - Constructor for class org.apache.flink.connector.blackhole.table.BlackHoleTableSinkFactory
 - BoundedOutOfOrderTimestamps - Class in org.apache.flink.table.sources.wmstrategies
 - 
A watermark strategy for rowtime attributes which are out-of-order by a bounded time interval.
 - BoundedOutOfOrderTimestamps(long) - Constructor for class org.apache.flink.table.sources.wmstrategies.BoundedOutOfOrderTimestamps
 - build() - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.Apply the current values and constructs a newly-created CsvTableSource.
 - builder() - Static method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.Return a new builder that builds a CsvTableSource.
 - Builder() - Constructor for class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.
 
C
- close() - Method in class org.apache.flink.table.sources.CsvTableSource.CsvLookupFunction
 - 
Deprecated.
 - commentPrefix(String) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.Sets a prefix to indicate comments, null by default.
 - config - Variable in class org.apache.flink.connector.datagen.table.DataGenVisitorBase
 - configure(String[], TypeInformation<?>[]) - Method in class org.apache.flink.table.sinks.CsvTableSink
 - 
Deprecated.
 - consumeDataStream(DataStream<RowData>) - Method in interface org.apache.flink.table.connector.sink.DataStreamSinkProvider
 - 
Deprecated.Use
DataStreamSinkProvider.consumeDataStream(ProviderContext, DataStream)and correctly set a unique identifier for each data stream transformation. - consumeDataStream(DataStream<Row>) - Method in class org.apache.flink.table.sinks.CsvTableSink
 - 
Deprecated.
 - consumeDataStream(DataStream<T>) - Method in class org.apache.flink.legacy.table.sinks.OutputFormatTableSink
 - 
Deprecated.
 - consumeDataStream(DataStream<T>) - Method in interface org.apache.flink.legacy.table.sinks.StreamTableSink
 - 
Deprecated.Consumes the DataStream and return the sink transformation
DataStreamSink. - consumeDataStream(ProviderContext, DataStream<RowData>) - Method in interface org.apache.flink.table.connector.sink.DataStreamSinkProvider
 - 
Consumes the given Java
DataStreamand returns the sink transformationDataStreamSink. - copy() - Method in class org.apache.flink.connector.datagen.table.DataGenTableSource
 - create(StreamExecutionEnvironment) - Static method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Creates a table environment that is the entry point and central context for creating Table and SQL API programs that integrate with the Java-specific
DataStreamAPI. - create(StreamExecutionEnvironment, EnvironmentSettings) - Static method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - create(StreamExecutionEnvironment, EnvironmentSettings) - Static method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Creates a table environment that is the entry point and central context for creating Table and SQL API programs that integrate with the Java-specific
DataStreamAPI. - createDefaultMask(int) - Static method in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - createDynamicTableSink(DynamicTableFactory.Context) - Method in class org.apache.flink.connector.blackhole.table.BlackHoleTableSinkFactory
 - createDynamicTableSink(DynamicTableFactory.Context) - Method in class org.apache.flink.connector.print.table.PrintTableSinkFactory
 - createDynamicTableSource(DynamicTableFactory.Context) - Method in class org.apache.flink.connector.datagen.table.DataGenTableSourceFactory
 - createSinkFunction() - Method in interface org.apache.flink.table.connector.sink.legacy.SinkFunctionProvider
 - 
Deprecated.Creates a
SinkFunctioninstance. - createSource() - Method in class org.apache.flink.connector.datagen.table.DataGenTableSource
 - createSourceFunction() - Method in interface org.apache.flink.legacy.table.connector.source.SourceFunctionProvider
 - 
Deprecated.Creates a
SourceFunctioninstance. - createStatementSet() - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - createStatementSet() - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Returns a
StatementSetthat integrates with the Java-specificDataStreamAPI. - createStreamTableSink(Map<String, String>) - Method in interface org.apache.flink.legacy.table.factories.StreamTableSinkFactory
 - 
Deprecated.
TableSinkFactory.Contextcontains more information, and already contains table schema too. Please useTableSinkFactory.createTableSink(Context)instead. - createStreamTableSink(Map<String, String>) - Method in class org.apache.flink.table.sinks.CsvAppendTableSinkFactory
 - 
Deprecated.
 - createStreamTableSink(Map<String, String>) - Method in class org.apache.flink.table.sinks.CsvBatchTableSinkFactory
 - 
Deprecated.
 - createStreamTableSource(Map<String, String>) - Method in interface org.apache.flink.legacy.table.factories.StreamTableSourceFactory
 - 
Deprecated.
TableSourceFactory.Contextcontains more information, and already contains table schema too. Please useTableSourceFactory.createTableSource(Context)instead. - createStreamTableSource(Map<String, String>) - Method in class org.apache.flink.table.sources.CsvAppendTableSourceFactory
 - 
Deprecated.
 - createStreamTableSource(Map<String, String>) - Method in class org.apache.flink.table.sources.CsvBatchTableSourceFactory
 - 
Deprecated.
 - createTableSink(Boolean, Map<String, String>) - Method in class org.apache.flink.table.sinks.CsvTableSinkFactoryBase
 - 
Deprecated.
 - createTableSink(Map<String, String>) - Method in interface org.apache.flink.legacy.table.factories.StreamTableSinkFactory
 - 
Deprecated.Only create stream table sink.
 - createTableSource(Boolean, Map<String, String>) - Method in class org.apache.flink.table.sources.CsvTableSourceFactoryBase
 - 
Deprecated.
 - createTableSource(Map<String, String>) - Method in interface org.apache.flink.legacy.table.factories.StreamTableSourceFactory
 - 
Deprecated.Only create a stream table source.
 - createTemporaryView(String, DataStream<T>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - createTemporaryView(String, DataStream<T>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Creates a view from the given
DataStreamin a given path. - createTemporaryView(String, DataStream<T>, Schema) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - createTemporaryView(String, DataStream<T>, Schema) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Creates a view from the given
DataStreamin a given path. - createTemporaryView(String, DataStream<T>, Expression...) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - createTemporaryView(String, DataStream<T>, Expression...) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Deprecated.Use
StreamTableEnvironment.createTemporaryView(String, DataStream, Schema)instead. In most cases,StreamTableEnvironment.createTemporaryView(String, DataStream)should already be sufficient. It integrates with the new type system and supports all kinds ofDataTypesthat the table runtime can consume. The semantics might be slightly different for raw and structured types. - CsvAppendTableSinkFactory - Class in org.apache.flink.table.sinks
 - 
Deprecated.The legacy CSV connector has been replaced by
FileSink. It is kept only to support tests for the legacy connector stack. - CsvAppendTableSinkFactory() - Constructor for class org.apache.flink.table.sinks.CsvAppendTableSinkFactory
 - 
Deprecated.
 - CsvAppendTableSourceFactory - Class in org.apache.flink.table.sources
 - 
Deprecated.The legacy CSV connector has been replaced by
FileSource. It is kept only to support tests for the legacy connector stack. - CsvAppendTableSourceFactory() - Constructor for class org.apache.flink.table.sources.CsvAppendTableSourceFactory
 - 
Deprecated.
 - CsvBatchTableSinkFactory - Class in org.apache.flink.table.sinks
 - 
Deprecated.The legacy CSV connector has been replaced by
FileSink. It is kept only to support tests for the legacy connector stack. - CsvBatchTableSinkFactory() - Constructor for class org.apache.flink.table.sinks.CsvBatchTableSinkFactory
 - 
Deprecated.
 - CsvBatchTableSourceFactory - Class in org.apache.flink.table.sources
 - 
Deprecated.The legacy CSV connector has been replaced by
FileSource. It is kept only to support tests for the legacy connector stack. - CsvBatchTableSourceFactory() - Constructor for class org.apache.flink.table.sources.CsvBatchTableSourceFactory
 - 
Deprecated.
 - CsvInputFormat<OUT> - Class in org.apache.flink.table.sources.format
 - 
Deprecated.
 - CsvInputFormat(Path) - Constructor for class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - CsvTableSink - Class in org.apache.flink.table.sinks
 - 
Deprecated.The legacy CSV connector has been replaced by
FileSink. It is kept only to support tests for the legacy connector stack. - CsvTableSink(String) - Constructor for class org.apache.flink.table.sinks.CsvTableSink
 - 
Deprecated.A simple
TableSinkto emit data as CSV files using comma as field delimiter, with default parallelism and write mode. - CsvTableSink(String, String) - Constructor for class org.apache.flink.table.sinks.CsvTableSink
 - 
Deprecated.A simple
TableSinkto emit data as CSV files, with default parallelism and write mode. - CsvTableSink(String, String, int, FileSystem.WriteMode) - Constructor for class org.apache.flink.table.sinks.CsvTableSink
 - 
Deprecated.A simple
TableSinkto emit data as CSV files. - CsvTableSink(String, String, int, FileSystem.WriteMode, String[], DataType[]) - Constructor for class org.apache.flink.table.sinks.CsvTableSink
 - 
Deprecated.A simple
TableSinkto emit data as CSV files. - CsvTableSink.CsvFormatter - Class in org.apache.flink.table.sinks
 - 
Deprecated.Formats a Row into a String with fields separated by the field delimiter.
 - CsvTableSinkFactoryBase - Class in org.apache.flink.table.sinks
 - 
Deprecated.The legacy CSV connector has been replaced by
FileSink. It is kept only to support tests for the legacy connector stack. - CsvTableSinkFactoryBase() - Constructor for class org.apache.flink.table.sinks.CsvTableSinkFactoryBase
 - 
Deprecated.
 - CsvTableSource - Class in org.apache.flink.table.sources
 - 
Deprecated.The legacy CSV connector has been replaced by
FileSource. It is kept only to support tests for the legacy connector stack. - CsvTableSource(String, String[], TypeInformation<?>[]) - Constructor for class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.A
InputFormatTableSourceandLookupableTableSourcefor simple CSV files with a (logically) unlimited number of fields. - CsvTableSource(String, String[], TypeInformation<?>[], int[], String, String, Character, boolean, String, boolean) - Constructor for class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.A
InputFormatTableSourceandLookupableTableSourcefor simple CSV files with a (logically) unlimited number of fields. - CsvTableSource(String, String[], TypeInformation<?>[], String, String, Character, boolean, String, boolean) - Constructor for class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.A
InputFormatTableSourceandLookupableTableSourcefor simple CSV files with a (logically) unlimited number of fields. - CsvTableSource.Builder - Class in org.apache.flink.table.sources
 - 
Deprecated.A builder for creating CsvTableSource instances.
 - CsvTableSource.CsvLookupFunction - Class in org.apache.flink.table.sources
 - 
Deprecated.LookupFunction to support lookup in CsvTableSource.
 - CsvTableSourceFactoryBase - Class in org.apache.flink.table.sources
 - 
Deprecated.The legacy CSV connector has been replaced by
FileSource. It is kept only to support tests for the legacy connector stack. - CsvTableSourceFactoryBase() - Constructor for class org.apache.flink.table.sources.CsvTableSourceFactoryBase
 - 
Deprecated.
 
D
- DataGenConnectorOptions - Class in org.apache.flink.connector.datagen.table
 - 
Options for the DataGen connector.
 - DataGenConnectorOptionsUtil - Class in org.apache.flink.connector.datagen.table
 - 
Utilities for
DataGenConnectorOptions. - DataGeneratorContainer - Class in org.apache.flink.connector.datagen.table
 - 
Container class for wrapping a
with its configuration options. - DataGeneratorMapper<A,B> - Class in org.apache.flink.connector.datagen.table.types
 - 
Utility for mapping the output of a
DataGenerator. - DataGeneratorMapper(DataGenerator<A>, SerializableFunction<A, B>, float) - Constructor for class org.apache.flink.connector.datagen.table.types.DataGeneratorMapper
 - DataGenTableSource - Class in org.apache.flink.connector.datagen.table
 - 
A
StreamTableSourcethat emits generated data rows. - DataGenTableSource(DataGenerator<?>[], String, DataType, long, Long, Integer) - Constructor for class org.apache.flink.connector.datagen.table.DataGenTableSource
 - DataGenTableSourceFactory - Class in org.apache.flink.connector.datagen.table
 - 
Factory for creating configured instances of
DataGenTableSourcein a stream environment. - DataGenTableSourceFactory() - Constructor for class org.apache.flink.connector.datagen.table.DataGenTableSourceFactory
 - DataGenVisitorBase - Class in org.apache.flink.connector.datagen.table
 - 
Base class for translating
LogicalTypestoDataGeneratorContainer's. - DataGenVisitorBase(String, ReadableConfig) - Constructor for class org.apache.flink.connector.datagen.table.DataGenVisitorBase
 - DataStreamScanProvider - Interface in org.apache.flink.table.connector.source
 - 
Provider that produces a Java
DataStreamas a runtime implementation forScanTableSource. - DataStreamSinkProvider - Interface in org.apache.flink.table.connector.sink
 - 
Provider that consumes a Java
DataStreamas a runtime implementation forDynamicTableSink. - DecimalDataRandomGenerator - Class in org.apache.flink.connector.datagen.table.types
 - 
Generates random
DecimalDatavalues. - DecimalDataRandomGenerator(int, int, double, double, float) - Constructor for class org.apache.flink.connector.datagen.table.types.DecimalDataRandomGenerator
 - DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - DEFAULT_LINE_DELIMITER - Static variable in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - defaultMethod(LogicalType) - Method in class org.apache.flink.connector.datagen.table.DataGenVisitorBase
 - defaultMethod(LogicalType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - DefaultProcedureContext - Class in org.apache.flink.table.procedure
 - 
The default implementation for
ProcedureContext. - DefaultProcedureContext(StreamExecutionEnvironment) - Constructor for class org.apache.flink.table.procedure.DefaultProcedureContext
 - deriveFieldMapping(DescriptorProperties, Optional<TypeInformation<?>>) - Static method in class org.apache.flink.legacy.table.descriptors.SchemaValidator
 - 
Deprecated.Finds a table source field mapping.
 - deriveProctimeAttribute(DescriptorProperties) - Static method in class org.apache.flink.legacy.table.descriptors.SchemaValidator
 - 
Deprecated.Finds the proctime attribute if defined.
 - deriveRowtimeAttributes(DescriptorProperties) - Static method in class org.apache.flink.legacy.table.descriptors.SchemaValidator
 - 
Deprecated.Finds the rowtime attributes if defined.
 - deriveTableSinkSchema(DescriptorProperties) - Static method in class org.apache.flink.legacy.table.descriptors.SchemaValidator
 - 
Deprecated.This method combines two separate concepts of table schema and field mapping. This should be split into two methods once we have support for the corresponding interfaces (see FLINK-9870).
 
E
- emptyColumnAsNull() - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.Treat empty column as null, false by default.
 - END - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - equals(Object) - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 - equals(Object) - Method in class org.apache.flink.table.sources.wmstrategies.AscendingTimestamps
 - equals(Object) - Method in class org.apache.flink.table.sources.wmstrategies.BoundedOutOfOrderTimestamps
 - eval(Object...) - Method in class org.apache.flink.table.sources.CsvTableSource.CsvLookupFunction
 - 
Deprecated.
 - explainSource() - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 
F
- factoryIdentifier() - Method in class org.apache.flink.connector.blackhole.table.BlackHoleTableSinkFactory
 - factoryIdentifier() - Method in class org.apache.flink.connector.datagen.table.DataGenTableSourceFactory
 - factoryIdentifier() - Method in class org.apache.flink.connector.print.table.PrintTableSinkFactory
 - field(String, TypeInformation<?>) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.This method will be removed in future versions as it uses the old type system. It is recommended to use
CsvTableSource.Builder.field(String, DataType)instead which uses the new type system based onDataTypes. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information. - field(String, DataType) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.Adds a field with the field name and the data type.
 - FIELD_END - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - 
Placeholder
ConfigOption. - FIELD_KIND - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - 
Placeholder
ConfigOption. - FIELD_LENGTH - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - 
Placeholder
ConfigOption. - FIELD_MAX - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - 
Placeholder
ConfigOption. - FIELD_MAX_PAST - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - 
Placeholder
ConfigOption. - FIELD_MIN - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - 
Placeholder
ConfigOption. - FIELD_NULL_RATE - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - 
Placeholder
ConfigOption. - FIELD_START - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - 
Placeholder
ConfigOption. - FIELD_VAR_LEN - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - 
Placeholder
ConfigOption. - fieldDelimiter(String) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.Sets the field delimiter, "," by default.
 - FIELDS - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - fillRecord(Row, Object[]) - Method in class org.apache.flink.table.sources.format.RowCsvInputFormat
 - 
Deprecated.
 - fillRecord(OUT, Object[]) - Method in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - FORMAT_COMMENT_PREFIX - Static variable in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - FORMAT_FIELD_DELIMITER - Static variable in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - FORMAT_FIELDS - Static variable in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - FORMAT_IGNORE_FIRST_LINE - Static variable in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - FORMAT_IGNORE_PARSE_ERRORS - Static variable in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - FORMAT_LINE_DELIMITER - Static variable in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - FORMAT_NUM_FILES - Static variable in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - FORMAT_QUOTE_CHARACTER - Static variable in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - FORMAT_TYPE_VALUE - Static variable in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - FORMAT_WRITE_MODE - Static variable in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - fromChangelogStream(DataStream<Row>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - fromChangelogStream(DataStream<Row>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Converts the given
DataStreamof changelog entries into aTable. - fromChangelogStream(DataStream<Row>, Schema) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - fromChangelogStream(DataStream<Row>, Schema) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Converts the given
DataStreamof changelog entries into aTable. - fromChangelogStream(DataStream<Row>, Schema, ChangelogMode) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - fromChangelogStream(DataStream<Row>, Schema, ChangelogMode) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Converts the given
DataStreamof changelog entries into aTable. - fromDataStream(DataStream<T>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - fromDataStream(DataStream<T>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Converts the given
DataStreaminto aTable. - fromDataStream(DataStream<T>, Schema) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - fromDataStream(DataStream<T>, Schema) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Converts the given
DataStreaminto aTable. - fromDataStream(DataStream<T>, Expression...) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - fromDataStream(DataStream<T>, Expression...) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Deprecated.Use
StreamTableEnvironment.fromDataStream(DataStream, Schema)instead. In most cases,StreamTableEnvironment.fromDataStream(DataStream)should already be sufficient. It integrates with the new type system and supports all kinds ofDataTypesthat the table runtime can consume. The semantics might be slightly different for raw and structured types. 
G
- generateUid(String) - Method in interface org.apache.flink.table.connector.ProviderContext
 - 
Generates a new unique identifier for a
Transformation/DataStreamoperator. - getAsyncLookupFunction(String[]) - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 - getChangelogMode() - Method in class org.apache.flink.connector.datagen.table.DataGenTableSource
 - getConsumedDataType() - Method in class org.apache.flink.table.sinks.CsvTableSink
 - 
Deprecated.
 - getDataStream(StreamExecutionEnvironment) - Method in class org.apache.flink.legacy.table.sources.InputFormatTableSource
 - 
Deprecated.
 - getDataStream(StreamExecutionEnvironment) - Method in interface org.apache.flink.legacy.table.sources.StreamTableSource
 - 
Deprecated.Returns the data of the table as a
DataStream. - getDataStream(StreamExecutionEnvironment) - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 - getExecutionEnvironment() - Method in class org.apache.flink.table.procedure.DefaultProcedureContext
 - getExecutionEnvironment() - Method in interface org.apache.flink.table.procedure.ProcedureContext
 - 
Return the
StreamExecutionEnvironmentwhere the procedure is called. - getFieldLogicalTypes(TableSchema) - Static method in class org.apache.flink.table.sources.CsvTableSourceFactoryBase
 - 
Deprecated.
 - getFieldTypes() - Method in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - getGenerator() - Method in class org.apache.flink.connector.datagen.table.DataGeneratorContainer
 - getInputFormat() - Method in class org.apache.flink.legacy.table.sources.InputFormatTableSource
 - 
Deprecated.Returns an
InputFormatfor reading the data of the table. - getLookupFunction(String[]) - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 - getOptions() - Method in class org.apache.flink.connector.datagen.table.DataGeneratorContainer
 - getOutputFormat() - Method in class org.apache.flink.legacy.table.sinks.OutputFormatTableSink
 - 
Deprecated.Returns an
OutputFormatfor writing the data of the table. - getOutputType() - Method in interface org.apache.flink.legacy.table.sinks.RetractStreamTableSink
 - 
Deprecated.
 - getOutputType() - Method in interface org.apache.flink.legacy.table.sinks.UpsertStreamTableSink
 - 
Deprecated.
 - getParallelism() - Method in interface org.apache.flink.table.connector.sink.DataStreamSinkProvider
 - getProducedDataType() - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 - getProducedType() - Method in class org.apache.flink.table.sources.format.RowCsvInputFormat
 - 
Deprecated.
 - getRecordType() - Method in interface org.apache.flink.legacy.table.sinks.RetractStreamTableSink
 - 
Deprecated.Returns the requested record type.
 - getRecordType() - Method in interface org.apache.flink.legacy.table.sinks.UpsertStreamTableSink
 - 
Deprecated.Returns the requested record type.
 - getResultType() - Method in class org.apache.flink.table.sources.CsvTableSource.CsvLookupFunction
 - 
Deprecated.
 - getRowtimeComponents(DescriptorProperties, String) - Static method in class org.apache.flink.legacy.table.descriptors.RowtimeValidator
 - 
Deprecated.
 - getScanRuntimeProvider(ScanTableSource.ScanContext) - Method in class org.apache.flink.connector.datagen.table.DataGenTableSource
 - getTableSchema() - Method in class org.apache.flink.table.sinks.CsvTableSink
 - 
Deprecated.
 - getTableSchema() - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 - getWatermark() - Method in class org.apache.flink.table.sources.wmstrategies.AscendingTimestamps
 - getWatermark() - Method in class org.apache.flink.table.sources.wmstrategies.BoundedOutOfOrderTimestamps
 - getWatermark() - Method in class org.apache.flink.table.sources.wmstrategies.PeriodicWatermarkAssigner
 - 
Returns the current watermark.
 - getWatermark(Row, long) - Method in class org.apache.flink.table.sources.wmstrategies.PunctuatedWatermarkAssigner
 - 
Returns the watermark for the current row or null if no watermark should be generated.
 
H
- hashCode() - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 - hashCode() - Method in class org.apache.flink.table.sources.wmstrategies.AscendingTimestamps
 - hashCode() - Method in class org.apache.flink.table.sources.wmstrategies.BoundedOutOfOrderTimestamps
 - hasNext() - Method in class org.apache.flink.connector.datagen.table.types.DataGeneratorMapper
 - hasNext() - Method in class org.apache.flink.connector.datagen.table.types.DecimalDataRandomGenerator
 - hasNext() - Method in class org.apache.flink.connector.datagen.table.types.RowDataGenerator
 
I
- IDENTIFIER - Static variable in class org.apache.flink.connector.blackhole.table.BlackHoleTableSinkFactory
 - IDENTIFIER - Static variable in class org.apache.flink.connector.datagen.table.DataGenTableSourceFactory
 - IDENTIFIER - Static variable in class org.apache.flink.connector.print.table.PrintTableSinkFactory
 - ignoreFirstLine() - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.Ignore the first line.
 - ignoreParseErrors() - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.Skip records with parse error instead to fail.
 - initializeSplit(FileInputSplit, Long) - Method in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - InputFormatTableSource<T> - Class in org.apache.flink.legacy.table.sources
 - 
Deprecated.This interface has been replaced by
DynamicTableSource. The new interface produces internal data structures. See FLIP-95 for more information. - InputFormatTableSource() - Constructor for class org.apache.flink.legacy.table.sources.InputFormatTableSource
 - 
Deprecated.
 - isAsyncEnabled() - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 - isBounded() - Method in class org.apache.flink.legacy.table.sources.InputFormatTableSource
 - 
Deprecated.Always returns true which indicates this is a bounded source.
 - isBounded() - Method in interface org.apache.flink.legacy.table.sources.StreamTableSource
 - 
Deprecated.Returns true if this is a bounded source, false if this is an unbounded source.
 - isBounded() - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 
K
- KIND - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 
L
- LENGTH - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - lineDelimiter(String) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.Sets the line delimiter, "\n" by default.
 
M
- map(Row) - Method in class org.apache.flink.table.sinks.CsvTableSink.CsvFormatter
 - 
Deprecated.
 - MAX - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - MAX_PAST - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - MIN - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 
N
- name - Variable in class org.apache.flink.connector.datagen.table.DataGenVisitorBase
 - next() - Method in class org.apache.flink.connector.datagen.table.types.DataGeneratorMapper
 - next() - Method in class org.apache.flink.connector.datagen.table.types.DecimalDataRandomGenerator
 - next() - Method in class org.apache.flink.connector.datagen.table.types.RowDataGenerator
 - nextRecord(OUT) - Method in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - nextTimestamp(long) - Method in class org.apache.flink.table.sources.wmstrategies.AscendingTimestamps
 - nextTimestamp(long) - Method in class org.apache.flink.table.sources.wmstrategies.BoundedOutOfOrderTimestamps
 - nextTimestamp(long) - Method in class org.apache.flink.table.sources.wmstrategies.PeriodicWatermarkAssigner
 - 
Updates the assigner with the next timestamp.
 - NULL_RATE - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - NUMBER_OF_ROWS - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 
O
- of(SinkFunction<RowData>) - Static method in interface org.apache.flink.table.connector.sink.legacy.SinkFunctionProvider
 - 
Deprecated.Helper method for creating a static provider.
 - of(SinkFunction<RowData>, Integer) - Static method in interface org.apache.flink.table.connector.sink.legacy.SinkFunctionProvider
 - 
Deprecated.Helper method for creating a SinkFunction provider with a provided sink parallelism.
 - of(DataGenerator, ConfigOption<?>...) - Static method in class org.apache.flink.connector.datagen.table.DataGeneratorContainer
 - of(SourceFunction<RowData>, boolean) - Static method in interface org.apache.flink.legacy.table.connector.source.SourceFunctionProvider
 - 
Deprecated.Helper method for creating a static provider.
 - of(SourceFunction<RowData>, boolean, Integer) - Static method in interface org.apache.flink.legacy.table.connector.source.SourceFunctionProvider
 - 
Deprecated.Helper method for creating a Source provider with a provided source parallelism.
 - OldCsvValidator - Class in org.apache.flink.table.descriptors
 - 
Deprecated.Use the RFC-compliant
Csvformat in the dedicated flink-formats/flink-csv module instead. - OldCsvValidator() - Constructor for class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - open(String, FunctionInitializationContext, RuntimeContext) - Method in class org.apache.flink.connector.datagen.table.types.DataGeneratorMapper
 - open(String, FunctionInitializationContext, RuntimeContext) - Method in class org.apache.flink.connector.datagen.table.types.DecimalDataRandomGenerator
 - open(String, FunctionInitializationContext, RuntimeContext) - Method in class org.apache.flink.connector.datagen.table.types.RowDataGenerator
 - open(FunctionContext) - Method in class org.apache.flink.table.sources.CsvTableSource.CsvLookupFunction
 - 
Deprecated.
 - optionalOptions() - Method in class org.apache.flink.connector.blackhole.table.BlackHoleTableSinkFactory
 - optionalOptions() - Method in class org.apache.flink.connector.datagen.table.DataGenTableSourceFactory
 - optionalOptions() - Method in class org.apache.flink.connector.print.table.PrintTableSinkFactory
 - org.apache.flink.connector.blackhole.table - package org.apache.flink.connector.blackhole.table
 - org.apache.flink.connector.datagen.table - package org.apache.flink.connector.datagen.table
 - org.apache.flink.connector.datagen.table.types - package org.apache.flink.connector.datagen.table.types
 - org.apache.flink.connector.print.table - package org.apache.flink.connector.print.table
 - org.apache.flink.legacy.table.connector.source - package org.apache.flink.legacy.table.connector.source
 - org.apache.flink.legacy.table.descriptors - package org.apache.flink.legacy.table.descriptors
 - org.apache.flink.legacy.table.factories - package org.apache.flink.legacy.table.factories
 - org.apache.flink.legacy.table.sinks - package org.apache.flink.legacy.table.sinks
 - org.apache.flink.legacy.table.sources - package org.apache.flink.legacy.table.sources
 - org.apache.flink.table.api.bridge.java - package org.apache.flink.table.api.bridge.java
 - org.apache.flink.table.api.bridge.java.internal - package org.apache.flink.table.api.bridge.java.internal
 - org.apache.flink.table.connector - package org.apache.flink.table.connector
 - org.apache.flink.table.connector.sink - package org.apache.flink.table.connector.sink
 - org.apache.flink.table.connector.sink.legacy - package org.apache.flink.table.connector.sink.legacy
 - org.apache.flink.table.connector.source - package org.apache.flink.table.connector.source
 - org.apache.flink.table.descriptors - package org.apache.flink.table.descriptors
 - org.apache.flink.table.procedure - package org.apache.flink.table.procedure
 - org.apache.flink.table.sinks - package org.apache.flink.table.sinks
 - org.apache.flink.table.sources - package org.apache.flink.table.sources
 - org.apache.flink.table.sources.format - package org.apache.flink.table.sources.format
 - org.apache.flink.table.sources.wmstrategies - package org.apache.flink.table.sources.wmstrategies
 - OutputFormatTableSink<T> - Class in org.apache.flink.legacy.table.sinks
 - 
Deprecated.This interface has been replaced by
DynamicTableSink. The new interface consumes internal data structures. See FLIP-95 for more information. - OutputFormatTableSink() - Constructor for class org.apache.flink.legacy.table.sinks.OutputFormatTableSink
 - 
Deprecated.
 
P
- parsedValues - Variable in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.table.sources.format.RowCsvInputFormat
 - 
Deprecated.
 - path(String) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.Sets the path to the CSV file.
 - PeriodicWatermarkAssigner - Class in org.apache.flink.table.sources.wmstrategies
 - 
A periodic watermark assigner.
 - PeriodicWatermarkAssigner() - Constructor for class org.apache.flink.table.sources.wmstrategies.PeriodicWatermarkAssigner
 - PRINT_IDENTIFIER - Static variable in class org.apache.flink.connector.print.table.PrintConnectorOptions
 - PrintConnectorOptions - Class in org.apache.flink.connector.print.table
 - 
Options for the Print sink connector.
 - printExplain(ExplainDetail...) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamStatementSetImpl
 - printExplain(ExplainDetail...) - Method in interface org.apache.flink.table.api.bridge.java.StreamStatementSet
 - PrintTableSinkFactory - Class in org.apache.flink.connector.print.table
 - 
Print table sink factory writing every row to the standard output or standard error stream.
 - PrintTableSinkFactory() - Constructor for class org.apache.flink.connector.print.table.PrintTableSinkFactory
 - ProcedureContext - Interface in org.apache.flink.table.procedure
 - 
A context to provide necessary context used by stored procedure.
 - produceDataStream(StreamExecutionEnvironment) - Method in interface org.apache.flink.table.connector.source.DataStreamScanProvider
 - 
Deprecated.
 - produceDataStream(ProviderContext, StreamExecutionEnvironment) - Method in interface org.apache.flink.table.connector.source.DataStreamScanProvider
 - 
Creates a scan Java
DataStreamfrom aStreamExecutionEnvironment. - projectFields(int[]) - Method in class org.apache.flink.table.sources.CsvTableSource
 - 
Deprecated.
 - ProviderContext - Interface in org.apache.flink.table.connector
 - 
Context provided by some
ScanTableSource.ScanRuntimeProviderandDynamicTableSink.SinkRuntimeProviderwith utilities for generating the runtime implementation. - PunctuatedWatermarkAssigner - Class in org.apache.flink.table.sources.wmstrategies
 - 
A punctuated watermark assigner.
 - PunctuatedWatermarkAssigner() - Constructor for class org.apache.flink.table.sources.wmstrategies.PunctuatedWatermarkAssigner
 
Q
- quoteCharacter(Character) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
 - 
Deprecated.Sets a quote character for String values, null by default.
 
R
- RANDOM - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - RANDOM_BYTES_LENGTH_DEFAULT - Static variable in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - RANDOM_STRING_LENGTH_DEFAULT - Static variable in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - RandomGeneratorVisitor - Class in org.apache.flink.connector.datagen.table
 - 
Creates a random
DataGeneratorContainerfor a particular logical type. - RandomGeneratorVisitor(String, ReadableConfig) - Constructor for class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - readRecord(OUT, byte[], int, int) - Method in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - registerDataStream(String, DataStream<T>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - registerDataStream(String, DataStream<T>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Deprecated.
 - registerFunction(String, AggregateFunction<T, ACC>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - registerFunction(String, AggregateFunction<T, ACC>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Deprecated.Use
TableEnvironment.createTemporarySystemFunction(String, UserDefinedFunction)instead. Please note that the new method also uses the new type system and reflective extraction logic. It might be necessary to update the function implementation as well. See the documentation ofAggregateFunctionfor more information on the new function design. - registerFunction(String, TableAggregateFunction<T, ACC>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - registerFunction(String, TableAggregateFunction<T, ACC>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Deprecated.Use
TableEnvironment.createTemporarySystemFunction(String, UserDefinedFunction)instead. Please note that the new method also uses the new type system and reflective extraction logic. It might be necessary to update the function implementation as well. See the documentation ofTableAggregateFunctionfor more information on the new function design. - registerFunction(String, TableFunction<T>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - registerFunction(String, TableFunction<T>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Deprecated.Use
TableEnvironment.createTemporarySystemFunction(String, UserDefinedFunction)instead. Please note that the new method also uses the new type system and reflective extraction logic. It might be necessary to update the function implementation as well. See the documentation ofTableFunctionfor more information on the new function design. - requiredContext() - Method in class org.apache.flink.table.sinks.CsvAppendTableSinkFactory
 - 
Deprecated.
 - requiredContext() - Method in class org.apache.flink.table.sinks.CsvTableSinkFactoryBase
 - 
Deprecated.
 - requiredContext() - Method in class org.apache.flink.table.sources.CsvAppendTableSourceFactory
 - 
Deprecated.
 - requiredContext() - Method in class org.apache.flink.table.sources.CsvTableSourceFactoryBase
 - 
Deprecated.
 - requiredOptions() - Method in class org.apache.flink.connector.blackhole.table.BlackHoleTableSinkFactory
 - requiredOptions() - Method in class org.apache.flink.connector.datagen.table.DataGenTableSourceFactory
 - requiredOptions() - Method in class org.apache.flink.connector.print.table.PrintTableSinkFactory
 - RetractStreamTableSink<T> - Interface in org.apache.flink.legacy.table.sinks
 - 
Deprecated.This interface has been replaced by
DynamicTableSink. The new interface consumes internal data structures. See FLIP-95 for more information. - RowCsvInputFormat - Class in org.apache.flink.table.sources.format
 - 
Deprecated.All Flink DataSet APIs are deprecated since Flink 1.18 and will be removed in a future Flink major version. You can still build your application in DataSet, but you should move to either the DataStream and/or Table API.
 - RowCsvInputFormat(Path, TypeInformation[]) - Constructor for class org.apache.flink.table.sources.format.RowCsvInputFormat
 - 
Deprecated.
 - RowCsvInputFormat(Path, TypeInformation[], boolean) - Constructor for class org.apache.flink.table.sources.format.RowCsvInputFormat
 - 
Deprecated.
 - RowCsvInputFormat(Path, TypeInformation[], int[]) - Constructor for class org.apache.flink.table.sources.format.RowCsvInputFormat
 - 
Deprecated.
 - RowCsvInputFormat(Path, TypeInformation[], String, String) - Constructor for class org.apache.flink.table.sources.format.RowCsvInputFormat
 - 
Deprecated.
 - RowCsvInputFormat(Path, TypeInformation[], String, String, int[]) - Constructor for class org.apache.flink.table.sources.format.RowCsvInputFormat
 - 
Deprecated.
 - RowCsvInputFormat(Path, TypeInformation[], String, String, int[], boolean) - Constructor for class org.apache.flink.table.sources.format.RowCsvInputFormat
 - 
Deprecated.
 - RowDataGenerator - Class in org.apache.flink.connector.datagen.table.types
 - 
Data generator for Flink's internal
RowDatatype. - RowDataGenerator(DataGenerator<?>[], List<String>, float) - Constructor for class org.apache.flink.connector.datagen.table.types.RowDataGenerator
 - ROWS_PER_SECOND - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - ROWS_PER_SECOND_DEFAULT_VALUE - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - RowtimeValidator - Class in org.apache.flink.legacy.table.descriptors
 - 
Deprecated.See
Rowtimefor details. - RowtimeValidator(boolean, boolean) - Constructor for class org.apache.flink.legacy.table.descriptors.RowtimeValidator
 - 
Deprecated.
 - RowtimeValidator(boolean, boolean, String) - Constructor for class org.apache.flink.legacy.table.descriptors.RowtimeValidator
 - 
Deprecated.
 
S
- SchemaValidator - Class in org.apache.flink.legacy.table.descriptors
 - 
Deprecated.See
Schemafor details. - SchemaValidator(boolean, boolean, boolean) - Constructor for class org.apache.flink.legacy.table.descriptors.SchemaValidator
 - 
Deprecated.
 - SEQUENCE - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - SequenceGeneratorVisitor - Class in org.apache.flink.connector.datagen.table
 - 
Creates a sequential
DataGeneratorContainerfor a particular logical type. - SequenceGeneratorVisitor(String, ReadableConfig) - Constructor for class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - setIsAppendOnly(Boolean) - Method in interface org.apache.flink.legacy.table.sinks.UpsertStreamTableSink
 - 
Deprecated.Specifies whether the
Tableto write is append-only or not. - setKeyFields(String[]) - Method in interface org.apache.flink.legacy.table.sinks.UpsertStreamTableSink
 - 
Deprecated.Configures the unique key fields of the
Tableto write. - SinkFunctionProvider - Interface in org.apache.flink.table.connector.sink.legacy
 - 
Deprecated.This interface is based on the
SinkFunctionAPI, which is due to be removed. UseSinkV2Providerinstead. - snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.connector.datagen.table.types.RowDataGenerator
 - SOURCE_PARALLELISM - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptions
 - SourceFunctionProvider - Interface in org.apache.flink.legacy.table.connector.source
 - 
Deprecated.This interface is based on the
SourceFunctionAPI, which is due to be removed. UseSourceProviderinstead. - STANDARD_ERROR - Static variable in class org.apache.flink.connector.print.table.PrintConnectorOptions
 - START - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - StreamStatementSet - Interface in org.apache.flink.table.api.bridge.java
 - 
A
StatementSetthat integrates with the Java-specificDataStreamAPI. - StreamStatementSetImpl - Class in org.apache.flink.table.api.bridge.java.internal
 - 
Implementation for
StreamStatementSet. - StreamStatementSetImpl(StreamTableEnvironmentImpl) - Constructor for class org.apache.flink.table.api.bridge.java.internal.StreamStatementSetImpl
 - StreamTableEnvironment - Interface in org.apache.flink.table.api.bridge.java
 - 
This table environment is the entry point and central context for creating Table and SQL API programs that integrate with the Java-specific
DataStreamAPI. - StreamTableEnvironmentImpl - Class in org.apache.flink.table.api.bridge.java.internal
 - 
The implementation for a Java
StreamTableEnvironment. - StreamTableEnvironmentImpl(CatalogManager, ModuleManager, ResourceManager, FunctionCatalog, TableConfig, StreamExecutionEnvironment, Planner, Executor, boolean) - Constructor for class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - StreamTableSink<T> - Interface in org.apache.flink.legacy.table.sinks
 - 
Deprecated.This interface has been replaced by
DynamicTableSink. The new interface consumes internal data structures. See FLIP-95 for more information. - StreamTableSinkFactory<T> - Interface in org.apache.flink.legacy.table.factories
 - 
Deprecated.This interface has been replaced by
DynamicTableSinkFactory. The new interface creates instances ofDynamicTableSink. See FLIP-95 for more information. - StreamTableSource<T> - Interface in org.apache.flink.legacy.table.sources
 - 
Deprecated.This interface has been replaced by
DynamicTableSource. The new interface produces internal data structures. See FLIP-95 for more information. - StreamTableSourceFactory<T> - Interface in org.apache.flink.legacy.table.factories
 - 
Deprecated.This interface has been replaced by
DynamicTableSourceFactory. The new interface creates instances ofDynamicTableSource. See FLIP-95 for more information. - supportedProperties() - Method in class org.apache.flink.table.sinks.CsvTableSinkFactoryBase
 - 
Deprecated.
 - supportedProperties() - Method in class org.apache.flink.table.sources.CsvTableSourceFactoryBase
 - 
Deprecated.
 
T
- toAppendStream(Table, Class<T>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - toAppendStream(Table, Class<T>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Deprecated.Use
StreamTableEnvironment.toDataStream(Table, Class)instead. It integrates with the new type system and supports all kinds ofDataTypesthat the table runtime can produce. The semantics might be slightly different for raw and structured types. UsetoDataStream(DataTypes.of(TypeInformation.of(Class)))ifTypeInformationshould be used as source of truth. - toAppendStream(Table, TypeInformation<T>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - toAppendStream(Table, TypeInformation<T>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Deprecated.Use
StreamTableEnvironment.toDataStream(Table, Class)instead. It integrates with the new type system and supports all kinds ofDataTypesthat the table runtime can produce. The semantics might be slightly different for raw and structured types. UsetoDataStream(DataTypes.of(TypeInformation.of(Class)))ifTypeInformationshould be used as source of truth. - toBooleanMask(int[]) - Static method in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 - toChangelogStream(Table) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - toChangelogStream(Table) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Converts the given
Tableinto aDataStreamof changelog entries. - toChangelogStream(Table, Schema) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - toChangelogStream(Table, Schema) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Converts the given
Tableinto aDataStreamof changelog entries. - toChangelogStream(Table, Schema, ChangelogMode) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - toChangelogStream(Table, Schema, ChangelogMode) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Converts the given
Tableinto aDataStreamof changelog entries. - toDataStream(Table) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - toDataStream(Table) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Converts the given
Tableinto aDataStream. - toDataStream(Table, Class<T>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - toDataStream(Table, Class<T>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - toDataStream(Table, AbstractDataType<?>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - toDataStream(Table, AbstractDataType<?>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Converts the given
Tableinto aDataStreamof the givenDataType. - toProperties() - Method in class org.apache.flink.table.sources.wmstrategies.AscendingTimestamps
 - toProperties() - Method in class org.apache.flink.table.sources.wmstrategies.BoundedOutOfOrderTimestamps
 - toRetractStream(Table, Class<T>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - toRetractStream(Table, Class<T>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Deprecated.Use
StreamTableEnvironment.toChangelogStream(Table, Schema)instead. It integrates with the new type system and supports all kinds ofDataTypesand everyChangelogModethat the table runtime can produce. - toRetractStream(Table, TypeInformation<T>) - Method in class org.apache.flink.table.api.bridge.java.internal.StreamTableEnvironmentImpl
 - toRetractStream(Table, TypeInformation<T>) - Method in interface org.apache.flink.table.api.bridge.java.StreamTableEnvironment
 - 
Deprecated.Use
StreamTableEnvironment.toChangelogStream(Table, Schema)instead. It integrates with the new type system and supports all kinds ofDataTypesand everyChangelogModethat the table runtime can produce. - toString() - Method in class org.apache.flink.table.sources.format.CsvInputFormat
 - 
Deprecated.
 
U
- UpsertStreamTableSink<T> - Interface in org.apache.flink.legacy.table.sinks
 - 
Deprecated.This interface has been replaced by
DynamicTableSink. The new interface consumes internal data structures. See FLIP-95 for more information. 
V
- validate(DescriptorProperties) - Method in class org.apache.flink.legacy.table.descriptors.RowtimeValidator
 - 
Deprecated.
 - validate(DescriptorProperties) - Method in class org.apache.flink.legacy.table.descriptors.SchemaValidator
 - 
Deprecated.
 - validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.OldCsvValidator
 - 
Deprecated.
 - VAR_LEN - Static variable in class org.apache.flink.connector.datagen.table.DataGenConnectorOptionsUtil
 - visit(ArrayType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(BigIntType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(BigIntType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(BinaryType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(BinaryType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(BooleanType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(BooleanType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(CharType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(CharType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(DateType) - Method in class org.apache.flink.connector.datagen.table.DataGenVisitorBase
 - visit(DayTimeIntervalType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(DecimalType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(DecimalType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(DoubleType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(DoubleType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(FloatType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(FloatType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(IntType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(IntType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(LocalZonedTimestampType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(MapType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(MultisetType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(RowType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(SmallIntType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(SmallIntType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(TimestampType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(TimeType) - Method in class org.apache.flink.connector.datagen.table.DataGenVisitorBase
 - visit(TinyIntType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(TinyIntType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(VarBinaryType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(VarBinaryType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(VarCharType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(VarCharType) - Method in class org.apache.flink.connector.datagen.table.SequenceGeneratorVisitor
 - visit(YearMonthIntervalType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 - visit(ZonedTimestampType) - Method in class org.apache.flink.connector.datagen.table.RandomGeneratorVisitor
 
All Classes All Packages