Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W Y Z 

A

ABS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
AbstractCatalog - Class in org.apache.flink.table.catalog
Abstract class for catalogs.
AbstractCatalog(String, String) - Constructor for class org.apache.flink.table.catalog.AbstractCatalog
 
AbstractDataType<T extends AbstractDataType<T>> - Interface in org.apache.flink.table.types
Highest abstraction that describes the data type of a value in the table ecosystem.
accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.AggregateExpression
 
accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.CallExpression
 
accept(ExpressionVisitor<R>) - Method in interface org.apache.flink.table.expressions.Expression
 
accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.SqlCallExpression
 
accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
 
accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
accept(DataTypeVisitor<R>) - Method in class org.apache.flink.table.types.AtomicDataType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.flink.table.types.CollectionDataType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.flink.table.types.DataType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.flink.table.types.FieldsDataType
 
accept(DataTypeVisitor<R>) - Method in class org.apache.flink.table.types.KeyValueDataType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.ArrayType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.BigIntType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.BinaryType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.BooleanType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.CharType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DateType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DecimalType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DistinctType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DoubleType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.FloatType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.IntType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.LogicalType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.MapType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.MultisetType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.NullType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.RawType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.RowType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.SmallIntType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.StructuredType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.SymbolType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TimestampType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TimeType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TinyIntType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.VarCharType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
accumulate(Object, Object...) - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
accumulate(Object, Object...) - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
accumulatorTypeStrategy(TypeStrategy) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
Sets the strategy for inferring the intermediate accumulator data type of a function call.
ACOS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
adaptArguments(TypeInference, CallContext, DataType) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
Adapts the call's argument if necessary.
AdaptedCallContext - Class in org.apache.flink.table.types.inference.utils
Helper context that deals with adapted arguments.
AdaptedCallContext(CallContext, DataType) - Constructor for class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
add(T) - Method in class org.apache.flink.table.api.dataview.ListView
Adds the given value to the list.
add(TableColumn) - Method in class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
Adds a TableColumn to this builder.
addAll(List<T>) - Method in class org.apache.flink.table.api.dataview.ListView
Adds all of the elements of the specified list to this list view.
addContainedKind(RowKind) - Method in class org.apache.flink.table.connector.ChangelogMode.Builder
 
additionalProperties() - Method in class org.apache.flink.table.descriptors.TableDescriptor
Enables adding more specific properties to TableDescriptor.toProperties().
addPropertiesWithPrefix(String, DescriptorProperties) - Method in class org.apache.flink.table.descriptors.ClassInstance
Internal method for properties conversion.
addPropertiesWithPrefix(String, DescriptorProperties) - Method in class org.apache.flink.table.descriptors.HierarchyDescriptor
Internal method for properties conversion.
addPropertiesWithPrefix(String, DescriptorProperties) - Method in class org.apache.flink.table.descriptors.LiteralValue
 
aggArg0(Function<LogicalType, LogicalType>, boolean) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy specific for aggregations that partially produce different nullability depending whether the result is grouped or not.
AGGREGATE_ACCUMULATE - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
AGGREGATE_MERGE - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
AGGREGATE_RETRACT - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
AggregateExpression - Class in org.apache.flink.table.expressions
Resolved and validated expression for calling an aggregate function.
AggregateExpression(FunctionDefinition, List<FieldReferenceExpression>, CallExpression, DataType, boolean, boolean, boolean) - Constructor for class org.apache.flink.table.expressions.AggregateExpression
 
AggregateFunction<T,ACC> - Class in org.apache.flink.table.functions
Base class for a user-defined aggregate function.
AggregateFunction() - Constructor for class org.apache.flink.table.functions.AggregateFunction
 
AggregateFunctionDefinition - Class in org.apache.flink.table.functions
A "marker" function definition of an user-defined aggregate function that uses the old type system stack.
AggregateFunctionDefinition(String, AggregateFunction<?, ?>, TypeInformation<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.functions.AggregateFunctionDefinition
 
all() - Static method in class org.apache.flink.table.connector.ChangelogMode
Shortcut for a changelog that can contain all RowKinds.
allocateReuseBytes(int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Allocate bytes that is only for temporary usage, it should not be stored in somewhere else.
allocateReuseChars(int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
 
alterDatabase(String, CatalogDatabase, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Modify an existing database.
alterFunction(ObjectPath, CatalogFunction, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Modify an existing function.
alterPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Alter a partition.
alterPartitionColumnStatistics(ObjectPath, CatalogPartitionSpec, CatalogColumnStatistics, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Update the column statistics of a table partition.
alterPartitionStatistics(ObjectPath, CatalogPartitionSpec, CatalogTableStatistics, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Update the statistics of a table partition.
alterTable(ObjectPath, CatalogBaseTable, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Modifies an existing table or view.
alterTableColumnStatistics(ObjectPath, CatalogColumnStatistics, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Update the column statistics of a table.
alterTableStatistics(ObjectPath, CatalogTableStatistics, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Update the statistics of a table.
AmbiguousTableFactoryException - Exception in org.apache.flink.table.api
Exception for finding more than one TableFactory for the given properties.
AmbiguousTableFactoryException(List<? extends TableFactory>, Class<? extends TableFactory>, List<TableFactory>, Map<String, String>, Throwable) - Constructor for exception org.apache.flink.table.api.AmbiguousTableFactoryException
 
AmbiguousTableFactoryException(List<? extends TableFactory>, Class<? extends TableFactory>, List<TableFactory>, Map<String, String>) - Constructor for exception org.apache.flink.table.api.AmbiguousTableFactoryException
 
AND - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
and(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a conjunction of multiple ArgumentTypeStrategys into one like f(NUMERIC && LITERAL).
AndArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for inferring and validating an argument using a conjunction of multiple ArgumentTypeStrategys into one like f(NUMERIC && LITERAL)
AndArgumentTypeStrategy(List<? extends ArgumentTypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
 
any() - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
 
ANY - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that can be of any type.
AnyArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for an argument that can be of any type.
AnyArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
 
anyNull() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
anyNull() - Method in class org.apache.flink.table.data.binary.BinaryRowData
The bit is 1 when the field is null.
anyNull(int[]) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
anyNull() - Method in interface org.apache.flink.table.data.binary.NullAwareGetters
If no field is null, return false.
anyNull(int[]) - Method in interface org.apache.flink.table.data.binary.NullAwareGetters
For the input fields, if no field is null, return false.
appendRowFields(DataType, List<DataTypes.Field>) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Appends the given list of fields to an existing row data type.
applyAggregates(List<int[]>, List<AggregateExpression>, DataType) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsAggregatePushDown
Provides a list of aggregate expressions and the grouping keys.
applyFilters(List<ResolvedExpression>) - Method in interface org.apache.flink.table.connector.format.BulkDecodingFormat
Provides a list of filters in conjunctive form for filtering on a best-effort basis.
applyFilters(List<ResolvedExpression>) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown
Provides a list of filters in conjunctive form.
applyLimit(long) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsLimitPushDown
Provides the expected maximum number of produced records for limiting on a best-effort basis.
applyLimit(long) - Method in interface org.apache.flink.table.sources.LimitableTableSource
Deprecated.
Check and push down the limit to the table source.
applyOverwrite(boolean) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsOverwrite
Provides whether existing data should be overwritten or not.
applyPartitionPruning(List<Map<String, String>>) - Method in interface org.apache.flink.table.sources.PartitionableTableSource
Deprecated.
Applies the remaining partitions to the table source.
applyPartitions(List<Map<String, String>>) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsPartitionPushDown
Provides a list of remaining partitions.
applyPredicate(List<Expression>) - Method in interface org.apache.flink.table.sources.FilterableTableSource
Deprecated.
Check and pick all predicates this table source can support.
applyProjection(int[][]) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsProjectionPushDown
Provides the field index paths that should be used for a projection.
applyReadableMetadata(List<String>) - Method in interface org.apache.flink.table.connector.format.DecodingFormat
Provides a list of metadata keys that the produced row must contain as appended metadata columns.
applyReadableMetadata(List<String>, DataType) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsReadingMetadata
Provides a list of metadata keys that the produced RowData must contain as appended metadata columns.
applySourceWatermark() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsSourceWatermark
Instructs the source to emit source-specific watermarks during runtime.
applyStaticPartition(Map<String, String>) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsPartitioning
Provides the static part of a partition.
applyWatermark(WatermarkStrategy<RowData>) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsWatermarkPushDown
Provides a WatermarkStrategy which defines how to generate Watermarks in the stream source.
applyWritableMetadata(List<String>) - Method in interface org.apache.flink.table.connector.format.EncodingFormat
Provides a list of metadata keys that the consumed row will contain as appended metadata columns.
applyWritableMetadata(List<String>, DataType) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsWritingMetadata
Provides a list of metadata keys that the consumed RowData will contain as appended metadata columns which must be persisted.
argument(ArgumentTypeStrategy) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
Defines that we expect a single argument at the next position.
argument(int) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the n-th input argument.
ArgumentCount - Interface in org.apache.flink.table.types.inference
Defines the count of accepted arguments (including open intervals) that a function can take.
ArgumentTypeStrategy - Interface in org.apache.flink.table.types.inference
Strategy for inferring and validating a single input argument type of a function call.
ARRAY(DataType) - Static method in class org.apache.flink.table.api.DataTypes
Data type of an array of elements with same subtype.
ARRAY(AbstractDataType<?>) - Static method in class org.apache.flink.table.api.DataTypes
Unresolved data type of an array of elements with same subtype.
ARRAY - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ARRAY - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns a DataTypes.ARRAY(DataType) with element type equal to the type of the first argument.
ARRAY_ELEMENT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ArrayData - Interface in org.apache.flink.table.data
Base interface of an internal data structure representing data of ArrayType.
ArrayData.ElementGetter - Interface in org.apache.flink.table.data
Accessor for getting the elements of an array during runtime.
ArrayType - Class in org.apache.flink.table.types.logical
Logical type of an array of elements with same subtype.
ArrayType(boolean, LogicalType) - Constructor for class org.apache.flink.table.types.logical.ArrayType
 
ArrayType(LogicalType) - Constructor for class org.apache.flink.table.types.logical.ArrayType
 
AS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ASIN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
asMap() - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns the properties as a map copy.
asPrefixedMap(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns the properties as a map copy with a prefix key.
asSerializableString() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
Returns a string that fully serializes this instance.
asSerializableString() - Method in interface org.apache.flink.table.expressions.ResolvedExpression
Returns a string that fully serializes this instance.
asSerializableString() - Method in class org.apache.flink.table.types.logical.ArrayType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.BigIntType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.BinaryType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.BooleanType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.CharType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.DateType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.DecimalType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.DoubleType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.FloatType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.IntType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.LogicalType
Returns a string that fully serializes this instance.
asSerializableString() - Method in class org.apache.flink.table.types.logical.MapType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.MultisetType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.NullType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.RawType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.RowType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.RowType.RowField
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.SmallIntType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.SymbolType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.TimestampType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.TimeType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.TinyIntType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.UserDefinedType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.VarCharType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
asSerializableString() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
asSummaryString() - Method in interface org.apache.flink.table.api.constraints.Constraint
Deprecated.
Prints the constraint in a readable way.
asSummaryString() - Method in class org.apache.flink.table.api.constraints.UniqueConstraint
Deprecated.
Returns constraint's summary.
asSummaryString() - Method in class org.apache.flink.table.api.TableColumn
Deprecated.
Returns a string that summarizes this column for printing to a console.
asSummaryString() - Method in class org.apache.flink.table.api.WatermarkSpec
Deprecated.
 
asSummaryString() - Method in class org.apache.flink.table.catalog.Column
Returns a string that summarizes this column for printing to a console.
asSummaryString() - Method in interface org.apache.flink.table.catalog.Constraint
Prints the constraint in a readable way.
asSummaryString() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
Returns a string that summarizes this instance for printing to a console or log.
asSummaryString() - Method in class org.apache.flink.table.catalog.UniqueConstraint
Returns constraint's summary.
asSummaryString() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
Returns a string that summarizes this instance for printing to a console or log.
asSummaryString() - Method in class org.apache.flink.table.catalog.WatermarkSpec
 
asSummaryString() - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
Returns a string that summarizes this sink for printing to a console or log.
asSummaryString() - Method in interface org.apache.flink.table.connector.source.DynamicTableSource
Returns a string that summarizes this source for printing to a console or log.
asSummaryString() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
asSummaryString() - Method in class org.apache.flink.table.expressions.CallExpression
 
asSummaryString() - Method in interface org.apache.flink.table.expressions.Expression
Returns a string that summarizes this expression for printing to a console.
asSummaryString() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
asSummaryString() - Method in class org.apache.flink.table.expressions.SqlCallExpression
 
asSummaryString() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
 
asSummaryString() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
asSummaryString() - Method in class org.apache.flink.table.functions.FunctionIdentifier
Returns a string that summarizes this instance for printing to a console or log.
asSummaryString() - Method in class org.apache.flink.table.types.logical.ArrayType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.BinaryType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.CharType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.LogicalType
Returns a string that summarizes this type for printing to a console.
asSummaryString() - Method in class org.apache.flink.table.types.logical.MapType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.MultisetType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.RawType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.RowType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.RowType.RowField
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.StructuredType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.SymbolType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.TimestampType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.VarCharType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
ASYNC_TABLE_EVAL - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
AsyncTableFunction<T> - Class in org.apache.flink.table.functions
Base class for a user-defined asynchronous table function.
AsyncTableFunction() - Constructor for class org.apache.flink.table.functions.AsyncTableFunction
 
AsyncTableFunctionProvider<T> - Interface in org.apache.flink.table.connector.source
Provider of an AsyncTableFunction instance as a runtime implementation for LookupTableSource.
AT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ATAN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ATAN2 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
AtomicDataType - Class in org.apache.flink.table.types
A data type that does not contain further data types (e.g.
AtomicDataType(LogicalType, Class<?>) - Constructor for class org.apache.flink.table.types.AtomicDataType
 
AtomicDataType(LogicalType) - Constructor for class org.apache.flink.table.types.AtomicDataType
 
attributes(List<StructuredType.StructuredAttribute>) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
AVG - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 

B

BETWEEN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
between(int, int) - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
 
BIGINT() - Static method in class org.apache.flink.table.api.DataTypes
Data type of an 8-byte signed integer with values from -9,223,372,036,854,775,808 to 9,223,372,036,854,775,807.
BigIntType - Class in org.apache.flink.table.types.logical
Logical type of an 8-byte signed integer with values from -9,223,372,036,854,775,808 to 9,223,372,036,854,775,807.
BigIntType(boolean) - Constructor for class org.apache.flink.table.types.logical.BigIntType
 
BigIntType() - Constructor for class org.apache.flink.table.types.logical.BigIntType
 
BIN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
BINARY(int) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a fixed-length binary string (=a sequence of bytes) BINARY(n) where n is the number of bytes.
BinaryArrayData - Class in org.apache.flink.table.data.binary
A binary implementation of ArrayData which is backed by MemorySegments.
BinaryArrayData() - Constructor for class org.apache.flink.table.data.binary.BinaryArrayData
 
BinaryFormat - Interface in org.apache.flink.table.data.binary
Binary format spanning MemorySegments.
BinaryMapData - Class in org.apache.flink.table.data.binary
[4 byte(keyArray size in bytes)] + [Key BinaryArray] + [Value BinaryArray].
BinaryMapData() - Constructor for class org.apache.flink.table.data.binary.BinaryMapData
 
BinaryRawValueData<T> - Class in org.apache.flink.table.data.binary
A lazily binary implementation of RawValueData which is backed by MemorySegments and generic Object.
BinaryRawValueData(T) - Constructor for class org.apache.flink.table.data.binary.BinaryRawValueData
 
BinaryRawValueData(MemorySegment[], int, int) - Constructor for class org.apache.flink.table.data.binary.BinaryRawValueData
 
BinaryRawValueData(MemorySegment[], int, int, T) - Constructor for class org.apache.flink.table.data.binary.BinaryRawValueData
 
BinaryRowData - Class in org.apache.flink.table.data.binary
An implementation of RowData which is backed by MemorySegment instead of Object.
BinaryRowData(int) - Constructor for class org.apache.flink.table.data.binary.BinaryRowData
 
BinarySection - Class in org.apache.flink.table.data.binary
A basic implementation of BinaryFormat which describe a section of memory.
BinarySection() - Constructor for class org.apache.flink.table.data.binary.BinarySection
 
BinarySection(MemorySegment[], int, int) - Constructor for class org.apache.flink.table.data.binary.BinarySection
 
BinarySegmentUtils - Class in org.apache.flink.table.data.binary
Utilities for binary data segments which heavily uses MemorySegment.
BinaryStringData - Class in org.apache.flink.table.data.binary
A lazily binary implementation of StringData which is backed by MemorySegments and String.
BinaryStringData() - Constructor for class org.apache.flink.table.data.binary.BinaryStringData
 
BinaryStringData(String) - Constructor for class org.apache.flink.table.data.binary.BinaryStringData
 
BinaryStringData(MemorySegment[], int, int) - Constructor for class org.apache.flink.table.data.binary.BinaryStringData
 
BinaryStringData(MemorySegment[], int, int, String) - Constructor for class org.apache.flink.table.data.binary.BinaryStringData
 
BinaryType - Class in org.apache.flink.table.types.logical
Logical type of a fixed-length binary string (=a sequence of bytes).
BinaryType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.BinaryType
 
BinaryType(int) - Constructor for class org.apache.flink.table.types.logical.BinaryType
 
BinaryType() - Constructor for class org.apache.flink.table.types.logical.BinaryType
 
bitGet(MemorySegment, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
read bit.
bitGet(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
read bit from segments.
bitSet(MemorySegment, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
set bit.
bitSet(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
set bit from segments.
bitUnSet(MemorySegment, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
unset bit.
bitUnSet(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
unset bit from segments.
blankString(int) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
Creates a BinaryStringData instance that contains `length` spaces.
BOOLEAN() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a boolean with a (possibly) three-valued logic of TRUE, FALSE, UNKNOWN.
BOOLEAN() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API boolean or SQL BOOLEAN type.
BooleanType - Class in org.apache.flink.table.types.logical
Logical type of a boolean with a (possibly) three-valued logic of TRUE, FALSE, UNKNOWN.
BooleanType(boolean) - Constructor for class org.apache.flink.table.types.logical.BooleanType
 
BooleanType() - Constructor for class org.apache.flink.table.types.logical.BooleanType
 
bridgedTo(Class<?>) - Method in interface org.apache.flink.table.types.AbstractDataType
Adds a hint that data should be represented using the given class when entering or leaving the table ecosystem.
bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.AtomicDataType
 
bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.CollectionDataType
 
bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.FieldsDataType
 
bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.KeyValueDataType
 
bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.UnresolvedDataType
 
build() - Method in class org.apache.flink.table.api.Schema.Builder
Returns an instance of an unresolved Schema.
build() - Method in class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
Returns a TableSchema instance.
build() - Method in class org.apache.flink.table.connector.ChangelogMode.Builder
 
build() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
build() - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
 
build() - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
 
build() - Method in class org.apache.flink.table.types.logical.DistinctType.Builder
 
build() - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
builder() - Static method in class org.apache.flink.table.api.TableSchema
Deprecated.
 
Builder() - Constructor for class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
 
Builder() - Constructor for class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
Builder() - Constructor for class org.apache.flink.table.plan.stats.ColumnStats.Builder
 
builder() - Static method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
 
Builder() - Constructor for class org.apache.flink.table.types.inference.TypeInference.Builder
 
Builder(ObjectIdentifier, LogicalType) - Constructor for class org.apache.flink.table.types.logical.DistinctType.Builder
 
Builder(Class<?>) - Constructor for class org.apache.flink.table.types.logical.StructuredType.Builder
 
Builder(ObjectIdentifier) - Constructor for class org.apache.flink.table.types.logical.StructuredType.Builder
 
Builder(ObjectIdentifier, Class<?>) - Constructor for class org.apache.flink.table.types.logical.StructuredType.Builder
 
builderWithGivenSchema(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
Creates a builder with given table schema.
BuiltInFunctionDefinition - Class in org.apache.flink.table.functions
Definition of a built-in function.
BuiltInFunctionDefinition.Builder - Class in org.apache.flink.table.functions
Builder for fluent definition of built-in functions.
BuiltInFunctionDefinitions - Class in org.apache.flink.table.functions
Dictionary of function definitions for all built-in functions.
BuiltInFunctionDefinitions() - Constructor for class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
BuiltInPythonAggregateFunction - Enum in org.apache.flink.table.functions.python
The list of the built-in aggregate functions which can be mixed with the Python UDAF.
BulkDecodingFormat<T> - Interface in org.apache.flink.table.connector.format
A Format for a DynamicTableSource for reading rows by BulkFormat.
BulkReaderFormatFactory - Interface in org.apache.flink.table.factories
Base interface for configuring a BulkFormat for file system connector.
BulkWriterFormatFactory - Interface in org.apache.flink.table.factories
Base interface for configuring a BulkWriter.Factory for file system connector.
BYTE() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API byte or SQL TINYINT type.
byteAt(int) - Method in class org.apache.flink.table.data.binary.BinaryStringData
Returns the byte value at the specified index.
BYTES() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a variable-length binary string (=a sequence of bytes) with defined maximum length.

C

calculateBitSetWidthInBytes(int) - Static method in class org.apache.flink.table.data.binary.BinaryRowData
 
calculateFixLengthPartSize(LogicalType) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
It store real value when type is primitive.
calculateFixPartSizeInBytes(int) - Static method in class org.apache.flink.table.data.binary.BinaryRowData
 
calculateHeaderInBytes(int) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
 
CallContext - Interface in org.apache.flink.table.types.inference
Provides details about a function call during TypeInference.
CallExpression - Class in org.apache.flink.table.expressions
Resolved and validated call expression for calling a function.
CallExpression(FunctionIdentifier, FunctionDefinition, List<ResolvedExpression>, DataType) - Constructor for class org.apache.flink.table.expressions.CallExpression
 
CallExpression(FunctionDefinition, List<ResolvedExpression>, DataType) - Constructor for class org.apache.flink.table.expressions.CallExpression
 
canBeTimeAttributeType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
canEqual(Object) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
canEqual(Object) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
canEqual(Object) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
CARDINALITY - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CAST - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CastInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
CastInputTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.CastInputTypeStrategy
 
Catalog - Interface in org.apache.flink.table.catalog
This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.
CATALOG_TYPE - Static variable in class org.apache.flink.table.catalog.CommonCatalogOptions
ConfigOption which is used during catalog discovery to match it against Factory.factoryIdentifier().
CatalogBaseTable - Interface in org.apache.flink.table.catalog
A common parent that describes the unresolved metadata of a table or view in a catalog.
CatalogBaseTable.TableKind - Enum in org.apache.flink.table.catalog
The kind of CatalogBaseTable.
CatalogColumnStatistics - Class in org.apache.flink.table.catalog.stats
Column statistics of a table or partition.
CatalogColumnStatistics(Map<String, CatalogColumnStatisticsDataBase>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
 
CatalogColumnStatistics(Map<String, CatalogColumnStatisticsDataBase>, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
 
CatalogColumnStatisticsDataBase - Class in org.apache.flink.table.catalog.stats
Column statistics value base class.
CatalogColumnStatisticsDataBase(Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
 
CatalogColumnStatisticsDataBase(Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
 
CatalogColumnStatisticsDataBinary - Class in org.apache.flink.table.catalog.stats
Column statistics value of binary type.
CatalogColumnStatisticsDataBinary(Long, Double, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
 
CatalogColumnStatisticsDataBinary(Long, Double, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
 
CatalogColumnStatisticsDataBoolean - Class in org.apache.flink.table.catalog.stats
Column statistics value of boolean type.
CatalogColumnStatisticsDataBoolean(Long, Long, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
 
CatalogColumnStatisticsDataBoolean(Long, Long, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
 
CatalogColumnStatisticsDataDate - Class in org.apache.flink.table.catalog.stats
Column statistics value of date type.
CatalogColumnStatisticsDataDate(Date, Date, Long, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
 
CatalogColumnStatisticsDataDate(Date, Date, Long, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
 
CatalogColumnStatisticsDataDouble - Class in org.apache.flink.table.catalog.stats
Column statistics value of double type.
CatalogColumnStatisticsDataDouble(Double, Double, Long, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
 
CatalogColumnStatisticsDataDouble(Double, Double, Long, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
 
CatalogColumnStatisticsDataLong - Class in org.apache.flink.table.catalog.stats
Column statistics value of long type.
CatalogColumnStatisticsDataLong(Long, Long, Long, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
 
CatalogColumnStatisticsDataLong(Long, Long, Long, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
 
CatalogColumnStatisticsDataString - Class in org.apache.flink.table.catalog.stats
Column statistics value of string type.
CatalogColumnStatisticsDataString(Long, Double, Long, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
 
CatalogColumnStatisticsDataString(Long, Double, Long, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
 
CatalogDatabase - Interface in org.apache.flink.table.catalog
Interface of a database in a catalog.
CatalogException - Exception in org.apache.flink.table.catalog.exceptions
A catalog-related, runtime exception.
CatalogException(String) - Constructor for exception org.apache.flink.table.catalog.exceptions.CatalogException
 
CatalogException(Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.CatalogException
 
CatalogException(String, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.CatalogException
 
CatalogFactory - Interface in org.apache.flink.table.factories
A factory to create configured catalog instances based on string-based properties.
CatalogFactory.Context - Interface in org.apache.flink.table.factories
Context provided when a catalog is created.
CatalogFactoryHelper(CatalogFactory, CatalogFactory.Context) - Constructor for class org.apache.flink.table.factories.FactoryUtil.CatalogFactoryHelper
 
CatalogFunction - Interface in org.apache.flink.table.catalog
Interface for a function in a catalog.
CatalogNotExistException - Exception in org.apache.flink.table.api
Exception for an operation on a nonexistent catalog.
CatalogNotExistException(String) - Constructor for exception org.apache.flink.table.api.CatalogNotExistException
 
CatalogNotExistException(String, Throwable) - Constructor for exception org.apache.flink.table.api.CatalogNotExistException
 
CatalogPartition - Interface in org.apache.flink.table.catalog
Represents a partition object in catalog.
CatalogPartitionSpec - Class in org.apache.flink.table.catalog
Represents a partition spec object in catalog.
CatalogPartitionSpec(Map<String, String>) - Constructor for class org.apache.flink.table.catalog.CatalogPartitionSpec
 
CatalogPropertiesUtil - Class in org.apache.flink.table.catalog
Utilities for de/serializing Catalog objects into a map of string properties.
CatalogTable - Interface in org.apache.flink.table.catalog
Represents the unresolved metadata of a table in a Catalog.
CatalogTableStatistics - Class in org.apache.flink.table.catalog.stats
Statistics for a non-partitioned table or a partition of a partitioned table.
CatalogTableStatistics(long, int, long, long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
CatalogTableStatistics(long, int, long, long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
CatalogView - Interface in org.apache.flink.table.catalog
Represents the unresolved metadata of a view in a Catalog.
CEIL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ChangelogMode - Class in org.apache.flink.table.connector
The set of changes contained in a changelog.
ChangelogMode.Builder - Class in org.apache.flink.table.connector
Builder for configuring and creating instances of ChangelogMode.
CHAR(int) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a fixed-length character string CHAR(n) where n is the number of code points.
CHAR_LENGTH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CharType - Class in org.apache.flink.table.types.logical
Logical type of a fixed-length character string.
CharType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.CharType
 
CharType(int) - Constructor for class org.apache.flink.table.types.logical.CharType
 
CharType() - Constructor for class org.apache.flink.table.types.logical.CharType
 
checkOnlyPhysicalColumns(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
Throws an exception if the given TableSchema contains any non-physical columns.
checkPhysicalLogicalTypeCompatible(LogicalType, LogicalType, String, String, boolean) - Static method in class org.apache.flink.table.utils.TypeMappingUtils
Checks whether the given physical field type and logical field type are compatible at the edges of the table ecosystem.
CLASS - Static variable in class org.apache.flink.table.descriptors.ClassInstanceValidator
 
ClassDataTypeConverter - Class in org.apache.flink.table.types.utils
Class-based data type extractor that supports extraction of clearly identifiable data types for input and output conversion.
ClassInstance - Class in org.apache.flink.table.descriptors
Descriptor for a class instance.
ClassInstance() - Constructor for class org.apache.flink.table.descriptors.ClassInstance
 
ClassInstanceValidator - Class in org.apache.flink.table.descriptors
Validator for ClassInstance.
ClassInstanceValidator(String) - Constructor for class org.apache.flink.table.descriptors.ClassInstanceValidator
 
ClassInstanceValidator() - Constructor for class org.apache.flink.table.descriptors.ClassInstanceValidator
 
clear() - Method in interface org.apache.flink.table.api.dataview.DataView
Clears the DataView and removes all data.
clear() - Method in class org.apache.flink.table.api.dataview.ListView
Removes all of the elements from this list view.
clear() - Method in class org.apache.flink.table.api.dataview.MapView
Removes all entries of this map.
clear() - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
close() - Method in interface org.apache.flink.table.catalog.Catalog
Close the catalog when it is no longer needed and release any resource that it might be holding.
close() - Method in class org.apache.flink.table.functions.UserDefinedFunction
Tear-down method for user-defined function.
COLLECT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
collect(T) - Method in class org.apache.flink.table.functions.TableFunction
Emits an (implicit or explicit) output row.
CollectionDataType - Class in org.apache.flink.table.types
A data type that contains an element type (e.g.
CollectionDataType(LogicalType, Class<?>, DataType) - Constructor for class org.apache.flink.table.types.CollectionDataType
 
CollectionDataType(LogicalType, DataType) - Constructor for class org.apache.flink.table.types.CollectionDataType
 
collectMethods(Class<?>, String) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Collects methods of the given name.
column(String, AbstractDataType<?>) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a physical column that is appended to this schema.
column(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a physical column that is appended to this schema.
Column - Class in org.apache.flink.table.catalog
Representation of a column in a ResolvedSchema.
Column.ComputedColumn - Class in org.apache.flink.table.catalog
Representation of a computed column.
Column.MetadataColumn - Class in org.apache.flink.table.catalog
Representation of a metadata column.
Column.PhysicalColumn - Class in org.apache.flink.table.catalog
Representation of a physical column.
columnByExpression(String, Expression) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a computed column that is appended to this schema.
columnByExpression(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a computed column that is appended to this schema.
columnByMetadata(String, AbstractDataType<?>) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
columnByMetadata(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
columnByMetadata(String, AbstractDataType<?>, boolean) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
columnByMetadata(String, AbstractDataType<?>, String) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
columnByMetadata(String, AbstractDataType<?>, String, boolean) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
columnByMetadata(String, String, String, boolean) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
ColumnStats - Class in org.apache.flink.table.plan.stats
Column statistics.
ColumnStats(Long, Long, Double, Integer, Number, Number) - Constructor for class org.apache.flink.table.plan.stats.ColumnStats
Deprecated.
ColumnStats.Builder - Class in org.apache.flink.table.plan.stats
ColumnStats builder.
columnWidthsByType(List<Column>, int, String, String) - Static method in class org.apache.flink.table.utils.PrintUtils
Try to derive column width based on column types.
COMMENT - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
COMMON - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns a common, least restrictive type of all arguments.
COMMON_ARG - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Argument type strategy that checks and casts for a common, least restrictive type of all arguments.
COMMON_ARG_NULLABLE - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Argument type strategy that checks and casts for a common, least restrictive type of all arguments.
CommonArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Argument type strategy that checks and casts for a common, least restrictive type of all arguments.
CommonArgumentTypeStrategy(boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.CommonArgumentTypeStrategy
 
CommonCatalogOptions - Class in org.apache.flink.table.catalog
A collection of ConfigOption which are consistently used in multiple catalogs.
CommonCatalogOptions() - Constructor for class org.apache.flink.table.catalog.CommonCatalogOptions
 
CommonInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
An InputTypeStrategy that expects that all arguments have a common type.
CommonInputTypeStrategy(ArgumentCount) - Constructor for class org.apache.flink.table.types.inference.strategies.CommonInputTypeStrategy
 
commonType(int) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
An InputTypeStrategy that expects count arguments that have a common type.
CommonTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Type strategy that returns a common, least restrictive type of all arguments.
CommonTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
 
comparable(ConstantArgumentCount, StructuredType.StructuredComparision) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that checks all types are comparable with each other.
ComparableTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
An InputTypeStrategy that checks if all input arguments can be compared with each other with the minimal provided comparision.
ComparableTypeStrategy(ConstantArgumentCount, StructuredType.StructuredComparision) - Constructor for class org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
 
compareTo(StringData) - Method in class org.apache.flink.table.data.binary.BinaryStringData
Compares two strings lexicographically.
compareTo(DecimalData) - Method in class org.apache.flink.table.data.DecimalData
 
compareTo(TimestampData) - Method in class org.apache.flink.table.data.TimestampData
 
comparision(StructuredType.StructuredComparision) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
COMPOSITE - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that checks that the argument has a composite type.
CompositeArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy that checks that the argument has a composite type.
CompositeArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.CompositeArgumentTypeStrategy
 
compositeSequence() - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
An strategy that lets you apply other strategies for subsequences of the actual arguments.
computed(String, DataType, String) - Static method in class org.apache.flink.table.api.TableColumn
Deprecated.
Creates a computed column that is computed from the given SQL expression.
computed(String, ResolvedExpression) - Static method in class org.apache.flink.table.catalog.Column
Creates a computed column that is computed from the given ResolvedExpression.
computePhysicalIndices(List<TableColumn>, DataType, Function<String, String>) - Static method in class org.apache.flink.table.utils.TypeMappingUtils
Computes indices of physical fields corresponding to the selected logical fields of a TableSchema.
computePhysicalIndicesOrTimeAttributeMarkers(TableSource<?>, List<TableColumn>, boolean, Function<String, String>) - Static method in class org.apache.flink.table.utils.TypeMappingUtils
Computes indices of physical fields corresponding to the selected logical fields of a TableSchema.
CONCAT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CONCAT_WS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
configure(String[], TypeInformation<?>[]) - Method in interface org.apache.flink.table.sinks.TableSink
Deprecated.
This method will be dropped in future versions. It is recommended to pass a static schema when instantiating the sink instead.
configure(String[], TypeInformation<?>[]) - Method in class org.apache.flink.table.sinks.TableSinkBase
Returns a copy of this TableSink configured with the field names and types of the table to emit.
configurePartitionGrouping(boolean) - Method in interface org.apache.flink.table.sinks.PartitionableTableSink
Deprecated.
If returns true, sink can trust all records will definitely be grouped by partition fields before consumed by the TableSink, i.e.
CONNECTOR - Static variable in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
Prefix for connector-related properties.
CONNECTOR - Static variable in class org.apache.flink.table.factories.FactoryUtil
 
CONNECTOR_PATH - Static variable in class org.apache.flink.table.descriptors.FileSystemValidator
 
CONNECTOR_PROPERTY_VERSION - Static variable in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
Key for describing the property version.
CONNECTOR_TYPE - Static variable in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
Key for describing the type of the connector.
CONNECTOR_TYPE_VALUE - Static variable in class org.apache.flink.table.descriptors.FileSystemValidator
 
CONNECTOR_VERSION - Static variable in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
Key for describing the version of the connector.
ConnectorDescriptor - Class in org.apache.flink.table.descriptors
Describes a connector to an other system.
ConnectorDescriptor(String, int, boolean) - Constructor for class org.apache.flink.table.descriptors.ConnectorDescriptor
Constructs a ConnectorDescriptor.
ConnectorDescriptorValidator - Class in org.apache.flink.table.descriptors
Validator for ConnectorDescriptor.
ConnectorDescriptorValidator() - Constructor for class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
 
ConstantArgumentCount - Class in org.apache.flink.table.types.inference
Helper class for ArgumentCount with constant boundaries.
ConstantFunctionContext - Class in org.apache.flink.table.functions
A FunctionContext for constant expression reduction.
ConstantFunctionContext(Configuration) - Constructor for class org.apache.flink.table.functions.ConstantFunctionContext
 
Constraint - Interface in org.apache.flink.table.api.constraints
Deprecated.
Constraint - Interface in org.apache.flink.table.catalog
Integrity constraints, generally referred to simply as constraints, define the valid states of SQL-data by constraining the values in the base tables.
constraint(String, Function<List<DataType>, Boolean>) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that must fulfill a given constraint.
Constraint.ConstraintType - Enum in org.apache.flink.table.api.constraints
Deprecated.
Type of the constraint.
Constraint.ConstraintType - Enum in org.apache.flink.table.catalog
Type of the constraint.
ConstraintArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for an argument that must fulfill a given constraint.
ConstraintArgumentTypeStrategy(String, Function<List<DataType>, Boolean>) - Constructor for class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
 
CONSTRUCTOR - Static variable in class org.apache.flink.table.descriptors.ClassInstanceValidator
 
constructor - Variable in class org.apache.flink.table.types.extraction.ExtractionUtils.AssigningConstructor
 
contains(K) - Method in class org.apache.flink.table.api.dataview.MapView
Checks if the map view contains a value for a given key.
contains(RowKind) - Method in class org.apache.flink.table.connector.ChangelogMode
 
contains(BinaryStringData) - Method in class org.apache.flink.table.data.binary.BinaryStringData
Returns true if and only if this BinaryStringData contains the specified sequence of bytes values.
containsKey(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns if the given key is contained.
containsOnly(RowKind) - Method in class org.apache.flink.table.connector.ChangelogMode
 
containsPhysicalColumnsOnly(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
Returns true if there are only physical columns in the given TableSchema.
conversionClass - Variable in class org.apache.flink.table.types.DataType
 
conversionSet(String...) - Static method in class org.apache.flink.table.types.logical.LogicalType
 
convertStringToInternalValue(String, DataType) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
Restore partition value from string and type.
copy() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns a deep copy of the table schema.
copy() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
Get a deep copy of the CatalogBaseTable instance.
copy() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
Get a deep copy of the CatalogDatabase instance.
copy(Map<String, String>) - Method in interface org.apache.flink.table.catalog.CatalogDatabase
Returns a copy of this CatalogDatabase with the given properties.
copy() - Method in interface org.apache.flink.table.catalog.CatalogFunction
Create a deep copy of the function.
copy() - Method in interface org.apache.flink.table.catalog.CatalogPartition
Get a deep copy of the CatalogPartition instance.
copy(Map<String, String>) - Method in interface org.apache.flink.table.catalog.CatalogTable
Returns a copy of this CatalogTable with given table options options.
copy(DataType) - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
 
copy(DataType) - Method in class org.apache.flink.table.catalog.Column
Returns a copy of the column with a replaced DataType.
copy(DataType) - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
 
copy(DataType) - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
 
copy() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
copy() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
 
copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
Create a deep copy of "this" instance.
copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
Create a deep copy of "this" instance.
copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
 
copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
 
copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
 
copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
 
copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
 
copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
 
copy() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
Create a deep copy of "this" instance.
copy() - Method in class org.apache.flink.table.catalog.stats.Date
 
copy() - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
Creates a copy of this instance during planning.
copy() - Method in interface org.apache.flink.table.connector.source.DynamicTableSource
Creates a copy of this instance during planning.
copy() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
copy(BinaryArrayData) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
copy() - Method in class org.apache.flink.table.data.binary.BinaryMapData
 
copy(BinaryMapData) - Method in class org.apache.flink.table.data.binary.BinaryMapData
 
copy() - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
copy(BinaryRowData) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
copy() - Method in class org.apache.flink.table.data.binary.BinaryStringData
Copy a new BinaryStringData.
copy() - Method in class org.apache.flink.table.data.binary.NestedRowData
 
copy(RowData) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
copy() - Method in class org.apache.flink.table.data.DecimalData
Returns a copy of this DecimalData object.
copy(ListView<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
copy(ListView<T>, ListView<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
copy(MapView<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
copy(MapView<K, V>, MapView<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
copy(Map<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
copy(Map<K, V>, Map<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
copy(Object) - Method in class org.apache.flink.table.dataview.NullSerializer
 
copy(Object, Object) - Method in class org.apache.flink.table.dataview.NullSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.NullSerializer
 
copy() - Method in class org.apache.flink.table.plan.stats.ColumnStats
Create a deep copy of "this" instance.
copy() - Method in class org.apache.flink.table.plan.stats.TableStats
Create a deep copy of "this" instance.
copy() - Method in class org.apache.flink.table.sinks.TableSinkBase
Returns a deep copy of the TableSink.
copy(boolean) - Method in class org.apache.flink.table.types.logical.ArrayType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.BigIntType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.BinaryType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.BooleanType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.CharType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.DateType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.DecimalType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.DistinctType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.DoubleType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.FloatType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.IntType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.LogicalType
Returns a deep copy of this type with possibly different nullability.
copy() - Method in class org.apache.flink.table.types.logical.LogicalType
Returns a deep copy of this type.
copy(boolean) - Method in class org.apache.flink.table.types.logical.MapType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.MultisetType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.NullType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.RawType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.RowType
 
copy() - Method in class org.apache.flink.table.types.logical.RowType.RowField
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.SmallIntType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType
 
copy() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.SymbolType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.TimestampType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.TimeType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.TinyIntType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.VarCharType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
copy(boolean) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
copyFromBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Copy target segments from source byte[].
copyMultiSegmentsToBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
 
copyToBytes(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Copy segments to a new byte[].
copyToBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Copy segments to target byte[].
copyToUnsafe(MemorySegment[], int, Object, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Copy segments to target unsafe pointer.
copyToView(MemorySegment[], int, int, DataOutputView) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Copy bytes of segments to output view.
CoreModule - Class in org.apache.flink.table.module
Module of default core metadata in Flink.
CoreModuleDescriptor - Class in org.apache.flink.table.descriptors
Module descriptor for CoreModule.
CoreModuleDescriptor() - Constructor for class org.apache.flink.table.descriptors.CoreModuleDescriptor
 
CoreModuleDescriptorValidator - Class in org.apache.flink.table.descriptors
Validator for CoreModuleDescriptor.
CoreModuleDescriptorValidator() - Constructor for class org.apache.flink.table.descriptors.CoreModuleDescriptorValidator
 
CoreModuleFactory - Class in org.apache.flink.table.module
Factory for CoreModule.
CoreModuleFactory() - Constructor for class org.apache.flink.table.module.CoreModuleFactory
 
COS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
COSH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
COT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
COUNT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
create(ClassLoader) - Static method in interface org.apache.flink.table.connector.RuntimeConverter.Context
Creates a new instance of RuntimeConverter.Context.
createAccumulator() - Method in class org.apache.flink.table.functions.ImperativeAggregateFunction
Creates and initializes the accumulator for this ImperativeAggregateFunction.
createAccumulator() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
createAsyncTableFunction() - Method in interface org.apache.flink.table.connector.source.AsyncTableFunctionProvider
Creates a AsyncTableFunction instance.
createCatalog(String, Map<String, String>) - Method in interface org.apache.flink.table.factories.CatalogFactory
Deprecated.
Use this#createCatalog(Context) instead and implement Factory instead of TableFactory.
createCatalog(CatalogFactory.Context) - Method in interface org.apache.flink.table.factories.CatalogFactory
Creates and configures a Catalog using the given context.
createCatalog(String, Map<String, String>, ReadableConfig, ClassLoader) - Static method in class org.apache.flink.table.factories.FactoryUtil
Attempts to discover an appropriate catalog factory and creates an instance of the catalog.
createCatalogFactoryHelper(CatalogFactory, CatalogFactory.Context) - Static method in class org.apache.flink.table.factories.FactoryUtil
Creates a utility that helps validating options for a CatalogFactory.
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
createDatabase(String, CatalogDatabase, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Create a database.
createDataStructureConverter(DataType) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
Creates a converter for mapping between Flink's internal data structures and objects specified by the given DataType that can be passed into a runtime implementation.
createDataStructureConverter(DataType) - Method in interface org.apache.flink.table.connector.source.DynamicTableSource.Context
Creates a converter for mapping between objects specified by the given DataType and Flink's internal data structures that can be passed into a runtime implementation.
createDataType(AbstractDataType<?>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
Creates a type out of an AbstractDataType.
createDataType(String) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
Creates a type by a fully or partially defined name.
createDataType(UnresolvedIdentifier) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
Creates a type by a fully or partially defined identifier.
createDataType(Class<T>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
Creates a type by analyzing the given class.
createDataType(TypeInformation<T>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
Creates a type for the given TypeInformation.
createDecodingFormat(DynamicTableFactory.Context, ReadableConfig) - Method in interface org.apache.flink.table.factories.BulkReaderFormatFactory
Creates a BulkDecodingFormat from the given context and format options.
createDecodingFormat(DynamicTableFactory.Context, ReadableConfig) - Method in interface org.apache.flink.table.factories.DecodingFormatFactory
Creates a format from the given context and format options.
createDeserializationSchema(Map<String, String>) - Method in interface org.apache.flink.table.factories.DeserializationSchemaFactory
Creates and configures a DeserializationSchema using the given properties.
createDynamicTableSink(DynamicTableFactory.Context) - Method in interface org.apache.flink.table.factories.DynamicTableSinkFactory
Creates a DynamicTableSink instance from a CatalogTable and additional context information.
createDynamicTableSource(DynamicTableFactory.Context) - Method in interface org.apache.flink.table.factories.DynamicTableSourceFactory
Creates a DynamicTableSource instance from a CatalogTable and additional context information.
createElementGetter(LogicalType) - Static method in interface org.apache.flink.table.data.ArrayData
Creates an accessor for getting elements in an internal array data structure at the given position.
createEncodingFormat(DynamicTableFactory.Context, ReadableConfig) - Method in interface org.apache.flink.table.factories.EncodingFormatFactory
Creates a format from the given context and format options.
createFieldGetter(LogicalType, int) - Static method in interface org.apache.flink.table.data.RowData
Creates an accessor for getting elements in an internal row data structure at the given position.
createFunction(ObjectPath, CatalogFunction, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Create a function.
createFunction(FunctionDescriptor) - Static method in class org.apache.flink.table.functions.FunctionService
Creates a user-defined function with the given properties and the current thread's context class loader.
createFunction(FunctionDescriptor, ClassLoader) - Static method in class org.apache.flink.table.functions.FunctionService
Creates a user-defined function with the given properties.
createFunction(FunctionDescriptor, ClassLoader, boolean) - Static method in class org.apache.flink.table.functions.FunctionService
Creates a user-defined function with the given properties.
createFunction(FunctionDescriptor, ClassLoader, boolean, ReadableConfig) - Static method in class org.apache.flink.table.functions.FunctionService
Creates a user-defined function with the given properties.
createFunctionDefinition(String, CatalogFunction) - Method in interface org.apache.flink.table.factories.FunctionDefinitionFactory
Creates a FunctionDefinition from given CatalogFunction.
createInputFormat() - Method in interface org.apache.flink.table.connector.source.InputFormatProvider
Creates an InputFormat instance.
createInstance() - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
createInstance() - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
createInstance() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
createInstance() - Method in class org.apache.flink.table.dataview.NullSerializer
 
createInvalidCallException(CallContext, ValidationException) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
Returns an exception for an invalid call to a function.
createInvalidInputException(TypeInference, CallContext, ValidationException) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
Returns an exception for invalid input arguments.
createMethodSignatureString(String, Class<?>[], Class<?>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Creates a method signature string like int eval(Integer, String).
createModule(Map<String, String>) - Method in interface org.apache.flink.table.factories.ModuleFactory
Creates and configures a Module using the given properties.
createModule(Map<String, String>) - Method in class org.apache.flink.table.module.CoreModuleFactory
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.dataview.ListViewSerializerSnapshot
Deprecated.
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.dataview.MapViewSerializerSnapshot
Deprecated.
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
Deprecated.
 
createOutputFormat() - Method in interface org.apache.flink.table.connector.sink.OutputFormatProvider
Creates an OutputFormat instance.
createPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Create a partition.
createProctimeDataType() - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Returns a PROCTIME data type.
createRawDataType(Class<T>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
Creates a RAW type for the given class in cases where no serializer is known and a generic serializer should be used.
createRawDataType(TypeInformation<T>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
Creates a RAW type for the given TypeInformation.
createReader(FileSystemFormatFactory.ReaderContext) - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory
Deprecated.
Create InputFormat reader.
createRuntimeDecoder(DynamicTableSource.Context, DataType) - Method in interface org.apache.flink.table.connector.format.DecodingFormat
Creates runtime decoder implementation that is configured to produce data of the given data type.
createRuntimeEncoder(DynamicTableSink.Context, DataType) - Method in interface org.apache.flink.table.connector.format.EncodingFormat
Creates runtime encoder implementation that is configured to consume data of the given data type.
createSerializationSchema(Map<String, String>) - Method in interface org.apache.flink.table.factories.SerializationSchemaFactory
Creates and configures a [[SerializationSchema]] using the given properties.
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
createSink() - Method in interface org.apache.flink.table.connector.sink.SinkProvider
Creates a Sink instance.
createSource() - Method in interface org.apache.flink.table.connector.source.SourceProvider
Creates a Source instance.
createSpecializedFunction(String, FunctionDefinition, CallContext, ClassLoader, ReadableConfig) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Creates the runtime implementation of a FunctionDefinition as an instance of UserDefinedFunction.
createTable(ObjectPath, CatalogBaseTable, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Creates a new table or view.
createTableFactoryHelper(DynamicTableFactory, DynamicTableFactory.Context) - Static method in class org.apache.flink.table.factories.FactoryUtil
Creates a utility that helps in discovering formats and validating all options for a DynamicTableFactory.
createTableFunction() - Method in interface org.apache.flink.table.connector.source.TableFunctionProvider
Creates a TableFunction instance.
createTableSink(Catalog, ObjectIdentifier, ResolvedCatalogTable, ReadableConfig, ClassLoader, boolean) - Static method in class org.apache.flink.table.factories.FactoryUtil
Creates a DynamicTableSink from a CatalogTable.
createTableSink(Map<String, String>) - Method in interface org.apache.flink.table.factories.TableSinkFactory
Deprecated.
TableSinkFactory.Context contains more information, and already contains table schema too. Please use TableSinkFactory.createTableSink(Context) instead.
createTableSink(ObjectPath, CatalogTable) - Method in interface org.apache.flink.table.factories.TableSinkFactory
Deprecated.
TableSinkFactory.Context contains more information, and already contains table schema too. Please use TableSinkFactory.createTableSink(Context) instead.
createTableSink(TableSinkFactory.Context) - Method in interface org.apache.flink.table.factories.TableSinkFactory
Creates and configures a TableSink based on the given TableSinkFactory.Context.
createTableSource(Catalog, ObjectIdentifier, ResolvedCatalogTable, ReadableConfig, ClassLoader, boolean) - Static method in class org.apache.flink.table.factories.FactoryUtil
createTableSource(Map<String, String>) - Method in interface org.apache.flink.table.factories.TableSourceFactory
Deprecated.
TableSourceFactory.Context contains more information, and already contains table schema too. Please use TableSourceFactory.createTableSource(Context) instead.
createTableSource(ObjectPath, CatalogTable) - Method in interface org.apache.flink.table.factories.TableSourceFactory
Deprecated.
TableSourceFactory.Context contains more information, and already contains table schema too. Please use TableSourceFactory.createTableSource(Context) instead.
createTableSource(TableSourceFactory.Context) - Method in interface org.apache.flink.table.factories.TableSourceFactory
Creates and configures a TableSource based on the given TableSourceFactory.Context.
createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.table.dataview.ListViewTypeInfoFactory
Deprecated.
 
createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.table.dataview.MapViewTypeInfoFactory
Deprecated.
 
createTypeInformation(DataType) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
Creates type information describing the internal data structures of the given DataType.
createTypeInformation(DataType) - Method in interface org.apache.flink.table.connector.source.DynamicTableSource.Context
Creates type information describing the internal data structures of the given DataType.
createUnexpectedException(CallContext, Throwable) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
Returns an exception for an unexpected error during type inference.
CURRENT_DATE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CURRENT_RANGE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CURRENT_ROW - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CURRENT_ROW_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CURRENT_TIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CURRENT_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CustomConnectorDescriptor - Class in org.apache.flink.table.descriptors
Describes a custom connector to an other system.
CustomConnectorDescriptor(String, int, boolean) - Constructor for class org.apache.flink.table.descriptors.CustomConnectorDescriptor

D

DATA_TYPE - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
DatabaseAlreadyExistException - Exception in org.apache.flink.table.catalog.exceptions
Exception for trying to create a database that already exists.
DatabaseAlreadyExistException(String, String, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseAlreadyExistException
 
DatabaseAlreadyExistException(String, String) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseAlreadyExistException
 
databaseExists(String) - Method in interface org.apache.flink.table.catalog.Catalog
Check if a database exists in this catalog.
DatabaseNotEmptyException - Exception in org.apache.flink.table.catalog.exceptions
Exception for trying to drop on a database that is not empty.
DatabaseNotEmptyException(String, String, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseNotEmptyException
 
DatabaseNotEmptyException(String, String) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseNotEmptyException
 
DatabaseNotExistException - Exception in org.apache.flink.table.catalog.exceptions
Exception for trying to operate on a database that doesn't exist.
DatabaseNotExistException(String, String, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseNotExistException
 
DatabaseNotExistException(String, String) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseNotExistException
 
dataType - Variable in class org.apache.flink.table.catalog.Column
 
DataType - Class in org.apache.flink.table.types
Describes the data type of a value in the table ecosystem.
DataTypeConversionClassTransformation - Class in org.apache.flink.table.types.inference.transforms
This type transformation transforms the specified data types to a new one with the expected conversion class.
DataTypeConversionClassTransformation(Map<LogicalTypeRoot, Class<?>>) - Constructor for class org.apache.flink.table.types.inference.transforms.DataTypeConversionClassTransformation
 
DataTypeDefaultVisitor<R> - Class in org.apache.flink.table.types.utils
Implementation of DataTypeVisitor that redirects all calls to DataTypeDefaultVisitor.defaultMethod(DataType).
DataTypeDefaultVisitor() - Constructor for class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
 
DataTypeExtractor - Class in org.apache.flink.table.types.extraction
Reflection-based utility that analyzes a given Type, method, or class to extract a (possibly nested) DataType from it.
DataTypeFactory - Interface in org.apache.flink.table.catalog
Factory for creating fully resolved data types that can be used for planning.
DataTypeHint - Annotation Type in org.apache.flink.table.annotation
A hint that influences the reflection-based extraction of a DataType.
DataTypeQueryable - Interface in org.apache.flink.table.types
Indicates that a DataType can be retrieved from a class that implements this interfaces.
DataTypes - Class in org.apache.flink.table.api
A DataType can be used to declare input and/or output types of operations.
DataTypes.AbstractField - Class in org.apache.flink.table.api
Common helper class for resolved and unresolved fields of a row or structured type.
DataTypes.Field - Class in org.apache.flink.table.api
Helper class for defining the field of a row or structured type.
DataTypes.Resolution - Class in org.apache.flink.table.api
Helper class for defining the resolution of an interval.
DataTypes.UnresolvedField - Class in org.apache.flink.table.api
Helper class for defining the unresolved field of a row or structured type.
DataTypeUtils - Class in org.apache.flink.table.types.utils
Utilities for handling DataTypes.
DataTypeVisitor<R> - Interface in org.apache.flink.table.types
The visitor definition of DataType.
DataView - Interface in org.apache.flink.table.api.dataview
A DataView is a collection type that can be used in the accumulator of an ImperativeAggregateFunction.
DATE() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a date consisting of year-month-day with values ranging from 0000-01-01 to 9999-12-31.
Date - Class in org.apache.flink.table.catalog.stats
Class representing a date value in statistics.
Date(long) - Constructor for class org.apache.flink.table.catalog.stats.Date
 
DATE_FORMAT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
DateType - Class in org.apache.flink.table.types.logical
Logical type of a date consisting of year-month-day with values ranging from 0000-01-01 to 9999-12-31.
DateType(boolean) - Constructor for class org.apache.flink.table.types.logical.DateType
 
DateType() - Constructor for class org.apache.flink.table.types.logical.DateType
 
DAY(int) - Static method in class org.apache.flink.table.api.DataTypes
Resolution in days.
DAY() - Static method in class org.apache.flink.table.api.DataTypes
Resolution in days with 2 digits for the number of days by default.
DayTimeIntervalType - Class in org.apache.flink.table.types.logical
Logical type for a group of day-time interval types.
DayTimeIntervalType(boolean, DayTimeIntervalType.DayTimeResolution, int, int) - Constructor for class org.apache.flink.table.types.logical.DayTimeIntervalType
 
DayTimeIntervalType(DayTimeIntervalType.DayTimeResolution, int, int) - Constructor for class org.apache.flink.table.types.logical.DayTimeIntervalType
 
DayTimeIntervalType(DayTimeIntervalType.DayTimeResolution) - Constructor for class org.apache.flink.table.types.logical.DayTimeIntervalType
 
DayTimeIntervalType.DayTimeResolution - Enum in org.apache.flink.table.types.logical
Supported resolutions of this type.
DECIMAL(int, int) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a decimal number with fixed precision and scale DECIMAL(p, s) where p is the number of digits in a number (=precision) and s is the number of digits to the right of the decimal point in a number (=scale).
DECIMAL() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API big decimal or SQL DECIMAL type.
DECIMAL_DIVIDE - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the quotient of an exact numeric division that includes at least one decimal.
DECIMAL_MOD - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the modulo of an exact numeric division that includes at least one decimal.
DECIMAL_PLUS - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the sum of an exact numeric addition that includes at least one decimal.
DECIMAL_SCALE0 - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Strategy that returns a decimal type but with a scale of 0.
DECIMAL_TIMES - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the product of an exact numeric multiplication that includes at least one decimal.
DecimalData - Class in org.apache.flink.table.data
An internal data structure representing data of DecimalType.
DecimalType - Class in org.apache.flink.table.types.logical
Logical type of a decimal number with fixed precision and scale.
DecimalType(boolean, int, int) - Constructor for class org.apache.flink.table.types.logical.DecimalType
 
DecimalType(int, int) - Constructor for class org.apache.flink.table.types.logical.DecimalType
 
DecimalType(int) - Constructor for class org.apache.flink.table.types.logical.DecimalType
 
DecimalType() - Constructor for class org.apache.flink.table.types.logical.DecimalType
 
decodeBase64ToBytes(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
decodeBase64ToString(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
decodeStringToObject(String, ClassLoader) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
decodeStringToObject(String, Class<T>) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
decodeStringToObject(String, Class<T>, ClassLoader) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
DecodingFormat<I> - Interface in org.apache.flink.table.connector.format
A Format for a DynamicTableSource for reading rows.
DecodingFormatFactory<I> - Interface in org.apache.flink.table.factories
Base interface for configuring a DecodingFormat for ScanTableSource and LookupTableSource.
DEFAULT_DATABASE_KEY - Static variable in class org.apache.flink.table.catalog.CommonCatalogOptions
Key used for specifying a default database ConfigOption.
DEFAULT_DAY_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
DEFAULT_FRACTIONAL_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
DEFAULT_LENGTH - Static variable in class org.apache.flink.table.types.logical.BinaryType
 
DEFAULT_LENGTH - Static variable in class org.apache.flink.table.types.logical.CharType
 
DEFAULT_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarBinaryType
 
DEFAULT_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarCharType
 
DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.DecimalType
 
DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimestampType
 
DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimeType
 
DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.ZonedTimestampType
 
DEFAULT_SCALE - Static variable in class org.apache.flink.table.types.logical.DecimalType
 
DefaultCatalogContext(String, Map<String, String>, ReadableConfig, ClassLoader) - Constructor for class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
 
DefaultDynamicTableContext(ObjectIdentifier, ResolvedCatalogTable, ReadableConfig, ClassLoader, boolean) - Constructor for class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
defaultMethod(Expression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
 
defaultMethod(LogicalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
defaultMethod(LogicalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
 
defaultMethod(DataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
 
DefinedFieldMapping - Interface in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. See FLIP-95 for more information.
DefinedProctimeAttribute - Interface in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use the concept of computed columns instead. See FLIP-95 for more information.
DefinedRowtimeAttributes - Interface in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use the concept of computed columns instead. See FLIP-95 for more information.
DEGREES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
deriveSchema(Map<String, String>) - Static method in class org.apache.flink.table.factories.TableFormatFactoryBase
Finds the table schema that can be used for a format schema (without time attributes and generated columns).
description - Variable in class org.apache.flink.table.api.DataTypes.AbstractField
 
description(String) - Method in class org.apache.flink.table.types.logical.DistinctType.Builder
 
description(String) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
Descriptor - Interface in org.apache.flink.table.descriptors
Interface that adds a set of string-based, normalized properties for describing DDL information.
DescriptorBase - Class in org.apache.flink.table.descriptors
Base class for Descriptors.
DescriptorBase() - Constructor for class org.apache.flink.table.descriptors.DescriptorBase
 
DescriptorProperties - Class in org.apache.flink.table.descriptors
Deprecated.
This utility will be dropped soon. DynamicTableFactory is based on ConfigOption and catalogs use CatalogPropertiesUtil.
DescriptorProperties(boolean) - Constructor for class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
DescriptorProperties() - Constructor for class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
DescriptorValidator - Interface in org.apache.flink.table.descriptors
Validator for a descriptor.
DeserializationFormatFactory - Interface in org.apache.flink.table.factories
Factory for creating a DecodingFormat for DeserializationSchema.
DeserializationSchemaFactory<T> - Interface in org.apache.flink.table.factories
Factory for creating configured instances of DeserializationSchema.
deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
deserialize(ListView<T>, DataInputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
deserialize(MapView<K, V>, DataInputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
deserialize(Map<K, V>, DataInputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.NullSerializer
 
deserialize(Object, DataInputView) - Method in class org.apache.flink.table.dataview.NullSerializer
 
deserializeCatalogTable(Map<String, String>) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
Deserializes the given map of string properties into an unresolved CatalogTable.
discoverDecodingFormat(Class<F>, ConfigOption<String>) - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
Discovers a DecodingFormat of the given type using the given option as factory identifier.
discoverEncodingFormat(Class<F>, ConfigOption<String>) - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
Discovers a EncodingFormat of the given type using the given option as factory identifier.
discoverFactory(ClassLoader, Class<T>, String) - Static method in class org.apache.flink.table.factories.FactoryUtil
Discovers a factory using the given factory base class and identifier.
discoverOptionalDecodingFormat(Class<F>, ConfigOption<String>) - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
Discovers a DecodingFormat of the given type using the given option (if present) as factory identifier.
discoverOptionalEncodingFormat(Class<F>, ConfigOption<String>) - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
Discovers a EncodingFormat of the given type using the given option (if present) as factory identifier.
DISTINCT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
DistinctType - Class in org.apache.flink.table.types.logical
Logical type of a user-defined distinct type.
DistinctType.Builder - Class in org.apache.flink.table.types.logical
A builder for a DistinctType.
DIVIDE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
DOUBLE() - Static method in class org.apache.flink.table.api.DataTypes
Data type of an 8-byte double precision floating point number.
DOUBLE() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API integer or SQL DOUBLE type.
DoubleType - Class in org.apache.flink.table.types.logical
Logical type of an 8-byte double precision floating point number.
DoubleType(boolean) - Constructor for class org.apache.flink.table.types.logical.DoubleType
 
DoubleType() - Constructor for class org.apache.flink.table.types.logical.DoubleType
 
dropConstraint(TableSchema, String) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
Creates a new schema but drop the constraint with given name.
dropDatabase(String, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Drop a database.
dropDatabase(String, boolean, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Drop a database.
dropFunction(ObjectPath, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Drop a function.
dropPartition(ObjectPath, CatalogPartitionSpec, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Drop a partition.
dropTable(ObjectPath, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Drop a table or view.
duplicate() - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
duplicate() - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
duplicate() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
DynamicTableFactory - Interface in org.apache.flink.table.factories
Base interface for configuring a dynamic table connector for an external storage system from catalog and session information.
DynamicTableFactory.Context - Interface in org.apache.flink.table.factories
Provides catalog and session information describing the dynamic table to be accessed.
DynamicTableSink - Interface in org.apache.flink.table.connector.sink
Sink of a dynamic table to an external storage system.
DynamicTableSink.Context - Interface in org.apache.flink.table.connector.sink
Context for creating runtime implementation via a DynamicTableSink.SinkRuntimeProvider.
DynamicTableSink.DataStructureConverter - Interface in org.apache.flink.table.connector.sink
Converter for mapping between Flink's internal data structures and objects specified by the given DataType that can be passed into a runtime implementation.
DynamicTableSink.SinkRuntimeProvider - Interface in org.apache.flink.table.connector.sink
Provides actual runtime implementation for writing the data.
DynamicTableSinkFactory - Interface in org.apache.flink.table.factories
Creates a DynamicTableSink instance from a CatalogTable and additional context information.
DynamicTableSource - Interface in org.apache.flink.table.connector.source
Source of a dynamic table from an external storage system.
DynamicTableSource.Context - Interface in org.apache.flink.table.connector.source
Base context for creating runtime implementation via a ScanTableSource.ScanRuntimeProvider and LookupTableSource.LookupRuntimeProvider.
DynamicTableSource.DataStructureConverter - Interface in org.apache.flink.table.connector.source
Converter for mapping between objects and Flink's internal data structures during runtime.
DynamicTableSourceFactory - Interface in org.apache.flink.table.factories
Creates a DynamicTableSource instance from a CatalogTable and additional context information.

E

E - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
elementType - Variable in class org.apache.flink.table.api.dataview.ListView
Deprecated.
emitValue(Object, Object) - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
EMPTY_LITERAL_LENGTH - Static variable in class org.apache.flink.table.types.logical.BinaryType
 
EMPTY_LITERAL_LENGTH - Static variable in class org.apache.flink.table.types.logical.CharType
 
EMPTY_LITERAL_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarBinaryType
 
EMPTY_LITERAL_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarCharType
 
EMPTY_PREFIX - Static variable in class org.apache.flink.table.descriptors.HierarchyDescriptorValidator
 
EMPTY_UTF8 - Static variable in class org.apache.flink.table.data.binary.BinaryStringData
 
encodeBytesToBase64(byte[]) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
encodeObjectToString(Object) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
encodeObjectToString(Serializable) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
encodeStringToBase64(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
EncodingFormat<I> - Interface in org.apache.flink.table.connector.format
A Format for a DynamicTableSink for writing rows.
EncodingFormatFactory<I> - Interface in org.apache.flink.table.factories
Base interface for configuring an EncodingFormat for a DynamicTableSink.
EncodingUtils - Class in org.apache.flink.table.utils
General utilities for string-encoding.
endsWith(BinaryStringData) - Method in class org.apache.flink.table.data.binary.BinaryStringData
Tests if this BinaryStringData ends with the specified suffix.
ensureMaterialized() - Method in class org.apache.flink.table.data.binary.BinaryStringData
 
ensureMaterialized(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
Ensure we have materialized binary format.
entries() - Method in class org.apache.flink.table.api.dataview.MapView
Returns all entries of the map view.
equals(Object) - Method in class org.apache.flink.table.api.constraints.UniqueConstraint
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.api.DataTypes.AbstractField
 
equals(Object) - Method in class org.apache.flink.table.api.DataTypes.Field
 
equals(Object) - Method in class org.apache.flink.table.api.DataTypes.UnresolvedField
 
equals(Object) - Method in class org.apache.flink.table.api.dataview.ListView
 
equals(Object) - Method in class org.apache.flink.table.api.dataview.MapView
 
equals(Object) - Method in class org.apache.flink.table.api.Schema
 
equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
 
equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
 
equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedConstraint
 
equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
 
equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
 
equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
 
equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
 
equals(Object) - Method in class org.apache.flink.table.api.TableColumn.ComputedColumn
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.api.TableColumn
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.api.WatermarkSpec
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
 
equals(Object) - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
 
equals(Object) - Method in class org.apache.flink.table.catalog.Column
 
equals(Object) - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
 
equals(Object) - Method in class org.apache.flink.table.catalog.ObjectIdentifier
 
equals(Object) - Method in class org.apache.flink.table.catalog.ObjectPath
 
equals(Object) - Method in class org.apache.flink.table.catalog.ResolvedSchema
 
equals(Object) - Method in class org.apache.flink.table.catalog.UniqueConstraint
 
equals(Object) - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
 
equals(Object) - Method in class org.apache.flink.table.catalog.WatermarkSpec
 
equals(Object) - Method in class org.apache.flink.table.connector.ChangelogMode
 
equals(Object) - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
 
equals(Object) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
equals(Object) - Method in class org.apache.flink.table.data.binary.BinarySection
 
equals(MemorySegment[], int, MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Equals two memory segments regions.
equals(Object) - Method in class org.apache.flink.table.data.binary.BinaryStringData
 
equals(Object) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
equals(Object) - Method in class org.apache.flink.table.data.DecimalData
 
equals(Object) - Method in class org.apache.flink.table.data.GenericArrayData
 
equals(Object) - Method in class org.apache.flink.table.data.GenericMapData
 
equals(Object) - Method in class org.apache.flink.table.data.GenericRowData
 
equals(Object) - Method in class org.apache.flink.table.data.TimestampData
 
equals(Object) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
equals(Object) - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.expressions.AggregateExpression
 
equals(Object) - Method in class org.apache.flink.table.expressions.CallExpression
 
equals(Object) - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
equals(Object) - Method in class org.apache.flink.table.expressions.SqlCallExpression
 
equals(Object) - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
 
equals(Object) - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
equals(Object) - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
EQUALS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
equals(Object) - Method in class org.apache.flink.table.functions.FunctionIdentifier
 
equals(Object) - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
 
equals(Object) - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
equals(Object) - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
equals(Object) - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
equals(Object) - Method in class org.apache.flink.table.plan.stats.TableStats
 
equals(Object) - Method in class org.apache.flink.table.sources.RowtimeAttributeDescriptor
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
 
equals(Object) - Method in class org.apache.flink.table.types.CollectionDataType
 
equals(Object) - Method in class org.apache.flink.table.types.DataType
 
equals(Object) - Method in class org.apache.flink.table.types.FieldsDataType
 
equals(Object) - Method in class org.apache.flink.table.types.inference.ConstantArgumentCount
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.ExplicitTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.MatchFamilyTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.NullableTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.VaryingStringTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
equals(Object) - Method in class org.apache.flink.table.types.KeyValueDataType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.ArrayType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.BinaryType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.CharType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.DecimalType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.DistinctType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.LogicalType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.MapType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.MultisetType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.RawType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.RowType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.RowType.RowField
 
equals(Object) - Method in class org.apache.flink.table.types.logical.StructuredType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
equals(Object) - Method in class org.apache.flink.table.types.logical.SymbolType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.TimestampType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.TimeType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
equals(Object) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.UserDefinedType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.VarCharType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
equals(Object) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
escapeBackticks(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
escapeIdentifier(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
escapeJava(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
Escapes the characters in a String using Java String rules.
escapeSingleQuotes(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
eval(Object...) - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
 
eval(Object...) - Method in class org.apache.flink.table.functions.python.PythonTableFunction
 
EXP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
expandCompositeTypeToSchema(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Expands a composite DataType to a corresponding ResolvedSchema.
explainExtras() - Method in class org.apache.flink.table.api.TableColumn.ComputedColumn
Deprecated.
 
explainExtras() - Method in class org.apache.flink.table.api.TableColumn
Deprecated.
Returns an explanation of specific column extras next to name and type.
explainExtras() - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
Deprecated.
 
explainExtras() - Method in class org.apache.flink.table.api.TableColumn.PhysicalColumn
Deprecated.
 
explainExtras() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
 
explainExtras() - Method in class org.apache.flink.table.catalog.Column
Returns an explanation of specific column extras next to name and type.
explainExtras() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
 
explainExtras() - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
 
explainSource() - Method in interface org.apache.flink.table.sources.TableSource
Deprecated.
Describes the table source.
explicit(DataType) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that corresponds to an explicitly defined type casting.
explicit(DataType) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns a fixed DataType.
ExplicitArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for an argument that corresponds to an explicitly defined type.
ExplicitArgumentTypeStrategy(DataType) - Constructor for class org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
 
explicitSequence(DataType...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a function signature of explicitly defined types like f(STRING, INT).
explicitSequence(String[], DataType[]) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a named function signature of explicitly defined types like f(s STRING, i INT).
ExplicitTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Type strategy that returns a fixed DataType.
ExplicitTypeStrategy(DataType) - Constructor for class org.apache.flink.table.types.inference.strategies.ExplicitTypeStrategy
 
EXPR - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
Expression - Interface in org.apache.flink.table.expressions
General interface for all kinds of expressions.
ExpressionDefaultVisitor<T> - Class in org.apache.flink.table.expressions
Implementation of ExpressionVisitor that redirects all calls to ExpressionDefaultVisitor.defaultMethod(Expression).
ExpressionDefaultVisitor() - Constructor for class org.apache.flink.table.expressions.ExpressionDefaultVisitor
 
ExpressionParserException - Exception in org.apache.flink.table.api
Exception for all errors occurring during expression parsing.
ExpressionParserException(String) - Constructor for exception org.apache.flink.table.api.ExpressionParserException
 
ExpressionUtils - Class in org.apache.flink.table.expressions
Utility methods for working with Expressions.
ExpressionVisitor<R> - Interface in org.apache.flink.table.expressions
The visitor definition of Expression.
EXTRACT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
extractAssigningConstructor(Class<?>, List<Field>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Checks whether the given constructor takes all of the given fields with matching (possibly primitive) type and name.
extractDataType(Class<?>) - Static method in class org.apache.flink.table.types.utils.ClassDataTypeConverter
Returns the clearly identifiable data type if possible.
extractDataType(Object) - Static method in class org.apache.flink.table.types.utils.ValueDataTypeConverter
Returns the clearly identifiable data type if possible.
extractFromGeneric(DataTypeFactory, Class<?>, int, Type) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
Extracts a data type from a type variable at genericPos of baseClass using the information of the most specific type contextType.
extractFromMethodOutput(DataTypeFactory, Class<?>, Method) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
Extracts a data type from a method return type by considering surrounding classes and method annotation.
extractFromMethodParameter(DataTypeFactory, Class<?>, Method, int) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
Extracts a data type from a method parameter by considering surrounding classes and parameter annotation.
extractFromType(DataTypeFactory, Type) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
Extracts a data type from a type without considering surrounding classes or templates.
extractFromType(DataTypeFactory, DataTypeTemplate, Type) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
Extracts a data type from a type without considering surrounding classes but templates.
ExtractionUtils - Class in org.apache.flink.table.types.extraction
Utilities for performing reflection tasks.
ExtractionUtils.AssigningConstructor - Class in org.apache.flink.table.types.extraction
ExtractionVersion - Enum in org.apache.flink.table.annotation
Logical version that describes the expected behavior of the reflection-based data type extraction.
extractPartitionSpecFromPath(Path) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
Make partition spec from path.
extractPartitionValues(Path) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
Make partition values from path.
extractSimpleGeneric(Class<?>, Class<?>, int) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
A minimal version to extract a generic parameter from a given class.
extractValue(Expression, Class<V>) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
Extracts the value (excluding null) of a given class from an expression assuming it is a ValueLiteralExpression.

F

Factory - Interface in org.apache.flink.table.factories
Base interface for all kind of factories that create object instances from a list of key-value pairs in Flink's Table & SQL API.
factoryIdentifier() - Method in interface org.apache.flink.table.factories.CatalogFactory
 
factoryIdentifier() - Method in interface org.apache.flink.table.factories.Factory
Returns a unique identifier among same factory interfaces.
FactoryUtil - Class in org.apache.flink.table.factories
Utility for working with Factorys.
FactoryUtil.CatalogFactoryHelper - Class in org.apache.flink.table.factories
Helper utility for catalog implementations to validate options provided by CatalogFactory.
FactoryUtil.DefaultCatalogContext - Class in org.apache.flink.table.factories
Default implementation of CatalogFactory.Context.
FactoryUtil.DefaultDynamicTableContext - Class in org.apache.flink.table.factories
Default implementation of DynamicTableFactory.Context.
FactoryUtil.TableFactoryHelper - Class in org.apache.flink.table.factories
Helper utility for discovering formats and validating all options for a DynamicTableFactory.
FamilyArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for an argument that corresponds to a given LogicalTypeFamily and nullability.
FamilyArgumentTypeStrategy(LogicalTypeFamily, Boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
 
FIELD(String, DataType) - Static method in class org.apache.flink.table.api.DataTypes
Field definition with field name and data type.
FIELD(String, DataType, String) - Static method in class org.apache.flink.table.api.DataTypes
Field definition with field name, data type, and a description.
FIELD(String, AbstractDataType<?>) - Static method in class org.apache.flink.table.api.DataTypes
Unresolved field definition with field name and data type.
FIELD(String, AbstractDataType<?>, String) - Static method in class org.apache.flink.table.api.DataTypes
Unresolved field definition with field name, unresolved data type, and a description.
field(String, DataType) - Method in class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
Add a field with name and data type.
field(String, DataType, String) - Method in class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
Add a computed field which is generated by the given expression.
field(String, TypeInformation<?>) - Method in class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSchema.Builder.field(String, DataType) instead which uses the new type system based on DataTypes. 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.descriptors.Schema
Adds a field with the field name and the data type.
field(String, TypeInformation<?>) - Method in class org.apache.flink.table.descriptors.Schema
Deprecated.
This method will be removed in future versions as it uses the old type system. Please use Schema.field(String, DataType) instead.
field(String, String) - Method in class org.apache.flink.table.descriptors.Schema
Adds a field with the field name and the type string.
FIELD_FORMAT_NO_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.RowType.RowField
 
FIELD_FORMAT_NO_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
FIELD_FORMAT_WITH_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.RowType.RowField
 
FIELD_FORMAT_WITH_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
FieldComputer<T> - Interface in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use the concept of computed columns instead. See FLIP-95 for more information.
fieldIndex() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
FieldReferenceExpression - Class in org.apache.flink.table.expressions
A reference to a field in an input.
FieldReferenceExpression(String, DataType, int, int) - Constructor for class org.apache.flink.table.expressions.FieldReferenceExpression
 
fields(String[], DataType[]) - Method in class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
Add an array of fields with names and data types.
FieldsDataType - Class in org.apache.flink.table.types
A data type that contains field data types (i.e.
FieldsDataType(LogicalType, Class<?>, List<DataType>) - Constructor for class org.apache.flink.table.types.FieldsDataType
 
FieldsDataType(LogicalType, List<DataType>) - Constructor for class org.apache.flink.table.types.FieldsDataType
 
FileSystem - Class in org.apache.flink.table.descriptors
Connector descriptor for a file system.
FileSystem() - Constructor for class org.apache.flink.table.descriptors.FileSystem
 
FileSystemFormatFactory - Interface in org.apache.flink.table.factories
Deprecated.
This interface has been replaced by BulkReaderFormatFactory and BulkWriterFormatFactory.
FileSystemFormatFactory.ReaderContext - Interface in org.apache.flink.table.factories
Deprecated.
FileSystemValidator - Class in org.apache.flink.table.descriptors
Validator for FileSystem.
FileSystemValidator() - Constructor for class org.apache.flink.table.descriptors.FileSystemValidator
 
fillPartitionValueForRecord(String[], DataType[], int[], List<String>, Path, String) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
Extract partition value from path and fill to record.
FilterableTableSource<T> - Interface in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use SupportsFilterPushDown instead. See FLIP-95 for more information.
find(MemorySegment[], int, int, MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Find equal segments2 in segments1.
find(Class<T>, Descriptor) - Static method in class org.apache.flink.table.factories.TableFactoryService
Finds a table factory of the given class and descriptor.
find(Class<T>, Descriptor, ClassLoader) - Static method in class org.apache.flink.table.factories.TableFactoryService
Finds a table factory of the given class, descriptor, and classloader.
find(Class<T>, Map<String, String>) - Static method in class org.apache.flink.table.factories.TableFactoryService
Finds a table factory of the given class and property map.
find(Class<T>, Map<String, String>, ClassLoader) - Static method in class org.apache.flink.table.factories.TableFactoryService
Finds a table factory of the given class, property map, and classloader.
findAdditionDecimalType(int, int, int, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal addition operation.
findAll(Class<T>, Map<String, String>) - Static method in class org.apache.flink.table.factories.TableFactoryService
Finds all table factories of the given class and property map.
findAvgAggType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal average aggregation.
findCommonType(List<LogicalType>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Returns the most common, more general LogicalType for a given set of types.
findDivisionDecimalType(int, int, int, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal division operation.
findModuloDecimalType(int, int, int, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal modulo operation.
findMultiplicationDecimalType(int, int, int, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal multiplication operation.
findRoundDecimalType(int, int, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal rounding operation.
findSumAggType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal sum aggregation.
finish() - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
Constructs the given strategy.
finishWithVarying(InputTypeStrategy) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
Defines a common InputTypeStrategy for the next arguments.
first(TypeStrategy...) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the first type that could be inferred.
FirstTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Type strategy that returns the first type that could be inferred.
FirstTypeStrategy(List<? extends TypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
 
FLATTEN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
flattenToDataTypes(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Returns the data types of the flat representation in the first level of the given data type.
flattenToNames(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Returns the names of the flat representation in the first level of the given data type.
flattenToNames(DataType, List<String>) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Returns the names of the flat representation in the first level of the given data type.
FLINK_PROPERTY_PREFIX - Static variable in class org.apache.flink.table.catalog.CatalogPropertiesUtil
Globally reserved prefix for catalog properties.
FLOAT() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a 4-byte single precision floating point number.
FLOAT() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API float or SQL FLOAT/REAL type.
FloatType - Class in org.apache.flink.table.types.logical
Logical type of a 4-byte single precision floating point number.
FloatType(boolean) - Constructor for class org.apache.flink.table.types.logical.FloatType
 
FloatType() - Constructor for class org.apache.flink.table.types.logical.FloatType
 
FLOOR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
forAggregateFunction(DataTypeFactory, Class<? extends AggregateFunction<?, ?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
Extracts a type inference from a AggregateFunction.
forAsyncTableFunction(DataTypeFactory, Class<? extends AsyncTableFunction<?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
Extracts a type inference from a AsyncTableFunction.
Format - Interface in org.apache.flink.table.connector.format
Base interface for connector formats.
FORMAT - Static variable in class org.apache.flink.table.descriptors.FormatDescriptorValidator
Prefix for format-related properties.
FORMAT - Static variable in class org.apache.flink.table.factories.FactoryUtil
 
FORMAT - Static variable in class org.apache.flink.table.types.logical.ArrayType
 
FORMAT - Static variable in class org.apache.flink.table.types.logical.MapType
 
FORMAT - Static variable in class org.apache.flink.table.types.logical.MultisetType
 
FORMAT - Static variable in class org.apache.flink.table.types.logical.RawType
 
FORMAT - Static variable in class org.apache.flink.table.types.logical.RowType
 
FORMAT - Static variable in class org.apache.flink.table.types.logical.StructuredType
 
FORMAT_DERIVE_SCHEMA - Static variable in class org.apache.flink.table.descriptors.FormatDescriptorValidator
Key for deriving the schema of the format from the table's schema.
FORMAT_PROPERTY_VERSION - Static variable in class org.apache.flink.table.descriptors.FormatDescriptorValidator
Key for describing the property version.
FORMAT_SUFFIX - Static variable in class org.apache.flink.table.factories.FactoryUtil
Suffix for keys of ConfigOption in case a connector requires multiple formats (e.g.
FORMAT_TYPE - Static variable in class org.apache.flink.table.descriptors.FormatDescriptorValidator
Key for describing the type of the format.
FORMAT_VERSION - Static variable in class org.apache.flink.table.descriptors.FormatDescriptorValidator
Key for describing the version of the format.
FormatDescriptor - Class in org.apache.flink.table.descriptors
Describes the format of data.
FormatDescriptor(String, int) - Constructor for class org.apache.flink.table.descriptors.FormatDescriptor
Constructs a FormatDescriptor.
FormatDescriptorValidator - Class in org.apache.flink.table.descriptors
Validator for FormatDescriptor.
FormatDescriptorValidator() - Constructor for class org.apache.flink.table.descriptors.FormatDescriptorValidator
 
forScalarFunction(DataTypeFactory, Class<? extends ScalarFunction>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
Extracts a type inference from a ScalarFunction.
forTableAggregateFunction(DataTypeFactory, Class<? extends TableAggregateFunction<?, ?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
Extracts a type inference from a TableAggregateFunction.
forTableFunction(DataTypeFactory, Class<? extends TableFunction<?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
Extracts a type inference from a TableFunction.
FROM - Static variable in class org.apache.flink.table.descriptors.FunctionDescriptorValidator
 
from(String) - Method in class org.apache.flink.table.descriptors.Schema
Specifies the origin of the previously defined field.
from(int) - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
 
FROM_BASE64 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
FROM_VALUE_CLASS - Static variable in class org.apache.flink.table.descriptors.FunctionDescriptorValidator
 
FROM_VALUE_PYTHON - Static variable in class org.apache.flink.table.descriptors.FunctionDescriptorValidator
 
fromAddress(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
Creates a BinaryStringData instance from the given address (base and offset) and length.
fromBigDecimal(BigDecimal, int, int) - Static method in class org.apache.flink.table.data.DecimalData
Creates an instance of DecimalData from a BigDecimal and the given precision and scale.
fromBytes(byte[]) - Static method in class org.apache.flink.table.data.binary.BinaryRawValueData
Creates a BinaryStringData instance from the given bytes.
fromBytes(byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinaryRawValueData
Creates a BinaryStringData instance from the given bytes with offset and number of bytes.
fromBytes(byte[]) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
Creates a BinaryStringData instance from the given UTF-8 bytes.
fromBytes(byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
Creates a BinaryStringData instance from the given UTF-8 bytes with offset and number of bytes.
fromBytes(byte[]) - Static method in interface org.apache.flink.table.data.RawValueData
Creates an instance of RawValueData from the given byte array.
fromBytes(byte[]) - Static method in interface org.apache.flink.table.data.StringData
Creates an instance of StringData from the given UTF-8 byte array.
fromBytes(byte[], int, int) - Static method in interface org.apache.flink.table.data.StringData
Creates an instance of StringData from the given UTF-8 byte array with offset and number of bytes.
fromClass(ClassInstance) - Method in class org.apache.flink.table.descriptors.FunctionDescriptor
Creates a function from a class description.
fromClassToDataType(Class<?>) - Static method in class org.apache.flink.table.types.utils.TypeConversions
 
fromColumns(List<Schema.UnresolvedColumn>) - Method in class org.apache.flink.table.api.Schema.Builder
Adopts all columns from the given list.
fromDataToLogicalType(DataType) - Static method in class org.apache.flink.table.types.utils.TypeConversions
 
fromDataToLogicalType(DataType[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
 
fromDataTypeToLegacyInfo(DataType) - Static method in class org.apache.flink.table.types.utils.TypeConversions
Deprecated.
Please don't use this method anymore. It will be removed soon and we should not make the removal more painful.
fromDataTypeToLegacyInfo(DataType[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
Deprecated.
Please don't use this method anymore. It will be removed soon and we should not make the removal more painful.
fromEpochMillis(long) - Static method in class org.apache.flink.table.data.TimestampData
Creates an instance of TimestampData from milliseconds.
fromEpochMillis(long, int) - Static method in class org.apache.flink.table.data.TimestampData
Creates an instance of TimestampData from milliseconds and a nanos-of-millisecond.
fromFields(String[], AbstractDataType<?>[]) - Method in class org.apache.flink.table.api.Schema.Builder
Adopts the given field names and field data types as physical columns of the schema.
fromFields(List<String>, List<? extends AbstractDataType<?>>) - Method in class org.apache.flink.table.api.Schema.Builder
Adopts the given field names and field data types as physical columns of the schema.
fromInstant(Instant) - Static method in class org.apache.flink.table.data.TimestampData
Creates an instance of TimestampData from an instance of Instant.
fromLegacyInfoToDataType(TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.TypeConversions
Deprecated.
Please don't use this method anymore. It will be removed soon and we should not make the removal more painful.
fromLegacyInfoToDataType(TypeInformation<?>[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
Deprecated.
Please don't use this method anymore. It will be removed soon and we should not make the removal more painful.
fromLocalDateTime(LocalDateTime) - Static method in class org.apache.flink.table.data.TimestampData
Creates an instance of TimestampData from an instance of LocalDateTime.
fromLogicalToDataType(LogicalType) - Static method in class org.apache.flink.table.types.utils.TypeConversions
 
fromLogicalToDataType(LogicalType[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
 
fromObject(T) - Static method in class org.apache.flink.table.data.binary.BinaryRawValueData
Creates a BinaryRawValueData instance from the given Java object.
fromObject(T) - Static method in interface org.apache.flink.table.data.RawValueData
Creates an instance of RawValueData from a Java object.
fromPrimitiveArray(boolean[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(byte[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(short[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(int[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(long[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(float[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(double[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
 
fromProperties(Map<String, String>) - Static method in interface org.apache.flink.table.catalog.CatalogTable
Creates an instance of CatalogTable from a map of string properties that were previously created with ResolvedCatalogTable.toProperties().
fromResolvedSchema(ResolvedSchema) - Method in class org.apache.flink.table.api.Schema.Builder
Adopts all members from the given resolved schema.
fromResolvedSchema(ResolvedSchema) - Static method in class org.apache.flink.table.api.TableSchema
Deprecated.
Helps to migrate to the new ResolvedSchema to old API methods.
fromRowDataType(DataType) - Method in class org.apache.flink.table.api.Schema.Builder
Adopts all fields of the given row as physical columns of the schema.
fromSchema(Schema) - Method in class org.apache.flink.table.api.Schema.Builder
Adopts all members from the given unresolved schema.
fromString(String) - Static method in class org.apache.flink.table.catalog.ObjectPath
 
fromString(String) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
Creates a BinaryStringData instance from the given Java string.
fromString(String) - Static method in interface org.apache.flink.table.data.StringData
Creates an instance of StringData from the given String.
fromTimestamp(Timestamp) - Static method in class org.apache.flink.table.data.TimestampData
Creates an instance of TimestampData from an instance of Timestamp.
fromTypeInfo(TypeInformation<?>) - Static method in class org.apache.flink.table.api.TableSchema
Deprecated.
This method will be removed soon. Use DataTypes to declare types.
fromUnscaledBytes(byte[], int, int) - Static method in class org.apache.flink.table.data.DecimalData
Creates an instance of DecimalData from an unscaled byte array value and the given precision and scale.
fromUnscaledLong(long, int, int) - Static method in class org.apache.flink.table.data.DecimalData
Creates an instance of DecimalData from an unscaled long value and the given precision and scale.
FULLY_QUALIFIED_NAME - Static variable in class org.apache.flink.table.descriptors.PythonFunctionValidator
 
FunctionAlreadyExistException - Exception in org.apache.flink.table.catalog.exceptions
Exception for trying to create a function that already exists.
FunctionAlreadyExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.FunctionAlreadyExistException
 
FunctionAlreadyExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.FunctionAlreadyExistException
 
FunctionContext - Class in org.apache.flink.table.functions
A FunctionContext allows to obtain global runtime information about the context in which the user-defined function is executed.
FunctionContext(RuntimeContext) - Constructor for class org.apache.flink.table.functions.FunctionContext
Wraps the underlying RuntimeContext.
FunctionDefinition - Interface in org.apache.flink.table.functions
Definition of a function.
FunctionDefinitionFactory - Interface in org.apache.flink.table.factories
A factory to create FunctionDefinition.
FunctionDescriptor - Class in org.apache.flink.table.descriptors
Descriptor for describing a function.
FunctionDescriptor() - Constructor for class org.apache.flink.table.descriptors.FunctionDescriptor
 
FunctionDescriptorValidator - Class in org.apache.flink.table.descriptors
Validator for FunctionDescriptor.
FunctionDescriptorValidator() - Constructor for class org.apache.flink.table.descriptors.FunctionDescriptorValidator
 
functionExists(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
Check whether a function exists or not.
FunctionHint - Annotation Type in org.apache.flink.table.annotation
A hint that influences the reflection-based extraction of input types, accumulator types, and output types for constructing the TypeInference logic of a UserDefinedFunction.
FunctionHints - Annotation Type in org.apache.flink.table.annotation
Helper annotation for repeatable FunctionHints.
FunctionIdentifier - Class in org.apache.flink.table.functions
Identifies a system function with function name or a catalog function with a fully qualified identifier.
functionIdentifier() - Method in class org.apache.flink.table.functions.UserDefinedFunction
Returns a unique, serialized representation for this function.
FunctionKind - Enum in org.apache.flink.table.functions
Categorizes the semantics of a FunctionDefinition.
FunctionLanguage - Enum in org.apache.flink.table.catalog
Categorizes the language semantics of a CatalogFunction.
FunctionNotExistException - Exception in org.apache.flink.table.catalog.exceptions
Exception for trying to operate on a function that doesn't exist.
FunctionNotExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.FunctionNotExistException
 
FunctionNotExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.FunctionNotExistException
 
FunctionRequirement - Enum in org.apache.flink.table.functions
Characteristics that a FunctionDefinition requires.
FunctionService - Class in org.apache.flink.table.functions
Service for creating configured instances of UserDefinedFunction using a FunctionDescriptor.
FunctionService() - Constructor for class org.apache.flink.table.functions.FunctionService
 

G

genBorderLine(int[]) - Static method in class org.apache.flink.table.utils.PrintUtils
 
generatePartitionPath(LinkedHashMap<String, String>) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
Make partition path from partition spec.
generateRuntimeName(Class<?>, String[]) - Static method in class org.apache.flink.table.util.TableConnectorUtil
Deprecated.
Returns the table connector name used for log and web UI.
generateRuntimeName(Class<?>, String[]) - Static method in class org.apache.flink.table.utils.TableConnectorUtils
Returns the table connector name used for logging and web UI.
generateSignature(TypeInference, String, FunctionDefinition) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
Generates a signature of the given FunctionDefinition.
GenericArrayData - Class in org.apache.flink.table.data
An internal data structure representing data of ArrayType.
GenericArrayData(Object[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
Creates an instance of GenericArrayData using the given Java array.
GenericArrayData(int[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(long[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(float[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(double[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(short[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(byte[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(boolean[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
 
GenericMapData - Class in org.apache.flink.table.data
An internal data structure representing data of MapType or MultisetType.
GenericMapData(Map<?, ?>) - Constructor for class org.apache.flink.table.data.GenericMapData
Creates an instance of GenericMapData using the given Java map.
GenericRowData - Class in org.apache.flink.table.data
An internal data structure representing data of RowType and other (possibly nested) structured types such as StructuredType.
GenericRowData(RowKind, int) - Constructor for class org.apache.flink.table.data.GenericRowData
Creates an instance of GenericRowData with given kind and number of fields.
GenericRowData(int) - Constructor for class org.apache.flink.table.data.GenericRowData
Creates an instance of GenericRowData with given number of fields.
get() - Method in class org.apache.flink.table.api.dataview.ListView
Returns an iterable of the list view.
get(K) - Method in class org.apache.flink.table.api.dataview.MapView
Return the value for the specified key or null if the key is not in the map view.
get(Object) - Method in class org.apache.flink.table.data.GenericMapData
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
GET - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
GET - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns a type of a field nested inside a composite type that is described by the second argument.
get(K) - Method in class org.apache.flink.table.utils.ThreadLocalCache
 
getAbstractDataType() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
 
getAbstractDataType() - Method in class org.apache.flink.table.api.DataTypes.Field
 
getAbstractDataType() - Method in class org.apache.flink.table.api.DataTypes.UnresolvedField
 
getAcceptedFilters() - Method in class org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown.Result
 
getAccessedFields(TimestampExtractor, DataType, Function<String, String>) - Static method in class org.apache.flink.table.sources.tsextractors.TimestampExtractorUtils
Retrieves all field accesses needed for the given TimestampExtractor.
getAccumulatorDataType() - Method in class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.ImperativeAggregateFunction
Deprecated.
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getAccumulatorType() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getAccumulatorTypeInfo() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
getAccumulatorTypeInfo() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
getAccumulatorTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getAccumulatorTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>, TypeInformation<ACC>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getAccumulatorTypeStrategy() - Method in class org.apache.flink.table.types.inference.TypeInference
 
getAggregateFunction() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
getArgs() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
getArgumentCount() - Method in interface org.apache.flink.table.types.inference.InputTypeStrategy
Initial input validation based on the number of arguments.
getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.CastInputTypeStrategy
 
getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.CommonInputTypeStrategy
 
getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
 
getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.MapInputTypeStrategy
 
getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
 
getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
 
getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy
 
getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
 
getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
getArgumentDataTypes() - Method in interface org.apache.flink.table.types.inference.CallContext
Returns a resolved list of the call's argument types.
getArgumentDataTypes() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
getArgumentDataTypes() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
 
getArgumentFields() - Method in interface org.apache.flink.table.sources.FieldComputer
Deprecated.
Returns the names of all fields that the expression of the field computer accesses.
getArguments() - Method in class org.apache.flink.table.types.inference.Signature
 
getArgumentValue(int, Class<T>) - Method in interface org.apache.flink.table.types.inference.CallContext
Returns the literal value of the argument at the given position, given that the argument is a literal, is not null, and can be expressed as an instance of the provided class.
getArgumentValue(int, Class<T>) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
getArgumentValue(int, Class<T>) - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
 
getArity() - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getArity() - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getArity() - Method in class org.apache.flink.table.data.GenericRowData
 
getArity() - Method in interface org.apache.flink.table.data.RowData
Returns the number of fields in this row.
getArity() - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getArity() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
getArity() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
getArity() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
getArray(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the array value at the given position.
getArray(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getArray(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getArray(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getArray(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getArray(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getArray(int) - Method in interface org.apache.flink.table.data.RowData
Returns the array value at the given position.
getArray(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getArray(String, Function<String, E>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns all array elements under a given existing key.
getAsyncLookupFunction(String[]) - Method in interface org.apache.flink.table.sources.LookupableTableSource
Deprecated.
Gets the AsyncTableFunction which supports async lookup one key at a time.
getAtomicName(List<String>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
Returns a unique name for an atomic type.
getAttributeName() - Method in class org.apache.flink.table.sources.RowtimeAttributeDescriptor
Deprecated.
Returns the name of the rowtime attribute.
getAttributes() - Method in class org.apache.flink.table.types.logical.StructuredType
 
getAvgLen() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
getAvgLength() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
 
getAvgLength() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
 
getBigDecimal(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a big decimal value under the given existing key.
getBinary(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the binary value at the given position.
getBinary(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getBinary(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getBinary(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getBinary(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getBinary(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getBinary(int) - Method in interface org.apache.flink.table.data.RowData
Returns the binary value at the given position.
getBinary(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getBinarySection() - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
 
getBoolean(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the boolean value at the given position.
getBoolean(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getBoolean(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getBoolean(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
get boolean from segments.
getBoolean(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getBoolean(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getBoolean(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getBoolean(int) - Method in interface org.apache.flink.table.data.RowData
Returns the boolean value at the given position.
getBoolean(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getBoolean(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a boolean value under the given existing key.
getBuiltInClassLoader() - Method in interface org.apache.flink.table.functions.SpecializedFunction.SpecializedContext
Returns the classloader used to resolve built-in functions.
getByte(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the byte value at the given position.
getByte(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getByte(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getByte(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
get byte from segments.
getByte(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getByte(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getByte(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getByte(int) - Method in interface org.apache.flink.table.data.RowData
Returns the byte value at the given position.
getByte(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getByte(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a byte value under the given existing key.
getBytes(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Maybe not copied, if want copy, please use copyTo.
getCachedFile(String) - Method in class org.apache.flink.table.functions.ConstantFunctionContext
 
getCachedFile(String) - Method in class org.apache.flink.table.functions.FunctionContext
Gets the local temporary file copy of a distributed cache files.
getCallContext() - Method in interface org.apache.flink.table.functions.SpecializedFunction.SpecializedContext
Returns the context of the current call.
getCatalogName() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
 
getCatalogName() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
 
getCatalogTable() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
Returns the resolved table information received from the Catalog.
getCatalogTable() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
getChangelogMode() - Method in interface org.apache.flink.table.connector.format.Format
Returns the set of changes that a connector (and transitively the planner) can expect during runtime.
getChangelogMode(ChangelogMode) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
Returns the set of changes that the sink accepts during runtime.
getChangelogMode() - Method in interface org.apache.flink.table.connector.source.ScanTableSource
Returns the set of changes that the planner can expect during runtime.
getCharacter(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a character value under the given existing key.
getChildren() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
getChildren() - Method in class org.apache.flink.table.expressions.CallExpression
 
getChildren() - Method in interface org.apache.flink.table.expressions.Expression
 
getChildren() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
getChildren() - Method in class org.apache.flink.table.expressions.SqlCallExpression
 
getChildren() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
 
getChildren() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
getChildren() - Method in class org.apache.flink.table.types.AtomicDataType
 
getChildren() - Method in class org.apache.flink.table.types.CollectionDataType
 
getChildren() - Method in class org.apache.flink.table.types.DataType
 
getChildren() - Method in class org.apache.flink.table.types.FieldsDataType
 
getChildren() - Method in class org.apache.flink.table.types.KeyValueDataType
 
getChildren() - Method in class org.apache.flink.table.types.logical.ArrayType
 
getChildren() - Method in class org.apache.flink.table.types.logical.BigIntType
 
getChildren() - Method in class org.apache.flink.table.types.logical.BinaryType
 
getChildren() - Method in class org.apache.flink.table.types.logical.BooleanType
 
getChildren() - Method in class org.apache.flink.table.types.logical.CharType
 
getChildren() - Method in class org.apache.flink.table.types.logical.DateType
 
getChildren() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
getChildren() - Method in class org.apache.flink.table.types.logical.DecimalType
 
getChildren() - Method in class org.apache.flink.table.types.logical.DistinctType
 
getChildren() - Method in class org.apache.flink.table.types.logical.DoubleType
 
getChildren() - Method in class org.apache.flink.table.types.logical.FloatType
 
getChildren() - Method in class org.apache.flink.table.types.logical.IntType
 
getChildren() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
getChildren() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
getChildren() - Method in class org.apache.flink.table.types.logical.LogicalType
 
getChildren() - Method in class org.apache.flink.table.types.logical.MapType
 
getChildren() - Method in class org.apache.flink.table.types.logical.MultisetType
 
getChildren() - Method in class org.apache.flink.table.types.logical.NullType
 
getChildren() - Method in class org.apache.flink.table.types.logical.RawType
 
getChildren() - Method in class org.apache.flink.table.types.logical.RowType
 
getChildren() - Method in class org.apache.flink.table.types.logical.SmallIntType
 
getChildren() - Method in class org.apache.flink.table.types.logical.StructuredType
 
getChildren() - Method in class org.apache.flink.table.types.logical.SymbolType
 
getChildren() - Method in class org.apache.flink.table.types.logical.TimestampType
 
getChildren() - Method in class org.apache.flink.table.types.logical.TimeType
 
getChildren() - Method in class org.apache.flink.table.types.logical.TinyIntType
 
getChildren() - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
getChildren() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
getChildren() - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
getChildren() - Method in class org.apache.flink.table.types.logical.VarCharType
 
getChildren() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
getChildren() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
getClass(String, Class<T>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a class value under the given existing key.
getClassLoader() - Method in interface org.apache.flink.table.connector.RuntimeConverter.Context
Runtime classloader for loading user-defined classes.
getClassLoader() - Method in interface org.apache.flink.table.factories.CatalogFactory.Context
Returns the class loader of the current session.
getClassLoader() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
Returns the class loader of the current session.
getClassLoader() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
 
getClassLoader() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
getClassName() - Method in interface org.apache.flink.table.catalog.CatalogFunction
Get the full name of the class backing the function.
getColumn(int) - Method in class org.apache.flink.table.catalog.ResolvedSchema
Returns the Column instance for the given column index.
getColumn(String) - Method in class org.apache.flink.table.catalog.ResolvedSchema
Returns the Column instance for the given column name.
getColumnCount() - Method in class org.apache.flink.table.catalog.ResolvedSchema
Returns the number of Columns of this schema.
getColumnDataTypes() - Method in class org.apache.flink.table.catalog.ResolvedSchema
Returns all column data types.
getColumnName() - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
 
getColumnNames() - Method in class org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
 
getColumnNames() - Method in class org.apache.flink.table.catalog.ResolvedSchema
Returns all column names.
getColumns() - Method in class org.apache.flink.table.api.constraints.UniqueConstraint
Deprecated.
List of column names for which the primary key was defined.
getColumns() - Method in class org.apache.flink.table.api.Schema
 
getColumns() - Method in class org.apache.flink.table.catalog.ResolvedSchema
Returns all Columns of this schema.
getColumns() - Method in class org.apache.flink.table.catalog.UniqueConstraint
List of column names for which the primary key was defined.
getColumnStatisticsData() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
 
getColumnStats() - Method in class org.apache.flink.table.plan.stats.TableStats
 
getComment() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
Get comment of the table or view.
getComment() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
Get comment of the database.
getComment() - Method in interface org.apache.flink.table.catalog.CatalogPartition
Get comment of the partition.
getComment() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
getComment() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
 
getComparision() - Method in class org.apache.flink.table.types.logical.StructuredType
 
getConfiguration() - Method in interface org.apache.flink.table.factories.CatalogFactory.Context
Gives read-only access to the configuration of the current session.
getConfiguration() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
Gives read-only access to the configuration of the current session.
getConfiguration() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
 
getConfiguration() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
getConfiguration() - Method in interface org.apache.flink.table.factories.TableSinkFactory.Context
 
getConfiguration() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
getConfiguration() - Method in interface org.apache.flink.table.factories.TableSourceFactory.Context
 
getConfiguration() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
 
getConfiguration() - Method in interface org.apache.flink.table.functions.SpecializedFunction.SpecializedContext
Gives read-only access to the configuration of the current session.
getConstraintName() - Method in class org.apache.flink.table.api.Schema.UnresolvedConstraint
 
getConsumedDataType() - Method in interface org.apache.flink.table.sinks.TableSink
Deprecated.
Returns the data type consumed by this TableSink.
getContainedKinds() - Method in class org.apache.flink.table.connector.ChangelogMode
 
getConversionClass() - Method in class org.apache.flink.table.types.DataType
Returns the corresponding conversion class for representing values.
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.dataview.ListViewSerializerSnapshot
Deprecated.
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.dataview.MapViewSerializerSnapshot
Deprecated.
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
Deprecated.
 
getDatabase(String) - Method in interface org.apache.flink.table.catalog.Catalog
Get a database from this catalog.
getDatabaseName() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
 
getDatabaseName() - Method in class org.apache.flink.table.catalog.ObjectPath
 
getDatabaseName() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
 
getDataType() - Method in class org.apache.flink.table.api.DataTypes.Field
 
getDataType() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
 
getDataType() - Method in class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
 
getDataType() - Method in class org.apache.flink.table.catalog.Column
Returns the data type of this column.
getDataType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns the DataType under the given existing key.
getDataType() - Method in interface org.apache.flink.table.types.DataTypeQueryable
 
getDataType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
getDataTypeFactory() - Method in interface org.apache.flink.table.types.inference.CallContext
Enables to lookup types in a catalog and resolve RAW types.
getDataTypeFactory() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
getDataTypeFactory() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
 
getDayPrecision() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
getDayPrecision(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
getDaysSinceEpoch() - Method in class org.apache.flink.table.catalog.stats.Date
 
getDecimal(int, int, int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the decimal value at the given position.
getDecimal(int, int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getDecimal(int, int, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getDecimal(int, int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getDecimal(int, int, int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getDecimal(int, int, int) - Method in class org.apache.flink.table.data.GenericRowData
 
getDecimal(int, int, int) - Method in interface org.apache.flink.table.data.RowData
Returns the decimal value at the given position.
getDecimal(int, int, int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.ArrayType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.BigIntType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.BinaryType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.BooleanType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.CharType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DateType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DecimalType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DistinctType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DoubleType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.FloatType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.IntType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.LogicalType
Returns the default conversion class.
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.MapType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.MultisetType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.NullType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.RawType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.RowType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.SmallIntType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.StructuredType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.SymbolType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TimestampType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TimeType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TinyIntType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.VarCharType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
getDefaultDatabase() - Method in class org.apache.flink.table.catalog.AbstractCatalog
 
getDefaultDatabase() - Method in interface org.apache.flink.table.catalog.Catalog
Get the name of the default database for this catalog.
getDefaultPartName() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
The default partition name in case the dynamic partition column value is null/empty string.
getDefinitions() - Static method in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
getDescription() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
 
getDescription() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
Get a brief description of the table or view.
getDescription() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
Get a brief description of the database.
getDescription() - Method in interface org.apache.flink.table.catalog.CatalogFunction
Get a brief description of the function.
getDescription() - Method in interface org.apache.flink.table.catalog.CatalogPartition
Get a brief description of the database.
getDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
getDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
 
getDescription() - Method in class org.apache.flink.table.types.logical.RowType.RowField
 
getDescription() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
getDescription() - Method in class org.apache.flink.table.types.logical.UserDefinedType
 
getDetailedDescription() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
Get a detailed description of the table or view.
getDetailedDescription() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
Get a detailed description of the database.
getDetailedDescription() - Method in interface org.apache.flink.table.catalog.CatalogFunction
Get a detailed description of the function.
getDetailedDescription() - Method in interface org.apache.flink.table.catalog.CatalogPartition
Get a detailed description of the database.
getDetailedDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
getDetailedDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
 
getDouble(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the double value at the given position.
getDouble(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getDouble(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getDouble(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
get double from segments.
getDouble(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getDouble(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getDouble(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getDouble(int) - Method in interface org.apache.flink.table.data.RowData
Returns the double value at the given position.
getDouble(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getDouble(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a double value under the given existing key.
getDuration(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a java Duration under the given existing key.
getElementDataType() - Method in class org.apache.flink.table.types.CollectionDataType
 
getElementOrNull(ArrayData, int) - Method in interface org.apache.flink.table.data.ArrayData.ElementGetter
 
getElementType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
getElementType() - Method in class org.apache.flink.table.types.logical.ArrayType
 
getElementType() - Method in class org.apache.flink.table.types.logical.MultisetType
 
getExecType() - Method in class org.apache.flink.table.functions.python.PythonEnv
 
getExpandedQuery() - Method in interface org.apache.flink.table.catalog.CatalogView
Expanded text of the original view definition This is needed because the context such as current DB is lost after the session, in which view is defined, is gone.
getExpandedQuery() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
 
getExpectedArgument(FunctionDefinition, int) - Method in interface org.apache.flink.table.types.inference.ArgumentTypeStrategy
Returns a summary of the function's expected argument at argumentPos.
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.CommonArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.CompositeArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
 
getExpectedArgumentTypes() - Method in class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
 
getExpectedSignatures(FunctionDefinition) - Method in interface org.apache.flink.table.types.inference.InputTypeStrategy
Returns a summary of the function's expected signatures.
getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.CastInputTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.CommonInputTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.MapInputTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
getExpression() - Method in class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
 
getExpression() - Method in class org.apache.flink.table.api.TableColumn.ComputedColumn
Deprecated.
 
getExpression() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
 
getExpression(ResolvedFieldReference[]) - Method in interface org.apache.flink.table.sources.FieldComputer
Deprecated.
Returns the Expression that computes the value of the field.
getExternalResourceInfos(String) - Method in class org.apache.flink.table.functions.ConstantFunctionContext
 
getExternalResourceInfos(String) - Method in class org.apache.flink.table.functions.FunctionContext
Get the external resource information.
getFactory() - Method in interface org.apache.flink.table.catalog.Catalog
Returns a factory for creating instances from catalog objects.
getFalseCount() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
 
getFamilies() - Method in enum org.apache.flink.table.types.logical.LogicalTypeRoot
 
getField(int) - Method in class org.apache.flink.table.data.GenericRowData
Returns the field value at the given position.
getField(DataType, int) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Retrieves a nested field from a composite type at given position.
getField(DataType, String) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Retrieves a nested field from a composite type with given name.
getFieldCount() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns the number of fields.
getFieldCount() - Method in class org.apache.flink.table.types.logical.RowType
 
getFieldCount(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Returns the field count of row and structured types.
getFieldDataType(int) - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns the specified data type for the given field index.
getFieldDataType(String) - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns the specified data type for the given field name.
getFieldDataTypes() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns all field data types as an array.
getFieldIndex() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
getFieldIndex(String) - Method in class org.apache.flink.table.types.logical.RowType
 
getFieldMapping() - Method in interface org.apache.flink.table.sources.DefinedFieldMapping
Deprecated.
Returns the mapping for the fields of the TableSource's TableSchema to the fields of its produced DataType.
getFieldName(int) - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns the specified name for the given field index.
getFieldNames() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns all field names as an array.
getFieldNames() - Method in interface org.apache.flink.table.sinks.TableSink
Deprecated.
Use the field names of TableSink.getTableSchema() instead.
getFieldNames() - Method in class org.apache.flink.table.sinks.TableSinkBase
Returns the field names of the table to emit.
getFieldNames() - Method in class org.apache.flink.table.types.logical.RowType
 
getFieldNames(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Returns the field names of row and structured types.
getFieldOrNull(RowData) - Method in interface org.apache.flink.table.data.RowData.FieldGetter
 
getFields() - Method in class org.apache.flink.table.types.logical.RowType
 
getFieldType(int) - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSchema.getFieldDataType(int) instead which uses the new type system based on DataTypes. 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.
getFieldType(String) - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSchema.getFieldDataType(String) instead which uses the new type system based on DataTypes. 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.
getFieldTypes() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSchema.getFieldDataTypes() instead which uses the new type system based on DataTypes. 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.
getFieldTypes() - Method in interface org.apache.flink.table.sinks.TableSink
Deprecated.
Use the field types of TableSink.getTableSchema() instead.
getFieldTypes() - Method in class org.apache.flink.table.sinks.TableSinkBase
Returns the field types of the table to emit.
getFieldTypes(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Returns the field types of row and structured types.
getFileCount() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
getFilterArg() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunctionInfo
 
getFilterExpression() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
getFixedIndexedProperties(String, List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns the property keys of fixed indexed properties.
getFixedLengthPartSize() - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getFloat(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the float value at the given position.
getFloat(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getFloat(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getFloat(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
get float from segments.
getFloat(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getFloat(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getFloat(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getFloat(int) - Method in interface org.apache.flink.table.data.RowData
Returns the float value at the given position.
getFloat(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getFloat(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a float value under the given given existing key.
getFormatFieldNames() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
Get field names without partition keys.
getFormatFieldTypes() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
Get field types without partition keys.
getFormatOptions() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
Options of this format.
getFormatProjectFields() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
Mapping from non-partition project fields index to all project fields index.
getFormatRowType() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
RowType of table that excludes partition key fields.
getFractionalPrecision() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
getFractionalPrecision(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
getFullName() - Method in class org.apache.flink.table.catalog.ObjectPath
 
getFunction(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
Get the function.
getFunctionDefinition() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
getFunctionDefinition() - Method in class org.apache.flink.table.expressions.CallExpression
 
getFunctionDefinition(String) - Method in class org.apache.flink.table.module.CoreModule
 
getFunctionDefinition(String) - Method in interface org.apache.flink.table.module.Module
Get an optional of FunctionDefinition by a given name.
getFunctionDefinition() - Method in interface org.apache.flink.table.types.inference.CallContext
Returns the function definition that defines the function currently being called.
getFunctionDefinition() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
getFunctionDefinition() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
 
getFunctionDefinitionFactory() - Method in interface org.apache.flink.table.catalog.Catalog
Get an optional FunctionDefinitionFactory instance that's responsible for instantiating function definitions.
getFunctionIdentifier() - Method in class org.apache.flink.table.expressions.CallExpression
 
getFunctionLanguage() - Method in interface org.apache.flink.table.catalog.CatalogFunction
Get the language used for the definition of function.
getFunctionName() - Method in class org.apache.flink.table.expressions.CallExpression
Returns a string representation of the call's function for logging or printing to a console.
getIdentifier() - Method in class org.apache.flink.table.functions.FunctionIdentifier
 
getImplementationClass() - Method in class org.apache.flink.table.types.logical.StructuredType
 
getIndexedProperty(String, String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns all properties under a given key that contains an index in between.
getInputIndex() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
getInputs() - Method in class org.apache.flink.table.functions.python.PythonFunctionInfo
 
getInputTypeStrategy() - Method in class org.apache.flink.table.types.inference.TypeInference
 
getInt(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the integer value at the given position.
getInt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getInt(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getInt(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
get int from segments.
getInt(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getInt(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getInt(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getInt(int) - Method in interface org.apache.flink.table.data.RowData
Returns the integer value at the given position.
getInt(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getInt(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns an integer value under the given existing key.
getJavaObject() - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
 
getJobParameter(String, String) - Method in class org.apache.flink.table.functions.ConstantFunctionContext
 
getJobParameter(String, String) - Method in class org.apache.flink.table.functions.FunctionContext
Gets the global job parameter value associated with the given key as a string.
getKeyDataType() - Method in class org.apache.flink.table.types.KeyValueDataType
 
getKeys() - Method in interface org.apache.flink.table.connector.source.LookupTableSource.LookupContext
Returns an array of key index paths that should be used during the lookup.
getKeySerializer() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
getKeyType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
getKeyType() - Method in class org.apache.flink.table.types.logical.MapType
 
getKind() - Method in class org.apache.flink.table.functions.AggregateFunction
 
getKind() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
getKind() - Method in class org.apache.flink.table.functions.AsyncTableFunction
 
getKind() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
 
getKind() - Method in interface org.apache.flink.table.functions.FunctionDefinition
Returns the kind of function this definition describes.
getKind() - Method in class org.apache.flink.table.functions.ScalarFunction
 
getKind() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
 
getKind() - Method in class org.apache.flink.table.functions.TableAggregateFunction
 
getKind() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
getKind() - Method in class org.apache.flink.table.functions.TableFunction
 
getKind() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
getKind() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
getKind() - Method in class org.apache.flink.table.types.logical.TimestampType
 
getKind() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
getLength() - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
getLength() - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
getLength() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
getLength() - Method in class org.apache.flink.table.dataview.NullSerializer
 
getLength() - Method in class org.apache.flink.table.types.logical.BinaryType
 
getLength() - Method in class org.apache.flink.table.types.logical.CharType
 
getLength(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
getLength() - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
getLength() - Method in class org.apache.flink.table.types.logical.VarCharType
 
getList() - Method in class org.apache.flink.table.api.dataview.ListView
Returns the entire view's content as an instance of List.
getListSerializer() - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
getLogicalType() - Method in class org.apache.flink.table.types.DataType
Returns the corresponding logical type.
getLong(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the long value at the given position.
getLong(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getLong(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getLong(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
get long from segments.
getLong(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getLong(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getLong(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getLong(int) - Method in interface org.apache.flink.table.data.RowData
Returns the long value at the given position.
getLong(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getLong(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a long value under the given existing key.
getLookupFunction(String[]) - Method in interface org.apache.flink.table.sources.LookupableTableSource
Deprecated.
Gets the TableFunction which supports lookup one key at a time.
getLookupRuntimeProvider(LookupTableSource.LookupContext) - Method in interface org.apache.flink.table.connector.source.LookupTableSource
Returns a provider of runtime implementation for reading the data.
getMap() - Method in class org.apache.flink.table.api.dataview.MapView
Returns the entire view's content as an instance of Map.
getMap(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the map value at the given position.
getMap(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getMap(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getMap(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getMap(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getMap(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getMap(int) - Method in interface org.apache.flink.table.data.RowData
Returns the map value at the given position.
getMap(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getMapSerializer() - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
getMax() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
 
getMax() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
 
getMax() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
 
getMax() - Method in class org.apache.flink.table.plan.stats.ColumnStats
Returns null if this instance is constructed by ColumnStats(Long, Long, Double, Integer, Number, Number).
getMaxCount() - Method in interface org.apache.flink.table.types.inference.ArgumentCount
Returns the maximum number of argument (inclusive) that a function can take.
getMaxCount() - Method in class org.apache.flink.table.types.inference.ConstantArgumentCount
 
getMaxLen() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
getMaxLength() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
 
getMaxLength() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
 
getMaxValue() - Method in class org.apache.flink.table.plan.stats.ColumnStats
Deprecated.
getMemorySize(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a Flink MemorySize under the given existing key.
getMessage() - Method in exception org.apache.flink.table.api.AmbiguousTableFactoryException
 
getMessage() - Method in exception org.apache.flink.table.api.NoMatchingTableFactoryException
 
getMetadataAlias() - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
Deprecated.
 
getMetadataKey() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
 
getMetadataKey() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
 
getMetricGroup() - Method in class org.apache.flink.table.functions.ConstantFunctionContext
 
getMetricGroup() - Method in class org.apache.flink.table.functions.FunctionContext
Returns the metric group for this parallel subtask.
getMillisecond() - Method in class org.apache.flink.table.data.TimestampData
Returns the number of milliseconds since 1970-01-01 00:00:00.
getMin() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
 
getMin() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
 
getMin() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
 
getMin() - Method in class org.apache.flink.table.plan.stats.ColumnStats
Returns null if this instance is constructed by ColumnStats(Long, Long, Double, Integer, Number, Number).
getMinCount() - Method in interface org.apache.flink.table.types.inference.ArgumentCount
Returns the minimum number of argument (inclusive) that a function can take.
getMinCount() - Method in class org.apache.flink.table.types.inference.ConstantArgumentCount
 
getMinValue() - Method in class org.apache.flink.table.plan.stats.ColumnStats
Deprecated.
getName() - Method in interface org.apache.flink.table.api.constraints.Constraint
Deprecated.
 
getName() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
 
getName() - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
 
getName() - Method in class org.apache.flink.table.api.TableColumn
Deprecated.
Returns the name of this column.
getName() - Method in class org.apache.flink.table.catalog.AbstractCatalog
 
getName() - Method in class org.apache.flink.table.catalog.Column
Returns the name of this column.
getName() - Method in interface org.apache.flink.table.catalog.Constraint
 
getName() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
getName() - Method in interface org.apache.flink.table.factories.CatalogFactory.Context
Returns the name with which the catalog is created.
getName() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
 
getName() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
getName() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
 
getName() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
 
getName() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
getName() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
getName() - Method in interface org.apache.flink.table.types.inference.CallContext
Returns the function's name usually referencing the function in a catalog.
getName() - Method in class org.apache.flink.table.types.inference.Signature.Argument
 
getName() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
getName() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
 
getName() - Method in class org.apache.flink.table.types.logical.RowType.RowField
 
getName() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
getNamedArguments() - Method in class org.apache.flink.table.types.inference.TypeInference
 
getNanoOfMillisecond() - Method in class org.apache.flink.table.data.TimestampData
Returns the number of nanoseconds (the nanoseconds within the milliseconds).
getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
 
getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
 
getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
 
getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
 
getNdv() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
getNestedSerializers(ListViewSerializer<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializerSnapshot
Deprecated.
 
getNestedSerializers(MapViewSerializer<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializerSnapshot
Deprecated.
 
getNestedSerializers(NullAwareMapSerializer<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
Deprecated.
 
getNewInstance(K) - Method in class org.apache.flink.table.utils.ThreadLocalCache
 
getNullCount() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
 
getNullCount() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
getObjectIdentifier() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
Returns the identifier of the table in the Catalog.
getObjectIdentifier() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
getObjectIdentifier() - Method in interface org.apache.flink.table.factories.TableSinkFactory.Context
 
getObjectIdentifier() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
getObjectIdentifier() - Method in interface org.apache.flink.table.factories.TableSourceFactory.Context
 
getObjectIdentifier() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
 
getObjectIdentifier() - Method in class org.apache.flink.table.types.logical.UserDefinedType
 
getObjectName() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
 
getObjectName() - Method in class org.apache.flink.table.catalog.ObjectPath
 
getObjectName() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
 
getOffset() - Method in interface org.apache.flink.table.data.binary.BinaryFormat
Gets the start offset of this binary data in the MemorySegments.
getOffset() - Method in class org.apache.flink.table.data.binary.BinarySection
 
getOffset() - Method in class org.apache.flink.table.data.binary.BinaryStringData
 
getOffset() - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
 
getOptionalArray(String, Function<String, E>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns all array elements under a given key if it exists.
getOptionalBigDecimal(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a big decimal value under the given key if it exists.
getOptionalBoolean(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a boolean value under the given key if it exists.
getOptionalByte(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a byte value under the given key if it exists.
getOptionalCharacter(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a character value under the given key if it exists.
getOptionalClass(String, Class<T>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a class value under the given key if it exists.
getOptionalDataType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns the DataType under the given key if it exists.
getOptionalDouble(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a double value under the given key if it exists.
getOptionalDuration(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a Java Duration under the given key if it exists.
getOptionalFloat(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a float value under the given key if it exists.
getOptionalInt(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns an integer value under the given key if it exists.
getOptionalLong(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a long value under the given key if it exists.
getOptionalMemorySize(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a Flink MemorySize under the given key if it exists.
getOptionalShort(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a short value under the given key if it exists.
getOptionalString(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a string value under the given key if it exists.
getOptionalTableSchema(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a table schema under the given key if it exists.
getOptionalType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns the type information under the given key if it exists.
getOptions() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
Returns a map of string-based options.
getOptions() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
getOptions() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
 
getOptions() - Method in interface org.apache.flink.table.factories.CatalogFactory.Context
Returns the options with which the catalog is created.
getOptions() - Method in class org.apache.flink.table.factories.FactoryUtil.CatalogFactoryHelper
Returns all options of the catalog.
getOptions() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
 
getOptions() - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
Returns all options of the table.
getOrigin() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogBaseTable
Returns the original, unresolved metadata object from the Catalog.
getOrigin() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
getOrigin() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
 
getOriginalQuery() - Method in interface org.apache.flink.table.catalog.CatalogView
Original text of the view definition that also preserves the original formatting.
getOriginalQuery() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
 
getOriginatingClass() - Method in class org.apache.flink.table.types.logical.RawType
 
getOutputDataType() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
getOutputDataType() - Method in class org.apache.flink.table.expressions.CallExpression
 
getOutputDataType() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
getOutputDataType() - Method in interface org.apache.flink.table.expressions.ResolvedExpression
Returns the data type of the computation result.
getOutputDataType() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
 
getOutputDataType() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
getOutputDataType() - Method in interface org.apache.flink.table.types.inference.CallContext
Returns the inferred output data type of the function call.
getOutputDataType() - Method in class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
 
getOutputDataType() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
getOutputDataType() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
 
getOutputType() - Method in interface org.apache.flink.table.sinks.TableSink
Deprecated.
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSink.getConsumedDataType() instead which uses the new type system based on DataTypes. 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.
getOutputTypeStrategy() - Method in class org.apache.flink.table.types.inference.TypeInference
 
getParallelism() - Method in interface org.apache.flink.table.connector.ParallelismProvider
Returns the parallelism for this instance.
getParameterTypes(Class[]) - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
 
getParameterTypes(Class[]) - Method in class org.apache.flink.table.functions.python.PythonTableFunction
 
getParameterTypes(Class<?>[]) - Method in class org.apache.flink.table.functions.ScalarFunction
Deprecated.
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getParameterTypes(Class<?>[]) - Method in class org.apache.flink.table.functions.TableFunction
Deprecated.
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getPartition(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
Get a partition of the given table.
getPartitionColumnStatistics(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
Get the column statistics of a partition.
getPartitionKeys() - Method in interface org.apache.flink.table.catalog.CatalogTable
Get the partition keys of the table.
getPartitionKeys() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
getPartitionKeys() - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns partition keys.
getPartitionKeys() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
Partition keys of the table.
getPartitions() - Method in interface org.apache.flink.table.sources.PartitionableTableSource
Deprecated.
Returns all the partitions of this PartitionableTableSource.
getPartitionSpec() - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
Get the partition spec as key-value map.
getPartitionStatistics(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
Get the statistics of a partition.
getPaths() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
Read paths.
getPhysicalSchema(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
Return TableSchema which consists of all physical columns.
getPrecision() - Method in class org.apache.flink.table.types.logical.DecimalType
 
getPrecision() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
getPrecision() - Method in class org.apache.flink.table.types.logical.TimestampType
 
getPrecision() - Method in class org.apache.flink.table.types.logical.TimeType
 
getPrecision(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Returns the precision of all types that define a precision implicitly or explicitly.
getPrecision() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
getPrimaryKey() - Method in class org.apache.flink.table.api.Schema
 
getPrimaryKey() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
 
getPrimaryKey() - Method in class org.apache.flink.table.catalog.ResolvedSchema
Returns the primary key if it has been defined.
getPrimaryKeyIndices(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
Returns the field indices of primary key in the physical columns of this schema (not include computed columns or metadata columns).
getProctimeAttribute() - Method in interface org.apache.flink.table.sources.DefinedProctimeAttribute
Deprecated.
Returns the name of a processing time attribute or null if no processing time attribute is present.
getProducedDataType() - Method in interface org.apache.flink.table.sources.TableSource
Deprecated.
Returns the DataType for the produced data of the TableSource.
getProjectFields() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
Project the fields of the reader returned.
getProperties() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
Get a map of properties associated with the database.
getProperties() - Method in interface org.apache.flink.table.catalog.CatalogPartition
Get a map of properties associated with the partition.
getProperties() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
 
getProperties() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
 
getProperties() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
getPropertiesWithPrefix(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a map of properties whose key starts with the given prefix, and the prefix is removed upon return.
getPushedDownFilters() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
Pushed down filters, reader can try its best to filter records.
getPushedDownLimit() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
Limiting push-down to reader.
getPythonEnv() - Method in enum org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
 
getPythonEnv() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
getPythonEnv() - Method in interface org.apache.flink.table.functions.python.PythonFunction
Returns the Python execution environment.
getPythonEnv() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
 
getPythonEnv() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getPythonEnv() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
 
getPythonFunction() - Method in class org.apache.flink.table.functions.python.PythonFunctionInfo
 
getPythonFunction(String, ReadableConfig, ClassLoader) - Static method in enum org.apache.flink.table.functions.python.utils.PythonFunctionUtils
 
getPythonFunctionKind() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
getPythonFunctionKind() - Method in interface org.apache.flink.table.functions.python.PythonFunction
Returns the kind of the user-defined python function.
getPythonFunctionKind() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
 
getPythonFunctionKind() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getPythonFunctionKind() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
 
getRawDataSize() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
getRawValue(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the raw value at the given position.
getRawValue(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getRawValue(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getRawValue(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getRawValue(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getRawValue(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getRawValue(int) - Method in interface org.apache.flink.table.data.RowData
Returns the raw value at the given position.
getRawValue(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getRemainingFilters() - Method in class org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown.Result
 
getRequirements() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
getRequirements() - Method in interface org.apache.flink.table.functions.FunctionDefinition
Returns the set of requirements this definition demands.
getRequirements() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
 
getRequirements() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
getRequirements() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
getResolution() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
getResolution() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
getResolvedChildren() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
getResolvedChildren() - Method in class org.apache.flink.table.expressions.CallExpression
 
getResolvedChildren() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
getResolvedChildren() - Method in interface org.apache.flink.table.expressions.ResolvedExpression
 
getResolvedChildren() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
 
getResolvedChildren() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
getResolvedSchema() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogBaseTable
Returns a fully resolved and validated ResolvedSchema.
getResolvedSchema() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
getResolvedSchema() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
 
getResultType() - Method in class org.apache.flink.table.functions.ImperativeAggregateFunction
Deprecated.
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getResultType() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
getResultType(Class[]) - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
 
getResultType() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getResultType() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
 
getResultType(Class<?>[]) - Method in class org.apache.flink.table.functions.ScalarFunction
Deprecated.
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getResultType() - Method in class org.apache.flink.table.functions.TableFunction
Deprecated.
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getResultType() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
getResultTypeInfo() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
getResultTypeInfo() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
getReturnType() - Method in interface org.apache.flink.table.sources.FieldComputer
Deprecated.
Returns the result type of the expression.
getReturnType() - Method in interface org.apache.flink.table.sources.TableSource
Deprecated.
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSource.getProducedDataType() instead which uses the new type system based on DataTypes. 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.
getReturnType() - Method in class org.apache.flink.table.sources.tsextractors.TimestampExtractor
Deprecated.
 
getReturnTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getReturnTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>, TypeInformation<T>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getReturnTypeOfTableFunction(TableFunction<T>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getReturnTypeOfTableFunction(TableFunction<T>, TypeInformation<T>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getRow(int, int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the row value at the given position.
getRow(int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getRow(int, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getRow(int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getRow(int, int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getRow(int, int) - Method in class org.apache.flink.table.data.GenericRowData
 
getRow(int, int) - Method in interface org.apache.flink.table.data.RowData
Returns the row value at the given position.
getRow(int, int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getRowCount() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
The number of rows.
getRowCount() - Method in class org.apache.flink.table.plan.stats.TableStats
 
getRowKind() - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getRowKind() - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getRowKind() - Method in class org.apache.flink.table.data.GenericRowData
 
getRowKind() - Method in interface org.apache.flink.table.data.RowData
Returns the kind of change that this row describes in a changelog.
getRowKind() - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getRowtimeAttribute() - Method in class org.apache.flink.table.api.WatermarkSpec
Deprecated.
Returns the name of rowtime attribute, it can be a nested field using dot separator.
getRowtimeAttribute() - Method in class org.apache.flink.table.catalog.WatermarkSpec
Returns the name of a rowtime attribute.
getRowtimeAttributeDescriptors() - Method in interface org.apache.flink.table.sources.DefinedRowtimeAttributes
Deprecated.
Returns a list of RowtimeAttributeDescriptor for all rowtime attributes of the table.
getRuntimeClass() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
 
getScalarFunction() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
 
getScale() - Method in class org.apache.flink.table.types.logical.DecimalType
 
getScale(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Returns the scale of all types that define a scale implicitly or explicitly.
getScanRuntimeProvider(ScanTableSource.ScanContext) - Method in interface org.apache.flink.table.connector.source.ScanTableSource
Returns a provider of runtime implementation for reading the data.
getSchema() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
Deprecated.
This method returns the deprecated TableSchema class. The old class was a hybrid of resolved and unresolved schema information. It has been replaced by the new Schema which is always unresolved and will be resolved by the framework later.
getSchema() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogBaseTable
Deprecated.
This method returns the deprecated TableSchema class. The old class was a hybrid of resolved and unresolved schema information. It has been replaced by the new ResolvedSchema which is resolved by the framework and accessible via ResolvedCatalogBaseTable.getResolvedSchema().
getSchema() - Method in interface org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
Deprecated.
Full schema of the table.
getSegments() - Method in interface org.apache.flink.table.data.binary.BinaryFormat
Gets the underlying MemorySegments this binary format spans.
getSegments() - Method in class org.apache.flink.table.data.binary.BinarySection
 
getSegments() - Method in class org.apache.flink.table.data.binary.BinaryStringData
 
getSegments() - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
 
getSerializedPythonFunction() - Method in enum org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
 
getSerializedPythonFunction() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
getSerializedPythonFunction() - Method in interface org.apache.flink.table.functions.python.PythonFunction
Returns the serialized representation of the user-defined python function.
getSerializedPythonFunction() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
 
getSerializedPythonFunction() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getSerializedPythonFunction() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
 
getSerializerString() - Method in class org.apache.flink.table.types.logical.RawType
Returns the serialized TypeSerializerSnapshot in Base64 encoding of this raw type.
getShort(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the short value at the given position.
getShort(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getShort(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getShort(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
get short from segments.
getShort(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getShort(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getShort(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getShort(int) - Method in interface org.apache.flink.table.data.RowData
Returns the short value at the given position.
getShort(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getShort(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a short value under the given existing key.
getSimpleName() - Method in class org.apache.flink.table.functions.FunctionIdentifier
 
getSinkRuntimeProvider(DynamicTableSink.Context) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
Returns a provider of runtime implementation for writing the data.
getSizeInBytes() - Method in interface org.apache.flink.table.data.binary.BinaryFormat
Gets the size in bytes of this binary data.
getSizeInBytes() - Method in class org.apache.flink.table.data.binary.BinarySection
 
getSizeInBytes() - Method in class org.apache.flink.table.data.binary.BinaryStringData
 
getSizeInBytes() - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
 
getSourceType() - Method in class org.apache.flink.table.types.logical.DistinctType
 
getSqlExpression() - Method in class org.apache.flink.table.expressions.SqlCallExpression
 
getString(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the string value at the given position.
getString(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getString(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getString(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getString(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getString(int) - Method in class org.apache.flink.table.data.GenericRowData
 
getString(int) - Method in interface org.apache.flink.table.data.RowData
Returns the string value at the given position.
getString(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getString(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a string value under the given existing key.
getStringDisplayWidth(String) - Static method in class org.apache.flink.table.utils.PrintUtils
 
getStructuredField(Class<?>, String) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Returns the field of a structured type.
getStructuredFieldGetter(Class<?>, Field) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Checks for a field getter of a structured type.
getStructuredFieldSetter(Class<?>, Field) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Checks for a field setters of a structured type.
getSuperType() - Method in class org.apache.flink.table.types.logical.StructuredType
 
getTable(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
Returns a CatalogTable or CatalogView identified by the given ObjectPath.
getTable() - Method in interface org.apache.flink.table.factories.TableSinkFactory.Context
 
getTable() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
getTable() - Method in interface org.apache.flink.table.factories.TableSourceFactory.Context
 
getTable() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
 
getTableAggregateFunction() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
getTableColumn(int) - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns the TableColumn instance for the given field index.
getTableColumn(String) - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns the TableColumn instance for the given field name.
getTableColumns() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns all the TableColumns for this table schema.
getTableColumnStatistics(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
Get the column statistics of a table.
getTableFactory() - Method in interface org.apache.flink.table.catalog.Catalog
Deprecated.
Use Catalog.getFactory() for the new factory stack. The new factory stack uses the new table sources and sinks defined in FLIP-95 and a slightly different discovery mechanism.
getTableFunction() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
getTableKind() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
The kind of table this CatalogBaseTable describes.
getTableKind() - Method in interface org.apache.flink.table.catalog.CatalogTable
 
getTableKind() - Method in interface org.apache.flink.table.catalog.CatalogView
 
getTableSchema(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a table schema under the given existing key.
getTableSchema() - Method in interface org.apache.flink.table.sinks.TableSink
Deprecated.
Returns the schema of the consumed table.
getTableSchema() - Method in interface org.apache.flink.table.sources.TableSource
Deprecated.
Table schema is a logical description of a table and should not be part of the physical TableSource. Define schema when registering a Table either in DDL or in TableEnvironment#connect(...).
getTableStatistics(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
Get the statistics of a table.
getTimestamp(int, int) - Method in interface org.apache.flink.table.data.ArrayData
Returns the timestamp value at the given position.
getTimestamp(int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
getTimestamp(int, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
getTimestamp(int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
getTimestamp(int, int) - Method in class org.apache.flink.table.data.GenericArrayData
 
getTimestamp(int, int) - Method in class org.apache.flink.table.data.GenericRowData
 
getTimestamp(int, int) - Method in interface org.apache.flink.table.data.RowData
Returns the timestamp value at the given position.
getTimestamp(int, int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
getTimestampExtractor() - Method in class org.apache.flink.table.sources.RowtimeAttributeDescriptor
Deprecated.
Returns the [[TimestampExtractor]] for the attribute.
getTotalFields() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
getTotalFields() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
getTotalFields() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
getTotalSize() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
getTrueCount() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
 
getType() - Method in interface org.apache.flink.table.api.constraints.Constraint
Deprecated.
Tells what kind of constraint it is, e.g.
getType() - Method in class org.apache.flink.table.api.constraints.UniqueConstraint
Deprecated.
 
getType() - Method in class org.apache.flink.table.api.TableColumn
Deprecated.
Returns the data type of this column.
getType() - Method in interface org.apache.flink.table.catalog.Constraint
Tells what kind of constraint it is, e.g.
getType() - Method in class org.apache.flink.table.catalog.UniqueConstraint
 
getType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns the type information under the given existing key.
getType() - Method in class org.apache.flink.table.types.inference.Signature.Argument
 
getType() - Method in class org.apache.flink.table.types.logical.RowType.RowField
 
getType() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
getTypeAt(int) - Method in class org.apache.flink.table.types.logical.RowType
 
getTypeClass() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
getTypeClass() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
getTypeClass() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
getTypedArguments() - Method in class org.apache.flink.table.types.inference.TypeInference
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.AggregateFunction
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.AsyncTableFunction
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
 
getTypeInference(DataTypeFactory) - Method in interface org.apache.flink.table.functions.FunctionDefinition
Returns the logic for performing type inference of a call to this function definition.
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.python.PythonTableFunction
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.ScalarFunction
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.TableAggregateFunction
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.TableFunction
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.UserDefinedFunction
Returns the logic for performing type inference of a call to this function definition.
getTypeInformation() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
getTypeInformation() - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
getTypeRoot() - Method in class org.apache.flink.table.types.logical.LogicalType
Returns the root of this type.
getTypeSerializer() - Method in class org.apache.flink.table.types.logical.RawType
 
getUnresolvedIdentifier() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
getUnresolvedSchema() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
Returns the schema of the table or view.
getUnresolvedSchema() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
getUnresolvedSchema() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
 
getValue(String, DescriptorProperties) - Static method in class org.apache.flink.table.descriptors.LiteralValueValidator
Gets the value according to the type and value strings.
getValue(ACC) - Method in class org.apache.flink.table.functions.AggregateFunction
Called every time when an aggregation result should be materialized.
getValue(Object) - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
getValueAs(Class<T>) - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
Returns the value (excluding null) as an instance of the given class.
getValueDataType() - Method in class org.apache.flink.table.types.KeyValueDataType
 
getValueSerializer() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
getValueType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
getValueType() - Method in class org.apache.flink.table.types.logical.MapType
 
getVariableIndexedProperties(String, List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns the property keys of variable indexed properties.
getWatermarkExpr() - Method in class org.apache.flink.table.api.WatermarkSpec
Deprecated.
Returns the string representation of watermark generation expression.
getWatermarkExpression() - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
 
getWatermarkExpression() - Method in class org.apache.flink.table.catalog.WatermarkSpec
Returns the ResolvedExpression for watermark generation.
getWatermarkExprOutputType() - Method in class org.apache.flink.table.api.WatermarkSpec
Deprecated.
Returns the data type of the computation result of watermark generation expression.
getWatermarkSpecs() - Method in class org.apache.flink.table.api.Schema
 
getWatermarkSpecs() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Returns a list of the watermark specification which contains rowtime attribute and watermark strategy expression.
getWatermarkSpecs() - Method in class org.apache.flink.table.catalog.ResolvedSchema
Returns a list of watermark specifications each consisting of a rowtime attribute and watermark strategy expression.
getWatermarkStrategy() - Method in class org.apache.flink.table.sources.RowtimeAttributeDescriptor
Deprecated.
Returns the [[WatermarkStrategy]] for the attribute.
getYearPrecision(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
getYearPrecision() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
GREATER_THAN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
GREATER_THAN_OR_EQUAL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 

H

hasDayPrecision(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
hasFamily(LogicalType, LogicalTypeFamily) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
hasFractionalPrecision(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
hash(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
hash segments to int.
hashByWords(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
hash segments to int, numBytes must be aligned to 4 bytes.
hashCode() - Method in class org.apache.flink.table.api.constraints.UniqueConstraint
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
 
hashCode() - Method in class org.apache.flink.table.api.DataTypes.Field
 
hashCode() - Method in class org.apache.flink.table.api.DataTypes.UnresolvedField
 
hashCode() - Method in class org.apache.flink.table.api.dataview.ListView
 
hashCode() - Method in class org.apache.flink.table.api.dataview.MapView
 
hashCode() - Method in class org.apache.flink.table.api.Schema
 
hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
 
hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
 
hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedConstraint
 
hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
 
hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
 
hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
 
hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
 
hashCode() - Method in class org.apache.flink.table.api.TableColumn.ComputedColumn
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.api.TableColumn
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.api.WatermarkSpec
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
 
hashCode() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
 
hashCode() - Method in class org.apache.flink.table.catalog.Column
 
hashCode() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
 
hashCode() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
 
hashCode() - Method in class org.apache.flink.table.catalog.ObjectPath
 
hashCode() - Method in class org.apache.flink.table.catalog.ResolvedSchema
 
hashCode() - Method in class org.apache.flink.table.catalog.UniqueConstraint
 
hashCode() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
 
hashCode() - Method in class org.apache.flink.table.catalog.WatermarkSpec
 
hashCode() - Method in class org.apache.flink.table.connector.ChangelogMode
 
hashCode() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
hashCode() - Method in class org.apache.flink.table.data.binary.BinaryMapData
 
hashCode() - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
 
hashCode() - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
hashCode() - Method in class org.apache.flink.table.data.binary.BinarySection
 
hashCode() - Method in class org.apache.flink.table.data.binary.BinaryStringData
 
hashCode() - Method in class org.apache.flink.table.data.binary.NestedRowData
 
hashCode() - Method in class org.apache.flink.table.data.DecimalData
 
hashCode() - Method in class org.apache.flink.table.data.GenericArrayData
 
hashCode() - Method in class org.apache.flink.table.data.GenericMapData
 
hashCode() - Method in class org.apache.flink.table.data.GenericRowData
 
hashCode() - Method in class org.apache.flink.table.data.TimestampData
 
hashCode() - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
hashCode() - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
hashCode() - Method in class org.apache.flink.table.expressions.CallExpression
 
hashCode() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
hashCode() - Method in class org.apache.flink.table.expressions.SqlCallExpression
 
hashCode() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
 
hashCode() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
hashCode() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
hashCode() - Method in class org.apache.flink.table.functions.FunctionIdentifier
 
hashCode() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
 
hashCode() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
hashCode() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
hashCode() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
hashCode() - Method in class org.apache.flink.table.plan.stats.TableStats
 
hashCode() - Method in class org.apache.flink.table.sources.RowtimeAttributeDescriptor
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
 
hashCode() - Method in class org.apache.flink.table.types.CollectionDataType
 
hashCode() - Method in class org.apache.flink.table.types.DataType
 
hashCode() - Method in class org.apache.flink.table.types.FieldsDataType
 
hashCode() - Method in class org.apache.flink.table.types.inference.ConstantArgumentCount
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.ExplicitTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.MatchFamilyTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.NullableTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.VaryingStringTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
hashCode() - Method in class org.apache.flink.table.types.KeyValueDataType
 
hashCode() - Method in class org.apache.flink.table.types.logical.ArrayType
 
hashCode() - Method in class org.apache.flink.table.types.logical.BinaryType
 
hashCode() - Method in class org.apache.flink.table.types.logical.CharType
 
hashCode() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
hashCode() - Method in class org.apache.flink.table.types.logical.DecimalType
 
hashCode() - Method in class org.apache.flink.table.types.logical.DistinctType
 
hashCode() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
hashCode() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
hashCode() - Method in class org.apache.flink.table.types.logical.LogicalType
 
hashCode() - Method in class org.apache.flink.table.types.logical.MapType
 
hashCode() - Method in class org.apache.flink.table.types.logical.MultisetType
 
hashCode() - Method in class org.apache.flink.table.types.logical.RawType
 
hashCode() - Method in class org.apache.flink.table.types.logical.RowType
 
hashCode() - Method in class org.apache.flink.table.types.logical.RowType.RowField
 
hashCode() - Method in class org.apache.flink.table.types.logical.StructuredType
 
hashCode() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
hashCode() - Method in class org.apache.flink.table.types.logical.SymbolType
 
hashCode() - Method in class org.apache.flink.table.types.logical.TimestampType
 
hashCode() - Method in class org.apache.flink.table.types.logical.TimeType
 
hashCode() - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
hashCode() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
hashCode() - Method in class org.apache.flink.table.types.logical.UserDefinedType
 
hashCode() - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
hashCode() - Method in class org.apache.flink.table.types.logical.VarCharType
 
hashCode() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
hashCode() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
hashCode() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
hasInvokableConstructor(Class<?>, Class<?>...) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Checks for an invokable constructor matching the given arguments.
hasLegacyTypes(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Checks whether a (possibly nested) logical type contains LegacyTypeInformationType or TypeInformationRawType.
hasLength(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
hasNested(LogicalType, Predicate<LogicalType>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Checks whether a (possibly nested) logical type fulfills the given predicate.
hasPrecision(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Checks the precision of a type that defines a precision implicitly or explicitly.
hasPrefix(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns if a given prefix exists in the properties.
hasProctimeAttribute(TableSource<?>) - Static method in class org.apache.flink.table.sources.TableSourceValidation
Checks if the given TableSource defines a proctime attribute.
hasRoot(LogicalType, LogicalTypeRoot) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
hasRowtimeAttribute(TableSource<?>) - Static method in class org.apache.flink.table.sources.TableSourceValidation
Checks if the given TableSource defines a rowtime attribute.
hasScale(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Checks the scale of all types that define a scale implicitly or explicitly.
hasWellDefinedString(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Checks whether the given LogicalType has a well-defined string representation when calling Object.toString() on the internal data structure.
hasYearPrecision(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
HEADER_SIZE_IN_BITS - Static variable in class org.apache.flink.table.data.binary.BinaryRowData
 
HEX - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
hex(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
hex(byte[]) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
HierarchyDescriptor - Class in org.apache.flink.table.descriptors
A descriptor that may exist in an arbitrary level (be recursively included by other descriptors).
HierarchyDescriptor() - Constructor for class org.apache.flink.table.descriptors.HierarchyDescriptor
 
HierarchyDescriptorValidator - Class in org.apache.flink.table.descriptors
Validator for a HierarchyDescriptor.
HierarchyDescriptorValidator(String) - Constructor for class org.apache.flink.table.descriptors.HierarchyDescriptorValidator
 
HIGHEST_FIRST_BIT - Static variable in interface org.apache.flink.table.data.binary.BinaryFormat
To get the mark in highest bit of long.
HIGHEST_SECOND_TO_EIGHTH_BIT - Static variable in interface org.apache.flink.table.data.binary.BinaryFormat
To get the 7 bits length in second bit to eighth bit out of a long.
HintFlag - Enum in org.apache.flink.table.annotation
Three-valued flag for representing TRUE, FALSE, and UNKNOWN.
HOUR() - Static method in class org.apache.flink.table.api.DataTypes
Resolution in hours.

I

IF - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
IF_NULL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
IF_NULL - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy specific for avoiding nulls.
ImperativeAggregateFunction<T,ACC> - Class in org.apache.flink.table.functions
Base class for user-defined AggregateFunction and TableAggregateFunction.
ImperativeAggregateFunction() - Constructor for class org.apache.flink.table.functions.ImperativeAggregateFunction
 
IN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
inAppendMode() - Method in class org.apache.flink.table.descriptors.TableDescriptor
Declares how to perform the conversion between a dynamic table and an external connector.
indexOf(BinaryStringData, int) - Method in class org.apache.flink.table.data.binary.BinaryStringData
Returns the index within this string of the first occurrence of the specified substring, starting at the specified index.
inferArgumentType(CallContext, int, boolean) - Method in interface org.apache.flink.table.types.inference.ArgumentTypeStrategy
Main logic for inferring and validating an argument.
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.CommonArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.CompositeArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
 
inferInputTypes(CallContext, boolean) - Method in interface org.apache.flink.table.types.inference.InputTypeStrategy
Main logic for inferring and validating the input arguments.
inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.CastInputTypeStrategy
 
inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.CommonInputTypeStrategy
 
inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
 
inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.MapInputTypeStrategy
 
inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
 
inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
 
inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy
 
inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
 
inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
inferOutputType(CallContext, TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
Infers an output type using the given TypeStrategy.
inferOutputType(DataTypeFactory) - Method in interface org.apache.flink.table.types.inference.TypeInferenceUtil.SurroundingInfo
 
inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
 
inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.ExplicitTypeStrategy
 
inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
 
inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
 
inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.MatchFamilyTypeStrategy
 
inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
 
inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.NullableTypeStrategy
 
inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.UseArgumentTypeStrategy
 
inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.VaryingStringTypeStrategy
 
inferType(CallContext) - Method in interface org.apache.flink.table.types.inference.TypeStrategy
Infers a type from the given function call.
INIT_CAP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
InputFormatProvider - Interface in org.apache.flink.table.connector.source
Provider of an InputFormat instance as a runtime implementation for ScanTableSource.
InputGroup - Enum in org.apache.flink.table.annotation
A list of commonly used pre-defined groups of similar types for accepting more than just one data type as an input argument in DataTypeHints.
InputTypeStrategies - Class in org.apache.flink.table.types.inference
Strategies for inferring and validating input arguments in a function call.
inputTypeStrategy(InputTypeStrategy) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
InputTypeStrategy - Interface in org.apache.flink.table.types.inference
Strategy for inferring and validating input arguments in a function call.
inputTypeStrategy(InputTypeStrategy) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
Sets the strategy for inferring and validating input arguments in a function call.
inRetractMode() - Method in class org.apache.flink.table.descriptors.TableDescriptor
Declares how to perform the conversion between a dynamic table and an external connector.
insertOnly() - Static method in class org.apache.flink.table.connector.ChangelogMode
Shortcut for a simple RowKind.INSERT-only changelog.
INSTANCE - Static variable in class org.apache.flink.table.dataview.NullSerializer
 
INSTANCE - Static variable in class org.apache.flink.table.module.CoreModule
 
INSTANCE - Static variable in class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
 
INSTANCE - Static variable in class org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
 
INSTANCE - Static variable in class org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
 
instantiateFunction(ClassLoader, ReadableConfig, String, CatalogFunction) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Instantiates a UserDefinedFunction from a CatalogFunction.
instantiateFunction(Class<? extends UserDefinedFunction>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Instantiates a UserDefinedFunction assuming a JVM function with default constructor.
INT() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a 4-byte signed integer with values from -2,147,483,648 to 2,147,483,647.
INT() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API integer or SQL INT/INTEGER type.
INTERVAL(DataTypes.Resolution) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a temporal interval.
INTERVAL(DataTypes.Resolution, DataTypes.Resolution) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a temporal interval.
INTERVAL_MILLIS() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API interval of milliseconds.
INTERVAL_MILLIS - Static variable in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
INTERVAL_MONTHS() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API interval of months.
INTERVAL_MONTHS - Static variable in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
IntType - Class in org.apache.flink.table.types.logical
Logical type of a 4-byte signed integer with values from -2,147,483,648 to 2,147,483,647.
IntType(boolean) - Constructor for class org.apache.flink.table.types.logical.IntType
 
IntType() - Constructor for class org.apache.flink.table.types.logical.IntType
 
inUpsertMode() - Method in class org.apache.flink.table.descriptors.TableDescriptor
Declares how to perform the conversion between a dynamic table and an external connector.
IS_FALSE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
IS_GENERIC - Static variable in class org.apache.flink.table.catalog.CatalogPropertiesUtil
Flag to distinguish if a meta-object is a generic Flink object or not.
IS_NOT_FALSE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
IS_NOT_NULL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
IS_NOT_TRUE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
IS_NULL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
IS_TRUE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
isApproximate() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
isArgumentLiteral(int) - Method in interface org.apache.flink.table.types.inference.CallContext
Returns whether the argument at the given position is a value literal.
isArgumentLiteral(int) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
isArgumentLiteral(int) - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
 
isArgumentNull(int) - Method in interface org.apache.flink.table.types.inference.CallContext
Returns true if the argument at the given position is a literal and null, false otherwise.
isArgumentNull(int) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
isArgumentNull(int) - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
 
isAssignable(Class<?>, Class<?>, boolean) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Checks if one Class can be assigned to a variable of another Class.
isAsyncEnabled() - Method in interface org.apache.flink.table.sources.LookupableTableSource
Deprecated.
Returns true if async lookup is enabled.
isBasicType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
isBasicType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
isBasicType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
isBounded() - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
Returns whether a runtime implementation can expect a finite number of rows.
isBounded() - Method in interface org.apache.flink.table.connector.source.ScanTableSource.ScanRuntimeProvider
Returns whether the data is bounded or not.
isBounded() - Method in interface org.apache.flink.table.factories.TableSinkFactory.Context
It depends on whether the TableEnvironment execution mode is batch.
isBounded() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
isCompact() - Method in class org.apache.flink.table.data.DecimalData
Returns whether the decimal value is small enough to be stored in a long.
isCompact(int) - Static method in class org.apache.flink.table.data.DecimalData
Returns whether the decimal value is small enough to be stored in a long.
isCompact(int) - Static method in class org.apache.flink.table.data.TimestampData
Returns whether the timestamp data is small enough to be stored in a long of milliseconds.
isComparison() - Method in enum org.apache.flink.table.types.logical.StructuredType.StructuredComparision
 
isCompositeType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Checks if the given type is a composite type.
isDeterministic() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
isDeterministic() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
 
isDeterministic() - Method in interface org.apache.flink.table.functions.FunctionDefinition
Returns information about the determinism of the function's results.
isDeterministic() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
isDeterministic() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
 
isDeterministic() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
isDeterministic() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
 
isDeterministic() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
 
isDeterministic() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
isDeterministic() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
isDistinct() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
isDistinct() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunctionInfo
 
isEmpty() - Method in class org.apache.flink.table.api.dataview.MapView
Returns true if the map view contains no key-value mappings, otherwise false.
isEnforced() - Method in interface org.apache.flink.table.api.constraints.Constraint
Deprecated.
Constraints can either be enforced or non-enforced.
isEnforced() - Method in interface org.apache.flink.table.catalog.Constraint
Constraints can either be enforced or non-enforced.
isEquality() - Method in enum org.apache.flink.table.types.logical.StructuredType.StructuredComparision
 
isEventTime() - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
isFilterPushedDown() - Method in interface org.apache.flink.table.sources.FilterableTableSource
Deprecated.
Return the flag to indicate whether filter push down has been tried.
isFinal() - Method in class org.apache.flink.table.types.logical.UserDefinedType
 
isFormatNeeded() - Method in class org.apache.flink.table.descriptors.ConnectorDescriptor
Returns if this connector requires a format descriptor.
isFullWidth(int) - Static method in class org.apache.flink.table.utils.PrintUtils
Check codePoint is FullWidth or not according to Unicode Standard version 12.0.0.
isGeneric() - Method in interface org.apache.flink.table.catalog.CatalogFunction
Distinguish if the function is a generic function.
isGroupedAggregation() - Method in interface org.apache.flink.table.types.inference.CallContext
Returns whether the function call happens as part of an aggregation that defines grouping columns.
isGroupedAggregation() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
isGroupedAggregation() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
 
isIgnoreNulls() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
isImmutableType() - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
isImmutableType() - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
isImmutableType() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
isImmutableType() - Method in class org.apache.flink.table.dataview.NullSerializer
 
isInFixedLengthPart(LogicalType) - Static method in class org.apache.flink.table.data.binary.BinaryRowData
If it is a fixed-length field, we can call this BinaryRowData's setXX method for in-place updates.
isInstantiable() - Method in class org.apache.flink.table.types.logical.StructuredType
 
isInternal(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Checks whether a given data type is an internal data structure.
isInvokable(Executable, Class<?>...) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Checks whether a method/constructor can be called with the given argument classes.
isKeyType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
isKeyType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
isKeyType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
isLimitPushedDown() - Method in interface org.apache.flink.table.sources.LimitableTableSource
Deprecated.
Return the flag to indicate whether limit push down has been tried.
isMutable(LogicalType) - Static method in class org.apache.flink.table.data.binary.BinaryRowData
 
isNull() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
isNullable() - Method in class org.apache.flink.table.types.logical.LogicalType
Returns whether a value of this type can be null.
isNullAt(int) - Method in interface org.apache.flink.table.data.ArrayData
Returns true if the element is null at the given position.
isNullAt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
isNullAt(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
isNullAt(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
isNullAt(int) - Method in class org.apache.flink.table.data.GenericArrayData
 
isNullAt(int) - Method in class org.apache.flink.table.data.GenericRowData
 
isNullAt(int) - Method in interface org.apache.flink.table.data.RowData
Returns true if the field is null at the given position.
isNullAt(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
isNullAware() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
isNullSerializer() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
isNullSerializer() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
isPartitioned() - Method in interface org.apache.flink.table.catalog.CatalogTable
Check if the table is partitioned or not.
isPartitioned() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
isPersisted() - Method in class org.apache.flink.table.api.TableColumn.ComputedColumn
Deprecated.
 
isPersisted() - Method in class org.apache.flink.table.api.TableColumn
Deprecated.
Returns whether the given column is persisted in a sink operation.
isPersisted() - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
Deprecated.
 
isPersisted() - Method in class org.apache.flink.table.api.TableColumn.PhysicalColumn
Deprecated.
 
isPersisted() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
 
isPersisted() - Method in class org.apache.flink.table.catalog.Column
Returns whether the given column is persisted in a sink operation.
isPersisted() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
 
isPersisted() - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
 
isPhysical() - Method in class org.apache.flink.table.api.TableColumn.ComputedColumn
Deprecated.
 
isPhysical() - Method in class org.apache.flink.table.api.TableColumn
Deprecated.
Returns whether the given column is a physical column of a table; neither computed nor metadata.
isPhysical() - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
Deprecated.
 
isPhysical() - Method in class org.apache.flink.table.api.TableColumn.PhysicalColumn
Deprecated.
 
isPhysical() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
 
isPhysical() - Method in class org.apache.flink.table.catalog.Column
Returns whether the given column is a physical column of a table; neither computed nor metadata.
isPhysical() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
 
isPhysical() - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
 
isPrimitiveArray() - Method in class org.apache.flink.table.data.GenericArrayData
Returns true if this is a primitive array.
isProctimeAttribute(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
isRowtimeAttribute(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
isSingleFieldInterval(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
isStructuredFieldDirectlyReadable(Field) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Checks whether a field is directly readable without a getter.
isStructuredFieldDirectlyWritable(Field) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Checks whether a field is directly writable without a setter or constructor.
isTemporary() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
Whether the table is temporary.
isTemporary() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
isTemporary() - Method in interface org.apache.flink.table.factories.TableSinkFactory.Context
Whether the table is temporary.
isTemporary() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
isTemporary() - Method in interface org.apache.flink.table.factories.TableSourceFactory.Context
Whether the table is temporary.
isTemporary() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
 
isTimeAttribute(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
isTupleType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
isTupleType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
isTupleType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
isValidCount(int) - Method in interface org.apache.flink.table.types.inference.ArgumentCount
Enables custom validation of argument counts after ArgumentCount.getMinCount() and ArgumentCount.getMaxCount() have been validated.
isValidCount(int) - Method in class org.apache.flink.table.types.inference.ConstantArgumentCount
 
isValue(String, String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns if a value under key is exactly equal to the given value.
isVirtual() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
 
isVirtual() - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
Deprecated.
 
isVirtual() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
 
iterator() - Method in class org.apache.flink.table.api.dataview.MapView
Returns an iterator over all entries of the map view.

J

JoinedRowData - Class in org.apache.flink.table.data.utils
An implementation of RowData which is backed by two concatenated RowData.
JoinedRowData() - Constructor for class org.apache.flink.table.data.utils.JoinedRowData
 
JoinedRowData(RowKind, RowData, RowData) - Constructor for class org.apache.flink.table.data.utils.JoinedRowData
 
JoinedRowData(RowData, RowData) - Constructor for class org.apache.flink.table.data.utils.JoinedRowData
 

K

keyArray() - Method in class org.apache.flink.table.data.binary.BinaryMapData
 
keyArray() - Method in class org.apache.flink.table.data.GenericMapData
 
keyArray() - Method in interface org.apache.flink.table.data.MapData
Returns an array view of the keys contained in this map.
keys() - Method in class org.apache.flink.table.api.dataview.MapView
Returns all the keys in the map view.
keyType - Variable in class org.apache.flink.table.api.dataview.MapView
Deprecated.
KeyValueDataType - Class in org.apache.flink.table.types
A data type that contains a key and value data type (e.g.
KeyValueDataType(LogicalType, Class<?>, DataType, DataType) - Constructor for class org.apache.flink.table.types.KeyValueDataType
 
KeyValueDataType(LogicalType, DataType, DataType) - Constructor for class org.apache.flink.table.types.KeyValueDataType
 
kind(FunctionKind) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 

L

LazyBinaryFormat<T> - Class in org.apache.flink.table.data.binary
An abstract implementation fo BinaryFormat which is lazily serialized into binary or lazily deserialized into Java object.
LazyBinaryFormat() - Constructor for class org.apache.flink.table.data.binary.LazyBinaryFormat
 
LazyBinaryFormat(MemorySegment[], int, int, T) - Constructor for class org.apache.flink.table.data.binary.LazyBinaryFormat
 
LazyBinaryFormat(MemorySegment[], int, int) - Constructor for class org.apache.flink.table.data.binary.LazyBinaryFormat
 
LazyBinaryFormat(T) - Constructor for class org.apache.flink.table.data.binary.LazyBinaryFormat
 
LazyBinaryFormat(T, BinarySection) - Constructor for class org.apache.flink.table.data.binary.LazyBinaryFormat
 
legacyRawToTypeInfoRaw() - Static method in class org.apache.flink.table.types.inference.TypeTransformations
Returns a type transformation that transforms LEGACY('RAW', ...) type to the RAW(..., ?) type.
LegacyRawTypeTransformation - Class in org.apache.flink.table.types.inference.transforms
This type transformation transforms the LEGACY('RAW', ...) type to the RAW(..., ?) type.
LegacyRawTypeTransformation() - Constructor for class org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
 
legacyToNonLegacy() - Static method in class org.apache.flink.table.types.inference.TypeTransformations
Returns a type transformation that transforms LEGACY(...) type to a non-legacy type.
LegacyToNonLegacyTransformation - Class in org.apache.flink.table.types.inference.transforms
LegacyToNonLegacyTransformation() - Constructor for class org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
 
LegacyTypeInfoDataTypeConverter - Class in org.apache.flink.table.types.utils
Deprecated.
Use DataTypeFactory.createDataType(TypeInformation) instead. Note that this method will not create legacy types anymore. It fully uses the new type system available only in the Blink planner.
LegacyTypeInformationType<T> - Class in org.apache.flink.table.types.logical
This type is a temporary solution to fully support the old type system stack through the new stack.
LegacyTypeInformationType(LogicalTypeRoot, TypeInformation<T>) - Constructor for class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
LESS_THAN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LESS_THAN_OR_EQUAL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LIKE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LimitableTableSource<T> - Interface in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use SupportsLimitPushDown instead. See FLIP-95 for more information.
listDatabases() - Method in interface org.apache.flink.table.catalog.Catalog
Get the names of all databases in this catalog.
listFunctions(String) - Method in interface org.apache.flink.table.catalog.Catalog
List the names of all functions in the given database.
listFunctions() - Method in class org.apache.flink.table.module.CoreModule
 
listFunctions() - Method in interface org.apache.flink.table.module.Module
List names of all functions in this module.
listPartitions(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
Get CatalogPartitionSpec of all partitions of the table.
listPartitions(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
Get CatalogPartitionSpec of all partitions that is under the given CatalogPartitionSpec in the table.
listPartitions() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsPartitionPushDown
Returns a list of all partitions that a source can read if available.
listPartitionsByFilter(ObjectPath, List<Expression>) - Method in interface org.apache.flink.table.catalog.Catalog
Get CatalogPartitionSpec of partitions by expression filters in the table.
listReadableMetadata() - Method in interface org.apache.flink.table.connector.format.DecodingFormat
Returns the map of metadata keys and their corresponding data types that can be produced by this format for reading.
listReadableMetadata() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsReadingMetadata
Returns the map of metadata keys and their corresponding data types that can be produced by this table source for reading.
listStatusWithoutHidden(FileSystem, Path) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
List file status without hidden files.
listTables(String) - Method in interface org.apache.flink.table.catalog.Catalog
Get names of all tables and views under this database.
ListView<T> - Class in org.apache.flink.table.api.dataview
A DataView that provides List-like functionality in the accumulator of an AggregateFunction or TableAggregateFunction when large amounts of data are expected.
ListView() - Constructor for class org.apache.flink.table.api.dataview.ListView
Creates a list view.
ListView(TypeInformation<?>) - Constructor for class org.apache.flink.table.api.dataview.ListView
Deprecated.
This method uses the old type system. Please use a DataTypeHint instead if the reflective type extraction is not successful.
listViews(String) - Method in interface org.apache.flink.table.catalog.Catalog
Get names of all views under this database.
ListViewSerializer<T> - Class in org.apache.flink.table.dataview
Deprecated.
ListViewSerializer(TypeSerializer<List<T>>) - Constructor for class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
ListViewSerializerSnapshot<T> - Class in org.apache.flink.table.dataview
Deprecated.
ListViewSerializerSnapshot() - Constructor for class org.apache.flink.table.dataview.ListViewSerializerSnapshot
Deprecated.
Constructor for read instantiation.
ListViewSerializerSnapshot(ListViewSerializer<T>) - Constructor for class org.apache.flink.table.dataview.ListViewSerializerSnapshot
Deprecated.
Constructor to create the snapshot for writing.
ListViewTypeInfo<T> - Class in org.apache.flink.table.dataview
Deprecated.
ListViewTypeInfo(TypeInformation<T>, boolean) - Constructor for class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
ListViewTypeInfo(TypeInformation<T>) - Constructor for class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
ListViewTypeInfoFactory<T> - Class in org.apache.flink.table.dataview
Deprecated.
ListViewTypeInfoFactory() - Constructor for class org.apache.flink.table.dataview.ListViewTypeInfoFactory
Deprecated.
 
listWritableMetadata() - Method in interface org.apache.flink.table.connector.format.EncodingFormat
Returns the map of metadata keys and their corresponding data types that can be consumed by this format for writing.
listWritableMetadata() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsWritingMetadata
Returns the map of metadata keys and their corresponding data types that can be consumed by this table sink for writing.
LITERAL - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that checks if an argument is a literal.
LITERAL_OR_NULL - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that checks if an argument is a literal or NULL.
LiteralArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy that checks if an argument is a literal.
LiteralArgumentTypeStrategy(boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
 
LiteralValue - Class in org.apache.flink.table.descriptors
Descriptor for a literal value.
LiteralValue() - Constructor for class org.apache.flink.table.descriptors.LiteralValue
 
LiteralValueValidator - Class in org.apache.flink.table.descriptors
Validator for LiteralValue.
LiteralValueValidator(String) - Constructor for class org.apache.flink.table.descriptors.LiteralValueValidator
 
LITTLE_ENDIAN - Static variable in class org.apache.flink.table.data.binary.BinaryRowData
 
LITTLE_ENDIAN - Static variable in class org.apache.flink.table.data.binary.BinarySegmentUtils
Constant that flags the byte order.
LN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
loadClass(String, ClassLoader) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
loadClass(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
LOCAL_DATE() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API LocalDate type.
LOCAL_DATE_TIME() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API LocalDateTime type.
LOCAL_TIME() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API LocalTime type.
LOCAL_TIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LOCAL_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
localTimeToUnixDate(LocalTime) - Static method in class org.apache.flink.table.utils.TimestampStringUtils
 
LocalZonedTimestampType - Class in org.apache.flink.table.types.logical
Logical type of a timestamp WITH LOCAL time zone consisting of year-month-day hour:minute:second[.fractional] zone with up to nanosecond precision and values ranging from 0000-01-01 00:00:00.000000000 +14:59 to 9999-12-31 23:59:59.999999999 -14:59.
LocalZonedTimestampType(boolean, TimestampKind, int) - Constructor for class org.apache.flink.table.types.logical.LocalZonedTimestampType
Internal constructor that allows attaching additional metadata about time attribute properties.
LocalZonedTimestampType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
LocalZonedTimestampType(int) - Constructor for class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
LocalZonedTimestampType() - Constructor for class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
LOG - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LOG10 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LOG2 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
logical(LogicalTypeRoot) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that corresponds to a given LogicalTypeRoot.
logical(LogicalTypeRoot, boolean) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that corresponds to a given LogicalTypeRoot and nullability.
logical(LogicalTypeFamily) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that corresponds to a given LogicalTypeFamily.
logical(LogicalTypeFamily, boolean) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that corresponds to a given LogicalTypeFamily and nullability.
logicalType - Variable in class org.apache.flink.table.types.DataType
 
LogicalType - Class in org.apache.flink.table.types.logical
A logical type that describes the data type of a value.
LogicalType(boolean, LogicalTypeRoot) - Constructor for class org.apache.flink.table.types.logical.LogicalType
 
LogicalTypeCasts - Class in org.apache.flink.table.types.logical.utils
Utilities for casting LogicalType.
LogicalTypeChecks - Class in org.apache.flink.table.types.logical.utils
Utilities for checking LogicalType and avoiding a lot of type casting and repetitive work.
LogicalTypeDataTypeConverter - Class in org.apache.flink.table.types.utils
A converter between LogicalType and DataType.
LogicalTypeDefaultVisitor<R> - Class in org.apache.flink.table.types.logical.utils
Implementation of LogicalTypeVisitor that redirects all calls to LogicalTypeDefaultVisitor.defaultMethod(LogicalType).
LogicalTypeDefaultVisitor() - Constructor for class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
LogicalTypeDuplicator - Class in org.apache.flink.table.types.logical.utils
Returns a deep copy of a LogicalType.
LogicalTypeDuplicator() - Constructor for class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
 
LogicalTypeFamily - Enum in org.apache.flink.table.types.logical
An enumeration of logical type families for clustering LogicalTypeRoots into categories.
LogicalTypeMerging - Class in org.apache.flink.table.types.logical.utils
Utilities for merging multiple LogicalType.
LogicalTypeParser - Class in org.apache.flink.table.types.logical.utils
Parser for creating instances of LogicalType from a serialized string created with LogicalType.asSerializableString().
LogicalTypeParser() - Constructor for class org.apache.flink.table.types.logical.utils.LogicalTypeParser
 
LogicalTypeRoot - Enum in org.apache.flink.table.types.logical
An enumeration of logical type roots containing static information about logical data types.
LogicalTypeUtils - Class in org.apache.flink.table.types.logical.utils
Utilities for handling LogicalTypes.
LogicalTypeVisitor<R> - Interface in org.apache.flink.table.types.logical
The visitor definition of LogicalType.
LONG() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API long or SQL BIGINT type.
LookupableTableSource<T> - Interface in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use LookupTableSource instead. See FLIP-95 for more information.
LookupTableSource - Interface in org.apache.flink.table.connector.source
A DynamicTableSource that looks up rows of an external storage system by one or more keys during runtime.
LookupTableSource.LookupContext - Interface in org.apache.flink.table.connector.source
Context for creating runtime implementation via a LookupTableSource.LookupRuntimeProvider.
LookupTableSource.LookupRuntimeProvider - Interface in org.apache.flink.table.connector.source
Provides actual runtime implementation for reading the data.
LOWER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LOWERCASE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LPAD - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LTRIM - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 

M

MAP(DataType, DataType) - Static method in class org.apache.flink.table.api.DataTypes
Data type of an associative array that maps keys (including NULL) to values (including NULL).
MAP(AbstractDataType<?>, AbstractDataType<?>) - Static method in class org.apache.flink.table.api.DataTypes
Unresolved data type of an associative array that maps keys (including NULL) to values (including NULL).
MAP(TypeInformation<K>, TypeInformation<V>) - Static method in class org.apache.flink.table.api.Types
Deprecated.
Generates type information for a Java HashMap.
MAP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
MAP - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns a DataTypes.MAP(DataType, DataType) with a key type equal to type of the first argument and a value type equal to the type of second argument.
MapData - Interface in org.apache.flink.table.data
Base interface of an internal data structure representing data of MapType or MultisetType.
MapInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
MapInputTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.MapInputTypeStrategy
 
mapping(Map<InputTypeStrategy, TypeStrategy>) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that maps an InputTypeStrategy to a TypeStrategy if the input strategy infers identical types.
MappingTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Type strategy that maps an InputTypeStrategy to a TypeStrategy if the input strategy infers compatible types.
MappingTypeStrategy(Map<InputTypeStrategy, TypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
 
MapType - Class in org.apache.flink.table.types.logical
Logical type of an associative array that maps keys (including NULL) to values (including NULL).
MapType(boolean, LogicalType, LogicalType) - Constructor for class org.apache.flink.table.types.logical.MapType
 
MapType(LogicalType, LogicalType) - Constructor for class org.apache.flink.table.types.logical.MapType
 
MapView<K,V> - Class in org.apache.flink.table.api.dataview
A DataView that provides Map-like functionality in the accumulator of an AggregateFunction or TableAggregateFunction when large amounts of data are expected.
MapView() - Constructor for class org.apache.flink.table.api.dataview.MapView
Creates a map view.
MapView(TypeInformation<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.api.dataview.MapView
Deprecated.
This method uses the old type system. Please use a DataTypeHint instead if the reflective type extraction is not successful.
MapViewSerializer<K,V> - Class in org.apache.flink.table.dataview
Deprecated.
MapViewSerializer(TypeSerializer<Map<K, V>>) - Constructor for class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
MapViewSerializerSnapshot<K,V> - Class in org.apache.flink.table.dataview
Deprecated.
MapViewSerializerSnapshot() - Constructor for class org.apache.flink.table.dataview.MapViewSerializerSnapshot
Deprecated.
Constructor for read instantiation.
MapViewSerializerSnapshot(MapViewSerializer<K, V>) - Constructor for class org.apache.flink.table.dataview.MapViewSerializerSnapshot
Deprecated.
Constructor to create the snapshot for writing.
MapViewTypeInfo<K,V> - Class in org.apache.flink.table.dataview
Deprecated.
MapViewTypeInfo(TypeInformation<K>, TypeInformation<V>, boolean, boolean) - Constructor for class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
MapViewTypeInfo(TypeInformation<K>, TypeInformation<V>) - Constructor for class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
MapViewTypeInfoFactory<K,V> - Class in org.apache.flink.table.dataview
Deprecated.
MapViewTypeInfoFactory() - Constructor for class org.apache.flink.table.dataview.MapViewTypeInfoFactory
Deprecated.
 
matchFamily(int, LogicalTypeFamily) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the given argument if it is of the same logical type family.
MatchFamilyTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Type strategy that returns the given argument if it is of the same logical type family.
MatchFamilyTypeStrategy(int, LogicalTypeFamily) - Constructor for class org.apache.flink.table.types.inference.strategies.MatchFamilyTypeStrategy
 
materialize(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
 
materialize(TypeSerializer<String>) - Method in class org.apache.flink.table.data.binary.BinaryStringData
 
materialize(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
Materialize java object to binary format.
MAX - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
MAX_COLUMN_WIDTH - Static variable in class org.apache.flink.table.utils.PrintUtils
 
MAX_DAY_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
MAX_FIX_PART_DATA_SIZE - Static variable in interface org.apache.flink.table.data.binary.BinaryFormat
It decides whether to put data in FixLenPart or VarLenPart.
MAX_FRACTIONAL_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
MAX_LENGTH - Static variable in class org.apache.flink.table.types.logical.BinaryType
 
MAX_LENGTH - Static variable in class org.apache.flink.table.types.logical.CharType
 
MAX_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarBinaryType
 
MAX_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarCharType
 
MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.DecimalType
 
MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimestampType
 
MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimeType
 
MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.ZonedTimestampType
 
MD5 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
md5(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
merge(ColumnStats) - Method in class org.apache.flink.table.plan.stats.ColumnStats
Merges two column stats.
merge(TableStats) - Method in class org.apache.flink.table.plan.stats.TableStats
Merges two table stats.
metadata(String, DataType) - Static method in class org.apache.flink.table.api.TableColumn
Deprecated.
Creates a metadata column from metadata of the given column name.
metadata(String, DataType, boolean) - Static method in class org.apache.flink.table.api.TableColumn
Deprecated.
Creates a metadata column from metadata of the given column name.
metadata(String, DataType, String) - Static method in class org.apache.flink.table.api.TableColumn
Deprecated.
Creates a metadata column from metadata of the given alias.
metadata(String, DataType, String, boolean) - Static method in class org.apache.flink.table.api.TableColumn
Deprecated.
Creates a metadata column from metadata of the given column name or from metadata of the given alias (if not null).
metadata(String, DataType, String, boolean) - Static method in class org.apache.flink.table.catalog.Column
Creates a metadata column from metadata of the given column name or from metadata of the given key (if not null).
METADATA - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
MIN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
MIN_DAY_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
MIN_FRACTIONAL_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
MIN_LENGTH - Static variable in class org.apache.flink.table.types.logical.BinaryType
 
MIN_LENGTH - Static variable in class org.apache.flink.table.types.logical.CharType
 
MIN_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarBinaryType
 
MIN_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarCharType
 
MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.DecimalType
 
MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimestampType
 
MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimeType
 
MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.ZonedTimestampType
 
MIN_SCALE - Static variable in class org.apache.flink.table.types.logical.DecimalType
 
MINUS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
Combines numeric subtraction and "datetime - interval" arithmetic.
MINUS_PREFIX - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
MINUTE() - Static method in class org.apache.flink.table.api.DataTypes
Resolution in minutes.
MISSING - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Placeholder for a missing type strategy.
MissingTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Placeholder for a missing type strategy.
MissingTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
 
MOD - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
Module - Interface in org.apache.flink.table.module
Modules define a set of metadata, including functions, user defined types, operators, rules, etc.
MODULE_TYPE - Static variable in class org.apache.flink.table.descriptors.ModuleDescriptorValidator
Key for describing the type of the module.
MODULE_TYPE_CORE - Static variable in class org.apache.flink.table.descriptors.CoreModuleDescriptorValidator
 
ModuleDescriptor - Class in org.apache.flink.table.descriptors
Describes a Module.
ModuleDescriptor(String) - Constructor for class org.apache.flink.table.descriptors.ModuleDescriptor
Constructs a ModuleDescriptor.
ModuleDescriptorValidator - Class in org.apache.flink.table.descriptors
Validator for ModuleDescriptor.
ModuleDescriptorValidator() - Constructor for class org.apache.flink.table.descriptors.ModuleDescriptorValidator
 
ModuleFactory - Interface in org.apache.flink.table.factories
A factory to create configured module instances based on string-based properties.
MONTH() - Static method in class org.apache.flink.table.api.DataTypes
Resolution in months.
MULTISET(DataType) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a multiset (=bag).
MULTISET(AbstractDataType<?>) - Static method in class org.apache.flink.table.api.DataTypes
Unresolved data type of a multiset (=bag).
MULTISET(TypeInformation<E>) - Static method in class org.apache.flink.table.api.Types
Deprecated.
Generates type information for a Multiset.
MultisetType - Class in org.apache.flink.table.types.logical
Logical type of a multiset (=bag).
MultisetType(boolean, LogicalType) - Constructor for class org.apache.flink.table.types.logical.MultisetType
 
MultisetType(LogicalType) - Constructor for class org.apache.flink.table.types.logical.MultisetType
 

N

name - Variable in class org.apache.flink.table.api.DataTypes.AbstractField
 
name - Variable in class org.apache.flink.table.catalog.Column
 
NAME - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
name() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
name(String) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
namedArguments(String...) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
namedArguments(List<String>) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
Sets the list of argument names for specifying a fixed, not overloaded, not vararg input signature explicitly.
namedArguments(String...) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
 
NestedFieldsProjectableTableSource<T> - Interface in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use SupportsProjectionPushDown instead. See FLIP-95 for more information.
NestedRowData - Class in org.apache.flink.table.data.binary
Its memory storage structure is exactly the same with BinaryRowData.
NestedRowData(int) - Constructor for class org.apache.flink.table.data.binary.NestedRowData
 
newBuilder() - Static method in class org.apache.flink.table.api.Schema
Builder for configuring and creating instances of Schema.
newBuilder() - Static method in class org.apache.flink.table.connector.ChangelogMode
Builder for configuring and creating instances of ChangelogMode.
newBuilder() - Static method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
Builder for configuring and creating instances of BuiltInFunctionDefinition.
newBuilder() - Static method in class org.apache.flink.table.types.inference.TypeInference
Builder for configuring and creating instances of TypeInference.
newBuilder(ObjectIdentifier, LogicalType) - Static method in class org.apache.flink.table.types.logical.DistinctType
Creates a builder for a DistinctType.
newBuilder(ObjectIdentifier) - Static method in class org.apache.flink.table.types.logical.StructuredType
Creates a builder for a StructuredType that has been stored in a catalog and is identified by an ObjectIdentifier.
newBuilder(ObjectIdentifier, Class<?>) - Static method in class org.apache.flink.table.types.logical.StructuredType
Creates a builder for a StructuredType that has been stored in a catalog and is identified by an ObjectIdentifier.
newBuilder(Class<?>) - Static method in class org.apache.flink.table.types.logical.StructuredType
Creates a builder for a StructuredType that is not stored in a catalog and is identified by an implementation Class.
newListViewDataType(DataType) - Static method in class org.apache.flink.table.api.dataview.ListView
Utility method for creating a DataType of ListView explicitly.
newMapViewDataType(DataType, DataType) - Static method in class org.apache.flink.table.api.dataview.MapView
Utility method for creating a DataType of MapView explicitly.
newValidationError(String, Object...) - Method in interface org.apache.flink.table.types.inference.CallContext
Creates a validation error for exiting the type inference process with a meaningful exception.
NO_ARGS - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that does not expect any arguments.
NoMatchingTableFactoryException - Exception in org.apache.flink.table.api
Exception for not finding a TableFactory for the given properties.
NoMatchingTableFactoryException(String, String, Class<?>, List<TableFactory>, Map<String, String>, Throwable) - Constructor for exception org.apache.flink.table.api.NoMatchingTableFactoryException
 
NoMatchingTableFactoryException(String, Class<?>, List<TableFactory>, Map<String, String>) - Constructor for exception org.apache.flink.table.api.NoMatchingTableFactoryException
 
NoMatchingTableFactoryException(String, String, Class<?>, List<TableFactory>, Map<String, String>) - Constructor for exception org.apache.flink.table.api.NoMatchingTableFactoryException
 
normalizeName(String) - Static method in class org.apache.flink.table.functions.FunctionIdentifier
Normalize a function name.
normalizeObjectIdentifier(ObjectIdentifier) - Static method in class org.apache.flink.table.functions.FunctionIdentifier
Normalize an object identifier by only normalizing the function name.
NOT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
NOT_BETWEEN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
NOT_EQUALS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
notDeterministic() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
notNull() - Method in interface org.apache.flink.table.types.AbstractDataType
Adds a hint that null values are not expected in the data for this type.
notNull() - Method in class org.apache.flink.table.types.AtomicDataType
 
notNull() - Method in class org.apache.flink.table.types.CollectionDataType
 
notNull() - Method in class org.apache.flink.table.types.FieldsDataType
 
notNull() - Method in class org.apache.flink.table.types.KeyValueDataType
 
notNull() - Method in class org.apache.flink.table.types.UnresolvedDataType
 
noValidation() - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns an empty validation logic.
NULL() - Static method in class org.apache.flink.table.api.DataTypes
Data type for representing untyped NULL values.
NULL_COLUMN - Static variable in class org.apache.flink.table.utils.PrintUtils
 
nullable() - Method in interface org.apache.flink.table.types.AbstractDataType
Adds a hint that null values are expected in the data for this type (default behavior).
nullable() - Method in class org.apache.flink.table.types.AtomicDataType
 
nullable() - Method in class org.apache.flink.table.types.CollectionDataType
 
nullable() - Method in class org.apache.flink.table.types.FieldsDataType
 
nullable(ConstantArgumentCount, TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
A type strategy that can be used to make a result type nullable if any of the selected input arguments is nullable.
nullable(TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
A type strategy that can be used to make a result type nullable if any of the input arguments is nullable.
nullable() - Method in class org.apache.flink.table.types.KeyValueDataType
 
nullable() - Method in class org.apache.flink.table.types.UnresolvedDataType
 
NullableTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
A type strategy that can be used to make a result type nullable if any of the selected input arguments is nullable.
NullableTypeStrategy(ConstantArgumentCount, TypeStrategy) - Constructor for class org.apache.flink.table.types.inference.strategies.NullableTypeStrategy
 
NullAwareGetters - Interface in org.apache.flink.table.data.binary
Provides null related getters.
NullAwareMapSerializer<K,V> - Class in org.apache.flink.table.dataview
Deprecated.
NullAwareMapSerializer(TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
NullAwareMapSerializerSnapshot<K,V> - Class in org.apache.flink.table.dataview
Deprecated.
NullAwareMapSerializerSnapshot() - Constructor for class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
Deprecated.
Constructor for read instantiation.
NullAwareMapSerializerSnapshot(NullAwareMapSerializer<K, V>) - Constructor for class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
Deprecated.
Constructor to create the snapshot for writing.
NullSerializer - Class in org.apache.flink.table.dataview
A serializer for null.
NullSerializer.NullSerializerSnapshot - Class in org.apache.flink.table.dataview
Serializer configuration snapshot for compatibility and format evolution.
NullSerializerSnapshot() - Constructor for class org.apache.flink.table.dataview.NullSerializer.NullSerializerSnapshot
 
NullType - Class in org.apache.flink.table.types.logical
Logical type for representing untyped NULL values.
NullType() - Constructor for class org.apache.flink.table.types.logical.NullType
 
numChars() - Method in class org.apache.flink.table.data.binary.BinaryStringData
Returns the number of UTF-8 code points in the string.

O

OBJECT_ARRAY(TypeInformation<E>) - Static method in class org.apache.flink.table.api.Types
Deprecated.
Generates type information for an array consisting of Java object elements.
ObjectIdentifier - Class in org.apache.flink.table.catalog
Identifies an object in a catalog.
ObjectPath - Class in org.apache.flink.table.catalog
A database name and object (table/view/function) name combo in a catalog.
ObjectPath(String, String) - Constructor for class org.apache.flink.table.catalog.ObjectPath
 
of(Class<?>) - Static method in class org.apache.flink.table.api.DataTypes
Creates an unresolved type that will be resolved to a DataType by analyzing the given class later.
of(String) - Static method in class org.apache.flink.table.api.DataTypes
Creates an unresolved type that will be resolved to a DataType by using a fully or partially defined name.
of(TypeInformation<?>) - Static method in class org.apache.flink.table.api.DataTypes
Creates an unresolved type that will be resolved to a DataType by converting the given TypeInformation later.
of(String, DataType) - Static method in class org.apache.flink.table.api.TableColumn
Deprecated.
of(String, DataType, String) - Static method in class org.apache.flink.table.api.TableColumn
of(Schema, String, List<String>, Map<String, String>) - Static method in interface org.apache.flink.table.catalog.CatalogTable
Creates a basic implementation of this interface.
of(Schema, String, String, String, Map<String, String>) - Static method in interface org.apache.flink.table.catalog.CatalogView
Creates a basic implementation of this interface.
of(String, String, String) - Static method in class org.apache.flink.table.catalog.ObjectIdentifier
 
of(List<Column>) - Static method in class org.apache.flink.table.catalog.ResolvedSchema
Shortcut for a resolved schema of only columns.
of(Column...) - Static method in class org.apache.flink.table.catalog.ResolvedSchema
Shortcut for a resolved schema of only columns.
of(String...) - Static method in class org.apache.flink.table.catalog.UnresolvedIdentifier
Constructs an UnresolvedIdentifier from an array of identifier segments.
of(List<String>) - Static method in class org.apache.flink.table.catalog.UnresolvedIdentifier
Constructs an UnresolvedIdentifier from a list of identifier segments.
of(String, ResolvedExpression) - Static method in class org.apache.flink.table.catalog.WatermarkSpec
 
of(OutputFormat<RowData>) - Static method in interface org.apache.flink.table.connector.sink.OutputFormatProvider
Helper method for creating a static provider.
of(OutputFormat<RowData>, Integer) - Static method in interface org.apache.flink.table.connector.sink.OutputFormatProvider
Helper method for creating a static provider with a provided sink parallelism.
of(Sink<RowData, ?, ?, ?>) - Static method in interface org.apache.flink.table.connector.sink.SinkProvider
Helper method for creating a static provider.
of(Sink<RowData, ?, ?, ?>, Integer) - Static method in interface org.apache.flink.table.connector.sink.SinkProvider
Helper method for creating a Sink provider with a provided sink parallelism.
of(List<ResolvedExpression>, List<ResolvedExpression>) - Static method in class org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown.Result
Constructs a filter push-down result.
of(AsyncTableFunction<T>) - Static method in interface org.apache.flink.table.connector.source.AsyncTableFunctionProvider
Helper method for creating a static provider.
of(InputFormat<RowData, ?>) - Static method in interface org.apache.flink.table.connector.source.InputFormatProvider
Helper method for creating a static provider.
of(Source<RowData, ?, ?>) - Static method in interface org.apache.flink.table.connector.source.SourceProvider
Helper method for creating a static provider.
of(TableFunction<T>) - Static method in interface org.apache.flink.table.connector.source.TableFunctionProvider
Helper method for creating a static provider.
of(Object...) - Static method in class org.apache.flink.table.data.GenericRowData
Creates an instance of GenericRowData with given field values.
of(String) - Method in class org.apache.flink.table.descriptors.ClassInstance
Sets the fully qualified class name for creating an instance.
of(TypeInformation<?>) - Method in class org.apache.flink.table.descriptors.LiteralValue
Type information of the literal value.
of(String) - Method in class org.apache.flink.table.descriptors.LiteralValue
Type string of the literal value.
of(ObjectIdentifier) - Static method in class org.apache.flink.table.functions.FunctionIdentifier
 
of(String) - Static method in class org.apache.flink.table.functions.FunctionIdentifier
 
of(int) - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
 
of(String, String) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
Returns an instance of Signature.Argument.
of(String) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
Returns an instance of Signature.Argument.
of(Signature.Argument...) - Static method in class org.apache.flink.table.types.inference.Signature
Creates an immutable instance of Signature.
of(List<Signature.Argument>) - Static method in class org.apache.flink.table.types.inference.Signature
Creates an immutable instance of Signature.
of(String, FunctionDefinition, TypeInference, int, int, boolean) - Static method in interface org.apache.flink.table.types.inference.TypeInferenceUtil.SurroundingInfo
 
of(DataType) - Static method in interface org.apache.flink.table.types.inference.TypeInferenceUtil.SurroundingInfo
 
of(LogicalType...) - Static method in class org.apache.flink.table.types.logical.RowType
 
of(boolean, LogicalType...) - Static method in class org.apache.flink.table.types.logical.RowType
 
of(LogicalType[], String[]) - Static method in class org.apache.flink.table.types.logical.RowType
 
of(boolean, LogicalType[], String[]) - Static method in class org.apache.flink.table.types.logical.RowType
 
ofEmptyLiteral() - Static method in class org.apache.flink.table.types.logical.BinaryType
The SQL standard defines that character string literals are allowed to be zero-length strings (i.e., to contain no characters) even though it is not permitted to declare a type that is zero.
ofEmptyLiteral() - Static method in class org.apache.flink.table.types.logical.CharType
The SQL standard defines that character string literals are allowed to be zero-length strings (i.e., to contain no characters) even though it is not permitted to declare a type that is zero.
ofEmptyLiteral() - Static method in class org.apache.flink.table.types.logical.VarBinaryType
The SQL standard defines that character string literals are allowed to be zero-length strings (i.e., to contain no characters) even though it is not permitted to declare a type that is zero.
ofEmptyLiteral() - Static method in class org.apache.flink.table.types.logical.VarCharType
The SQL standard defines that character string literals are allowed to be zero-length strings (i.e., to contain no characters) even though it is not permitted to declare a type that is zero.
offset - Variable in class org.apache.flink.table.data.binary.BinarySection
 
ofKind(RowKind, Object...) - Static method in class org.apache.flink.table.data.GenericRowData
Creates an instance of GenericRowData with given kind and field values.
onCreateTemporaryFunction(ObjectPath, CatalogFunction) - Method in interface org.apache.flink.table.catalog.TemporaryOperationListener
This method is called when a temporary function is to be created in this catalog.
onCreateTemporaryTable(ObjectPath, CatalogBaseTable) - Method in interface org.apache.flink.table.catalog.TemporaryOperationListener
This method is called when a temporary table or view is to be created in this catalog.
onDropTemporaryFunction(ObjectPath) - Method in interface org.apache.flink.table.catalog.TemporaryOperationListener
This method is called when a temporary function in this catalog is to be dropped.
onDropTemporaryTable(ObjectPath) - Method in interface org.apache.flink.table.catalog.TemporaryOperationListener
This method is called when a temporary table or view in this catalog is to be dropped.
open() - Method in interface org.apache.flink.table.catalog.Catalog
Open the catalog.
open(RuntimeConverter.Context) - Method in interface org.apache.flink.table.connector.RuntimeConverter
Initializes the converter during runtime.
open(FunctionContext) - Method in class org.apache.flink.table.functions.UserDefinedFunction
Setup method for user-defined function.
optionalOptions() - Method in interface org.apache.flink.table.factories.CatalogFactory
 
optionalOptions() - Method in interface org.apache.flink.table.factories.Factory
Returns a set of ConfigOption that an implementation of this factory consumes in addition to Factory.requiredOptions().
OR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
or(InputTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a disjunction of multiple InputTypeStrategys into one like f(NUMERIC) || f(STRING).
or(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a disjunction of multiple ArgumentTypeStrategys into one like f(NUMERIC || STRING).
OrArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for inferring and validating an argument using a disjunction of multiple ArgumentTypeStrategys into one like f(NUMERIC || STRING).
OrArgumentTypeStrategy(List<? extends ArgumentTypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
 
ORDER_ASC - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ORDER_DESC - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ORDERING - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
org.apache.flink.table.annotation - package org.apache.flink.table.annotation
 
org.apache.flink.table.api - package org.apache.flink.table.api
 
org.apache.flink.table.api.constraints - package org.apache.flink.table.api.constraints
 
org.apache.flink.table.api.dataview - package org.apache.flink.table.api.dataview
 
org.apache.flink.table.catalog - package org.apache.flink.table.catalog
 
org.apache.flink.table.catalog.exceptions - package org.apache.flink.table.catalog.exceptions
 
org.apache.flink.table.catalog.stats - package org.apache.flink.table.catalog.stats
 
org.apache.flink.table.connector - package org.apache.flink.table.connector
 
org.apache.flink.table.connector.format - package org.apache.flink.table.connector.format
 
org.apache.flink.table.connector.sink - package org.apache.flink.table.connector.sink
 
org.apache.flink.table.connector.sink.abilities - package org.apache.flink.table.connector.sink.abilities
 
org.apache.flink.table.connector.source - package org.apache.flink.table.connector.source
 
org.apache.flink.table.connector.source.abilities - package org.apache.flink.table.connector.source.abilities
 
org.apache.flink.table.data - package org.apache.flink.table.data
 
org.apache.flink.table.data.binary - package org.apache.flink.table.data.binary
 
org.apache.flink.table.data.utils - package org.apache.flink.table.data.utils
 
org.apache.flink.table.dataview - package org.apache.flink.table.dataview
 
org.apache.flink.table.descriptors - package org.apache.flink.table.descriptors
 
org.apache.flink.table.expressions - package org.apache.flink.table.expressions
 
org.apache.flink.table.factories - package org.apache.flink.table.factories
 
org.apache.flink.table.functions - package org.apache.flink.table.functions
 
org.apache.flink.table.functions.python - package org.apache.flink.table.functions.python
 
org.apache.flink.table.functions.python.utils - package org.apache.flink.table.functions.python.utils
 
org.apache.flink.table.module - package org.apache.flink.table.module
 
org.apache.flink.table.plan.stats - package org.apache.flink.table.plan.stats
 
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.tsextractors - package org.apache.flink.table.sources.tsextractors
 
org.apache.flink.table.sources.wmstrategies - package org.apache.flink.table.sources.wmstrategies
 
org.apache.flink.table.types - package org.apache.flink.table.types
 
org.apache.flink.table.types.extraction - package org.apache.flink.table.types.extraction
 
org.apache.flink.table.types.inference - package org.apache.flink.table.types.inference
 
org.apache.flink.table.types.inference.strategies - package org.apache.flink.table.types.inference.strategies
 
org.apache.flink.table.types.inference.transforms - package org.apache.flink.table.types.inference.transforms
 
org.apache.flink.table.types.inference.utils - package org.apache.flink.table.types.inference.utils
 
org.apache.flink.table.types.logical - package org.apache.flink.table.types.logical
 
org.apache.flink.table.types.logical.utils - package org.apache.flink.table.types.logical.utils
 
org.apache.flink.table.types.utils - package org.apache.flink.table.types.utils
 
org.apache.flink.table.typeutils - package org.apache.flink.table.typeutils
 
org.apache.flink.table.util - package org.apache.flink.table.util
 
org.apache.flink.table.utils - package org.apache.flink.table.utils
 
OrInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for inferring and validating the input using a disjunction of multiple InputTypeStrategys into one like f(NUMERIC) || f(STRING).
OrInputTypeStrategy(List<? extends InputTypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
 
OUTPUT_IF_NULL - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for inferring an unknown argument type from the function's output DataType if available.
OutputArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for inferring an unknown argument type from the function's output DataType if available.
OutputArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
 
OutputFormatProvider - Interface in org.apache.flink.table.connector.sink
Provider of an OutputFormat instance as a runtime implementation for DynamicTableSink.
outputTypeStrategy(TypeStrategy) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
outputTypeStrategy(TypeStrategy) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
Sets the strategy for inferring the final output data type of a function call.
OVER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
OVERLAY - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
OverwritableTableSink - Interface in org.apache.flink.table.sinks
Deprecated.
This interface will not be supported in the new sink design around DynamicTableSink which only works with the Blink planner. Use SupportsOverwrite instead. See FLIP-95 for more information.

P

ParallelismProvider - Interface in org.apache.flink.table.connector
Parallelism provider for other connector providers.
parameter(String, String) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of literal type.
parameter(TypeInformation<?>, String) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of literal type.
parameter(boolean) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of BOOLEAN type.
parameter(double) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of DOUBLE type.
parameter(float) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of FLOAT type.
parameter(int) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of INT type.
parameter(String) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of VARCHAR type.
parameter(long) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of BIGINT type.
parameter(byte) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of TINYINT type.
parameter(short) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of SMALLINT type.
parameter(BigDecimal) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of DECIMAL type.
parameter(ClassInstance) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of a class instance (i.e.
parameterNames - Variable in class org.apache.flink.table.types.extraction.ExtractionUtils.AssigningConstructor
 
parameterString(String) - Method in class org.apache.flink.table.descriptors.ClassInstance
Adds a constructor parameter value of literal type.
parse(String, ClassLoader) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeParser
Parses a type string.
parse(String) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeParser
Parses a type string.
PARTITION_KEYS - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
PartitionableTableSink - Interface in org.apache.flink.table.sinks
Deprecated.
This interface will not be supported in the new sink design around DynamicTableSink which only works with the Blink planner. Use SupportsPartitioning instead. See FLIP-95 for more information.
PartitionableTableSource - Interface in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use SupportsPartitionPushDown instead. See FLIP-95 for more information.
PartitionAlreadyExistsException - Exception in org.apache.flink.table.catalog.exceptions
Exception for trying to create a partition that already exists.
PartitionAlreadyExistsException(String, ObjectPath, CatalogPartitionSpec) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionAlreadyExistsException
 
PartitionAlreadyExistsException(String, ObjectPath, CatalogPartitionSpec, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionAlreadyExistsException
 
partitionExists(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
Check whether a partition exists or not.
PartitionNotExistException - Exception in org.apache.flink.table.catalog.exceptions
Exception for operation on a partition that doesn't exist.
PartitionNotExistException(String, ObjectPath, CatalogPartitionSpec) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionNotExistException
 
PartitionNotExistException(String, ObjectPath, CatalogPartitionSpec, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionNotExistException
 
PartitionPathUtils - Class in org.apache.flink.table.utils
Utils for file system.
PartitionPathUtils() - Constructor for class org.apache.flink.table.utils.PartitionPathUtils
 
PartitionSpecInvalidException - Exception in org.apache.flink.table.catalog.exceptions
Exception for invalid PartitionSpec compared with partition key list of a partitioned Table.
PartitionSpecInvalidException(String, List<String>, ObjectPath, CatalogPartitionSpec) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionSpecInvalidException
 
PartitionSpecInvalidException(String, List<String>, ObjectPath, CatalogPartitionSpec, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionSpecInvalidException
 
path(String) - Method in class org.apache.flink.table.descriptors.FileSystem
Sets the path to a file or directory in a file system.
physical(String, DataType) - Static method in class org.apache.flink.table.api.TableColumn
Deprecated.
Creates a regular table column that represents physical data.
physical(String, DataType) - Static method in class org.apache.flink.table.catalog.Column
Creates a regular table column that represents physical data.
physical(List<String>, List<DataType>) - Static method in class org.apache.flink.table.catalog.ResolvedSchema
Shortcut for a resolved schema of only physical columns.
physical(String[], DataType[]) - Static method in class org.apache.flink.table.catalog.ResolvedSchema
Shortcut for a resolved schema of only physical columns.
PI - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
PLACEHOLDER_SYMBOL - Static variable in class org.apache.flink.table.factories.FactoryUtil
The placeholder symbol to be used for keys of options which can be templated.
PLUS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
Combines numeric addition, "datetime + interval"/"interval + interval" arithmetic, and string concatenation.
pointTo(MemorySegment[], int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
pointTo(MemorySegment[], int, int) - Method in class org.apache.flink.table.data.binary.BinaryMapData
 
pointTo(MemorySegment, int, int) - Method in class org.apache.flink.table.data.binary.BinarySection
 
pointTo(MemorySegment[], int, int) - Method in class org.apache.flink.table.data.binary.BinarySection
 
POSITION - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
POWER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
precision() - Method in class org.apache.flink.table.data.DecimalData
Returns the precision of this DecimalData.
PRECISION - Static variable in class org.apache.flink.table.types.logical.BigIntType
 
PRECISION - Static variable in class org.apache.flink.table.types.logical.DoubleType
 
PRECISION - Static variable in class org.apache.flink.table.types.logical.FloatType
 
PRECISION - Static variable in class org.apache.flink.table.types.logical.IntType
 
PRECISION - Static variable in class org.apache.flink.table.types.logical.SmallIntType
 
PRECISION - Static variable in class org.apache.flink.table.types.logical.TinyIntType
 
prepareInstance(ReadableConfig, UserDefinedFunction) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Prepares a UserDefinedFunction instance for usage in the API.
PreserveWatermarks - Class in org.apache.flink.table.sources.wmstrategies
A strategy which indicates the watermarks should be preserved from the underlying datastream.
PreserveWatermarks() - Constructor for class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
 
PRIMARY_KEY_COLUMNS - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
PRIMARY_KEY_NAME - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
primaryKey(String, List<String>) - Static method in class org.apache.flink.table.api.constraints.UniqueConstraint
Deprecated.
Creates a non enforced ConstraintType#PRIMARY_KEY constraint.
primaryKey(String...) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a primary key constraint for a set of given columns.
primaryKey(List<String>) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a primary key constraint for a set of given columns.
primaryKey(String...) - Method in class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
Creates a primary key constraint for a set of given columns.
primaryKey(String, String[]) - Method in class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
Creates a primary key constraint for a set of given columns.
primaryKey(String, List<String>) - Static method in class org.apache.flink.table.catalog.UniqueConstraint
Creates a non enforced ConstraintType#PRIMARY_KEY constraint.
primaryKeyNamed(String, String...) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a primary key constraint for a set of given columns.
primaryKeyNamed(String, List<String>) - Method in class org.apache.flink.table.api.Schema.Builder
Declares a primary key constraint for a set of given columns.
PRIMITIVE_ARRAY(TypeInformation<?>) - Static method in class org.apache.flink.table.api.Types
Deprecated.
Generates type information for an array consisting of Java primitive elements.
primitiveToWrapper(Class<?>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Converts the specified primitive Class object to its corresponding wrapper Class object.
printAsTableauForm(ResolvedSchema, Iterator<Row>, PrintWriter, ZoneId) - Static method in class org.apache.flink.table.utils.PrintUtils
Displays the result in a tableau form.
printAsTableauForm(ResolvedSchema, Iterator<Row>, PrintWriter, int, String, boolean, boolean, ZoneId) - Static method in class org.apache.flink.table.utils.PrintUtils
Displays the result in a tableau form.
printSingleRow(int[], String[], PrintWriter) - Static method in class org.apache.flink.table.utils.PrintUtils
 
PrintUtils - Class in org.apache.flink.table.utils
Utilities for print formatting.
proctime() - Method in class org.apache.flink.table.descriptors.Schema
Specifies the previously defined field as a processing-time attribute.
PROCTIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
PROCTIME_BATCH_MARKER - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
PROCTIME_INDICATOR - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
PROCTIME_STREAM_MARKER - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
ProjectableTableSource<T> - Interface in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use SupportsProjectionPushDown instead. See FLIP-95 for more information.
projectFields(int[]) - Method in interface org.apache.flink.table.sources.ProjectableTableSource
Deprecated.
Creates a copy of the TableSource that projects its output to the given field indexes.
projectNestedFields(int[], String[][]) - Method in interface org.apache.flink.table.sources.NestedFieldsProjectableTableSource
Deprecated.
Creates a copy of the TableSource that projects its output to the given field indexes.
projectRow(DataType, int[][]) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Projects a (possibly nested) row data type by returning a new data type that only includes fields of the given index paths.
projectRow(DataType, int[]) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Projects a (possibly nested) row data type by returning a new data type that only includes fields of the given indices.
projectSchema(TableSchema, int[][]) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
Creates a new TableSchema with the projected fields from another TableSchema.
properties(Map<String, String>) - Method in class org.apache.flink.table.descriptors.CustomConnectorDescriptor
Adds a set of properties for the connector.
property(String, String) - Method in class org.apache.flink.table.descriptors.CustomConnectorDescriptor
Adds a configuration property for the connector.
PROPERTY_VERSION - Static variable in class org.apache.flink.table.factories.FactoryUtil
Describes the property version.
put(K, V) - Method in class org.apache.flink.table.api.dataview.MapView
Inserts a value for the given key into the map view.
putAll(Map<K, V>) - Method in class org.apache.flink.table.api.dataview.MapView
Inserts all mappings from the specified map to this map view.
putBoolean(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds a boolean under the given key.
putCharacter(String, char) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds a character under the given key.
putClass(String, Class<?>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds a class under the given key.
putIndexedFixedProperties(String, List<String>, List<List<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds an indexed sequence of properties (with sub-properties) under a common key.
putIndexedOptionalProperties(String, List<String>, List<List<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds an indexed sequence of properties (with sub-properties) under a common key.
putIndexedVariableProperties(String, List<Map<String, String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds an indexed mapping of properties under a common key.
putInt(String, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds an integer under the given key.
putLong(String, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds a long under the given key.
putMemorySize(String, MemorySize) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds a Flink MemorySize under the given key.
putPartitionKeys(List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds table partition keys.
putProperties(Map<String, String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds a set of properties.
putProperties(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds a set of descriptor properties.
putPropertiesWithPrefix(String, Map<String, String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds a properties map by appending the given prefix to element keys with a dot.
putString(String, String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds a string under the given key.
putTableSchema(String, TableSchema) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Adds a table schema under the given key.
PythonAggregateFunction - Class in org.apache.flink.table.functions.python
The wrapper of user defined python aggregate function.
PythonAggregateFunction(String, byte[], DataType[], DataType, DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonAggregateFunction
 
PythonAggregateFunctionInfo - Class in org.apache.flink.table.functions.python
PythonAggregateFunctionInfo contains the execution information of a Python aggregate function, such as: the actual Python aggregation function, the input arguments, the filter arg, the distinct flag, etc.
PythonAggregateFunctionInfo(PythonFunction, Object[], int, boolean) - Constructor for class org.apache.flink.table.functions.python.PythonAggregateFunctionInfo
 
PythonEnv - Class in org.apache.flink.table.functions.python
Python execution environments.
PythonEnv(PythonEnv.ExecType) - Constructor for class org.apache.flink.table.functions.python.PythonEnv
 
PythonEnv.ExecType - Enum in org.apache.flink.table.functions.python
The Execution type specifies how to execute the Python function.
PythonFunction - Interface in org.apache.flink.table.functions.python
The base interface of a wrapper of a Python function.
PythonFunctionInfo - Class in org.apache.flink.table.functions.python
PythonFunctionInfo contains the execution information of a Python function, such as: the actual Python function, the input arguments, etc.
PythonFunctionInfo(PythonFunction, Object[]) - Constructor for class org.apache.flink.table.functions.python.PythonFunctionInfo
 
PythonFunctionKind - Enum in org.apache.flink.table.functions.python
Categorizes the Python functions.
PythonFunctionUtils - Enum in org.apache.flink.table.functions.python.utils
Utilities for creating PythonFunction from the fully qualified name of a Python function.
PythonFunctionValidator - Class in org.apache.flink.table.descriptors
Validator of python function.
PythonFunctionValidator() - Constructor for class org.apache.flink.table.descriptors.PythonFunctionValidator
 
PythonScalarFunction - Class in org.apache.flink.table.functions.python
The wrapper of user defined python scalar function.
PythonScalarFunction(String, byte[], TypeInformation[], TypeInformation, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonScalarFunction
 
PythonTableAggregateFunction - Class in org.apache.flink.table.functions.python
The wrapper of user defined python table aggregate function.
PythonTableAggregateFunction(String, byte[], DataType[], DataType, DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
PythonTableFunction - Class in org.apache.flink.table.functions.python
The wrapper of user defined python table function.
PythonTableFunction(String, byte[], TypeInformation[], RowTypeInfo, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonTableFunction
 

R

RADIANS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
RAND - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
RAND_INTEGER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
RANGE_TO - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
RAW(Class<T>, TypeSerializer<T>) - Static method in class org.apache.flink.table.api.DataTypes
Data type of an arbitrary serialized type.
RAW(Class<T>) - Static method in class org.apache.flink.table.api.DataTypes
Unresolved data type of an arbitrary serialized type.
RAW(TypeInformation<T>) - Static method in class org.apache.flink.table.api.DataTypes
Data type of an arbitrary serialized type backed by TypeInformation.
RawType<T> - Class in org.apache.flink.table.types.logical
Logical type of an arbitrary serialized type.
RawType(boolean, Class<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.table.types.logical.RawType
 
RawType(Class<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.table.types.logical.RawType
 
RawValueData<T> - Interface in org.apache.flink.table.data
An internal data structure representing data of RawType.
readArrayData(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Gets an instance of ArrayData from underlying MemorySegment.
readBinary(MemorySegment[], int, int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Get binary, if len less than 8, will be include in variablePartOffsetAndLen.
readDecimalData(MemorySegment[], int, long, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Gets an instance of DecimalData from underlying MemorySegment.
readMapData(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Gets an instance of MapData from underlying MemorySegment.
readRawValueData(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Gets an instance of RawValueData from underlying MemorySegment.
readRowData(MemorySegment[], int, int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Gets an instance of RowData from underlying MemorySegment.
readStringData(MemorySegment[], int, int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Get binary string, if len less than 8, will be include in variablePartOffsetAndLen.
readTimestampData(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
Gets an instance of TimestampData from underlying MemorySegment.
readTypeInfo(String) - Static method in class org.apache.flink.table.utils.TypeStringUtils
Deprecated.
 
REGEXP_EXTRACT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
REGEXP_REPLACE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
REINTERPRET_CAST - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
remove(T) - Method in class org.apache.flink.table.api.dataview.ListView
Removes the given value from the list.
remove(K) - Method in class org.apache.flink.table.api.dataview.MapView
Deletes the value for the given key.
removeTimeAttribute(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Removes time attributes from the DataType.
removeTimeAttributes(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
 
renameRowFields(RowType, List<String>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
Renames the fields of the given RowType.
renameTable(ObjectPath, String, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Rename an existing table or view.
REPEAT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
repeat(String, int) - Static method in class org.apache.flink.table.utils.EncodingUtils
Repeat a String repeat times to form a new String.
repeat(char, int) - Static method in class org.apache.flink.table.utils.EncodingUtils
Returns padding using the specified delimiter repeated to a given length.
replace(RowData, RowData) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
REPLACE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
replaceLogicalType(DataType, LogicalType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Replaces the LogicalType of a DataType, i.e., it keeps the bridging class.
requiredContext() - Method in interface org.apache.flink.table.factories.CatalogFactory
Deprecated.
Implement the Factory based stack instead.
requiredContext() - Method in interface org.apache.flink.table.factories.TableFactory
Specifies the context that this factory has been implemented for.
requiredContext() - Method in class org.apache.flink.table.factories.TableFormatFactoryBase
 
requiredContext() - Method in class org.apache.flink.table.module.CoreModuleFactory
 
requiredFormatContext() - Method in class org.apache.flink.table.factories.TableFormatFactoryBase
Format specific context.
requiredOptions() - Method in interface org.apache.flink.table.factories.CatalogFactory
 
requiredOptions() - Method in interface org.apache.flink.table.factories.Factory
Returns a set of ConfigOption that an implementation of this factory requires in addition to Factory.optionalOptions().
requiresPartitionGrouping(boolean) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsPartitioning
Returns whether data needs to be grouped by partition before it is consumed by the sink.
resolve(SchemaResolver) - Method in class org.apache.flink.table.api.Schema
Resolves the given Schema to a validated ResolvedSchema.
resolve(Schema) - Method in interface org.apache.flink.table.catalog.SchemaResolver
 
resolve(ExecutionConfig) - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
ResolvedCatalogBaseTable<T extends CatalogBaseTable> - Interface in org.apache.flink.table.catalog
A common parent that describes the resolved metadata of a table or view in a catalog.
ResolvedCatalogTable - Class in org.apache.flink.table.catalog
A validated CatalogTable that is backed by the original metadata coming from the Catalog but resolved by the framework.
ResolvedCatalogTable(CatalogTable, ResolvedSchema) - Constructor for class org.apache.flink.table.catalog.ResolvedCatalogTable
 
ResolvedCatalogView - Class in org.apache.flink.table.catalog
A validated CatalogView that is backed by the original metadata coming from the Catalog but resolved by the framework.
ResolvedCatalogView(CatalogView, ResolvedSchema) - Constructor for class org.apache.flink.table.catalog.ResolvedCatalogView
 
ResolvedExpression - Interface in org.apache.flink.table.expressions
Expression that has been fully resolved and validated.
ResolvedFieldReference - Class in org.apache.flink.table.expressions
A reference to a field in an input which has been resolved.
ResolvedFieldReference(String, TypeInformation<?>, int) - Constructor for class org.apache.flink.table.expressions.ResolvedFieldReference
 
ResolvedSchema - Class in org.apache.flink.table.catalog
Schema of a table or view consisting of columns, constraints, and watermark specifications.
ResolvedSchema(List<Column>, List<WatermarkSpec>, UniqueConstraint) - Constructor for class org.apache.flink.table.catalog.ResolvedSchema
 
restore(ClassLoader, String, String) - Static method in class org.apache.flink.table.types.logical.RawType
Restores a raw type from the components of a serialized string representation.
Result(List<DataType>, DataType, DataType) - Constructor for class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
 
resultType() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
retract(T) - Method in interface org.apache.flink.table.functions.TableAggregateFunction.RetractableCollector
Retract a record.
RootArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for an argument that corresponds to a given LogicalTypeRoot and nullability.
RootArgumentTypeStrategy(LogicalTypeRoot, Boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
 
ROUND - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ROUND - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the result of a rounding operation.
ROW(DataTypes.Field...) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a sequence of fields.
ROW(DataType...) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a sequence of fields.
ROW() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a row type with no fields.
ROW(DataTypes.AbstractField...) - Static method in class org.apache.flink.table.api.DataTypes
Unresolved data type of a sequence of fields.
ROW(AbstractDataType<?>...) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a sequence of fields.
ROW(TypeInformation<?>...) - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for Row with fields of the given types.
ROW(String[], TypeInformation<?>[]) - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for Row with fields of the given types and with given names.
ROW - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ROW - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns a DataTypes.ROW() with fields types equal to input types.
ROW_KIND_COLUMN - Static variable in class org.apache.flink.table.utils.PrintUtils
 
RowData - Interface in org.apache.flink.table.data
Base interface for an internal data structure representing data of RowType and other (possibly nested) structured types such as StructuredType in the table ecosystem.
RowData.FieldGetter - Interface in org.apache.flink.table.data
Accessor for getting the field of a row during runtime.
RowField(String, LogicalType, String) - Constructor for class org.apache.flink.table.types.logical.RowType.RowField
 
RowField(String, LogicalType) - Constructor for class org.apache.flink.table.types.logical.RowType.RowField
 
Rowtime - Class in org.apache.flink.table.descriptors
Rowtime descriptor for describing an event time attribute in the schema.
Rowtime() - Constructor for class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
rowtime(Rowtime) - Method in class org.apache.flink.table.descriptors.Schema
Specifies the previously defined field as an event-time attribute.
ROWTIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ROWTIME_BATCH_MARKER - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
ROWTIME_INDICATOR - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
ROWTIME_STREAM_MARKER - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
ROWTIME_TIMESTAMPS_CLASS - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_TIMESTAMPS_FROM - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_TIMESTAMPS_SERIALIZED - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_TIMESTAMPS_TYPE - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_TIMESTAMPS_TYPE_VALUE_CUSTOM - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_TIMESTAMPS_TYPE_VALUE_FROM_FIELD - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_TIMESTAMPS_TYPE_VALUE_FROM_SOURCE - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_WATERMARKS_CLASS - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_WATERMARKS_DELAY - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_WATERMARKS_SERIALIZED - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_WATERMARKS_TYPE - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_WATERMARKS_TYPE_VALUE_CUSTOM - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_WATERMARKS_TYPE_VALUE_FROM_SOURCE - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_WATERMARKS_TYPE_VALUE_PERIODIC_ASCENDING - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
ROWTIME_WATERMARKS_TYPE_VALUE_PERIODIC_BOUNDED - Static variable in class org.apache.flink.table.descriptors.Rowtime
 
RowtimeAttributeDescriptor - Class in org.apache.flink.table.sources
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use the concept of computed columns instead. See FLIP-95 for more information.
RowtimeAttributeDescriptor(String, TimestampExtractor, WatermarkStrategy) - Constructor for class org.apache.flink.table.sources.RowtimeAttributeDescriptor
Deprecated.
 
rowToString(Row, ResolvedSchema, ZoneId) - Static method in class org.apache.flink.table.utils.PrintUtils
 
rowToString(Row, String, boolean, ResolvedSchema, ZoneId) - Static method in class org.apache.flink.table.utils.PrintUtils
 
RowType - Class in org.apache.flink.table.types.logical
Logical type of a sequence of fields.
RowType(boolean, List<RowType.RowField>) - Constructor for class org.apache.flink.table.types.logical.RowType
 
RowType(List<RowType.RowField>) - Constructor for class org.apache.flink.table.types.logical.RowType
 
RowType.RowField - Class in org.apache.flink.table.types.logical
Describes a field of a RowType.
RPAD - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
RTRIM - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
runtimeClass(String) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
RuntimeConverter - Interface in org.apache.flink.table.connector
Base interface for converting data during runtime.
RuntimeConverter.Context - Interface in org.apache.flink.table.connector
Context for conversions during runtime.
runTypeInference(TypeInference, CallContext, TypeInferenceUtil.SurroundingInfo) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
Runs the entire type inference process.

S

SCALAR_EVAL - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
ScalarFunction - Class in org.apache.flink.table.functions
Base class for a user-defined scalar function.
ScalarFunction() - Constructor for class org.apache.flink.table.functions.ScalarFunction
 
ScalarFunctionDefinition - Class in org.apache.flink.table.functions
A "marker" function definition of a user-defined scalar function that uses the old type system stack.
ScalarFunctionDefinition(String, ScalarFunction) - Constructor for class org.apache.flink.table.functions.ScalarFunctionDefinition
 
scale() - Method in class org.apache.flink.table.data.DecimalData
Returns the scale of this DecimalData.
ScanTableSource - Interface in org.apache.flink.table.connector.source
A DynamicTableSource that scans all rows from an external storage system during runtime.
ScanTableSource.ScanContext - Interface in org.apache.flink.table.connector.source
Context for creating runtime implementation via a ScanTableSource.ScanRuntimeProvider.
ScanTableSource.ScanRuntimeProvider - Interface in org.apache.flink.table.connector.source
Provides actual runtime implementation for reading the data.
Schema - Class in org.apache.flink.table.api
Schema of a table or view.
Schema - Class in org.apache.flink.table.descriptors
Describes a schema of a table.
Schema() - Constructor for class org.apache.flink.table.descriptors.Schema
 
SCHEMA - Static variable in class org.apache.flink.table.descriptors.Schema
 
schema(TableSchema) - Method in class org.apache.flink.table.descriptors.Schema
Sets the schema with field names and the types.
Schema.Builder - Class in org.apache.flink.table.api
A builder for constructing an immutable but still unresolved Schema.
Schema.UnresolvedColumn - Class in org.apache.flink.table.api
Super class for all kinds of columns in an unresolved schema.
Schema.UnresolvedComputedColumn - Class in org.apache.flink.table.api
Declaration of a computed column that will be resolved to Column.ComputedColumn during schema resolution.
Schema.UnresolvedConstraint - Class in org.apache.flink.table.api
Super class for all kinds of constraints in an unresolved schema.
Schema.UnresolvedMetadataColumn - Class in org.apache.flink.table.api
Declaration of a metadata column that will be resolved to Column.MetadataColumn during schema resolution.
Schema.UnresolvedPhysicalColumn - Class in org.apache.flink.table.api
Declaration of a physical column that will be resolved to Column.PhysicalColumn during schema resolution.
Schema.UnresolvedPrimaryKey - Class in org.apache.flink.table.api
Declaration of a primary key that will be resolved to UniqueConstraint during schema resolution.
Schema.UnresolvedWatermarkSpec - Class in org.apache.flink.table.api
Declaration of a watermark strategy that will be resolved to WatermarkSpec during schema resolution.
SCHEMA_DATA_TYPE - Static variable in class org.apache.flink.table.descriptors.Schema
 
SCHEMA_FROM - Static variable in class org.apache.flink.table.descriptors.Schema
 
SCHEMA_NAME - Static variable in class org.apache.flink.table.descriptors.Schema
 
SCHEMA_PROCTIME - Static variable in class org.apache.flink.table.descriptors.Schema
 
SCHEMA_TYPE - Static variable in class org.apache.flink.table.descriptors.Schema
Deprecated.
Schema uses the legacy type key (e.g. schema.0.type = LONG) to store type information in prior v1.9. Since v1.10, Schema uses data type key (e.g. schema.0.data-type = BIGINT) to store types.
SchemaResolver - Interface in org.apache.flink.table.catalog
Resolves a Schema to a validated ResolvedSchema.
searchPartSpecAndPaths(FileSystem, Path, int) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
Search all partitions in this path.
SECOND() - Static method in class org.apache.flink.table.api.DataTypes
Resolution in seconds with 6 digits for fractional seconds by default.
SECOND(int) - Static method in class org.apache.flink.table.api.DataTypes
Resolution in seconds and (possibly) fractional seconds.
segments - Variable in class org.apache.flink.table.data.binary.BinarySection
 
sequence(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a function signature like f(STRING, NUMERIC) using a sequence of ArgumentTypeStrategys.
sequence(String[], ArgumentTypeStrategy[]) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a named function signature like f(s STRING, n NUMERIC) using a sequence of ArgumentTypeStrategys.
SequenceInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for inferring and validating a function signature like f(STRING, NUMERIC) or f(s STRING, n NUMERIC) using a sequence of ArgumentTypeStrategys.
SequenceInputTypeStrategy(List<? extends ArgumentTypeStrategy>, List<String>) - Constructor for class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
 
SerializationFormatFactory - Interface in org.apache.flink.table.factories
Factory for creating a EncodingFormat for SerializationSchema.
SerializationSchemaFactory<T> - Interface in org.apache.flink.table.factories
Factory for creating configured instances of SerializationSchema.
serialize(ListView<T>, DataOutputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
serialize(MapView<K, V>, DataOutputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
serialize(Map<K, V>, DataOutputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
serialize(Object, DataOutputView) - Method in class org.apache.flink.table.dataview.NullSerializer
 
serializeCatalogTable(ResolvedCatalogTable) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
Serializes the given ResolvedCatalogTable into a map of string properties.
setAvgLen(Double) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
 
setBoolean(int, boolean) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setBoolean(int, boolean) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setBoolean(MemorySegment[], int, boolean) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
set boolean from segments.
setBoolean(int, boolean) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
setBoolean(int, boolean) - Method in interface org.apache.flink.table.data.binary.TypedSetters
 
setByte(int, byte) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setByte(int, byte) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setByte(MemorySegment[], int, byte) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
set byte from segments.
setByte(int, byte) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
setByte(int, byte) - Method in interface org.apache.flink.table.data.binary.TypedSetters
 
setCollector(Collector<T>) - Method in class org.apache.flink.table.functions.TableFunction
Internal use.
setDecimal(int, DecimalData, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setDecimal(int, DecimalData, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setDecimal(int, DecimalData, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
setDecimal(int, DecimalData, int) - Method in interface org.apache.flink.table.data.binary.TypedSetters
Set the decimal column value.
setDouble(int, double) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setDouble(int, double) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setDouble(MemorySegment[], int, double) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
set double from segments.
setDouble(int, double) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
setDouble(int, double) - Method in interface org.apache.flink.table.data.binary.TypedSetters
 
setExpectedArguments(List<DataType>) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
setField(int, Object) - Method in class org.apache.flink.table.data.GenericRowData
Sets the field value at the given position.
setFinal(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
setFloat(int, float) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setFloat(int, float) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setFloat(MemorySegment[], int, float) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
set float from segments.
setFloat(int, float) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
setFloat(int, float) - Method in interface org.apache.flink.table.data.binary.TypedSetters
 
setInstantiable(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
setInt(int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setInt(int, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setInt(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
set int from segments.
setInt(int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
setInt(int, int) - Method in interface org.apache.flink.table.data.binary.TypedSetters
 
setJavaObject(T) - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
Must be public as it is used during code generation.
setList(List<T>) - Method in class org.apache.flink.table.api.dataview.ListView
Replaces the entire view's content with the content of the given List.
setLong(int, long) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setLong(int, long) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setLong(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
set long from segments.
setLong(int, long) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
setLong(int, long) - Method in interface org.apache.flink.table.data.binary.TypedSetters
 
setMap(Map<K, V>) - Method in class org.apache.flink.table.api.dataview.MapView
Replaces the entire view's content with the content of the given Map.
setMax(Comparable<?>) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
 
setMaxLen(Integer) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
 
setMin(Comparable<?>) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
 
setNdv(Long) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
 
setNotNullAt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setNullable(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
setNullAt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setNullAt(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setNullAt(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
setNullAt(int) - Method in interface org.apache.flink.table.data.binary.TypedSetters
 
setNullBoolean(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setNullByte(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setNullCount(Long) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
 
setNullDouble(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setNullFloat(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setNullInt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setNullLong(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setNullSerializer(boolean) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
setNullSerializer(boolean) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
setNullShort(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setOverwrite(boolean) - Method in interface org.apache.flink.table.sinks.OverwritableTableSink
Deprecated.
Configures whether the insert should overwrite existing data or not.
setRowKind(RowKind) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setRowKind(RowKind) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
setRowKind(RowKind) - Method in class org.apache.flink.table.data.GenericRowData
 
setRowKind(RowKind) - Method in interface org.apache.flink.table.data.RowData
Sets the kind of change that this row describes in a changelog.
setRowKind(RowKind) - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
setShort(int, short) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setShort(int, short) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setShort(MemorySegment[], int, short) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
set short from segments.
setShort(int, short) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
setShort(int, short) - Method in interface org.apache.flink.table.data.binary.TypedSetters
 
setStaticPartition(Map<String, String>) - Method in interface org.apache.flink.table.sinks.PartitionableTableSink
Deprecated.
Sets the static partition into the TableSink.
setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
 
setTimestamp(int, TimestampData, int) - Method in interface org.apache.flink.table.data.binary.TypedSetters
Set Timestamp value.
setTotalSize(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
 
SHA1 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SHA2 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SHA224 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SHA256 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SHA384 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SHA512 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SHORT() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API short or SQL SMALLINT type.
SIGN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
Signature - Class in org.apache.flink.table.types.inference
Describes the signature of a function.
Signature.Argument - Class in org.apache.flink.table.types.inference
Representation of a single argument in a signature.
SIMILAR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SIN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SINH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SINK_PARALLELISM - Static variable in class org.apache.flink.table.factories.FactoryUtil
 
SinkProvider - Interface in org.apache.flink.table.connector.sink
Provider of a Sink instance as a runtime implementation for DynamicTableSink.
size() - Method in interface org.apache.flink.table.data.ArrayData
Returns the number of elements in this array.
size() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
size() - Method in class org.apache.flink.table.data.binary.BinaryMapData
 
size() - Method in class org.apache.flink.table.data.GenericArrayData
 
size() - Method in class org.apache.flink.table.data.GenericMapData
 
size() - Method in interface org.apache.flink.table.data.MapData
Returns the number of key-value mappings in this map.
sizeInBytes - Variable in class org.apache.flink.table.data.binary.BinarySection
 
SMALLINT() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a 2-byte signed integer with values from -32,768 to 32,767.
SmallIntType - Class in org.apache.flink.table.types.logical
Logical type of a 2-byte signed integer with values from -32,768 to 32,767.
SmallIntType(boolean) - Constructor for class org.apache.flink.table.types.logical.SmallIntType
 
SmallIntType() - Constructor for class org.apache.flink.table.types.logical.SmallIntType
 
snapshotConfiguration() - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
 
snapshotConfiguration() - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
 
snapshotConfiguration() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
Deprecated.
 
snapshotConfiguration() - Method in class org.apache.flink.table.dataview.NullSerializer
 
SOURCE_WATERMARK - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SOURCE_WATERMARK - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy specific for source watermarks that depend on the output type.
SourceProvider - Interface in org.apache.flink.table.connector.source
Provider of a Source instance as a runtime implementation for ScanTableSource.
specialize(SpecializedFunction.SpecializedContext) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
 
specialize(SpecializedFunction.SpecializedContext) - Method in interface org.apache.flink.table.functions.SpecializedFunction
Provides a runtime implementation that is specialized for the given call and session.
SpecializedFunction - Interface in org.apache.flink.table.functions
A FunctionDefinition that can provide a runtime implementation (i.e.
SpecializedFunction.SpecializedContext - Interface in org.apache.flink.table.functions
Provides call and session information for the specialized function.
SPECIFIC_FOR_ARRAY - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy specific for BuiltInFunctionDefinitions.ARRAY.
SPECIFIC_FOR_CAST - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy specific for BuiltInFunctionDefinitions.CAST.
SPECIFIC_FOR_MAP - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy specific for BuiltInFunctionDefinitions.MAP.
SQL_DATE() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API SQL date or SQL DATE type.
SQL_TIME() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API SQL time or SQL TIME type.
SQL_TIMESTAMP() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API SQL timestamp or SQL TIMESTAMP type.
SqlCallExpression - Class in org.apache.flink.table.expressions
A call to a SQL expression.
SqlCallExpression(String) - Constructor for class org.apache.flink.table.expressions.SqlCallExpression
 
SQRT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
startsWith(BinaryStringData) - Method in class org.apache.flink.table.data.binary.BinaryStringData
Tests if this BinaryStringData starts with the specified prefix.
STDDEV_POP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
STDDEV_SAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
STREAM_RECORD_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
StreamTableDescriptorValidator - Class in org.apache.flink.table.descriptors
Validator for StreamTableDescriptor.
StreamTableDescriptorValidator(boolean, boolean, boolean) - Constructor for class org.apache.flink.table.descriptors.StreamTableDescriptorValidator
 
STRING() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a variable-length character string with defined maximum length.
STRING() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API string or SQL VARCHAR type.
STRING_CONCAT - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the type of a string concatenation.
StringData - Interface in org.apache.flink.table.data
An internal data structure representing data of CharType and VarCharType.
stripRowPrefix(DataType, String) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Removes a string prefix from the fields of the given row data type.
STRUCTURED(Class<T>, DataTypes.Field...) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a user-defined object structured type.
StructuredAttribute(String, LogicalType, String) - Constructor for class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
StructuredAttribute(String, LogicalType) - Constructor for class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
StructuredType - Class in org.apache.flink.table.types.logical
Logical type of a user-defined object structured type.
StructuredType.Builder - Class in org.apache.flink.table.types.logical
A builder for a StructuredType.
StructuredType.StructuredAttribute - Class in org.apache.flink.table.types.logical
Defines an attribute of a StructuredType.
StructuredType.StructuredComparision - Enum in org.apache.flink.table.types.logical
Defines equality properties for scalar evaluation.
subsequence(InputTypeStrategy) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
Defines a common InputTypeStrategy for the next arguments.
SubsequenceInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
An InputTypeStrategy that lets you apply other strategies for subsequences of the actual arguments.
SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder - Class in org.apache.flink.table.types.inference.strategies
SubsequenceStrategyBuilder() - Constructor for class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
 
substring(int, int) - Method in class org.apache.flink.table.data.binary.BinaryStringData
Returns a binary string that is a substring of this binary string.
SUBSTRING - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SUM - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SUM0 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
superType(StructuredType) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
supportedFormatProperties() - Method in class org.apache.flink.table.factories.TableFormatFactoryBase
Format specific supported properties.
supportedProperties() - Method in interface org.apache.flink.table.factories.CatalogFactory
Deprecated.
Implement the Factory based stack instead.
supportedProperties() - Method in interface org.apache.flink.table.factories.TableFactory
List of property keys that this factory can handle.
supportedProperties() - Method in interface org.apache.flink.table.factories.TableFormatFactory
List of format property keys that this factory can handle.
supportedProperties() - Method in class org.apache.flink.table.factories.TableFormatFactoryBase
 
supportedProperties() - Method in class org.apache.flink.table.module.CoreModuleFactory
 
SupportsAggregatePushDown - Interface in org.apache.flink.table.connector.source.abilities
Enables to push down the local aggregates into a ScanTableSource.
supportsAvoidingCast(LogicalType, LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
Returns whether the source type can be safely interpreted as the target type.
supportsAvoidingCast(List<LogicalType>, List<LogicalType>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
supportsExplicitCast(LogicalType, LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
Returns whether the source type can be casted to the target type.
SupportsFilterPushDown - Interface in org.apache.flink.table.connector.source.abilities
Enables to push down filters into a ScanTableSource.
SupportsFilterPushDown.Result - Class in org.apache.flink.table.connector.source.abilities
Result of a filter push down.
supportsImplicitCast(LogicalType, LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
Returns whether the source type can be safely casted to the target type without loosing information.
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ArrayType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BigIntType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BinaryType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BooleanType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.CharType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DateType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DecimalType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DistinctType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DoubleType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.FloatType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.IntType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LogicalType
Returns whether an instance of the given class can be represented as a value of this logical type when entering the table ecosystem.
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MapType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MultisetType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.NullType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RawType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RowType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SmallIntType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.StructuredType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SymbolType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimestampType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimeType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TinyIntType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarCharType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
SupportsLimitPushDown - Interface in org.apache.flink.table.connector.source.abilities
Enables to push down a limit (the expected maximum number of produced records) into a ScanTableSource.
supportsNestedProjection() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsProjectionPushDown
Returns whether this source supports nested projection.
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ArrayType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BigIntType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BinaryType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BooleanType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.CharType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DateType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DecimalType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DistinctType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DoubleType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.FloatType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.IntType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LogicalType
Returns whether a value of this logical type can be represented as an instance of the given class when leaving the table ecosystem.
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MapType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MultisetType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.NullType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RawType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RowType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SmallIntType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.StructuredType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SymbolType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimestampType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimeType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TinyIntType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarBinaryType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarCharType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
 
SupportsOverwrite - Interface in org.apache.flink.table.connector.sink.abilities
Enables to overwrite existing data in a DynamicTableSink.
SupportsPartitioning - Interface in org.apache.flink.table.connector.sink.abilities
Enables to write partitioned data in a DynamicTableSink.
SupportsPartitionPushDown - Interface in org.apache.flink.table.connector.source.abilities
Enables to pass available partitions to the planner and push down partitions into a ScanTableSource.
SupportsProjectionPushDown - Interface in org.apache.flink.table.connector.source.abilities
Enables to push down a (possibly nested) projection into a ScanTableSource.
SupportsReadingMetadata - Interface in org.apache.flink.table.connector.source.abilities
Interface for ScanTableSources that support reading metadata columns.
supportsSchemaDerivation() - Method in interface org.apache.flink.table.factories.TableFormatFactory
Flag to indicate if the given format supports deriving information from a schema.
supportsSchemaDerivation() - Method in class org.apache.flink.table.factories.TableFormatFactoryBase
 
SupportsSourceWatermark - Interface in org.apache.flink.table.connector.source.abilities
Enables to fully rely on the watermark strategy provided by the ScanTableSource itself.
SupportsWatermarkPushDown - Interface in org.apache.flink.table.connector.source.abilities
Enables to push down a watermark strategy into a ScanTableSource.
SupportsWritingMetadata - Interface in org.apache.flink.table.connector.sink.abilities
Interface for DynamicTableSinks that support writing metadata columns.
SymbolType<T extends TableSymbol> - Class in org.apache.flink.table.types.logical
Logical type for representing symbol values.
SymbolType(boolean, Class<T>) - Constructor for class org.apache.flink.table.types.logical.SymbolType
 
SymbolType(Class<T>) - Constructor for class org.apache.flink.table.types.logical.SymbolType
 

T

TABLE_AGGREGATE_ACCUMULATE - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TABLE_AGGREGATE_EMIT - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TABLE_AGGREGATE_EMIT_RETRACT - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TABLE_AGGREGATE_MERGE - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TABLE_AGGREGATE_RETRACT - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TABLE_EVAL - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TableAggregateFunction<T,ACC> - Class in org.apache.flink.table.functions
Base class for a user-defined table aggregate function.
TableAggregateFunction() - Constructor for class org.apache.flink.table.functions.TableAggregateFunction
 
TableAggregateFunction.RetractableCollector<T> - Interface in org.apache.flink.table.functions
Collects a record and forwards it.
TableAggregateFunctionDefinition - Class in org.apache.flink.table.functions
A "marker" function definition of an user-defined table aggregate function that uses the old type system stack.
TableAggregateFunctionDefinition(String, TableAggregateFunction<?, ?>, TypeInformation<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
TableAlreadyExistException - Exception in org.apache.flink.table.catalog.exceptions
Exception for trying to create a table (or view) that already exists.
TableAlreadyExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableAlreadyExistException
 
TableAlreadyExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableAlreadyExistException
 
TableColumn - Class in org.apache.flink.table.api
Deprecated.
TableColumn.ComputedColumn - Class in org.apache.flink.table.api
Deprecated.
Representation of a computed column.
TableColumn.MetadataColumn - Class in org.apache.flink.table.api
Deprecated.
Representation of a metadata column.
TableColumn.PhysicalColumn - Class in org.apache.flink.table.api
Deprecated.
Representation of a physical column.
TableConnectorUtil - Class in org.apache.flink.table.util
Deprecated.
Use TableConnectorUtils instead.
TableConnectorUtil() - Constructor for class org.apache.flink.table.util.TableConnectorUtil
Deprecated.
 
TableConnectorUtils - Class in org.apache.flink.table.utils
Utilities for table sources and sinks.
TableDescriptor<D extends TableDescriptor<D>> - Class in org.apache.flink.table.descriptors
Describes a table consisting of a connector (in a given update mode) and a format.
TableDescriptor(ConnectorDescriptor) - Constructor for class org.apache.flink.table.descriptors.TableDescriptor
 
TableException - Exception in org.apache.flink.table.api
General Exception for all errors during table handling.
TableException(String, Throwable) - Constructor for exception org.apache.flink.table.api.TableException
 
TableException(String) - Constructor for exception org.apache.flink.table.api.TableException
 
tableExists(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
Check if a table or view exists in this catalog.
TableFactory - Interface in org.apache.flink.table.factories
A factory to create different table-related instances from string-based properties.
TableFactoryService - Class in org.apache.flink.table.factories
Unified class to search for a TableFactory of provided type and properties.
TableFactoryService() - Constructor for class org.apache.flink.table.factories.TableFactoryService
 
TableFormatFactory<T> - Interface in org.apache.flink.table.factories
A factory to create configured table format instances based on string-based properties.
TableFormatFactoryBase<T> - Class in org.apache.flink.table.factories
Base class for TableFormatFactorys.
TableFormatFactoryBase(String, int, boolean) - Constructor for class org.apache.flink.table.factories.TableFormatFactoryBase
 
TableFunction<T> - Class in org.apache.flink.table.functions
Base class for a user-defined table function.
TableFunction() - Constructor for class org.apache.flink.table.functions.TableFunction
 
TableFunctionDefinition - Class in org.apache.flink.table.functions
A "marker" function definition of an user-defined table function that uses the old type system stack.
TableFunctionDefinition(String, TableFunction<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.functions.TableFunctionDefinition
 
TableFunctionProvider<T> - Interface in org.apache.flink.table.connector.source
Provider of a TableFunction instance as a runtime implementation for LookupTableSource.
TableNotExistException - Exception in org.apache.flink.table.api
Exception for an operation on a nonexistent table.
TableNotExistException(String, String) - Constructor for exception org.apache.flink.table.api.TableNotExistException
 
TableNotExistException(String, String, Throwable) - Constructor for exception org.apache.flink.table.api.TableNotExistException
 
TableNotExistException - Exception in org.apache.flink.table.catalog.exceptions
Exception for trying to operate on a table (or view) that doesn't exist.
TableNotExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotExistException
 
TableNotExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotExistException
 
TableNotPartitionedException - Exception in org.apache.flink.table.catalog.exceptions
Exception for trying to operate partition on a non-partitioned table.
TableNotPartitionedException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotPartitionedException
 
TableNotPartitionedException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotPartitionedException
 
TablePartitionedException - Exception in org.apache.flink.table.catalog.exceptions
Exception for trying to operate non-partitioned on a partitioned table.
TablePartitionedException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TablePartitionedException
 
TablePartitionedException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TablePartitionedException
 
TableSchema - Class in org.apache.flink.table.api
Deprecated.
This class has been deprecated as part of FLIP-164. It has been replaced by two more dedicated classes Schema and ResolvedSchema. Use Schema for declaration in APIs. ResolvedSchema is offered by the framework after resolution and validation.
TableSchema(String[], TypeInformation<?>[]) - Constructor for class org.apache.flink.table.api.TableSchema
Deprecated.
Use the TableSchema.Builder instead.
TableSchema.Builder - Class in org.apache.flink.table.api
Deprecated.
Builder for creating a TableSchema.
TableSchemaUtils - Class in org.apache.flink.table.utils
Utilities to TableSchema.
TableSchemaUtils() - Constructor for class org.apache.flink.table.utils.TableSchemaUtils
 
TableSink<T> - Interface in org.apache.flink.table.sinks
Deprecated.
This interface has been replaced by DynamicTableSink. The new interface consumes internal data structures and only works with the Blink planner. See FLIP-95 for more information.
TableSinkBase<T> - Class in org.apache.flink.table.sinks
Base class for TableSink.
TableSinkBase() - Constructor for class org.apache.flink.table.sinks.TableSinkBase
 
TableSinkFactory<T> - Interface in org.apache.flink.table.factories
A factory to create configured table sink instances in a batch or stream environment based on string-based properties.
TableSinkFactory.Context - Interface in org.apache.flink.table.factories
Context of table sink creation.
TableSinkFactoryContextImpl - Class in org.apache.flink.table.factories
Implementation of TableSinkFactory.Context.
TableSinkFactoryContextImpl(ObjectIdentifier, CatalogTable, ReadableConfig, boolean, boolean) - Constructor for class org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
TableSource<T> - Interface in org.apache.flink.table.sources
Deprecated.
This interface has been replaced by DynamicTableSource. The new interface produces internal data structures and only works with the Blink planner. See FLIP-95 for more information.
TableSourceFactory<T> - Interface in org.apache.flink.table.factories
A factory to create configured table source instances in a batch or stream environment based on string-based properties.
TableSourceFactory.Context - Interface in org.apache.flink.table.factories
Context of table source creation.
TableSourceFactoryContextImpl - Class in org.apache.flink.table.factories
Implementation of TableSourceFactory.Context.
TableSourceFactoryContextImpl(ObjectIdentifier, CatalogTable, ReadableConfig, boolean) - Constructor for class org.apache.flink.table.factories.TableSourceFactoryContextImpl
 
TableSourceValidation - Class in org.apache.flink.table.sources
Logic to validate TableSource types.
TableStats - Class in org.apache.flink.table.plan.stats
Table statistics.
TableStats(long) - Constructor for class org.apache.flink.table.plan.stats.TableStats
 
TableStats(long, Map<String, ColumnStats>) - Constructor for class org.apache.flink.table.plan.stats.TableStats
 
TableSymbol - Interface in org.apache.flink.table.expressions
The base interface for all table symbols.
takesRowAsInput() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
takesRowAsInput() - Method in interface org.apache.flink.table.functions.python.PythonFunction
Returns Whether the Python function takes row as input instead of each columns of a row.
takesRowAsInput() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
 
takesRowAsInput() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
takesRowAsInput() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
 
TAN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TANH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TEMPORAL_OVERLAPS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TemporalTableFunction - Class in org.apache.flink.table.functions
Class representing temporal table function over some history table.
TemporalTableFunction() - Constructor for class org.apache.flink.table.functions.TemporalTableFunction
 
TemporaryOperationListener - Interface in org.apache.flink.table.catalog
This interface is for a Catalog to listen on temporary object operations.
ThreadLocalCache<K,V> - Class in org.apache.flink.table.utils
Provides a thread local cache with a maximum cache size per thread.
ThreadLocalCache() - Constructor for class org.apache.flink.table.utils.ThreadLocalCache
 
ThreadLocalCache(int) - Constructor for class org.apache.flink.table.utils.ThreadLocalCache
 
TIME(int) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a time WITHOUT time zone TIME(p) where p is the number of digits of fractional seconds (=precision).
TIME() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a time WITHOUT time zone TIME with no fractional seconds by default.
TIME_ATTRIBUTES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TimeIndicatorTypeInfo - Class in org.apache.flink.table.typeutils
Deprecated.
This class will be removed in future versions as it is used for the old type system. It is recommended to use DataTypes instead. 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.
TimeIndicatorTypeInfo(boolean) - Constructor for class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
TimeIntervalTypeInfo<T> - Class in org.apache.flink.table.typeutils
Deprecated.
This class will be removed in future versions as it is used for the old type system. It is recommended to use DataTypes instead. 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.
TimeIntervalUnit - Enum in org.apache.flink.table.expressions
Units for working with time intervals.
TimePointUnit - Enum in org.apache.flink.table.expressions
Units for working with points in time.
TIMES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TIMESTAMP(int) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a timestamp WITHOUT time zone TIMESTAMP(p) where p is the number of digits of fractional seconds (=precision).
TIMESTAMP() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a timestamp WITHOUT time zone TIMESTAMP with 6 digits of fractional seconds by default.
TIMESTAMP_DIFF - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TIMESTAMP_LTZ(int) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a timestamp WITH LOCAL time zone.
TIMESTAMP_LTZ() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a timestamp WITH LOCAL time zone.
TIMESTAMP_WITH_LOCAL_TIME_ZONE(int) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a timestamp WITH LOCAL time zone TIMESTAMP(p) WITH LOCAL TIME ZONE where p is the number of digits of fractional seconds (=precision).
TIMESTAMP_WITH_LOCAL_TIME_ZONE() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a timestamp WITH LOCAL time zone TIMESTAMP WITH LOCAL TIME ZONE with 6 digits of fractional seconds by default.
TIMESTAMP_WITH_TIME_ZONE(int) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a timestamp WITH time zone TIMESTAMP(p) WITH TIME ZONE where p is the number of digits of fractional seconds (=precision).
TIMESTAMP_WITH_TIME_ZONE() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a timestamp WITH time zone TIMESTAMP WITH TIME ZONE with 6 digits of fractional seconds by default.
TimestampData - Class in org.apache.flink.table.data
An internal data structure representing data of TimestampType and LocalZonedTimestampType.
TimestampExtractor - Class in org.apache.flink.table.sources.tsextractors
Deprecated.
This interface will not be supported in the new source design around DynamicTableSource which only works with the Blink planner. Use the concept of computed columns instead. See FLIP-95 for more information.
TimestampExtractor() - Constructor for class org.apache.flink.table.sources.tsextractors.TimestampExtractor
Deprecated.
 
TimestampExtractorUtils - Class in org.apache.flink.table.sources.tsextractors
Utility methods for dealing with TimestampExtractor.
TimestampKind - Enum in org.apache.flink.table.types.logical
Internal timestamp kind for attaching time attribute metadata to timestamps with or without a time zone.
timestampsFromExtractor(TimestampExtractor) - Method in class org.apache.flink.table.descriptors.Rowtime
Sets a custom timestamp extractor to be used for the rowtime attribute.
timestampsFromField(String) - Method in class org.apache.flink.table.descriptors.Rowtime
Sets a built-in timestamp extractor that converts an existing Long or Types.SQL_TIMESTAMP field into the rowtime attribute.
timestampsFromSource() - Method in class org.apache.flink.table.descriptors.Rowtime
Sets a built-in timestamp extractor that converts the assigned timestamps from a DataStream API record into the rowtime attribute and thus preserves the assigned timestamps from the source.
TimestampStringUtils - Class in org.apache.flink.table.utils
Utils to represent a LocalDateTime to String, considered the precision.
TimestampStringUtils() - Constructor for class org.apache.flink.table.utils.TimestampStringUtils
 
timestampToString(LocalDateTime, int) - Static method in class org.apache.flink.table.utils.TimestampStringUtils
 
TimestampType - Class in org.apache.flink.table.types.logical
Logical type of a timestamp WITHOUT time zone consisting of year-month-day hour:minute:second[.fractional] with up to nanosecond precision and values ranging from 0000-01-01 00:00:00.000000000 to 9999-12-31 23:59:59.999999999.
TimestampType(boolean, TimestampKind, int) - Constructor for class org.apache.flink.table.types.logical.TimestampType
Internal constructor that allows attaching additional metadata about time attribute properties.
TimestampType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.TimestampType
 
TimestampType(int) - Constructor for class org.apache.flink.table.types.logical.TimestampType
 
TimestampType() - Constructor for class org.apache.flink.table.types.logical.TimestampType
 
timeToInternal(Time) - Static method in class org.apache.flink.table.utils.TimestampStringUtils
 
timeToSqlTypes() - Static method in class org.apache.flink.table.types.inference.TypeTransformations
Returns a type transformation that transforms data type to a new data type whose conversion class is Timestamp/Time/Date if the original data type is TIMESTAMP/TIME/DATE.
TimeType - Class in org.apache.flink.table.types.logical
Logical type of a time WITHOUT time zone consisting of hour:minute:second[.fractional] with up to nanosecond precision and values ranging from 00:00:00.000000000 to 23:59:59.999999999.
TimeType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.TimeType
 
TimeType(int) - Constructor for class org.apache.flink.table.types.logical.TimeType
 
TimeType() - Constructor for class org.apache.flink.table.types.logical.TimeType
 
TINYINT() - Static method in class org.apache.flink.table.api.DataTypes
Data type of a 1-byte signed integer with values from -128 to 127.
TinyIntType - Class in org.apache.flink.table.types.logical
Logical type of a 1-byte signed integer with values from -128 to 127.
TinyIntType(boolean) - Constructor for class org.apache.flink.table.types.logical.TinyIntType
 
TinyIntType() - Constructor for class org.apache.flink.table.types.logical.TinyIntType
 
to(int) - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
 
TO_BASE64 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TO_INTERNAL_CLASS - Static variable in class org.apache.flink.table.types.inference.TypeTransformations
Transformation that uses internal data structures for all conversion classes.
TO_TIMESTAMP_LTZ - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
toBigDecimal() - Method in class org.apache.flink.table.data.DecimalData
Converts this DecimalData into an instance of BigDecimal.
toBooleanArray() - Method in interface org.apache.flink.table.data.ArrayData
 
toBooleanArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
toBooleanArray() - Method in class org.apache.flink.table.data.GenericArrayData
 
toByteArray() - Method in interface org.apache.flink.table.data.ArrayData
 
toByteArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
toByteArray() - Method in class org.apache.flink.table.data.GenericArrayData
 
toBytes(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
 
toBytes() - Method in class org.apache.flink.table.data.binary.BinaryStringData
 
toBytes(TypeSerializer<T>) - Method in interface org.apache.flink.table.data.RawValueData
Converts this RawValueData into a byte array.
toBytes() - Method in interface org.apache.flink.table.data.StringData
Converts this StringData object to a UTF-8 byte array.
toConnectorProperties() - Method in class org.apache.flink.table.descriptors.ConnectorDescriptor
Converts this descriptor into a set of connector properties.
toConnectorProperties() - Method in class org.apache.flink.table.descriptors.CustomConnectorDescriptor
 
toConnectorProperties() - Method in class org.apache.flink.table.descriptors.FileSystem
 
toDataType(DataTypeFactory) - Method in class org.apache.flink.table.types.UnresolvedDataType
Converts this instance to a resolved DataType possibly enriched with additional nullability and conversion class information.
toDataType(TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
Deprecated.
 
toDataType(LogicalType) - Static method in class org.apache.flink.table.types.utils.LogicalTypeDataTypeConverter
Returns the data type of a logical type without explicit conversions.
toDataType(DataTypeFactory, TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
Converts the given TypeInformation into DataType.
toDataType(DataTypeFactory, TypeInformation<?>, boolean) - Static method in class org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
Converts the given TypeInformation into DataType but allows to make all fields nullable independent of the nullability in the serialization stack.
toDoubleArray() - Method in interface org.apache.flink.table.data.ArrayData
 
toDoubleArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
toDoubleArray() - Method in class org.apache.flink.table.data.GenericArrayData
 
toExternal(Object) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.DataStructureConverter
Converts the given internal structure into an external object.
toFloatArray() - Method in interface org.apache.flink.table.data.ArrayData
 
toFloatArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
toFloatArray() - Method in class org.apache.flink.table.data.GenericArrayData
 
toFormatProperties() - Method in class org.apache.flink.table.descriptors.FormatDescriptor
Converts this descriptor into a set of format properties.
toInstant() - Method in class org.apache.flink.table.data.TimestampData
Converts this TimestampData object to a Instant.
toIntArray() - Method in interface org.apache.flink.table.data.ArrayData
 
toIntArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
toIntArray() - Method in class org.apache.flink.table.data.GenericArrayData
 
toInternal(Object) - Method in interface org.apache.flink.table.connector.source.DynamicTableSource.DataStructureConverter
Converts the given object into an internal data structure.
toInternalConversionClass(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
Returns the conversion class for the given LogicalType that is used by the table runtime as internal data structure.
toInternalDataType(LogicalType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Creates a DataType from the given LogicalType with internal data structures.
toInternalDataType(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Creates a DataType from the given DataType with internal data structures.
toJavaMap(LogicalType, LogicalType) - Method in class org.apache.flink.table.data.binary.BinaryMapData
 
toLegacyTypeInfo(DataType) - Static method in class org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
Deprecated.
 
toList() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
List of the component names of this object identifier.
toList() - Method in class org.apache.flink.table.functions.FunctionIdentifier
List of the component names of this function identifier.
toLocalDateTime() - Method in class org.apache.flink.table.data.TimestampData
Converts this TimestampData object to a LocalDateTime.
toLogicalType(DataType) - Static method in class org.apache.flink.table.types.utils.LogicalTypeDataTypeConverter
Returns the logical type of a data type.
toLongArray() - Method in interface org.apache.flink.table.data.ArrayData
 
toLongArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
toLongArray() - Method in class org.apache.flink.table.data.GenericArrayData
 
toLowerCase() - Method in class org.apache.flink.table.data.binary.BinaryStringData
Converts all of the characters in this BinaryStringData to lower case.
toModuleProperties() - Method in class org.apache.flink.table.descriptors.CoreModuleDescriptor
 
toModuleProperties() - Method in class org.apache.flink.table.descriptors.ModuleDescriptor
Converts this descriptor into a set of module properties.
toNullable() - Static method in class org.apache.flink.table.types.inference.TypeTransformations
Returns a type transformation that transforms data type to nullable data type but keeps other information unchanged.
toObject(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
 
toObject(TypeSerializer<T>) - Method in interface org.apache.flink.table.data.RawValueData
Converts this RawValueData into a Java object.
toObjectArray(LogicalType) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
toObjectArray() - Method in class org.apache.flink.table.data.GenericArrayData
Converts this GenericArrayData into an array of Java Object.
toObjectPath() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
 
toPersistedRowDataType() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Converts all persisted columns of this schema into a (possibly nested) row data type.
toPhysicalRowDataType() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Converts all physical columns of this schema into a (possibly nested) row data type.
toPhysicalRowDataType() - Method in class org.apache.flink.table.catalog.ResolvedSchema
Converts all physical columns of this schema into a (possibly nested) row data type.
toProperties() - Method in interface org.apache.flink.table.catalog.CatalogTable
Deprecated.
Only a ResolvedCatalogTable is serializable to properties.
toProperties() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
 
toProperties() - Method in class org.apache.flink.table.descriptors.ClassInstance
Converts this descriptor into a set of properties.
toProperties() - Method in class org.apache.flink.table.descriptors.ConnectorDescriptor
 
toProperties() - Method in interface org.apache.flink.table.descriptors.Descriptor
Converts this descriptor into a set of properties.
toProperties() - Method in class org.apache.flink.table.descriptors.FormatDescriptor
 
toProperties() - Method in class org.apache.flink.table.descriptors.FunctionDescriptor
Converts this descriptor into a set of properties.
toProperties() - Method in class org.apache.flink.table.descriptors.LiteralValue
 
toProperties() - Method in class org.apache.flink.table.descriptors.ModuleDescriptor
 
toProperties() - Method in class org.apache.flink.table.descriptors.Rowtime
Converts this descriptor into a set of properties.
toProperties() - Method in class org.apache.flink.table.descriptors.Schema
Converts this descriptor into a set of properties.
toProperties() - Method in class org.apache.flink.table.descriptors.TableDescriptor
Converts this descriptor into a set of properties.
toProperties() - Method in class org.apache.flink.table.sources.tsextractors.TimestampExtractor
Deprecated.
This method is a default implementation that uses java serialization and it is discouraged.
toProperties() - Method in class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
 
toProperties() - Method in class org.apache.flink.table.sources.wmstrategies.WatermarkStrategy
This method is a default implementation that uses java serialization and it is discouraged.
toRowDataType() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Converts all columns of this schema into a (possibly nested) row data type.
toRowType() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
toRowType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
Converts any logical type to a row type.
toSchema() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
Helps to migrate to the new Schema class.
toShortArray() - Method in interface org.apache.flink.table.data.ArrayData
 
toShortArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
 
toShortArray() - Method in class org.apache.flink.table.data.GenericArrayData
 
toSinkRowDataType() - Method in class org.apache.flink.table.catalog.ResolvedSchema
Converts all persisted columns of this schema into a (possibly nested) row data type.
toSourceRowDataType() - Method in class org.apache.flink.table.catalog.ResolvedSchema
Converts all columns of this schema into a (possibly nested) row data type.
toString() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
 
toString() - Method in class org.apache.flink.table.api.DataTypes.Resolution
 
toString() - Method in class org.apache.flink.table.api.Schema
 
toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
 
toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
 
toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedConstraint
 
toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
 
toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
 
toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
 
toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
 
toString() - Method in class org.apache.flink.table.api.TableColumn
Deprecated.
 
toString() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
 
toString() - Method in class org.apache.flink.table.api.WatermarkSpec
Deprecated.
 
toString() - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
 
toString() - Method in class org.apache.flink.table.catalog.Column
 
toString() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
 
toString() - Method in class org.apache.flink.table.catalog.ObjectPath
 
toString() - Method in class org.apache.flink.table.catalog.ResolvedSchema
 
toString() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
 
toString() - Method in class org.apache.flink.table.catalog.WatermarkSpec
 
toString() - Method in class org.apache.flink.table.connector.ChangelogMode
 
toString() - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
 
toString() - Method in class org.apache.flink.table.data.binary.BinaryStringData
 
toString() - Method in class org.apache.flink.table.data.DecimalData
 
toString() - Method in class org.apache.flink.table.data.GenericRowData
 
toString() - Method in interface org.apache.flink.table.data.StringData
Converts this StringData object to a String.
toString() - Method in class org.apache.flink.table.data.TimestampData
 
toString() - Method in class org.apache.flink.table.data.utils.JoinedRowData
 
toString() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
Deprecated.
 
toString() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
Deprecated.
 
toString() - Method in class org.apache.flink.table.descriptors.DescriptorBase
 
toString() - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
toString(String) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
toString(String, String) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
toString(Map<String, String>) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
toString() - Method in class org.apache.flink.table.expressions.AggregateExpression
 
toString() - Method in class org.apache.flink.table.expressions.CallExpression
 
toString() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
toString() - Method in class org.apache.flink.table.expressions.SqlCallExpression
 
toString() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
 
toString() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
toString() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
toString() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
 
toString() - Method in class org.apache.flink.table.functions.FunctionIdentifier
 
toString() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
 
toString() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
 
toString() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
toString() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
 
toString() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
 
toString() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
toString() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
toString() - Method in class org.apache.flink.table.functions.UserDefinedFunction
Returns the name of the UDF that is used for plan explanation and logging.
toString() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
toString() - Method in class org.apache.flink.table.plan.stats.TableStats
 
toString() - Method in class org.apache.flink.table.types.DataType
 
toString() - Method in class org.apache.flink.table.types.logical.LogicalType
 
toString() - Method in class org.apache.flink.table.types.UnresolvedDataType
 
toString() - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
toString() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
toTimestamp() - Method in class org.apache.flink.table.data.TimestampData
Converts this TimestampData object to a Timestamp.
toUnscaledBytes() - Method in class org.apache.flink.table.data.DecimalData
Returns a byte array describing the unscaled value of this DecimalData.
toUnscaledLong() - Method in class org.apache.flink.table.data.DecimalData
Returns a long describing the unscaled value of this DecimalData.
toUpperCase() - Method in class org.apache.flink.table.data.binary.BinaryStringData
Converts all of the characters in this BinaryStringData to upper case.
transform(DataType) - Method in class org.apache.flink.table.types.inference.transforms.DataTypeConversionClassTransformation
 
transform(DataType) - Method in class org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
 
transform(DataType) - Method in class org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
 
transform(DataTypeFactory, DataType) - Method in class org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
 
transform(DataType) - Method in interface org.apache.flink.table.types.inference.TypeTransformation
Transforms the given data type to a different data type.
transform(DataTypeFactory, DataType) - Method in interface org.apache.flink.table.types.inference.TypeTransformation
Transforms the given data type to a different data type.
transform(DataType, TypeTransformation...) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Transforms the given data type to a different data type using the given transformations.
transform(DataTypeFactory, DataType, TypeTransformation...) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
Transforms the given data type to a different data type using the given transformations.
transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
Deprecated.
We need to override this as a LegacySerializerSnapshotTransformer because in Flink 1.6.x and below, this serializer was incorrectly returning directly the snapshot of the nested list serializer as its own snapshot.
transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
Deprecated.
We need to override this as a LegacySerializerSnapshotTransformer because in Flink 1.6.x and below, this serializer was incorrectly returning directly the snapshot of the nested map serializer as its own snapshot.
trim() - Method in class org.apache.flink.table.data.binary.BinaryStringData
Returns a string whose value is this string, with any leading and trailing whitespace removed.
TRIM - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TRUNCATE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TWO_EQUALS_COMPARABLE - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that checks all types are equals comparable with each other.
TWO_FULLY_COMPARABLE - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that checks all types are fully comparable with each other.
TYPE - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
TYPE - Static variable in class org.apache.flink.table.descriptors.LiteralValueValidator
 
TYPE_OF - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TypeConversions - Class in org.apache.flink.table.types.utils
Conversion hub for interoperability of Class, TypeInformation, DataType, and LogicalType.
typedArguments(DataType...) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
typedArguments(List<DataType>) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
Sets the list of argument types for specifying a fixed, not overloaded, not vararg input signature explicitly.
typedArguments(DataType...) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
 
TypedSetters - Interface in org.apache.flink.table.data.binary
Provide type specialized setters to reduce if/else and eliminate box and unbox.
TypeInference - Class in org.apache.flink.table.types.inference
Provides logic for the type inference of function calls.
TypeInference.Builder - Class in org.apache.flink.table.types.inference
Builder for configuring and creating instances of TypeInference.
TypeInferenceExtractor - Class in org.apache.flink.table.types.extraction
Reflection-based utility for extracting a TypeInference from a supported subclass of UserDefinedFunction.
TypeInferenceExtractor() - Constructor for class org.apache.flink.table.types.extraction.TypeInferenceExtractor
 
TypeInferenceUtil - Class in org.apache.flink.table.types.inference
Utility for performing type inference.
TypeInferenceUtil.Result - Class in org.apache.flink.table.types.inference
The result of a type inference run.
TypeInferenceUtil.SurroundingInfo - Interface in org.apache.flink.table.types.inference
Information what the outer world (i.e.
TypeInfoDataTypeConverter - Class in org.apache.flink.table.types.utils
Converter from TypeInformation to DataType.
TypeInfoDataTypeConverter() - Constructor for class org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
 
TypeInformationRawType<T> - Class in org.apache.flink.table.types.logical
Deprecated.
Use RawType instead.
TypeInformationRawType(boolean, TypeInformation<T>) - Constructor for class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
TypeInformationRawType(TypeInformation<T>) - Constructor for class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
TypeInformationRawType() - Constructor for class org.apache.flink.table.types.logical.TypeInformationRawType
Deprecated.
 
TypeLiteralExpression - Class in org.apache.flink.table.expressions
Expression that wraps DataType as a literal.
TypeLiteralExpression(DataType) - Constructor for class org.apache.flink.table.expressions.TypeLiteralExpression
 
TypeMappingUtils - Class in org.apache.flink.table.utils
Utility methods for dealing with field types in TableSource and TableSink.
Types - Class in org.apache.flink.table.api
Deprecated.
This class will be removed in future versions as it uses the old type system. It is recommended to use DataTypes instead which uses the new type system based on instances of DataType. 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.
TypeStrategies - Class in org.apache.flink.table.types.inference
Strategies for inferring an output or accumulator data type of a function call.
TypeStrategy - Interface in org.apache.flink.table.types.inference
Strategy for inferring the data type of a function call.
TypeStringUtils - Class in org.apache.flink.table.utils
Deprecated.
This utility is based on TypeInformation. However, the Table & SQL API is currently updated to use DataTypes based on LogicalTypes. Use LogicalTypeParser instead.
TypeStringUtils() - Constructor for class org.apache.flink.table.utils.TypeStringUtils
Deprecated.
 
TypeTransformation - Interface in org.apache.flink.table.types.inference
Transforms one data type to another.
TypeTransformations - Class in org.apache.flink.table.types.inference
Transformations for transforming one data type to another.

U

UNBOUNDED_RANGE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
UNBOUNDED_ROW - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
unescapePathName(String) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
 
UniqueConstraint - Class in org.apache.flink.table.api.constraints
Deprecated.
UniqueConstraint - Class in org.apache.flink.table.catalog
A unique key constraint.
unixTimeToString(int) - Static method in class org.apache.flink.table.utils.TimestampStringUtils
Cast TIME type value to VARCHAR(N), we use same SQL format with codegen in org.apache.flink.table.runtime.functions.SqlDateTimeUtils.
UNKNOWN - Static variable in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
 
UNKNOWN - Static variable in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
UNKNOWN - Static variable in class org.apache.flink.table.plan.stats.TableStats
Unknown definition for table stats: Unknown TableStats.rowCount is -1.
UnknownCallContext - Class in org.apache.flink.table.types.inference.utils
A CallContext with unknown data types.
UnknownCallContext(DataTypeFactory, String, FunctionDefinition, int, boolean) - Constructor for class org.apache.flink.table.types.inference.utils.UnknownCallContext
 
UnresolvedDataType - Class in org.apache.flink.table.types
Partially resolved data type that requires a lookup in a catalog or configuration before creating the corresponding LogicalType.
UnresolvedDataType(Supplier<String>, Function<DataTypeFactory, DataType>) - Constructor for class org.apache.flink.table.types.UnresolvedDataType
 
UnresolvedException - Exception in org.apache.flink.table.api
Exception for unwanted method calling on unresolved expression.
UnresolvedException(String) - Constructor for exception org.apache.flink.table.api.UnresolvedException
 
UnresolvedIdentifier - Class in org.apache.flink.table.catalog
Identifier of an object, such as table, view, function or type in a catalog.
UnresolvedUserDefinedType - Class in org.apache.flink.table.types.logical
Placeholder type of an unresolved user-defined type that is identified by an UnresolvedIdentifier.
UnresolvedUserDefinedType(boolean, UnresolvedIdentifier) - Constructor for class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
UnresolvedUserDefinedType(UnresolvedIdentifier) - Constructor for class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
UPDATE_MODE - Static variable in class org.apache.flink.table.descriptors.StreamTableDescriptorValidator
 
UPDATE_MODE_VALUE_APPEND - Static variable in class org.apache.flink.table.descriptors.StreamTableDescriptorValidator
 
UPDATE_MODE_VALUE_RETRACT - Static variable in class org.apache.flink.table.descriptors.StreamTableDescriptorValidator
 
UPDATE_MODE_VALUE_UPSERT - Static variable in class org.apache.flink.table.descriptors.StreamTableDescriptorValidator
 
UPPER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
UPPERCASE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
upsert() - Static method in class org.apache.flink.table.connector.ChangelogMode
Shortcut for an upsert changelog that describes idempotent updates on a key and thus does not contain RowKind.UPDATE_BEFORE rows.
UseArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Type strategy that returns the n-th input argument.
UseArgumentTypeStrategy(int) - Constructor for class org.apache.flink.table.types.inference.strategies.UseArgumentTypeStrategy
 
UserDefinedFunction - Class in org.apache.flink.table.functions
Base class for all user-defined functions.
UserDefinedFunction() - Constructor for class org.apache.flink.table.functions.UserDefinedFunction
 
UserDefinedFunctionHelper - Class in org.apache.flink.table.functions
Utility for dealing with subclasses of UserDefinedFunction.
UserDefinedType - Class in org.apache.flink.table.types.logical
Logical type of a user-defined representation for one or more built-in types.
UUID - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 

V

validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
 
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.CoreModuleDescriptorValidator
 
validate(DescriptorProperties) - Method in interface org.apache.flink.table.descriptors.DescriptorValidator
Performs basic validation such as completeness tests.
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.FileSystemValidator
 
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.FormatDescriptorValidator
 
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.FunctionDescriptorValidator
 
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.HierarchyDescriptorValidator
 
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.ModuleDescriptorValidator
 
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.PythonFunctionValidator
 
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.StreamTableDescriptorValidator
 
validate() - Method in class org.apache.flink.table.factories.FactoryUtil.CatalogFactoryHelper
Validates the options of the CatalogFactory.
validate() - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
Validates the options of the DynamicTableFactory.
validateArgumentFields(TypeInformation<?>[]) - Method in interface org.apache.flink.table.sources.FieldComputer
Deprecated.
Validates that the fields that the expression references have the correct types.
validateArray(String, Consumer<String>, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates an array of values.
validateArray(String, Consumer<String>, int, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates an array of values.
validateBigDecimal(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a big decimal property.
validateBigDecimal(String, boolean, BigDecimal, BigDecimal) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a big decimal property.
validateBoolean(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates that a boolean value is present under the given key.
validateByte(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a byte property.
validateByte(String, boolean, byte) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a byte property.
validateByte(String, boolean, byte, byte) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a byte property.
validateClass(Class<? extends UserDefinedFunction>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Validates a UserDefinedFunction class for usage in the API.
validateClassForRuntime(Class<? extends UserDefinedFunction>, String, Class<?>[], Class<?>, String) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
Validates a UserDefinedFunction class for usage in the runtime.
validateDataType(String, String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a data type property.
validateDouble(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a double property.
validateDouble(String, boolean, double) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a double property.
validateDouble(String, boolean, double, double) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a double property.
validateDuration(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a Java Duration.
validateDuration(String, boolean, int, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a Java Duration.
validateDuration(String, boolean, int, long, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a Java Duration.
validateEnum(String, boolean, Map<String, Consumer<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates an enum property with a set of validation logic for each enum value.
validateEnumValues(String, boolean, List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates an enum property with a set of enum values.
validateExcept(String...) - Method in class org.apache.flink.table.factories.FactoryUtil.CatalogFactoryHelper
Validates the options of the CatalogFactory.
validateExcept(String...) - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
Validates the options of the DynamicTableFactory.
validateExclusion(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates that the given key is not included in these properties.
validateFactoryOptions(Factory, ReadableConfig) - Static method in class org.apache.flink.table.factories.FactoryUtil
Validates the required and optional ConfigOptions of a factory.
validateFactoryOptions(Set<ConfigOption<?>>, Set<ConfigOption<?>>, ReadableConfig) - Static method in class org.apache.flink.table.factories.FactoryUtil
Validates the required options and optional options.
validateFixedIndexedProperties(String, boolean, Map<String, Consumer<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validation for fixed indexed properties.
validateFloat(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a float property.
validateFloat(String, boolean, float) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a float property.
validateFloat(String, boolean, float, float) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a float property.
validateInputDataType(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
The DataType class can only partially verify the conversion class.
validateInt(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates an integer property.
validateInt(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates an integer property.
validateInt(String, boolean, int, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates an integer property.
validateLong(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates an long property.
validateLong(String, boolean, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates an long property.
validateLong(String, boolean, long, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates an long property.
validateMemorySize(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a Flink MemorySize.
validateMemorySize(String, boolean, int, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a Flink MemorySize.
validateMemorySize(String, boolean, int, long, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a Flink MemorySize.
validateOutputDataType(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
The DataType class can only partially verify the conversion class.
validatePrefixExclusion(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates that the given prefix is not included in these properties.
validateShort(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a short property.
validateShort(String, boolean, short) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a short property.
validateShort(String, boolean, short, short) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a short property.
validateString(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a string property.
validateString(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a string property.
validateString(String, boolean, int, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a string property.
validateStructuredClass(Class<?>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Validates the characteristics of a class for a StructuredType such as accessibility.
validateTableSchema(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a table schema property.
validateTableSource(TableSource<?>, TableSchema) - Static method in class org.apache.flink.table.sources.TableSourceValidation
Validates a TableSource.
validateType(String, boolean, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates a type property.
validateUnconsumedKeys(String, Set<String>, Set<String>) - Static method in class org.apache.flink.table.factories.FactoryUtil
Validates unconsumed option keys.
validateValue(String, String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Validates that a certain value is present under the given key.
validateWithPrefix(String, DescriptorProperties) - Method in class org.apache.flink.table.descriptors.ClassInstanceValidator
 
validateWithPrefix(String, DescriptorProperties) - Method in class org.apache.flink.table.descriptors.HierarchyDescriptorValidator
Performs validation with a prefix for the keys.
validateWithPrefix(String, DescriptorProperties) - Method in class org.apache.flink.table.descriptors.LiteralValueValidator
 
ValidationException - Exception in org.apache.flink.table.api
Exception for all errors occurring during validation phase.
ValidationException(String, Throwable) - Constructor for exception org.apache.flink.table.api.ValidationException
 
ValidationException(String) - Constructor for exception org.apache.flink.table.api.ValidationException
 
value(boolean) - Method in class org.apache.flink.table.descriptors.LiteralValue
Literal BOOLEAN value.
value(int) - Method in class org.apache.flink.table.descriptors.LiteralValue
Literal INT value.
value(double) - Method in class org.apache.flink.table.descriptors.LiteralValue
Literal DOUBLE value.
value(float) - Method in class org.apache.flink.table.descriptors.LiteralValue
Literal FLOAT value.
value(String) - Method in class org.apache.flink.table.descriptors.LiteralValue
Literal value either for an explicit VARCHAR type or automatically derived type.
value(long) - Method in class org.apache.flink.table.descriptors.LiteralValue
Literal BIGINT value.
value(byte) - Method in class org.apache.flink.table.descriptors.LiteralValue
Literal TINYINT value.
value(short) - Method in class org.apache.flink.table.descriptors.LiteralValue
Literal SMALLINT value.
value(BigDecimal) - Method in class org.apache.flink.table.descriptors.LiteralValue
Literal DECIMAL value.
VALUE - Static variable in class org.apache.flink.table.descriptors.LiteralValueValidator
 
valueArray() - Method in class org.apache.flink.table.data.binary.BinaryMapData
 
valueArray() - Method in class org.apache.flink.table.data.GenericMapData
 
valueArray() - Method in interface org.apache.flink.table.data.MapData
Returns an array view of the values contained in this map.
ValueDataTypeConverter - Class in org.apache.flink.table.types.utils
Value-based data type extractor that supports extraction of clearly identifiable data types for input conversion.
ValueLiteralExpression - Class in org.apache.flink.table.expressions
Expression for constant literal values.
ValueLiteralExpression(Object) - Constructor for class org.apache.flink.table.expressions.ValueLiteralExpression
 
ValueLiteralExpression(Object, DataType) - Constructor for class org.apache.flink.table.expressions.ValueLiteralExpression
 
valueOf(String) - Static method in enum org.apache.flink.table.annotation.ExtractionVersion
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.annotation.HintFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.annotation.InputGroup
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.api.constraints.Constraint.ConstraintType
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.catalog.CatalogBaseTable.TableKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.catalog.Constraint.ConstraintType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.catalog.FunctionLanguage
Returns the enum constant of this type with the specified name.
valueOf(BinaryArrayData, BinaryArrayData) - Static method in class org.apache.flink.table.data.binary.BinaryMapData
 
valueOf(String) - Static method in enum org.apache.flink.table.expressions.TimeIntervalUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.expressions.TimePointUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.functions.FunctionKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.functions.FunctionRequirement
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.functions.python.PythonEnv.ExecType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.functions.python.PythonFunctionKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.functions.python.utils.PythonFunctionUtils
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.types.logical.LogicalTypeFamily
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.types.logical.LogicalTypeRoot
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.types.logical.StructuredType.StructuredComparision
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.types.logical.TimestampKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.table.types.logical.YearMonthIntervalType.YearMonthResolution
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.flink.table.annotation.ExtractionVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.annotation.HintFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.annotation.InputGroup
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.api.constraints.Constraint.ConstraintType
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.flink.table.api.dataview.MapView
Returns all the values in the map view.
values() - Static method in enum org.apache.flink.table.catalog.CatalogBaseTable.TableKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.catalog.Constraint.ConstraintType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.catalog.FunctionLanguage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.expressions.TimeIntervalUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.expressions.TimePointUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.functions.FunctionKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.functions.FunctionRequirement
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.functions.python.PythonEnv.ExecType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.functions.python.PythonFunctionKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.functions.python.utils.PythonFunctionUtils
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.types.logical.LogicalTypeFamily
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.types.logical.LogicalTypeRoot
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.types.logical.StructuredType.StructuredComparision
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.types.logical.TimestampKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.table.types.logical.YearMonthIntervalType.YearMonthResolution
Returns an array containing the constants of this enum type, in the order they are declared.
valueType - Variable in class org.apache.flink.table.api.dataview.MapView
Deprecated.
VAR_POP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
VAR_SAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
VARBINARY(int) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a variable-length binary string (=a sequence of bytes) VARBINARY(n) where n is the maximum number of bytes.
VarBinaryType - Class in org.apache.flink.table.types.logical
Logical type of a variable-length binary string (=a sequence of bytes).
VarBinaryType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.VarBinaryType
 
VarBinaryType(int) - Constructor for class org.apache.flink.table.types.logical.VarBinaryType
 
VarBinaryType() - Constructor for class org.apache.flink.table.types.logical.VarBinaryType
 
VARCHAR(int) - Static method in class org.apache.flink.table.api.DataTypes
Data type of a variable-length character string VARCHAR(n) where n is the maximum number of code points.
VarCharType - Class in org.apache.flink.table.types.logical
Logical type of a variable-length character string.
VarCharType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.VarCharType
 
VarCharType(int) - Constructor for class org.apache.flink.table.types.logical.VarCharType
 
VarCharType() - Constructor for class org.apache.flink.table.types.logical.VarCharType
 
varyingSequence(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a varying function signature like f(INT, STRING, NUMERIC...) using a sequence of ArgumentTypeStrategys.
varyingSequence(String[], ArgumentTypeStrategy[]) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a varying named function signature like f(i INT, str STRING, num NUMERIC...) using a sequence of ArgumentTypeStrategys.
VaryingSequenceInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy for inferring and validating a varying function signature like f(INT, STRING, NUMERIC...) or f(i INT, str STRING, num NUMERIC...) using a sequence of ArgumentTypeStrategys.
VaryingSequenceInputTypeStrategy(List<ArgumentTypeStrategy>, List<String>) - Constructor for class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
 
varyingString(TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
A type strategy that ensures that the result type is either LogicalTypeRoot.VARCHAR or LogicalTypeRoot.VARBINARY from their corresponding non-varying roots.
VaryingStringTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
A type strategy that ensures that the result type is either LogicalTypeRoot.VARCHAR or LogicalTypeRoot.VARBINARY from their corresponding non-varying roots.
VaryingStringTypeStrategy(TypeStrategy) - Constructor for class org.apache.flink.table.types.inference.strategies.VaryingStringTypeStrategy
 
VIRTUAL - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
visit(CallExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
 
visit(ValueLiteralExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
 
visit(FieldReferenceExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
 
visit(TypeLiteralExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
 
visit(Expression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
 
visit(CallExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
 
visit(ValueLiteralExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
 
visit(FieldReferenceExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
 
visit(TypeLiteralExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
 
visit(Expression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
 
visit(AtomicDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
 
visit(CollectionDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
 
visit(FieldsDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
 
visit(KeyValueDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
 
visit(CharType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(VarCharType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(BooleanType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(BinaryType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(VarBinaryType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(DecimalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(TinyIntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(SmallIntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(IntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(BigIntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(FloatType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(DoubleType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(DateType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(TimeType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(TimestampType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(ZonedTimestampType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(LocalZonedTimestampType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(YearMonthIntervalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(DayTimeIntervalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(ArrayType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(MultisetType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(MapType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(RowType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(DistinctType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(StructuredType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(NullType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(RawType<?>) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(SymbolType<?>) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(LogicalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
 
visit(CharType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(VarCharType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(BooleanType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(BinaryType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(VarBinaryType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(DecimalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(TinyIntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(SmallIntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(IntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(BigIntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(FloatType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(DoubleType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(DateType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(TimeType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(TimestampType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(ZonedTimestampType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(LocalZonedTimestampType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(YearMonthIntervalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(DayTimeIntervalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(ArrayType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(MultisetType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(MapType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(RowType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(DistinctType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(StructuredType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(NullType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(RawType<?>) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(SymbolType<?>) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(LogicalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
visit(ArrayType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
 
visit(MultisetType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
 
visit(MapType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
 
visit(RowType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
 
visit(DistinctType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
 
visit(StructuredType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
 
visit(AtomicDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
 
visit(CollectionDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
 
visit(FieldsDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
 
visit(KeyValueDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
 

W

watermark(String, Expression) - Method in class org.apache.flink.table.api.Schema.Builder
Declares that the given column should serve as an event-time (i.e.
watermark(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
Declares that the given column should serve as an event-time (i.e.
watermark(String, String, DataType) - Method in class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
Specifies the previously defined field as an event-time attribute and specifies the watermark strategy.
watermark(WatermarkSpec) - Method in class org.apache.flink.table.api.TableSchema.Builder
Deprecated.
Adds the given WatermarkSpec to this builder.
WATERMARK - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
WATERMARK_ROWTIME - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
WATERMARK_STRATEGY - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
WATERMARK_STRATEGY_DATA_TYPE - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
WATERMARK_STRATEGY_EXPR - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
 
watermarksFromSource() - Method in class org.apache.flink.table.descriptors.Rowtime
Sets a built-in watermark strategy which indicates the watermarks should be preserved from the underlying DataStream API and thus preserves the assigned watermarks from the source.
watermarksFromStrategy(WatermarkStrategy) - Method in class org.apache.flink.table.descriptors.Rowtime
Sets a custom watermark strategy to be used for the rowtime attribute.
WatermarkSpec - Class in org.apache.flink.table.api
Deprecated.
WatermarkSpec(String, String, DataType) - Constructor for class org.apache.flink.table.api.WatermarkSpec
Deprecated.
 
WatermarkSpec - Class in org.apache.flink.table.catalog
Representation of a watermark specification in a ResolvedSchema.
watermarksPeriodicAscending() - Method in class org.apache.flink.table.descriptors.Rowtime
Sets a built-in watermark strategy for ascending rowtime attributes.
watermarksPeriodicBounded(long) - Method in class org.apache.flink.table.descriptors.Rowtime
Sets a built-in watermark strategy for rowtime attributes which are out-of-order by a bounded time interval.
WatermarkStrategy - Class in org.apache.flink.table.sources.wmstrategies
Provides a strategy to generate watermarks for a rowtime attribute.
WatermarkStrategy() - Constructor for class org.apache.flink.table.sources.wmstrategies.WatermarkStrategy
 
WILDCARD - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that does not perform any modification or validation of the input.
WildcardInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
Strategy that does not perform any modification or validation of the input.
WildcardInputTypeStrategy(ArgumentCount) - Constructor for class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
WildcardInputTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
wildcardWithCount(ArgumentCount) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that does not perform any modification or validation of the input.
WINDOW_END - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
WINDOW_PROPERTIES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
WINDOW_START - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
WITH_COLUMNS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
withFormat(FormatDescriptor) - Method in class org.apache.flink.table.descriptors.TableDescriptor
Specifies the format that defines how to read data from a connector.
withNullability(String, Object...) - Method in class org.apache.flink.table.types.logical.LogicalType
 
WITHOUT_COLUMNS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
withoutKeys(List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Deprecated.
Returns a new properties instance with the given keys removed.
wrapperToPrimitive(Class<?>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
Converts the specified wrapper class to its corresponding primitive class.
writeTypeInfo(TypeInformation<?>) - Static method in class org.apache.flink.table.utils.TypeStringUtils
Deprecated.
 

Y

YEAR(int) - Static method in class org.apache.flink.table.api.DataTypes
Resolution in years.
YEAR() - Static method in class org.apache.flink.table.api.DataTypes
Resolution in years with 2 digits for the number of years by default.
YearMonthIntervalType - Class in org.apache.flink.table.types.logical
Logical type for a group of year-month interval types.
YearMonthIntervalType(boolean, YearMonthIntervalType.YearMonthResolution, int) - Constructor for class org.apache.flink.table.types.logical.YearMonthIntervalType
 
YearMonthIntervalType(YearMonthIntervalType.YearMonthResolution, int) - Constructor for class org.apache.flink.table.types.logical.YearMonthIntervalType
 
YearMonthIntervalType(YearMonthIntervalType.YearMonthResolution) - Constructor for class org.apache.flink.table.types.logical.YearMonthIntervalType
 
YearMonthIntervalType.YearMonthResolution - Enum in org.apache.flink.table.types.logical
Supported resolutions of this type.

Z

zero(int, int) - Static method in class org.apache.flink.table.data.DecimalData
Creates an instance of DecimalData for a zero value with the given precision and scale.
ZonedTimestampType - Class in org.apache.flink.table.types.logical
Logical type of a timestamp WITH time zone consisting of year-month-day hour:minute:second[.fractional] zone with up to nanosecond precision and values ranging from 0000-01-01 00:00:00.000000000 +14:59 to 9999-12-31 23:59:59.999999999 -14:59.
ZonedTimestampType(boolean, TimestampKind, int) - Constructor for class org.apache.flink.table.types.logical.ZonedTimestampType
Internal constructor that allows attaching additional metadata about time attribute properties.
ZonedTimestampType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.ZonedTimestampType
 
ZonedTimestampType(int) - Constructor for class org.apache.flink.table.types.logical.ZonedTimestampType
 
ZonedTimestampType() - Constructor for class org.apache.flink.table.types.logical.ZonedTimestampType
 
A B C D E F G H I J K L M N O P R S T U V W Y Z 
Skip navigation links

Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.