Skip navigation links
A B C D E F G H I 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
 
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.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.AnyType
 
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.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.TypeInformationAnyType
 
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
 
accumulatorTypeStrategy(TypeStrategy) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
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
 
add(T) - Method in class org.apache.flink.table.api.dataview.ListView
Adds the given value to the list.
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.
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
 
AggregateFunction<T,ACC> - Class in org.apache.flink.table.functions
Base class for user-defined aggregates.
AggregateFunction() - Constructor for class org.apache.flink.table.functions.AggregateFunction
 
AggregateFunctionDefinition - Class in org.apache.flink.table.functions
The function definition of an user-defined aggregate function.
AggregateFunctionDefinition(String, AggregateFunction<?, ?>, TypeInformation<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.functions.AggregateFunctionDefinition
 
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
Modify 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
 
ANY(Class<T>, TypeSerializer<T>) - Static method in class org.apache.flink.table.api.DataTypes
Data type of an arbitrary serialized type.
ANY(TypeInformation<T>) - Static method in class org.apache.flink.table.api.DataTypes
Data type of an arbitrary serialized type backed by TypeInformation.
AnyType<T> - Class in org.apache.flink.table.types.logical
Logical type of an arbitrary serialized type.
AnyType(boolean, Class<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.table.types.logical.AnyType
 
AnyType(Class<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.table.types.logical.AnyType
 
applyPartitionPruning(List<Map<String, String>>) - Method in interface org.apache.flink.table.sources.PartitionableTableSource
Applies the remaining partitions to the table source.
applyPredicate(List<Expression>) - Method in interface org.apache.flink.table.sources.FilterableTableSource
Check and pick all predicates this table source can support.
areTypesCompatible(LogicalType, LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Returns true if the two given types are compatible.
ArgumentCount - Interface in org.apache.flink.table.types.inference
Defines the count of accepted arguments (including open intervals) that a function can take.
ARRAY(DataType) - Static method in class org.apache.flink.table.api.DataTypes
Data type of an array of elements with same subtype.
ARRAY - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ARRAY_ELEMENT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
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
Returns the properties as a map copy.
asPrefixedMap(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
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.AnyType
 
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.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.TypeInformationAnyType
 
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 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.TypeLiteralExpression
 
asSummaryString() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.AnyType
 
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.RowType
 
asSummaryString() - Method in class org.apache.flink.table.types.logical.RowType.RowField
 
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.TypeInformationAnyType
 
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
 
AsyncTableFunction<T> - Class in org.apache.flink.table.functions
Base class for a user-defined asynchronously table function (UDTF).
AsyncTableFunction() - Constructor for class org.apache.flink.table.functions.AsyncTableFunction
 
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
 
AVG - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
AVG_LENGTH - Static variable in class org.apache.flink.table.descriptors.StatisticsValidator
 

B

BETWEEN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
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.
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
 
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 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.DataType
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.FieldsDataType
 
bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.KeyValueDataType
 
build() - Method in class org.apache.flink.table.api.TableSchema.Builder
Returns a TableSchema instance.
build() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.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
 
Builder() - Constructor for class org.apache.flink.table.api.TableSchema.Builder
 
Builder() - Constructor for class org.apache.flink.table.functions.BuiltInFunctionDefinition.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(ObjectIdentifier, List<StructuredType.StructuredAttribute>) - Constructor for class org.apache.flink.table.types.logical.StructuredType.Builder
 
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
 
BYTE() - Static method in class org.apache.flink.table.api.Types
Deprecated.
Returns type information for a Table API byte or SQL TINYINT type.
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

CallContext - Interface in org.apache.flink.table.types.inference
Provides details about the function call for InputTypeValidator and TypeStrategy.
CallContextBase - Interface in org.apache.flink.table.types.inference
Provides details about the function call for which type inference is performed.
CallExpression - Class in org.apache.flink.table.expressions
Resolved and validated call expression for calling a function.
CallExpression(ObjectIdentifier, 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
 
canEqual(Object) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
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
 
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 - Static variable in class org.apache.flink.table.descriptors.ExternalCatalogDescriptorValidator
Deprecated.
Prefix for catalog-related properties.
CATALOG_DEFAULT_DATABASE - Static variable in class org.apache.flink.table.descriptors.CatalogDescriptorValidator
Key for describing the default database of the catalog.
CATALOG_PROPERTY_VERSION - Static variable in class org.apache.flink.table.descriptors.CatalogDescriptorValidator
Key for describing the property version.
CATALOG_PROPERTY_VERSION - Static variable in class org.apache.flink.table.descriptors.ExternalCatalogDescriptorValidator
Deprecated.
Key for describing the property version.
CATALOG_TYPE - Static variable in class org.apache.flink.table.descriptors.CatalogDescriptorValidator
Key for describing the type of the catalog.
CATALOG_TYPE - Static variable in class org.apache.flink.table.descriptors.ExternalCatalogDescriptorValidator
Deprecated.
Key for describing the type of the catalog.
CatalogBaseTable - Interface in org.apache.flink.table.catalog
CatalogBaseTable is the common parent of table and view.
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
 
CatalogConfig - Class in org.apache.flink.table.catalog.config
Config for catalog and catalog meta-objects.
CatalogConfig() - Constructor for class org.apache.flink.table.catalog.config.CatalogConfig
 
CatalogDatabase - Interface in org.apache.flink.table.catalog
Interface of a database in a catalog.
CatalogDescriptor - Class in org.apache.flink.table.descriptors
Describes a catalog of tables, views, and functions.
CatalogDescriptor(String, int) - Constructor for class org.apache.flink.table.descriptors.CatalogDescriptor
Constructs a CatalogDescriptor.
CatalogDescriptor(String, int, String) - Constructor for class org.apache.flink.table.descriptors.CatalogDescriptor
Constructs a CatalogDescriptor.
CatalogDescriptorValidator - Class in org.apache.flink.table.descriptors
Validator for CatalogDescriptor.
CatalogDescriptorValidator() - Constructor for class org.apache.flink.table.descriptors.CatalogDescriptorValidator
 
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.
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
 
CatalogTable - Interface in org.apache.flink.table.catalog
Represents 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 a view in a catalog.
CEIL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
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
 
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
 
clazz - Variable in class org.apache.flink.table.typeutils.InternalTypeInfo
 
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.
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 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
 
collector - Variable in class org.apache.flink.table.functions.TableFunction
The code generated collector used to emit rows.
columnAvgLength(String, Double) - Method in class org.apache.flink.table.descriptors.Statistics
Sets the average length statistic for the given column.
columnDistinctCount(String, Long) - Method in class org.apache.flink.table.descriptors.Statistics
Sets the number of distinct values statistic for the given column.
columnMaxLength(String, Integer) - Method in class org.apache.flink.table.descriptors.Statistics
Sets the maximum length statistic for the given column.
columnMaxValue(String, Number) - Method in class org.apache.flink.table.descriptors.Statistics
Sets the maximum value statistic for the given column.
columnMinValue(String, Number) - Method in class org.apache.flink.table.descriptors.Statistics
Sets the minimum value statistic for the given column.
columnNullCount(String, Long) - Method in class org.apache.flink.table.descriptors.Statistics
Sets the number of null values statistic for the given column.
columnStats(String, ColumnStats) - Method in class org.apache.flink.table.descriptors.Statistics
Sets statistics for a column.
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
 
comment(String) - Method in class org.apache.flink.table.descriptors.Metadata
Sets a comment.
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
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_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
 
CONSTRUCTOR - Static variable in class org.apache.flink.table.descriptors.ClassInstanceValidator
 
contains(K) - Method in class org.apache.flink.table.api.dataview.MapView
Checks if the map view contains a value for a given key.
containsKey(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns if the given key is contained.
conversionClass - Variable in class org.apache.flink.table.types.DataType
 
conversionSet(String...) - Static method in class org.apache.flink.table.types.logical.LogicalType
 
copy() - Method in class org.apache.flink.table.api.TableSchema
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() - 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() - 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(ListView<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
 
copy(ListView<T>, ListView<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
 
copy(MapView<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
copy(MapView<K, V>, MapView<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
copy(Map<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
copy(Map<K, V>, Map<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
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.AnyType
 
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.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.TypeInformationAnyType
 
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
 
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
 
createAccumulator() - Method in class org.apache.flink.table.functions.UserDefinedAggregateFunction
Creates and initializes the accumulator for this UserDefinedAggregateFunction.
createCatalog(String, Map<String, String>) - Method in interface org.apache.flink.table.factories.CatalogFactory
Creates and configures a Catalog using the given properties.
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
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.
createDeserializationSchema(Map<String, String>) - Method in interface org.apache.flink.table.factories.DeserializationSchemaFactory
Creates and configures a DeserializationSchema using the given properties.
createExternalCatalog(Map<String, String>) - Method in interface org.apache.flink.table.factories.ExternalCatalogFactory
Deprecated.
Creates and configures an ExternalCatalog using the given properties.
createFunction(ObjectPath, CatalogFunction, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Create a function.
createFunctionDefinition(String, CatalogFunction) - Method in interface org.apache.flink.table.factories.FunctionDefinitionFactory
Creates a FunctionDefinition from given CatalogFunction.
createInstance() - Method in class org.apache.flink.table.dataview.ListViewSerializer
 
createInstance() - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
createInstance() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
createInstance() - Method in class org.apache.flink.table.dataview.NullSerializer
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.dataview.ListViewSerializerSnapshot
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.dataview.MapViewSerializerSnapshot
 
createPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Create a partition.
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
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
createTable(ObjectPath, CatalogBaseTable, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
Create a new table or view.
createTableSink(Map<String, String>) - Method in interface org.apache.flink.table.factories.TableSinkFactory
Creates and configures a TableSink using the given properties.
createTableSink(ObjectPath, CatalogTable) - Method in interface org.apache.flink.table.factories.TableSinkFactory
Creates and configures a TableSink based on the given CatalogTable instance.
createTableSource(Map<String, String>) - Method in interface org.apache.flink.table.factories.TableSourceFactory
Creates and configures a TableSource using the given properties.
createTableSource(ObjectPath, CatalogTable) - Method in interface org.apache.flink.table.factories.TableSourceFactory
Creates and configures a TableSource based on the given CatalogTable instance.
createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.table.dataview.ListViewTypeInfoFactory
 
createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.table.dataview.MapViewTypeInfoFactory
 
creationTime(long) - Method in class org.apache.flink.table.descriptors.Metadata
Sets a creation time.
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_TIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CURRENT_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 

D

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 - Class in org.apache.flink.table.types
Describes the data type of a value in the table ecosystem.
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
 
DataTypes - Class in org.apache.flink.table.api
A DataType can be used to declare input and/or output types of operations.
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.
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 AggregateFunction.
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
 
DATE_TIME_PLUS - 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.
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, 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
 
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
 
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
The DefinedFieldMapping interface provides a mapping for the fields of the table schema (TableSource.getTableSchema() to fields of the physical produced data type TableSource.getProducedDataType() of a TableSource.
DefinedProctimeAttribute - Interface in org.apache.flink.table.sources
Extends a TableSource to specify a processing time attribute.
DefinedRowtimeAttributes - Interface in org.apache.flink.table.sources
Extends a TableSource to specify rowtime attributes via a RowtimeAttributeDescriptor.
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).
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
Utility class for having a unified string-based representation of Table API related classes such as TableSchema, TypeInformation, etc.
DescriptorProperties(boolean) - Constructor for class org.apache.flink.table.descriptors.DescriptorProperties
 
DescriptorProperties() - Constructor for class org.apache.flink.table.descriptors.DescriptorProperties
 
DescriptorValidator - Interface in org.apache.flink.table.descriptors
Validator for a descriptor.
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
 
deserialize(ListView<T>, DataInputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
deserialize(MapView<K, V>, DataInputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
deserialize(Map<K, V>, DataInputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.NullSerializer
 
deserialize(Object, DataInputView) - Method in class org.apache.flink.table.dataview.NullSerializer
 
DISTINCT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
DISTINCT_COUNT - Static variable in class org.apache.flink.table.descriptors.StatisticsValidator
 
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
 
dropDatabase(String, 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
 
duplicate() - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
duplicate() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 

E

E - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
elementType - Variable in class org.apache.flink.table.api.dataview.ListView
 
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
 
encodeBytesToBase64(byte[]) - 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
 
EncodingUtils - Class in org.apache.flink.table.utils
General utilities for string-encoding.
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.dataview.ListView
 
equals(Object) - Method in class org.apache.flink.table.api.dataview.MapView
 
equals(Object) - Method in class org.apache.flink.table.api.TableSchema
 
equals(Object) - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
 
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.dataview.ListViewSerializer
 
equals(Object) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
equals(Object) - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
equals(Object) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
equals(Object) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
equals(Object) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
 
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.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.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.sources.RowtimeAttributeDescriptor
 
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.KeyValueDataType
 
equals(Object) - Method in class org.apache.flink.table.types.logical.AnyType
 
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.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.TypeInformationAnyType
 
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.InternalTypeInfo
 
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
 
EXP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
explainSource() - Method in interface org.apache.flink.table.sources.TableSource
Describes the table source.
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.
ExternalCatalog - Interface in org.apache.flink.table.catalog
Deprecated.
use Catalog instead.
ExternalCatalogDescriptor - Class in org.apache.flink.table.descriptors
Deprecated.
use CatalogDescriptor instead.
ExternalCatalogDescriptor(String, int) - Constructor for class org.apache.flink.table.descriptors.ExternalCatalogDescriptor
Deprecated.
ExternalCatalogDescriptorValidator - Class in org.apache.flink.table.descriptors
Deprecated.
ExternalCatalogDescriptorValidator() - Constructor for class org.apache.flink.table.descriptors.ExternalCatalogDescriptorValidator
Deprecated.
 
ExternalCatalogFactory - Interface in org.apache.flink.table.factories
Deprecated.
use CatalogFactory instead.
ExternalCatalogTable - Class in org.apache.flink.table.catalog
Deprecated.
use CatalogTable instead.
ExternalCatalogTable(boolean, boolean, boolean, boolean, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.ExternalCatalogTable
Deprecated.
 
EXTRACT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
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.
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

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, DataType) - Method in class org.apache.flink.table.api.TableSchema.Builder
Add a field with name and data type.
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, TypeInformation<?>) - Method in class org.apache.flink.table.descriptors.Schema
Adds a field with the field name and the type information.
field(String, String) - Method in class org.apache.flink.table.descriptors.Schema
Adds a field with the field name and the type string.
FieldComputer<T> - Interface in org.apache.flink.table.sources
The FieldComputer interface returns an expression to compute the field of the table schema of a TableSource from one or more fields of the TableSource's return type.
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
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 (e.g.
FieldsDataType(LogicalType, Class<?>, Map<String, DataType>) - Constructor for class org.apache.flink.table.types.FieldsDataType
 
FieldsDataType(LogicalType, Map<String, 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
 
FileSystemValidator - Class in org.apache.flink.table.descriptors
Validator for FileSystem.
FileSystemValidator() - Constructor for class org.apache.flink.table.descriptors.FileSystemValidator
 
FilterableTableSource<T> - Interface in org.apache.flink.table.sources
Adds support for filtering push-down to a TableSource.
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.
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.
findCommonType(List<LogicalType>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeGeneralization
Returns the most common type of a set of types.
FLATTEN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
FLINK_PROPERTY_PREFIX - Static variable in class org.apache.flink.table.catalog.config.CatalogConfig
 
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
 
FORMAT - Static variable in class org.apache.flink.table.descriptors.FormatDescriptorValidator
Prefix for format-related properties.
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_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
 
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_BASE64 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
FROM_VALUE_CLASS - Static variable in class org.apache.flink.table.descriptors.FunctionDescriptorValidator
 
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
 
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
 
fromDataTypeToLegacyInfo(DataType[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
 
fromLegacyInfoToDataType(TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.TypeConversions
 
fromLegacyInfoToDataType(TypeInformation<?>[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
 
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
 
fromString(String) - Static method in class org.apache.flink.table.catalog.ObjectPath
 
fromTypeInfo(TypeInformation<?>) - Static method in class org.apache.flink.table.api.TableSchema
Deprecated.
This method will be removed soon. Use DataTypes to declare types.
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.
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.
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.

G

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.
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 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
get(K) - Method in class org.apache.flink.table.utils.ThreadLocalCache
 
getAccumulatorDataType() - Method in class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.UserDefinedAggregateFunction
Returns the TypeInformation of the UserDefinedAggregateFunction's accumulator.
getAccumulatorTypeInfo() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
getAccumulatorTypeInfo() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
getAccumulatorTypeStrategy() - Method in class org.apache.flink.table.types.inference.TypeInference
 
getAggregateFunction() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
getArgumentCount() - Method in interface org.apache.flink.table.types.inference.InputTypeValidator
Initial input validation based on the number of arguments.
getArgumentCount() - Method in class org.apache.flink.table.types.inference.validators.PassingTypeValidator
 
getArgumentDataTypes() - Method in interface org.apache.flink.table.types.inference.CallContext
Returns a resolved list of the call's argument types.
getArgumentFields() - Method in interface org.apache.flink.table.sources.FieldComputer
Returns the names of all fields that the expression of the field computer accesses.
getArgumentNames() - Method in class org.apache.flink.table.types.inference.TypeInference
 
getArguments() - Method in class org.apache.flink.table.types.inference.Signature
 
getArgumentTypes() - Method in class org.apache.flink.table.types.inference.TypeInference
 
getArgumentValue(int, Class<T>) - Method in interface org.apache.flink.table.types.inference.CallContextBase
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.
getArity() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
getArity() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
getArity() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
getArity() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
getArray(String, Function<String, E>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns all array elements under a given existing key.
getAsyncLookupFunction(String[]) - Method in interface org.apache.flink.table.sources.LookupableTableSource
Gets the AsyncTableFunction which supports async lookup one key at a time.
getAttributeName() - Method in class org.apache.flink.table.sources.RowtimeAttributeDescriptor
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
Returns a big decimal value under the given existing key.
getBoolean(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a boolean value under the given existing key.
getByte(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a byte value under the given existing key.
getCachedFile(String) - Method in class org.apache.flink.table.functions.FunctionContext
Gets the local temporary file copy of a distributed cache files.
getCatalog() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
getCatalogName() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
 
getCharacter(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a character value under the given existing key.
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.TypeLiteralExpression
 
getChildren() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
 
getChildren() - Method in class org.apache.flink.table.types.logical.AnyType
 
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.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.TypeInformationAnyType
 
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
Returns a class value under the given existing key.
getClassName() - Method in interface org.apache.flink.table.catalog.CatalogFunction
Get the full name of the class backing the function.
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.
getComparision() - Method in class org.apache.flink.table.types.logical.StructuredType
 
getConsumedDataType() - Method in interface org.apache.flink.table.sinks.TableSink
Returns the data type consumed by this TableSink.
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
 
getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.dataview.MapViewSerializerSnapshot
 
getDatabase(String) - Method in interface org.apache.flink.table.catalog.Catalog
Get a database from this catalog.
getDatabase() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
getDatabaseName() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
 
getDatabaseName() - Method in class org.apache.flink.table.catalog.ObjectPath
 
getDataType() - Method in class org.apache.flink.table.api.DataTypes.Field
 
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
 
getDefaultConversion() - Method in class org.apache.flink.table.types.logical.AnyType
 
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.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.TypeInformationAnyType
 
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.
getDefaultDatabase() - Method in class org.apache.flink.table.descriptors.CatalogDescriptor
 
getDefinitions() - Static method in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
getDescription() - Method in class org.apache.flink.table.api.DataTypes.Field
 
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.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.
getDouble(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a double value under the given existing key.
getDuration(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a java Duration under the given existing key.
getElementDataType() - Method in class org.apache.flink.table.types.CollectionDataType
 
getElementType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
getElementType() - Method in class org.apache.flink.table.types.logical.ArrayType
 
getElementType() - Method in class org.apache.flink.table.types.logical.MultisetType
 
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.
getExpectedArgumentTypes() - Method in class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
 
getExpectedSignatures(FunctionDefinition) - Method in interface org.apache.flink.table.types.inference.InputTypeValidator
Returns a summary of the function's expected signatures.
getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.validators.PassingTypeValidator
 
getExpression(ResolvedFieldReference[]) - Method in interface org.apache.flink.table.sources.FieldComputer
Returns the Expression that computes the value of the field.
getFalseCount() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
 
getFamilies() - Method in enum org.apache.flink.table.types.logical.LogicalTypeRoot
 
getFieldCount() - Method in class org.apache.flink.table.api.TableSchema
Returns the number of fields.
getFieldCount() - Method in class org.apache.flink.table.types.logical.RowType
 
getFieldDataType(int) - Method in class org.apache.flink.table.api.TableSchema
Returns the specified data type for the given field index.
getFieldDataType(String) - Method in class org.apache.flink.table.api.TableSchema
Returns the specified data type for the given field name.
getFieldDataTypes() - Method in class org.apache.flink.table.api.TableSchema
Returns all field data types as an array.
getFieldDataTypes() - Method in class org.apache.flink.table.types.FieldsDataType
 
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
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
Returns the specified name for the given field index.
getFieldNames() - Method in class org.apache.flink.table.api.TableSchema
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
 
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.
getFileCount() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
getFixedIndexedProperties(String, List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns the property keys of fixed indexed properties.
getFloat(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a float value under the given given existing key.
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.CallExpression
 
getFunctionDefinition() - Method in interface org.apache.flink.table.types.inference.CallContextBase
Returns the function definition that defines the function currently being called.
getImplementationClass() - Method in class org.apache.flink.table.types.logical.StructuredType
 
getIndexedProperty(String, String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns all properties under a given key that contains an index in between.
getInputIndex() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
getInputTypeValidator() - Method in class org.apache.flink.table.types.inference.TypeInference
 
getInt(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns an integer value under the given existing key.
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
 
getKeySerializer() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
getKeyType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
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
 
getLength() - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
getLength() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
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
 
getListSerializer() - Method in class org.apache.flink.table.dataview.ListViewSerializer
 
getLogicalType() - Method in class org.apache.flink.table.types.DataType
Returns the corresponding logical type.
getLong(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a long value under the given existing key.
getLookupFunction(String[]) - Method in interface org.apache.flink.table.sources.LookupableTableSource
Gets the TableFunction which supports lookup one key at a time.
getMapSerializer() - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
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
 
getMaxCount() - Method in interface org.apache.flink.table.types.inference.ArgumentCount
Returns the maximum number of argument (inclusive) that a function can take.
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
 
getMemorySize(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
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
 
getMetricGroup() - Method in class org.apache.flink.table.functions.FunctionContext
Returns the metric group for this parallel subtask.
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
 
getMinCount() - Method in interface org.apache.flink.table.types.inference.ArgumentCount
Returns the minimum number of argument (inclusive) that a function can take.
getMinValue() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
getName() - Method in class org.apache.flink.table.api.DataTypes.Field
 
getName() - Method in class org.apache.flink.table.catalog.AbstractCatalog
 
getName() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
 
getName() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
 
getName() - Method in interface org.apache.flink.table.types.inference.CallContextBase
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.logical.RowType.RowField
 
getName() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
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
 
getNestedSerializers(MapViewSerializer<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializerSnapshot
 
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 class org.apache.flink.table.expressions.CallExpression
 
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
 
getOptionalArray(String, Function<String, E>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns all array elements under a given key if it exists.
getOptionalBigDecimal(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a big decimal value under the given key if it exists.
getOptionalBoolean(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a boolean value under the given key if it exists.
getOptionalByte(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a byte value under the given key if it exists.
getOptionalCharacter(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a character value under the given key if it exists.
getOptionalClass(String, Class<T>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a class value under the given key if it exists.
getOptionalDouble(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a double value under the given key if it exists.
getOptionalDuration(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a Java Duration under the given key if it exists.
getOptionalFloat(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a float value under the given key if it exists.
getOptionalInt(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns an integer value under the given key if it exists.
getOptionalLong(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a long value under the given key if it exists.
getOptionalMemorySize(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a Flink MemorySize under the given key if it exists.
getOptionalShort(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a short value under the given key if it exists.
getOptionalString(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a string value under the given key if it exists.
getOptionalTableSchema(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a table schema under the given key if it exists.
getOptionalType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns the type information under the given key if it exists.
getOriginalQuery() - Method in interface org.apache.flink.table.catalog.CatalogView
Original text of the view definition that also perserves the original formatting.
getOriginatingClass() - Method in class org.apache.flink.table.types.logical.AnyType
 
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 class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
 
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
 
getParameterTypes(Class<?>[]) - Method in class org.apache.flink.table.functions.ScalarFunction
Returns TypeInformation about the operands of the evaluation method with a given signature.
getParameterTypes(Class<?>[]) - Method in class org.apache.flink.table.functions.TableFunction
Returns TypeInformation about the operands of the evaluation method with a given signature.
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.
getPartitionFieldNames() - Method in interface org.apache.flink.table.sinks.PartitionableTableSink
Gets the partition field names of the table.
getPartitionFieldNames() - Method in interface org.apache.flink.table.sources.PartitionableTableSource
Gets the partition field names of the table.
getPartitionKeys() - Method in interface org.apache.flink.table.catalog.CatalogTable
Get the partition keys of the table.
getPartitions() - Method in interface org.apache.flink.table.sources.PartitionableTableSource
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.
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
 
getProctimeAttribute() - Method in interface org.apache.flink.table.sources.DefinedProctimeAttribute
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
Returns the DataType for the produced data of the TableSource.
getProperties() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
Get the properties of the table.
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.CatalogFunction
Get the properties of the function.
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
Returns a map of properties whose key starts with the given prefix, and the prefix is removed upon return.
getRawDataSize() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
getRequirements() - Method in class org.apache.flink.table.functions.AggregateFunction
 
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.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
 
getResultType() - Method in class org.apache.flink.table.functions.AsyncTableFunction
Returns the result type of the evaluation method with a given signature.
getResultType(Class<?>[]) - Method in class org.apache.flink.table.functions.ScalarFunction
Returns the result type of the evaluation method with a given signature.
getResultType() - Method in class org.apache.flink.table.functions.TableFunction
Returns the result type of the evaluation method with a given signature.
getResultType() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
getResultType() - Method in class org.apache.flink.table.functions.UserDefinedAggregateFunction
Returns the TypeInformation of the UserDefinedAggregateFunction's result.
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
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
 
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
 
getRowtimeAttributeDescriptors() - Method in interface org.apache.flink.table.sources.DefinedRowtimeAttributes
Returns a list of RowtimeAttributeDescriptor for all rowtime attributes of the table.
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.
getSchema() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
Get the schema of the table.
getShort(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a short value under the given existing key.
getSourceType() - Method in class org.apache.flink.table.types.logical.DistinctType
 
getString(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a string value under the given existing key.
getSubCatalog(String) - Method in interface org.apache.flink.table.catalog.ExternalCatalog
Deprecated.
Gets a sub catalog from this catalog.
getSuperType() - Method in class org.apache.flink.table.types.logical.StructuredType
 
getTable(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
Get a CatalogTable or CatalogView identified by tablePath.
getTable(String) - Method in interface org.apache.flink.table.catalog.ExternalCatalog
Deprecated.
Get a table from this catalog.
getTableAggregateFunction() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
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
Get an optional TableFactory instance that's responsible for generating table-related instances stored in this catalog, instances such as source/sink and function definitions.
getTableFunction() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
getTableSchema(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns a table schema under the given existing key.
getTableSchema() - Method in interface org.apache.flink.table.sinks.TableSink
Returns the schema of the consumed table.
getTableSchema() - Method in interface org.apache.flink.table.sources.TableSource
Returns the schema of the produced table.
getTableStatistics(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
Get the statistics of a table.
getTableStats() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
Deprecated.
This method exists for backwards-compatibility only.
getTimestampExtractor() - Method in class org.apache.flink.table.sources.RowtimeAttributeDescriptor
Returns the [[TimestampExtractor]] for the attribute.
getTotalFields() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
getTotalFields() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
getTotalFields() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
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(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
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
 
getTypeClass() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
getTypeClass() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
getTypeClass() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
getTypeIdentifier() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
getTypeInference() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
Currently, the type inference is just exposed here.
getTypeInformation() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
 
getTypeInformation() - Method in class org.apache.flink.table.types.logical.TypeInformationAnyType
 
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.AnyType
 
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.
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
 
getValueType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
getValueType() - Method in class org.apache.flink.table.types.logical.MapType
 
getVariableIndexedProperties(String, List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns the property keys of variable indexed properties.
getWatermarkStrategy() - Method in class org.apache.flink.table.sources.RowtimeAttributeDescriptor
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
 
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.TableSchema
 
hashCode() - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
 
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.dataview.ListViewSerializer
 
hashCode() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
hashCode() - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
hashCode() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
hashCode() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
hashCode() - Method in class org.apache.flink.table.descriptors.DescriptorProperties
 
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.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.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.sources.RowtimeAttributeDescriptor
 
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.KeyValueDataType
 
hashCode() - Method in class org.apache.flink.table.types.logical.AnyType
 
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.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.TypeInformationAnyType
 
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.InternalTypeInfo
 
hashCode() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
hasLength(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
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
Returns if a given prefix exists in the properties.
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.
hasYearPrecision(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
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
 
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
 
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.
inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
 
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
 
inputTypeValidator(InputTypeValidator) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
InputTypeValidator - Interface in org.apache.flink.table.types.inference
Validator for checking the input data types of a function call.
inputTypeValidator(InputTypeValidator) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
Sets the validator for checking the input data types of a function call.
InputTypeValidators - Class in org.apache.flink.table.types.inference
Validators for checking the input data types of 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.
INSTANCE - Static variable in class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
 
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.
InternalTypeInfo<T> - Class in org.apache.flink.table.typeutils
Type information for internal types of the Table API that are for translation purposes only and should not be contained in final plan.
InternalTypeInfo(Class<T>) - Constructor for class org.apache.flink.table.typeutils.InternalTypeInfo
 
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.config.CatalogConfig
Flag to distinguish if a meta-object is 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
 
isArgumentLiteral(int) - Method in interface org.apache.flink.table.types.inference.CallContextBase
Returns whether the argument at the given position is a value literal.
isArgumentNull(int) - Method in interface org.apache.flink.table.types.inference.CallContextBase
Returns true if the argument at the given position is a literal and null, false otherwise.
isAsyncEnabled() - Method in interface org.apache.flink.table.sources.LookupableTableSource
Returns true if async lookup is enabled.
isBasicType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
isBasicType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
isBasicType() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
isBasicType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
isBatchTable() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
Deprecated.
Returns whether this external table is intended for batch environments.
isDeterministic() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
 
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.ScalarFunctionDefinition
 
isDeterministic() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
isDeterministic() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
 
isEventTime() - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
isFilterPushedDown() - Method in interface org.apache.flink.table.sources.FilterableTableSource
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.
isImmutableType() - Method in class org.apache.flink.table.dataview.ListViewSerializer
 
isImmutableType() - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
isImmutableType() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
isImmutableType() - Method in class org.apache.flink.table.dataview.NullSerializer
 
isInstantiable() - Method in class org.apache.flink.table.types.logical.StructuredType
 
isKeyType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
isKeyType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
isKeyType() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
isKeyType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
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.
isNullAware() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
isNullSerializer() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
isNullSerializer() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
isPartitioned() - Method in interface org.apache.flink.table.catalog.CatalogTable
Check if the table is partitioned or not.
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
 
isStreamTable() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
Deprecated.
Returns whether this external table is intended for stream environments.
isTableSink() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
Deprecated.
Returns whether this external table is declared as table sink.
isTableSource() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
Deprecated.
Returns whether this external table is declared as table source.
isTimeAttribute(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
isTupleType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
isTupleType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
isTupleType() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
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.
isValue(String, String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns if a value under key is exactly equal to the given value.
iterator() - Method in class org.apache.flink.table.api.dataview.MapView
Returns an iterator over all entries of the map view.

K

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
 
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

lastAccessTime(long) - Method in class org.apache.flink.table.descriptors.Metadata
Sets a last access time.
LegacyTypeInfoDataTypeConverter - Class in org.apache.flink.table.types.utils
Converter between TypeInformation and DataType that reflects the behavior before Flink 1.9.
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
 
list - Variable in class org.apache.flink.table.api.dataview.ListView
 
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.
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.
listSubCatalogs() - Method in interface org.apache.flink.table.catalog.ExternalCatalog
Deprecated.
Gets the names of all sub catalogs registered in this catalog.
listTables(String) - Method in interface org.apache.flink.table.catalog.Catalog
Get names of all tables and views under this database.
listTables() - Method in interface org.apache.flink.table.catalog.ExternalCatalog
Deprecated.
Gets the names of all tables registered in this catalog.
ListView<T> - Class in org.apache.flink.table.api.dataview
A ListView provides List functionality for accumulators used by user-defined aggregate functions AggregateFunction.
ListView(TypeInformation<?>, List<T>) - Constructor for class org.apache.flink.table.api.dataview.ListView
 
ListView(TypeInformation<?>) - Constructor for class org.apache.flink.table.api.dataview.ListView
Creates a list view for elements of the specified type.
ListView() - Constructor for class org.apache.flink.table.api.dataview.ListView
Creates a list view.
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
A serializer for [[ListView]].
ListViewSerializer(TypeSerializer<List<T>>) - Constructor for class org.apache.flink.table.dataview.ListViewSerializer
 
ListViewSerializerSnapshot<T> - Class in org.apache.flink.table.dataview
A TypeSerializerSnapshot for the ListViewSerializer.
ListViewSerializerSnapshot() - Constructor for class org.apache.flink.table.dataview.ListViewSerializerSnapshot
Constructor for read instantiation.
ListViewSerializerSnapshot(ListViewSerializer<T>) - Constructor for class org.apache.flink.table.dataview.ListViewSerializerSnapshot
Constructor to create the snapshot for writing.
ListViewTypeInfo<T> - Class in org.apache.flink.table.dataview
Type information for ListView.
ListViewTypeInfo(TypeInformation<T>, boolean) - Constructor for class org.apache.flink.table.dataview.ListViewTypeInfo
 
ListViewTypeInfo(TypeInformation<T>) - Constructor for class org.apache.flink.table.dataview.ListViewTypeInfo
 
ListViewTypeInfoFactory<T> - Class in org.apache.flink.table.dataview
TypeInformation factory for ListView.
ListViewTypeInfoFactory() - Constructor for class org.apache.flink.table.dataview.ListViewTypeInfoFactory
 
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
 
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
 
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
 
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.
LogicalTypeGeneralization - Class in org.apache.flink.table.types.logical.utils
Utilities for finding a common, more general LogicalType for a given set of types.
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
A TableSource which supports for lookup accessing via key column(s).
LOWER - 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 - Variable in class org.apache.flink.table.api.dataview.MapView
 
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
 
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 MapView provides Map functionality for accumulators used by user-defined aggregate functions [[AggregateFunction]].
MapView(TypeInformation<?>, TypeInformation<?>, Map<K, V>) - Constructor for class org.apache.flink.table.api.dataview.MapView
 
MapView(TypeInformation<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.api.dataview.MapView
Creates a MapView with the specified key and value types.
MapView() - Constructor for class org.apache.flink.table.api.dataview.MapView
Creates a MapView.
MapViewSerializer<K,V> - Class in org.apache.flink.table.dataview
A serializer for MapView.
MapViewSerializer(TypeSerializer<Map<K, V>>) - Constructor for class org.apache.flink.table.dataview.MapViewSerializer
 
MapViewSerializerSnapshot<K,V> - Class in org.apache.flink.table.dataview
A TypeSerializerSnapshot for the MapViewSerializer.
MapViewSerializerSnapshot() - Constructor for class org.apache.flink.table.dataview.MapViewSerializerSnapshot
Constructor for read instantiation.
MapViewSerializerSnapshot(MapViewSerializer<K, V>) - Constructor for class org.apache.flink.table.dataview.MapViewSerializerSnapshot
Constructor to create the snapshot for writing.
MapViewTypeInfo<K,V> - Class in org.apache.flink.table.dataview
TypeInformation for MapView.
MapViewTypeInfo(TypeInformation<K>, TypeInformation<V>, boolean, boolean) - Constructor for class org.apache.flink.table.dataview.MapViewTypeInfo
 
MapViewTypeInfo(TypeInformation<K>, TypeInformation<V>) - Constructor for class org.apache.flink.table.dataview.MapViewTypeInfo
 
MapViewTypeInfoFactory<K,V> - Class in org.apache.flink.table.dataview
TypeInformation factory for MapView.
MapViewTypeInfoFactory() - Constructor for class org.apache.flink.table.dataview.MapViewTypeInfoFactory
 
MAX - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
MAX_DAY_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
MAX_FRACTIONAL_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
 
MAX_LENGTH - Static variable in class org.apache.flink.table.descriptors.StatisticsValidator
 
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
 
MAX_VALUE - Static variable in class org.apache.flink.table.descriptors.StatisticsValidator
 
MD5 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
md5(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
Metadata - Class in org.apache.flink.table.descriptors
Metadata descriptor for adding additional, useful information.
Metadata() - Constructor for class org.apache.flink.table.descriptors.Metadata
 
METADATA_COMMENT - Static variable in class org.apache.flink.table.descriptors.MetadataValidator
 
METADATA_CREATION_TIME - Static variable in class org.apache.flink.table.descriptors.MetadataValidator
 
METADATA_LAST_ACCESS_TIME - Static variable in class org.apache.flink.table.descriptors.MetadataValidator
 
METADATA_PROPERTY_VERSION - Static variable in class org.apache.flink.table.descriptors.MetadataValidator
 
MetadataValidator - Class in org.apache.flink.table.descriptors
Validator for Metadata.
MetadataValidator() - Constructor for class org.apache.flink.table.descriptors.MetadataValidator
 
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
 
MIN_VALUE - Static variable in class org.apache.flink.table.descriptors.StatisticsValidator
 
MINUS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
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
 
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(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 - Static variable in class org.apache.flink.table.descriptors.StatisticsValidator
 
name() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
name(String) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 
namedArguments(List<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 static input explicitly.
NestedFieldsProjectableTableSource<T> - Interface in org.apache.flink.table.sources
Adds support for projection push-down to a TableSource with nested fields.
NoMatchingTableFactoryException - Exception in org.apache.flink.table.api
Exception for not finding a TableFactory for the given properties.
NoMatchingTableFactoryException(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
 
normalizeColumnStats(ColumnStats) - Static method in class org.apache.flink.table.descriptors.StatisticsValidator
 
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
 
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.DataType
Adds a hint that null values are not expected in the data for this type.
notNull() - Method in class org.apache.flink.table.types.FieldsDataType
 
notNull() - Method in class org.apache.flink.table.types.KeyValueDataType
 
noValidation() - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
Returns an empty validation logic.
NULL() - Static method in class org.apache.flink.table.api.DataTypes
Data type for representing untyped NULL values.
NULL_COUNT - Static variable in class org.apache.flink.table.descriptors.StatisticsValidator
 
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.DataType
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.FieldsDataType
 
nullable() - Method in class org.apache.flink.table.types.KeyValueDataType
 
NullAwareMapSerializer<K,V> - Class in org.apache.flink.table.dataview
The NullAwareMapSerializer is similar to MapSerializer, the only difference is that the NullAwareMapSerializer can handle null keys.
NullAwareMapSerializer(TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.table.dataview.NullAwareMapSerializer
 
NullSerializer - Class in org.apache.flink.table.dataview
A serializer for null.
NullSerializer() - Constructor for class org.apache.flink.table.dataview.NullSerializer
 
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
 

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
 
objectToString(Object) - Static method in class org.apache.flink.table.utils.EncodingUtils
 
of(String, String, String) - Static method in class org.apache.flink.table.catalog.ObjectIdentifier
 
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(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(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
 
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.
open() - Method in interface org.apache.flink.table.catalog.Catalog
Open the catalog.
open(FunctionContext) - Method in class org.apache.flink.table.functions.UserDefinedFunction
Setup method for user-defined function.
OR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
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.api - package org.apache.flink.table.api
 
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.config - package org.apache.flink.table.catalog.config
 
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.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.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.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.validators - package org.apache.flink.table.types.inference.validators
 
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
 
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
A TableSink that supports INSERT OVERWRITE should implement this trait.

P

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.
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.
PartitionableTableSink - Interface in org.apache.flink.table.sinks
An interface for partitionable TableSink.
PartitionableTableSource - Interface in org.apache.flink.table.sources
An interface for partitionable TableSource.
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
 
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
 
PASSING - Static variable in class org.apache.flink.table.types.inference.InputTypeValidators
Validator that does not perform any validation and always passes.
PassingTypeValidator - Class in org.apache.flink.table.types.inference.validators
Validator that does not perform any validation and always passes.
PassingTypeValidator() - Constructor for class org.apache.flink.table.types.inference.validators.PassingTypeValidator
 
path(String) - Method in class org.apache.flink.table.descriptors.FileSystem
Sets the path to a file or directory in a file system.
PI - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
PLUS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
POSITION - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
POWER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
PRECISION - Static variable in class org.apache.flink.table.types.logical.BigIntType
 
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
 
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
 
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.
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
Adds support for projection push-down to a TableSource.
projectFields(int[]) - Method in interface org.apache.flink.table.sources.ProjectableTableSource
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
Creates a copy of the TableSource that projects its output to the given field indexes.
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
Adds a boolean under the given key.
putCharacter(String, char) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Adds a character under the given key.
putClass(String, Class<?>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Adds a class under the given key.
putIndexedFixedProperties(String, List<String>, List<List<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
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
Adds an indexed mapping of properties under a common key.
putInt(String, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Adds an integer under the given key.
putLong(String, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Adds a long under the given key.
putMemorySize(String, MemorySize) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Adds a Flink MemorySize under the given key.
putProperties(Map<String, String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Adds a set of properties.
putProperties(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Adds a set of descriptor properties.
putPropertiesWithPrefix(String, Map<String, String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
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
Adds a string under the given key.
putTableSchema(String, TableSchema) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Adds a table schema under the given key.

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
 
readColumnStats(DescriptorProperties, String) - Static method in class org.apache.flink.table.descriptors.StatisticsValidator
 
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.
removeTimeAttributes(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
 
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 - 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.TableFactory
Specifies the context that this factory has been implemented for.
requiredContext() - Method in class org.apache.flink.table.factories.TableFormatFactoryBase
 
requiredFormatContext() - Method in class org.apache.flink.table.factories.TableFormatFactoryBase
Format specific context.
requiresOver() - Method in class org.apache.flink.table.functions.AggregateFunction
Deprecated.
resolve(ExecutionConfig) - Method in class org.apache.flink.table.types.logical.TypeInformationAnyType
 
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
 
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.
ROUND - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ROW(DataTypes.Field...) - 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
 
rowCount(long) - Method in class org.apache.flink.table.descriptors.Statistics
Sets statistics for the overall row count.
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
Describes a rowtime attribute of a TableSource.
RowtimeAttributeDescriptor(String, TimestampExtractor, WatermarkStrategy) - Constructor for class org.apache.flink.table.sources.RowtimeAttributeDescriptor
 
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
 
runTypeInference(TypeInference, CallContext) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
 

S

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
The function definition of an user-defined scalar function.
ScalarFunctionDefinition(String, ScalarFunction) - Constructor for class org.apache.flink.table.functions.ScalarFunctionDefinition
 
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_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
 
SchematicDescriptor<D extends SchematicDescriptor<D>> - Interface in org.apache.flink.table.descriptors
Deprecated.
This class can be dropped once we remove external catalog support.
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.
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
 
serialize(MapView<K, V>, DataOutputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
serialize(Map<K, V>, DataOutputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
serialize(Object, DataOutputView) - Method in class org.apache.flink.table.dataview.NullSerializer
 
setCollector(Collector<T>) - Method in class org.apache.flink.table.functions.TableFunction
Internal use.
setComparision(StructuredType.StructuredComparision) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
setDescription(String) - Method in class org.apache.flink.table.types.logical.DistinctType.Builder
 
setDescription(String) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
setFinal(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
setImplementationClass(Class<?>) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
setInstantiable(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
setNullable(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
setNullSerializer(boolean) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
 
setNullSerializer(boolean) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
setOverwrite(boolean) - Method in interface org.apache.flink.table.sinks.OverwritableTableSink
Configures whether the insert should overwrite existing data or not.
setStaticPartition(Map<String, String>) - Method in interface org.apache.flink.table.sinks.PartitionableTableSink
Sets the static partition into the TableSink.
setSuperType(StructuredType) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
 
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
 
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
 
snapshotConfiguration() - Method in class org.apache.flink.table.dataview.MapViewSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.table.dataview.NullSerializer
 
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.
SQRT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
Statistics - Class in org.apache.flink.table.descriptors
Statistics descriptor for describing table stats.
Statistics() - Constructor for class org.apache.flink.table.descriptors.Statistics
 
STATISTICS_COLUMNS - Static variable in class org.apache.flink.table.descriptors.StatisticsValidator
 
STATISTICS_PROPERTY_VERSION - Static variable in class org.apache.flink.table.descriptors.StatisticsValidator
 
STATISTICS_ROW_COUNT - Static variable in class org.apache.flink.table.descriptors.StatisticsValidator
 
StatisticsValidator - Class in org.apache.flink.table.descriptors
Validator for Statistics.
StatisticsValidator() - Constructor for class org.apache.flink.table.descriptors.StatisticsValidator
 
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.
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.
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
 
supportedFormatProperties() - Method in class org.apache.flink.table.factories.TableFormatFactoryBase
Format specific supported properties.
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
 
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.
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.AnyType
 
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.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.TypeInformationAnyType
 
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
 
supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.AnyType
 
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.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.TypeInformationAnyType
 
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
 
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
 
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_SCHEMA_NAME - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
 
TABLE_SCHEMA_TYPE - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
 
TableAggregateFunction<T,ACC> - Class in org.apache.flink.table.functions
Base class for user-defined table aggregates.
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
The function definition of an user-defined table aggregate function.
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
 
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 (UDTF).
TableFunction() - Constructor for class org.apache.flink.table.functions.TableFunction
 
TableFunctionDefinition - Class in org.apache.flink.table.functions
The function definition of an user-defined table function.
TableFunctionDefinition(String, TableFunction<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.functions.TableFunctionDefinition
 
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
A table schema that represents a table's structure with field names and data types.
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
Builder for creating a TableSchema.
TableSink<T> - Interface in org.apache.flink.table.sinks
A TableSink specifies how to emit a table to an external system or location.
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.
TableSource<T> - Interface in org.apache.flink.table.sources
Defines an external table with the schema that is provided by TableSource.getTableSchema().
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.
TableSourceValidation - Class in org.apache.flink.table.sources
Logic to validate TableSource types.
tableStats(TableStats) - Method in class org.apache.flink.table.descriptors.Statistics
Sets the statistics from a TableStats instance.
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.
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
 
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_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.
TimestampExtractor - Class in org.apache.flink.table.sources.tsextractors
Provides an expression to extract the timestamp for a rowtime attribute.
TimestampExtractor() - Constructor for class org.apache.flink.table.sources.tsextractors.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.
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
 
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_BASE64 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
toCatalogProperties() - Method in class org.apache.flink.table.descriptors.CatalogDescriptor
Converts this descriptor into a set of catalog properties.
toCatalogProperties() - Method in class org.apache.flink.table.descriptors.ExternalCatalogDescriptor
Deprecated.
Converts this descriptor into a set of catalog properties.
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.FileSystem
 
toDataType(TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
 
toDataType(LogicalType) - Static method in class org.apache.flink.table.types.utils.LogicalTypeDataTypeConverter
Returns the data type of a logical type without explicit conversions.
toFormatProperties() - Method in class org.apache.flink.table.descriptors.FormatDescriptor
Converts this descriptor into a set of format properties.
toLegacyTypeInfo(DataType) - Static method in class org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
 
toLogicalType(DataType) - Static method in class org.apache.flink.table.types.utils.LogicalTypeDataTypeConverter
Returns the logical type of a data type.
toProperties() - Method in interface org.apache.flink.table.catalog.CatalogTable
Return a property map for table factory discovery purpose.
toProperties() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
Deprecated.
Converts this descriptor into a set of properties.
toProperties() - Method in class org.apache.flink.table.descriptors.CatalogDescriptor
 
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.ExternalCatalogDescriptor
Deprecated.
 
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.Metadata
Converts this descriptor into a set of properties.
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.Statistics
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
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
Converts a table schema into a (nested) data type describing a DataTypes.ROW(Field...).
toRowType() - Method in class org.apache.flink.table.api.TableSchema
Deprecated.
toString() - Method in class org.apache.flink.table.api.DataTypes.Resolution
 
toString() - Method in class org.apache.flink.table.api.TableSchema
 
toString() - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
 
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.dataview.ListViewTypeInfo
 
toString() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
 
toString() - Method in class org.apache.flink.table.descriptors.DescriptorBase
 
toString() - Method in class org.apache.flink.table.descriptors.DescriptorProperties
 
toString(String) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
 
toString(String, String) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
 
toString(Map<String, String>) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
 
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.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.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.types.DataType
 
toString() - Method in class org.apache.flink.table.types.logical.LogicalType
 
toString() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
toString() - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
Deprecated.
 
toString() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
Deprecated.
 
transform(CallContext, DataType) - Method in interface org.apache.flink.table.types.inference.TypeTransformation
Transforms the given data type to a different data type under the given context.
transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
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
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 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TRUNCATE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TYPE - Static variable in class org.apache.flink.table.descriptors.LiteralValueValidator
 
TypeConversions - Class in org.apache.flink.table.types.utils
Conversion hub for interoperability of Class, TypeInformation, DataType, and LogicalType.
typedArguments(List<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 static input explicitly.
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.
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.
TypeInformationAnyType<T> - Class in org.apache.flink.table.types.logical
Placeholder type of an arbitrary serialized type backed by TypeInformation.
TypeInformationAnyType(boolean, TypeInformation<T>) - Constructor for class org.apache.flink.table.types.logical.TypeInformationAnyType
 
TypeInformationAnyType(TypeInformation<T>) - Constructor for class org.apache.flink.table.types.logical.TypeInformationAnyType
 
TypeInformationAnyType() - Constructor for class org.apache.flink.table.types.logical.TypeInformationAnyType
 
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
 
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.

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
 
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
 
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
 
UnresolvedUserDefinedType - Class in org.apache.flink.table.types.logical
Placeholder type of an unresolved user-defined type that is identified by a partially or fully qualified path ([catalog].[database].[type]).
UnresolvedUserDefinedType(boolean, String, String, String) - Constructor for class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
 
UnresolvedUserDefinedType(String, String, String) - 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
 
UserDefinedAggregateFunction<T,ACC> - Class in org.apache.flink.table.functions
Base class for user-defined aggregates and table aggregates.
UserDefinedAggregateFunction() - Constructor for class org.apache.flink.table.functions.UserDefinedAggregateFunction
 
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
 
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.CatalogDescriptorValidator
 
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
 
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.ExternalCatalogDescriptorValidator
Deprecated.
 
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.MetadataValidator
 
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.StatisticsValidator
 
validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.StreamTableDescriptorValidator
 
validate(CallContext, boolean) - Method in interface org.apache.flink.table.types.inference.InputTypeValidator
Main logic for validating the input.
validate(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.validators.PassingTypeValidator
 
validateArgumentFields(TypeInformation<?>[]) - Method in interface org.apache.flink.table.sources.FieldComputer
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
Validates an array of values.
validateArray(String, Consumer<String>, int, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates an array of values.
validateBigDecimal(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a big decimal property.
validateBigDecimal(String, boolean, BigDecimal, BigDecimal) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a big decimal property.
validateBoolean(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates that a boolean value is present under the given key.
validateByte(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a byte property.
validateByte(String, boolean, byte) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a byte property.
validateByte(String, boolean, byte, byte) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a byte property.
validateColumnStats(DescriptorProperties, String) - Static method in class org.apache.flink.table.descriptors.StatisticsValidator
 
validateDouble(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a double property.
validateDouble(String, boolean, double) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a double property.
validateDouble(String, boolean, double, double) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a double property.
validateDuration(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a Java Duration.
validateDuration(String, boolean, int, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a Java Duration.
validateDuration(String, boolean, int, long, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a Java Duration.
validateEnum(String, boolean, Map<String, Consumer<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
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
Validates an enum property with a set of enum values.
validateExclusion(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates that the given key is not included in these properties.
validateFixedIndexedProperties(String, boolean, Map<String, Consumer<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validation for fixed indexed properties.
validateFloat(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a float property.
validateFloat(String, boolean, float) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a float property.
validateFloat(String, boolean, float, float) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a float property.
validateInt(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates an integer property.
validateInt(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates an integer property.
validateInt(String, boolean, int, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates an integer property.
validateLong(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates an long property.
validateLong(String, boolean, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates an long property.
validateLong(String, boolean, long, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates an long property.
validateMemorySize(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a Flink MemorySize.
validateMemorySize(String, boolean, int, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a Flink MemorySize.
validateMemorySize(String, boolean, int, long, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a Flink MemorySize.
validatePrefixExclusion(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates that the given prefix is not included in these properties.
validateShort(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a short property.
validateShort(String, boolean, short) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a short property.
validateShort(String, boolean, short, short) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a short property.
validateString(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a string property.
validateString(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a string property.
validateString(String, boolean, int, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a string property.
validateTableSchema(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
Validates a table schema property.
validateTableSource(TableSource<?>) - 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
Validates a type property.
validateValue(String, String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
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
 
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.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.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() - 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.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.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
 
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
 
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(AnyType<?>) - 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(AnyType<?>) - 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

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.
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
 
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
Returns a new properties instance with the given keys removed.
withSchema(Schema) - Method in interface org.apache.flink.table.descriptors.SchematicDescriptor
Deprecated.
Specifies the resulting table schema.
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

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 K L M N O P R S T U V W Y Z 
Skip navigation links

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