- ABS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- AbstractCatalog - org.apache.flink.table.catalog中的类
-
Abstract class for catalogs.
- AbstractCatalog(String, String) - 类 的构造器org.apache.flink.table.catalog.AbstractCatalog
-
- accept(ExpressionVisitor<R>) - 类 中的方法org.apache.flink.table.expressions.CallExpression
-
- accept(ExpressionVisitor<R>) - 接口 中的方法org.apache.flink.table.expressions.Expression
-
- accept(ExpressionVisitor<R>) - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
-
- accept(ExpressionVisitor<R>) - 类 中的方法org.apache.flink.table.expressions.TypeLiteralExpression
-
- accept(ExpressionVisitor<R>) - 类 中的方法org.apache.flink.table.expressions.ValueLiteralExpression
-
- accept(DataTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.AtomicDataType
-
- accept(DataTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.CollectionDataType
-
- accept(DataTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.DataType
-
- accept(DataTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.FieldsDataType
-
- accept(DataTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.KeyValueDataType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.ArrayType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.BigIntType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.BinaryType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.BooleanType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.CharType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.DateType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.DayTimeIntervalType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.DecimalType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.DistinctType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.DoubleType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.FloatType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.IntType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.LogicalType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.MapType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.MultisetType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.NullType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.RawType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.SmallIntType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.SymbolType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.TimestampType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.TimeType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.TinyIntType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.TypeInformationRawType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.VarBinaryType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.VarCharType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.YearMonthIntervalType
-
- accept(LogicalTypeVisitor<R>) - 类 中的方法org.apache.flink.table.types.logical.ZonedTimestampType
-
- accumulatorTypeStrategy(TypeStrategy) - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
- accumulatorTypeStrategy(TypeStrategy) - 类 中的方法org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets the strategy for inferring the intermediate accumulator data type of a function call.
- ACOS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- AdaptedCallContext - org.apache.flink.table.types.inference.utils中的类
-
Helper context that deals with adapted arguments.
- AdaptedCallContext(CallContext, DataType) - 类 的构造器org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- add(T) - 类 中的方法org.apache.flink.table.api.dataview.ListView
-
Adds the given value to the list.
- addAll(List<T>) - 类 中的方法org.apache.flink.table.api.dataview.ListView
-
Adds all of the elements of the specified list to this list view.
- additionalProperties() - 类 中的方法org.apache.flink.table.descriptors.TableDescriptor
-
- addPropertiesWithPrefix(String, DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Internal method for properties conversion.
- addPropertiesWithPrefix(String, DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.HierarchyDescriptor
-
Internal method for properties conversion.
- addPropertiesWithPrefix(String, DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
- AggregateFunction<T,ACC> - org.apache.flink.table.functions中的类
-
Base class for user-defined aggregates.
- AggregateFunction() - 类 的构造器org.apache.flink.table.functions.AggregateFunction
-
- AggregateFunctionDefinition - org.apache.flink.table.functions中的类
-
The function definition of an user-defined aggregate function.
- AggregateFunctionDefinition(String, AggregateFunction<?, ?>, TypeInformation<?>, TypeInformation<?>) - 类 的构造器org.apache.flink.table.functions.AggregateFunctionDefinition
-
- allowRawGlobally - 类 中的变量org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
- allowRawPattern - 类 中的变量org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
- alterDatabase(String, CatalogDatabase, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Modify an existing database.
- alterFunction(ObjectPath, CatalogFunction, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Modify an existing function.
- alterPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Alter a partition.
- alterPartitionColumnStatistics(ObjectPath, CatalogPartitionSpec, CatalogColumnStatistics, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Update the column statistics of a table partition.
- alterPartitionStatistics(ObjectPath, CatalogPartitionSpec, CatalogTableStatistics, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Update the statistics of a table partition.
- alterTable(ObjectPath, CatalogBaseTable, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Modify an existing table or view.
- alterTableColumnStatistics(ObjectPath, CatalogColumnStatistics, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Update the column statistics of a table.
- alterTableStatistics(ObjectPath, CatalogTableStatistics, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Update the statistics of a table.
- AmbiguousTableFactoryException - 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) - 异常错误 的构造器org.apache.flink.table.api.AmbiguousTableFactoryException
-
- AmbiguousTableFactoryException(List<? extends TableFactory>, Class<? extends TableFactory>, List<TableFactory>, Map<String, String>) - 异常错误 的构造器org.apache.flink.table.api.AmbiguousTableFactoryException
-
- AND - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- and(ArgumentTypeStrategy...) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
-
- AndArgumentTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
-
Strategy for inferring and validating an argument using a conjunction of multiple
ArgumentTypeStrategy
s
into one like
f(NUMERIC && LITERAL)
Some
ArgumentTypeStrategy
s cannot contribute an inferred type that is different from
the input type (e.g.
- AndArgumentTypeStrategy(List<? extends ArgumentTypeStrategy>) - 类 的构造器org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
-
- ANY(Class<T>, TypeSerializer<T>) - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
- ANY(TypeInformation<T>) - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
- any() - 类 中的静态方法org.apache.flink.table.types.inference.ConstantArgumentCount
-
- ANY - 类 中的静态变量org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for an argument that can be of any type.
- AnyArgumentTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
-
Strategy for an argument that can be of any type.
- AnyArgumentTypeStrategy() - 类 的构造器org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
-
- applyLimit(long) - 接口 中的方法org.apache.flink.table.sources.LimitableTableSource
-
Check and push down the limit to the table source.
- applyPartitionPruning(List<Map<String, String>>) - 接口 中的方法org.apache.flink.table.sources.PartitionableTableSource
-
Applies the remaining partitions to the table source.
- applyPredicate(List<Expression>) - 接口 中的方法org.apache.flink.table.sources.FilterableTableSource
-
Check and pick all predicates this table source can support.
- areTypesCompatible(LogicalType, LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns true if the two given types are compatible.
- ArgumentCount - org.apache.flink.table.types.inference中的接口
-
Defines the count of accepted arguments (including open intervals) that a function can take.
- ArgumentTypeStrategy - org.apache.flink.table.types.inference中的接口
-
Strategy for inferring and validating a single input argument type of a function call.
- ARRAY(DataType) - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Data type of an array of elements with same subtype.
- ARRAY - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- ARRAY_ELEMENT - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- ArrayType - org.apache.flink.table.types.logical中的类
-
Logical type of an array of elements with same subtype.
- ArrayType(boolean, LogicalType) - 类 的构造器org.apache.flink.table.types.logical.ArrayType
-
- ArrayType(LogicalType) - 类 的构造器org.apache.flink.table.types.logical.ArrayType
-
- AS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- ASIN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- asMap() - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns the properties as a map copy.
- asPrefixedMap(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns the properties as a map copy with a prefix key.
- asSerializableString() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
-
Returns a string that fully serializes this instance.
- asSerializableString() - 接口 中的方法org.apache.flink.table.expressions.ResolvedExpression
-
Returns a string that fully serializes this instance.
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.ArrayType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.BigIntType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.BinaryType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.BooleanType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.CharType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.DateType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.DayTimeIntervalType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.DecimalType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.DoubleType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.FloatType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.IntType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.LogicalType
-
Returns a string that fully serializes this instance.
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.MapType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.MultisetType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.NullType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.RawType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.RowType.RowField
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.SmallIntType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.SymbolType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.TimestampType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.TimeType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.TinyIntType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.TypeInformationRawType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.UserDefinedType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.VarBinaryType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.VarCharType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.YearMonthIntervalType
-
- asSerializableString() - 类 中的方法org.apache.flink.table.types.logical.ZonedTimestampType
-
- asSummaryString() - 接口 中的方法org.apache.flink.table.api.constraints.Constraint
-
Prints the constraint in a readable way.
- asSummaryString() - 类 中的方法org.apache.flink.table.api.constraints.UniqueConstraint
-
Returns constraint's summary.
- asSummaryString() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
-
Returns a string that summarizes this instance for printing to a console or log.
- asSummaryString() - 类 中的方法org.apache.flink.table.catalog.UnresolvedIdentifier
-
Returns a string that summarizes this instance for printing to a console or log.
- asSummaryString() - 类 中的方法org.apache.flink.table.expressions.CallExpression
-
- asSummaryString() - 接口 中的方法org.apache.flink.table.expressions.Expression
-
Returns a string that summarizes this expression for printing to a console.
- asSummaryString() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
-
- asSummaryString() - 类 中的方法org.apache.flink.table.expressions.TypeLiteralExpression
-
- asSummaryString() - 类 中的方法org.apache.flink.table.expressions.ValueLiteralExpression
-
- asSummaryString() - 类 中的方法org.apache.flink.table.functions.FunctionIdentifier
-
Returns a string that summarizes this instance for printing to a console or log.
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.ArrayType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.BinaryType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.CharType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.LogicalType
-
Returns a string that summarizes this type for printing to a console.
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.MapType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.MultisetType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.RawType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.RowType.RowField
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.SymbolType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.TimestampType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.TypeInformationRawType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.VarBinaryType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.VarCharType
-
- asSummaryString() - 类 中的方法org.apache.flink.table.types.logical.ZonedTimestampType
-
- AsyncTableFunction<T> - org.apache.flink.table.functions中的类
-
Base class for a user-defined asynchronously table function (UDTF).
- AsyncTableFunction() - 类 的构造器org.apache.flink.table.functions.AsyncTableFunction
-
- AT - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- ATAN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- ATAN2 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- AtomicDataType - org.apache.flink.table.types中的类
-
A data type that does not contain further data types (e.g.
- AtomicDataType(LogicalType, Class<?>) - 类 的构造器org.apache.flink.table.types.AtomicDataType
-
- AtomicDataType(LogicalType) - 类 的构造器org.apache.flink.table.types.AtomicDataType
-
- attributes(List<StructuredType.StructuredAttribute>) - 类 中的方法org.apache.flink.table.types.logical.StructuredType.Builder
-
- AVG - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- CallContext - org.apache.flink.table.types.inference中的接口
-
- CallExpression - org.apache.flink.table.expressions中的类
-
Resolved and validated call expression for calling a function.
- CallExpression(FunctionIdentifier, FunctionDefinition, List<ResolvedExpression>, DataType) - 类 的构造器org.apache.flink.table.expressions.CallExpression
-
- CallExpression(FunctionDefinition, List<ResolvedExpression>, DataType) - 类 的构造器org.apache.flink.table.expressions.CallExpression
-
- canEqual(Object) - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- canEqual(Object) - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- canEqual(Object) - 类 中的方法org.apache.flink.table.typeutils.InternalTypeInfo
-
- canEqual(Object) - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- CARDINALITY - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- CAST - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- Catalog - 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_DEFAULT_DATABASE - 类 中的静态变量org.apache.flink.table.descriptors.CatalogDescriptorValidator
-
Key for describing the default database of the catalog.
- CATALOG_PROPERTY_VERSION - 类 中的静态变量org.apache.flink.table.descriptors.CatalogDescriptorValidator
-
Key for describing the property version.
- CATALOG_TYPE - 类 中的静态变量org.apache.flink.table.descriptors.CatalogDescriptorValidator
-
Key for describing the type of the catalog.
- CatalogBaseTable - org.apache.flink.table.catalog中的接口
-
CatalogBaseTable is the common parent of table and view.
- CatalogColumnStatistics - org.apache.flink.table.catalog.stats中的类
-
Column statistics of a table or partition.
- CatalogColumnStatistics(Map<String, CatalogColumnStatisticsDataBase>) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatistics
-
- CatalogColumnStatistics(Map<String, CatalogColumnStatisticsDataBase>, Map<String, String>) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatistics
-
- CatalogColumnStatisticsDataBase - org.apache.flink.table.catalog.stats中的类
-
Column statistics value base class.
- CatalogColumnStatisticsDataBase(Long) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
-
- CatalogColumnStatisticsDataBase(Long, Map<String, String>) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
-
- CatalogColumnStatisticsDataBinary - org.apache.flink.table.catalog.stats中的类
-
Column statistics value of binary type.
- CatalogColumnStatisticsDataBinary(Long, Double, Long) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
-
- CatalogColumnStatisticsDataBinary(Long, Double, Long, Map<String, String>) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
-
- CatalogColumnStatisticsDataBoolean - org.apache.flink.table.catalog.stats中的类
-
Column statistics value of boolean type.
- CatalogColumnStatisticsDataBoolean(Long, Long, Long) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
-
- CatalogColumnStatisticsDataBoolean(Long, Long, Long, Map<String, String>) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
-
- CatalogColumnStatisticsDataDate - org.apache.flink.table.catalog.stats中的类
-
Column statistics value of date type.
- CatalogColumnStatisticsDataDate(Date, Date, Long, Long) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
-
- CatalogColumnStatisticsDataDate(Date, Date, Long, Long, Map<String, String>) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
-
- CatalogColumnStatisticsDataDouble - org.apache.flink.table.catalog.stats中的类
-
Column statistics value of double type.
- CatalogColumnStatisticsDataDouble(Double, Double, Long, Long) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
-
- CatalogColumnStatisticsDataDouble(Double, Double, Long, Long, Map<String, String>) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
-
- CatalogColumnStatisticsDataLong - org.apache.flink.table.catalog.stats中的类
-
Column statistics value of long type.
- CatalogColumnStatisticsDataLong(Long, Long, Long, Long) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
-
- CatalogColumnStatisticsDataLong(Long, Long, Long, Long, Map<String, String>) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
-
- CatalogColumnStatisticsDataString - org.apache.flink.table.catalog.stats中的类
-
Column statistics value of string type.
- CatalogColumnStatisticsDataString(Long, Double, Long, Long) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
-
- CatalogColumnStatisticsDataString(Long, Double, Long, Long, Map<String, String>) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
-
- CatalogConfig - org.apache.flink.table.catalog.config中的类
-
Config for catalog and catalog meta-objects.
- CatalogConfig() - 类 的构造器org.apache.flink.table.catalog.config.CatalogConfig
-
- CatalogDatabase - org.apache.flink.table.catalog中的接口
-
Interface of a database in a catalog.
- CatalogDescriptor - org.apache.flink.table.descriptors中的类
-
Describes a catalog of tables, views, and functions.
- CatalogDescriptor(String, int) - 类 的构造器org.apache.flink.table.descriptors.CatalogDescriptor
-
- CatalogDescriptor(String, int, String) - 类 的构造器org.apache.flink.table.descriptors.CatalogDescriptor
-
- CatalogDescriptorValidator - org.apache.flink.table.descriptors中的类
-
- CatalogDescriptorValidator() - 类 的构造器org.apache.flink.table.descriptors.CatalogDescriptorValidator
-
- CatalogException - org.apache.flink.table.catalog.exceptions中的异常错误
-
A catalog-related, runtime exception.
- CatalogException(String) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.CatalogException
-
- CatalogException(Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.CatalogException
-
- CatalogException(String, Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.CatalogException
-
- CatalogFactory - org.apache.flink.table.factories中的接口
-
A factory to create configured catalog instances based on string-based properties.
- CatalogFunction - org.apache.flink.table.catalog中的接口
-
Interface for a function in a catalog.
- CatalogNotExistException - org.apache.flink.table.api中的异常错误
-
Exception for an operation on a nonexistent catalog.
- CatalogNotExistException(String) - 异常错误 的构造器org.apache.flink.table.api.CatalogNotExistException
-
- CatalogNotExistException(String, Throwable) - 异常错误 的构造器org.apache.flink.table.api.CatalogNotExistException
-
- CatalogPartition - org.apache.flink.table.catalog中的接口
-
Represents a partition object in catalog.
- CatalogPartitionSpec - org.apache.flink.table.catalog中的类
-
Represents a partition spec object in catalog.
- CatalogPartitionSpec(Map<String, String>) - 类 的构造器org.apache.flink.table.catalog.CatalogPartitionSpec
-
- CatalogTable - org.apache.flink.table.catalog中的接口
-
Represents a table in a catalog.
- CatalogTableStatistics - org.apache.flink.table.catalog.stats中的类
-
Statistics for a non-partitioned table or a partition of a partitioned table.
- CatalogTableStatistics(long, int, long, long) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
- CatalogTableStatistics(long, int, long, long, Map<String, String>) - 类 的构造器org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
- CatalogView - org.apache.flink.table.catalog中的接口
-
Represents a view in a catalog.
- CEIL - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- CHAR(int) - 类 中的静态方法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 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- CharType - org.apache.flink.table.types.logical中的类
-
Logical type of a fixed-length character string.
- CharType(boolean, int) - 类 的构造器org.apache.flink.table.types.logical.CharType
-
- CharType(int) - 类 的构造器org.apache.flink.table.types.logical.CharType
-
- CharType() - 类 的构造器org.apache.flink.table.types.logical.CharType
-
- checkNoGeneratedColumns(TableSchema) - 类 中的静态方法org.apache.flink.table.utils.TableSchemaUtils
-
Throws exception if the given
TableSchema
contains any generated columns.
- checkPhysicalLogicalTypeCompatible(LogicalType, LogicalType, String, String, boolean) - 类 中的静态方法org.apache.flink.table.utils.TypeMappingUtils
-
Checks whether the given physical field type and logical field type are compatible
at the edges of the table ecosystem.
- CLASS - 类 中的静态变量org.apache.flink.table.descriptors.ClassInstanceValidator
-
- ClassDataTypeConverter - 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 - org.apache.flink.table.descriptors中的类
-
Descriptor for a class instance.
- ClassInstance() - 类 的构造器org.apache.flink.table.descriptors.ClassInstance
-
- ClassInstanceValidator - org.apache.flink.table.descriptors中的类
-
- ClassInstanceValidator(String) - 类 的构造器org.apache.flink.table.descriptors.ClassInstanceValidator
-
- ClassInstanceValidator() - 类 的构造器org.apache.flink.table.descriptors.ClassInstanceValidator
-
- clazz - 类 中的变量org.apache.flink.table.typeutils.InternalTypeInfo
-
- clear() - 接口 中的方法org.apache.flink.table.api.dataview.DataView
-
Clears the
DataView
and removes all data.
- clear() - 类 中的方法org.apache.flink.table.api.dataview.ListView
-
Removes all of the elements from this list view.
- clear() - 类 中的方法org.apache.flink.table.api.dataview.MapView
-
Removes all entries of this map.
- close() - 接口 中的方法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() - 类 中的方法org.apache.flink.table.functions.UserDefinedFunction
-
Tear-down method for user-defined function.
- COLLECT - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- collect(T) - 类 中的方法org.apache.flink.table.functions.TableFunction
-
Emits an output row.
- CollectionDataType - org.apache.flink.table.types中的类
-
A data type that contains an element type (e.g.
- CollectionDataType(LogicalType, Class<?>, DataType) - 类 的构造器org.apache.flink.table.types.CollectionDataType
-
- CollectionDataType(LogicalType, DataType) - 类 的构造器org.apache.flink.table.types.CollectionDataType
-
- collector - 类 中的变量org.apache.flink.table.functions.TableFunction
-
The code generated collector used to emit rows.
- collectStructuredFields(Class<?>) - 类 中的静态方法org.apache.flink.table.types.extraction.utils.ExtractionUtils
-
- collectStructuredMethods(Class<?>) - 类 中的静态方法org.apache.flink.table.types.extraction.utils.ExtractionUtils
-
- collectTypeHierarchy(Type) - 类 中的静态方法org.apache.flink.table.types.extraction.utils.ExtractionUtils
-
Collects the partially ordered type hierarchy (i.e. all involved super classes and super
interfaces) of the given type.
- ColumnStats - org.apache.flink.table.plan.stats中的类
-
Column statistics.
- ColumnStats(Long, Long, Double, Integer, Number, Number) - 类 的构造器org.apache.flink.table.plan.stats.ColumnStats
-
已过时。
- ColumnStats.Builder - org.apache.flink.table.plan.stats中的类
-
ColumnStats builder.
- comparision(StructuredType.StructuredComparision) - 类 中的方法org.apache.flink.table.types.logical.StructuredType.Builder
-
- computePhysicalIndices(List<TableColumn>, DataType, Function<String, String>) - 类 中的静态方法org.apache.flink.table.utils.TypeMappingUtils
-
Computes indices of physical fields corresponding to the selected logical fields of a
TableSchema
.
- computePhysicalIndicesOrTimeAttributeMarkers(TableSource<?>, List<TableColumn>, boolean, Function<String, String>) - 类 中的静态方法org.apache.flink.table.utils.TypeMappingUtils
-
Computes indices of physical fields corresponding to the selected logical fields of a
TableSchema
.
- CONCAT - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- CONCAT_WS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- configure(String[], TypeInformation<?>[]) - 接口 中的方法org.apache.flink.table.sinks.TableSink
-
- configure(String[], TypeInformation<?>[]) - 类 中的方法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) - 接口 中的方法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. the sink will receive all elements of one
partition and then all elements of another partition, elements of different partitions
will not be mixed.
- CONNECTOR - 类 中的静态变量org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
Prefix for connector-related properties.
- CONNECTOR_PATH - 类 中的静态变量org.apache.flink.table.descriptors.FileSystemValidator
-
- CONNECTOR_PROPERTY_VERSION - 类 中的静态变量org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
Key for describing the property version.
- CONNECTOR_TYPE - 类 中的静态变量org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
Key for describing the type of the connector.
- CONNECTOR_TYPE_VALUE - 类 中的静态变量org.apache.flink.table.descriptors.FileSystemValidator
-
- CONNECTOR_VERSION - 类 中的静态变量org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
Key for describing the version of the connector.
- ConnectorDescriptor - org.apache.flink.table.descriptors中的类
-
Describes a connector to an other system.
- ConnectorDescriptor(String, int, boolean) - 类 的构造器org.apache.flink.table.descriptors.ConnectorDescriptor
-
- ConnectorDescriptorValidator - org.apache.flink.table.descriptors中的类
-
- ConnectorDescriptorValidator() - 类 的构造器org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
- ConstantArgumentCount - org.apache.flink.table.types.inference中的类
-
- Constraint - org.apache.flink.table.api.constraints中的接口
-
Integrity constraints, generally referred to simply as constraints, define the valid
states of SQL-data by constraining the values in the base tables.
- Constraint.ConstraintType - org.apache.flink.table.api.constraints中的枚举
-
Type of the constraint.
- CONSTRUCTOR - 类 中的静态变量org.apache.flink.table.descriptors.ClassInstanceValidator
-
- constructor - 类 中的变量org.apache.flink.table.types.extraction.utils.ExtractionUtils.AssigningConstructor
-
- contains(K) - 类 中的方法org.apache.flink.table.api.dataview.MapView
-
Checks if the map view contains a value for a given key.
- containsGeneratedColumns(TableSchema) - 类 中的静态方法org.apache.flink.table.utils.TableSchemaUtils
-
Returns true if there are any generated columns in the given
TableColumn
.
- containsKey(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns if the given key is contained.
- conversionClass - 类 中的变量org.apache.flink.table.types.DataType
-
- conversionSet(String...) - 类 中的静态方法org.apache.flink.table.types.logical.LogicalType
-
- copy() - 类 中的方法org.apache.flink.table.api.TableSchema
-
Returns a deep copy of the table schema.
- copy() - 接口 中的方法org.apache.flink.table.catalog.CatalogBaseTable
-
Get a deep copy of the CatalogBaseTable instance.
- copy() - 接口 中的方法org.apache.flink.table.catalog.CatalogDatabase
-
Get a deep copy of the CatalogDatabase instance.
- copy() - 接口 中的方法org.apache.flink.table.catalog.CatalogFunction
-
Create a deep copy of the function.
- copy() - 接口 中的方法org.apache.flink.table.catalog.CatalogPartition
-
Get a deep copy of the CatalogPartition instance.
- copy() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatistics
-
Create a deep copy of "this" instance.
- copy() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
-
Create a deep copy of "this" instance.
- copy() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
-
- copy() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
-
- copy() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
-
- copy() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
-
- copy() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
-
- copy() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
-
- copy() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
Create a deep copy of "this" instance.
- copy() - 类 中的方法org.apache.flink.table.catalog.stats.Date
-
- copy(ListView<T>) - 类 中的方法org.apache.flink.table.dataview.ListViewSerializer
-
- copy(ListView<T>, ListView<T>) - 类 中的方法org.apache.flink.table.dataview.ListViewSerializer
-
- copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.table.dataview.ListViewSerializer
-
- copy(MapView<K, V>) - 类 中的方法org.apache.flink.table.dataview.MapViewSerializer
-
- copy(MapView<K, V>, MapView<K, V>) - 类 中的方法org.apache.flink.table.dataview.MapViewSerializer
-
- copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.table.dataview.MapViewSerializer
-
- copy(Map<K, V>) - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializer
-
- copy(Map<K, V>, Map<K, V>) - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializer
-
- copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializer
-
- copy(Object) - 类 中的方法org.apache.flink.table.dataview.NullSerializer
-
- copy(Object, Object) - 类 中的方法org.apache.flink.table.dataview.NullSerializer
-
- copy(DataInputView, DataOutputView) - 类 中的方法org.apache.flink.table.dataview.NullSerializer
-
- copy() - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
-
Create a deep copy of "this" instance.
- copy() - 类 中的方法org.apache.flink.table.plan.stats.TableStats
-
Create a deep copy of "this" instance.
- copy() - 类 中的方法org.apache.flink.table.sinks.TableSinkBase
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.ArrayType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.BigIntType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.BinaryType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.BooleanType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.CharType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.DateType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.DayTimeIntervalType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.DecimalType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.DistinctType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.DoubleType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.FloatType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.IntType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.LogicalType
-
Returns a deep copy of this type with possibly different nullability.
- copy() - 类 中的方法org.apache.flink.table.types.logical.LogicalType
-
Returns a deep copy of this type.
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.MapType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.MultisetType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.NullType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.RawType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- copy() - 类 中的方法org.apache.flink.table.types.logical.RowType.RowField
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.SmallIntType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- copy() - 类 中的方法org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.SymbolType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.TimestampType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.TimeType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.TinyIntType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.TypeInformationRawType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.VarBinaryType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.VarCharType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.YearMonthIntervalType
-
- copy(boolean) - 类 中的方法org.apache.flink.table.types.logical.ZonedTimestampType
-
- copyWithoutDataType() - 类 中的方法org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
Copies this template but removes the explicit data type (if available).
- CoreModule - org.apache.flink.table.module中的类
-
Module of default core metadata in Flink.
- CoreModuleDescriptor - org.apache.flink.table.descriptors中的类
-
- CoreModuleDescriptor() - 类 的构造器org.apache.flink.table.descriptors.CoreModuleDescriptor
-
- CoreModuleDescriptorValidator - org.apache.flink.table.descriptors中的类
-
- CoreModuleDescriptorValidator() - 类 的构造器org.apache.flink.table.descriptors.CoreModuleDescriptorValidator
-
- CoreModuleFactory - org.apache.flink.table.module中的类
-
- CoreModuleFactory() - 类 的构造器org.apache.flink.table.module.CoreModuleFactory
-
- COS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- COSH - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- COT - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- COUNT - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- createAccumulator() - 类 中的方法org.apache.flink.table.functions.UserDefinedAggregateFunction
-
- createCatalog(String, Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.CatalogFactory
-
Creates and configures a
Catalog
using the given properties.
- createComparator(boolean, ExecutionConfig) - 类 中的方法org.apache.flink.table.typeutils.InternalTypeInfo
-
- createComparator(boolean, ExecutionConfig) - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- createDatabase(String, CatalogDatabase, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Create a database.
- createDeserializationSchema(Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.DeserializationSchemaFactory
-
Creates and configures a DeserializationSchema
using the given properties.
- createFunction(ObjectPath, CatalogFunction, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Create a function.
- createFunction(FunctionDescriptor) - 类 中的静态方法org.apache.flink.table.functions.FunctionService
-
Creates a user-defined function with the given properties and the current thread's
context class loader.
- createFunction(FunctionDescriptor, ClassLoader) - 类 中的静态方法org.apache.flink.table.functions.FunctionService
-
Creates a user-defined function with the given properties.
- createFunction(FunctionDescriptor, ClassLoader, boolean) - 类 中的静态方法org.apache.flink.table.functions.FunctionService
-
Creates a user-defined function with the given properties.
- createFunctionDefinition(String, CatalogFunction) - 接口 中的方法org.apache.flink.table.factories.FunctionDefinitionFactory
-
- createInstance() - 类 中的方法org.apache.flink.table.dataview.ListViewSerializer
-
- createInstance() - 类 中的方法org.apache.flink.table.dataview.MapViewSerializer
-
- createInstance() - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializer
-
- createInstance() - 类 中的方法org.apache.flink.table.dataview.NullSerializer
-
- createModule(Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.ModuleFactory
-
Creates and configures a
Module
using the given properties.
- createModule(Map<String, String>) - 类 中的方法org.apache.flink.table.module.CoreModuleFactory
-
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.table.dataview.MapViewSerializerSnapshot
-
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
-
- createPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Create a partition.
- createRawType(DataTypeLookup, Class<? extends TypeSerializer<?>>, Class<?>) - 类 中的静态方法org.apache.flink.table.types.extraction.utils.ExtractionUtils
-
Creates a raw data type.
- createSerializationSchema(Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.SerializationSchemaFactory
-
Creates and configures a [[SerializationSchema]] using the given properties.
- createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.table.typeutils.InternalTypeInfo
-
- createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
已过时。
- createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- createTable(ObjectPath, CatalogBaseTable, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Create a new table or view.
- createTableSink(Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.TableSinkFactory
-
Creates and configures a
TableSink
using the given properties.
- createTableSink(ObjectPath, CatalogTable) - 接口 中的方法org.apache.flink.table.factories.TableSinkFactory
-
- createTableSource(Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.TableSourceFactory
-
Creates and configures a
TableSource
using the given properties.
- createTableSource(ObjectPath, CatalogTable) - 接口 中的方法org.apache.flink.table.factories.TableSourceFactory
-
- createTypeInfo(Type, Map<String, TypeInformation<?>>) - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfoFactory
-
- createTypeInfo(Type, Map<String, TypeInformation<?>>) - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfoFactory
-
- CURRENT_DATE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- CURRENT_RANGE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- CURRENT_ROW - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- CURRENT_TIME - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- CURRENT_TIMESTAMP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- FIELD(String, DataType) - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Field definition with field name and data type.
- FIELD(String, DataType, String) - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Field definition with field name, data type, and a description.
- field(String, DataType) - 类 中的方法org.apache.flink.table.api.TableSchema.Builder
-
Add a field with name and data type.
- field(String, DataType, String) - 类 中的方法org.apache.flink.table.api.TableSchema.Builder
-
Add a computed field which is generated by the given expression.
- field(String, TypeInformation<?>) - 类 中的方法org.apache.flink.table.api.TableSchema.Builder
-
- field(String, DataType) - 类 中的方法org.apache.flink.table.descriptors.Schema
-
Adds a field with the field name and the data type.
- field(String, TypeInformation<?>) - 类 中的方法org.apache.flink.table.descriptors.Schema
-
- field(String, String) - 类 中的方法org.apache.flink.table.descriptors.Schema
-
Adds a field with the field name and the type string.
- FieldComputer<T> - org.apache.flink.table.sources中的接口
-
- fieldIndex() - 类 中的方法org.apache.flink.table.expressions.ResolvedFieldReference
-
- FieldReferenceExpression - org.apache.flink.table.expressions中的类
-
A reference to a field in an input.
- FieldReferenceExpression(String, DataType, int, int) - 类 的构造器org.apache.flink.table.expressions.FieldReferenceExpression
-
- fields(String[], DataType[]) - 类 中的方法org.apache.flink.table.api.TableSchema.Builder
-
Add an array of fields with names and data types.
- FieldsDataType - org.apache.flink.table.types中的类
-
A data type that contains field data types (e.g.
- FieldsDataType(LogicalType, Class<?>, Map<String, DataType>) - 类 的构造器org.apache.flink.table.types.FieldsDataType
-
- FieldsDataType(LogicalType, Map<String, DataType>) - 类 的构造器org.apache.flink.table.types.FieldsDataType
-
- FileSystem - org.apache.flink.table.descriptors中的类
-
Connector descriptor for a file system.
- FileSystem() - 类 的构造器org.apache.flink.table.descriptors.FileSystem
-
- FileSystemValidator - org.apache.flink.table.descriptors中的类
-
- FileSystemValidator() - 类 的构造器org.apache.flink.table.descriptors.FileSystemValidator
-
- FilterableTableSource<T> - org.apache.flink.table.sources中的接口
-
- find(Class<T>, Descriptor) - 类 中的静态方法org.apache.flink.table.factories.TableFactoryService
-
Finds a table factory of the given class and descriptor.
- find(Class<T>, Descriptor, ClassLoader) - 类 中的静态方法org.apache.flink.table.factories.TableFactoryService
-
Finds a table factory of the given class, descriptor, and classloader.
- find(Class<T>, Map<String, String>) - 类 中的静态方法org.apache.flink.table.factories.TableFactoryService
-
Finds a table factory of the given class and property map.
- find(Class<T>, Map<String, String>, ClassLoader) - 类 中的静态方法org.apache.flink.table.factories.TableFactoryService
-
Finds a table factory of the given class, property map, and classloader.
- findAll(Class<T>, Map<String, String>) - 类 中的静态方法org.apache.flink.table.factories.TableFactoryService
-
Finds all table factories of the given class and property map.
- findCommonType(List<LogicalType>) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeGeneralization
-
Returns the most common type of a set of types.
- FLATTEN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- FLINK_PROPERTY_PREFIX - 类 中的静态变量org.apache.flink.table.catalog.config.CatalogConfig
-
- FLOAT() - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Data type of a 4-byte single precision floating point number.
- FLOAT() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API float or SQL FLOAT/REAL type.
- FloatType - org.apache.flink.table.types.logical中的类
-
Logical type of a 4-byte single precision floating point number.
- FloatType(boolean) - 类 的构造器org.apache.flink.table.types.logical.FloatType
-
- FloatType() - 类 的构造器org.apache.flink.table.types.logical.FloatType
-
- FLOOR - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- forceRawPattern - 类 中的变量org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
- FORMAT - 类 中的静态变量org.apache.flink.table.descriptors.FormatDescriptorValidator
-
Prefix for format-related properties.
- FORMAT_DERIVE_SCHEMA - 类 中的静态变量org.apache.flink.table.descriptors.FormatDescriptorValidator
-
Key for deriving the schema of the format from the table's schema.
- FORMAT_PROPERTY_VERSION - 类 中的静态变量org.apache.flink.table.descriptors.FormatDescriptorValidator
-
Key for describing the property version.
- FORMAT_TYPE - 类 中的静态变量org.apache.flink.table.descriptors.FormatDescriptorValidator
-
Key for describing the type of the format.
- FORMAT_VERSION - 类 中的静态变量org.apache.flink.table.descriptors.FormatDescriptorValidator
-
Key for describing the version of the format.
- FormatDescriptor - org.apache.flink.table.descriptors中的类
-
Describes the format of data.
- FormatDescriptor(String, int) - 类 的构造器org.apache.flink.table.descriptors.FormatDescriptor
-
- FormatDescriptorValidator - org.apache.flink.table.descriptors中的类
-
- FormatDescriptorValidator() - 类 的构造器org.apache.flink.table.descriptors.FormatDescriptorValidator
-
- FROM - 类 中的静态变量org.apache.flink.table.descriptors.FunctionDescriptorValidator
-
- from(String) - 类 中的方法org.apache.flink.table.descriptors.Schema
-
Specifies the origin of the previously defined field.
- from(int) - 类 中的静态方法org.apache.flink.table.types.inference.ConstantArgumentCount
-
- FROM_BASE64 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- FROM_VALUE_CLASS - 类 中的静态变量org.apache.flink.table.descriptors.FunctionDescriptorValidator
-
- fromAnnotation(DataTypeLookup, DataTypeHint) - 类 中的静态方法org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
- fromAnnotation(DataTypeHint, DataType) - 类 中的静态方法org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
Creates an instance from the given
DataTypeHint
with a resolved data type if available.
- fromClass(ClassInstance) - 类 中的方法org.apache.flink.table.descriptors.FunctionDescriptor
-
Creates a function from a class description.
- fromClassToDataType(Class<?>) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
-
- fromDataToLogicalType(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
-
- fromDataToLogicalType(DataType[]) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
-
- fromDataTypeToLegacyInfo(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
-
- fromDataTypeToLegacyInfo(DataType[]) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
-
- fromDefaults() - 类 中的静态方法org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
Creates an instance with no parameter content.
- fromLegacyInfoToDataType(TypeInformation<?>) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
-
- fromLegacyInfoToDataType(TypeInformation<?>[]) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
-
- fromLogicalToDataType(LogicalType) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
-
- fromLogicalToDataType(LogicalType[]) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
-
- fromString(String) - 类 中的静态方法org.apache.flink.table.catalog.ObjectPath
-
- fromTypeInfo(TypeInformation<?>) - 类 中的静态方法org.apache.flink.table.api.TableSchema
-
- FunctionAlreadyExistException - org.apache.flink.table.catalog.exceptions中的异常错误
-
Exception for trying to create a function that already exists.
- FunctionAlreadyExistException(String, ObjectPath) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.FunctionAlreadyExistException
-
- FunctionAlreadyExistException(String, ObjectPath, Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.FunctionAlreadyExistException
-
- FunctionContext - 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) - 类 的构造器org.apache.flink.table.functions.FunctionContext
-
Wraps the underlying RuntimeContext
.
- FunctionDefinition - org.apache.flink.table.functions中的接口
-
Definition of a function.
- FunctionDefinitionFactory - org.apache.flink.table.factories中的接口
-
- FunctionDescriptor - org.apache.flink.table.descriptors中的类
-
Descriptor for describing a function.
- FunctionDescriptor() - 类 的构造器org.apache.flink.table.descriptors.FunctionDescriptor
-
- FunctionDescriptorValidator - org.apache.flink.table.descriptors中的类
-
- FunctionDescriptorValidator() - 类 的构造器org.apache.flink.table.descriptors.FunctionDescriptorValidator
-
- functionExists(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Check whether a function exists or not.
- FunctionIdentifier - org.apache.flink.table.functions中的类
-
Identifies a system function with function name or a catalog function with a fully qualified identifier.
- functionIdentifier() - 类 中的方法org.apache.flink.table.functions.UserDefinedFunction
-
Returns a unique, serialized representation for this function.
- FunctionKind - org.apache.flink.table.functions中的枚举
-
- FunctionLanguage - org.apache.flink.table.catalog中的枚举
-
- FunctionNotExistException - org.apache.flink.table.catalog.exceptions中的异常错误
-
Exception for trying to operate on a function that doesn't exist.
- FunctionNotExistException(String, ObjectPath) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.FunctionNotExistException
-
- FunctionNotExistException(String, ObjectPath, Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.FunctionNotExistException
-
- FunctionRequirement - org.apache.flink.table.functions中的枚举
-
- FunctionService - org.apache.flink.table.functions中的类
-
- FunctionService() - 类 的构造器org.apache.flink.table.functions.FunctionService
-
- generateRuntimeName(Class<?>, String[]) - 类 中的静态方法org.apache.flink.table.util.TableConnectorUtil
-
已过时。
Returns the table connector name used for log and web UI.
- generateRuntimeName(Class<?>, String[]) - 类 中的静态方法org.apache.flink.table.utils.TableConnectorUtils
-
Returns the table connector name used for logging and web UI.
- generateSignature(String, FunctionDefinition, TypeInference) - 类 中的静态方法org.apache.flink.table.types.inference.TypeInferenceUtil
-
- get() - 类 中的方法org.apache.flink.table.api.dataview.ListView
-
Returns an iterable of the list view.
- get(K) - 类 中的方法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 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- get(K) - 类 中的方法org.apache.flink.table.utils.ThreadLocalCache
-
- getAccessedFields(TimestampExtractor, DataType, Function<String, String>) - 类 中的静态方法org.apache.flink.table.sources.tsextractors.TimestampExtractorUtils
-
- getAccumulatorDataType() - 类 中的方法org.apache.flink.table.types.inference.TypeInferenceUtil.Result
-
- getAccumulatorType() - 类 中的方法org.apache.flink.table.functions.UserDefinedAggregateFunction
-
- getAccumulatorTypeInfo() - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
-
- getAccumulatorTypeInfo() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
- getAccumulatorTypeStrategy() - 类 中的方法org.apache.flink.table.types.inference.TypeInference
-
- getAggregateFunction() - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
-
- getArgumentCount() - 接口 中的方法org.apache.flink.table.types.inference.InputTypeStrategy
-
Initial input validation based on the number of arguments.
- getArgumentCount() - 类 中的方法org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
-
- getArgumentCount() - 类 中的方法org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
-
- getArgumentCount() - 类 中的方法org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
-
- getArgumentCount() - 类 中的方法org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
-
- getArgumentDataTypes() - 接口 中的方法org.apache.flink.table.types.inference.CallContext
-
Returns a resolved list of the call's argument types.
- getArgumentDataTypes() - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- getArgumentDataTypes() - 类 中的方法org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- getArgumentFields() - 接口 中的方法org.apache.flink.table.sources.FieldComputer
-
Returns the names of all fields that the expression of the field computer accesses.
- getArguments() - 类 中的方法org.apache.flink.table.types.inference.Signature
-
- getArgumentValue(int, Class<T>) - 接口 中的方法org.apache.flink.table.types.inference.CallContext
-
Returns the literal value of the argument at the given position, given that the argument is a
literal, is not null, and can be expressed as an instance of the provided class.
- getArgumentValue(int, Class<T>) - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- getArgumentValue(int, Class<T>) - 类 中的方法org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- getArity() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- getArity() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- getArity() - 类 中的方法org.apache.flink.table.typeutils.InternalTypeInfo
-
- getArity() - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- getArray(String, Function<String, E>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns all array elements under a given existing key.
- getAsyncLookupFunction(String[]) - 接口 中的方法org.apache.flink.table.sources.LookupableTableSource
-
- getAttributeName() - 类 中的方法org.apache.flink.table.sources.RowtimeAttributeDescriptor
-
Returns the name of the rowtime attribute.
- getAttributes() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- getAvgLen() - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
-
- getAvgLength() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
-
- getAvgLength() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
-
- getBigDecimal(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a big decimal value under the given existing key.
- getBoolean(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a boolean value under the given existing key.
- getByte(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a byte value under the given existing key.
- getCachedFile(String) - 类 中的方法org.apache.flink.table.functions.FunctionContext
-
Gets the local temporary file copy of a distributed cache files.
- getCatalogName() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
-
- getCatalogName() - 类 中的方法org.apache.flink.table.catalog.UnresolvedIdentifier
-
- getCharacter(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a character value under the given existing key.
- getChildren() - 类 中的方法org.apache.flink.table.expressions.CallExpression
-
- getChildren() - 接口 中的方法org.apache.flink.table.expressions.Expression
-
- getChildren() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
-
- getChildren() - 类 中的方法org.apache.flink.table.expressions.TypeLiteralExpression
-
- getChildren() - 类 中的方法org.apache.flink.table.expressions.ValueLiteralExpression
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.ArrayType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.BigIntType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.BinaryType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.BooleanType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.CharType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.DateType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.DayTimeIntervalType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.DecimalType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.DistinctType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.DoubleType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.FloatType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.IntType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.LogicalType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.MapType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.MultisetType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.NullType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.RawType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.SmallIntType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.SymbolType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.TimestampType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.TimeType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.TinyIntType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.TypeInformationRawType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.VarBinaryType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.VarCharType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.YearMonthIntervalType
-
- getChildren() - 类 中的方法org.apache.flink.table.types.logical.ZonedTimestampType
-
- getClass(String, Class<T>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a class value under the given existing key.
- getClassName() - 接口 中的方法org.apache.flink.table.catalog.CatalogFunction
-
Get the full name of the class backing the function.
- getColumns() - 类 中的方法org.apache.flink.table.api.constraints.UniqueConstraint
-
List of column names for which the primary key was defined.
- getColumnStatisticsData() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatistics
-
- getColumnStats() - 类 中的方法org.apache.flink.table.plan.stats.TableStats
-
- getComment() - 接口 中的方法org.apache.flink.table.catalog.CatalogBaseTable
-
Get comment of the table or view.
- getComment() - 接口 中的方法org.apache.flink.table.catalog.CatalogDatabase
-
Get comment of the database.
- getComment() - 接口 中的方法org.apache.flink.table.catalog.CatalogPartition
-
Get comment of the partition.
- getComparision() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- getConsumedDataType() - 接口 中的方法org.apache.flink.table.sinks.TableSink
-
Returns the data type consumed by this
TableSink
.
- getConversionClass() - 类 中的方法org.apache.flink.table.types.DataType
-
Returns the corresponding conversion class for representing values.
- getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
- getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.table.dataview.MapViewSerializerSnapshot
-
- getCurrentOuterSnapshotVersion() - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
-
- getDatabase(String) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get a database from this catalog.
- getDatabaseName() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
-
- getDatabaseName() - 类 中的方法org.apache.flink.table.catalog.ObjectPath
-
- getDatabaseName() - 类 中的方法org.apache.flink.table.catalog.UnresolvedIdentifier
-
- getDataType() - 类 中的方法org.apache.flink.table.api.DataTypes.Field
-
- getDataType(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns the DataType under the given existing key.
- getDataTypeLookup() - 接口 中的方法org.apache.flink.table.types.inference.CallContext
-
Enables to lookup types in a catalog and resolve RAW types.
- getDataTypeLookup() - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- getDataTypeLookup() - 类 中的方法org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- getDayPrecision() - 类 中的方法org.apache.flink.table.types.logical.DayTimeIntervalType
-
- getDayPrecision(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- getDaysSinceEpoch() - 类 中的方法org.apache.flink.table.catalog.stats.Date
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.ArrayType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.BigIntType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.BinaryType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.BooleanType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.CharType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.DateType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.DayTimeIntervalType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.DecimalType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.DistinctType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.DoubleType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.FloatType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.IntType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.LogicalType
-
Returns the default conversion class.
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.MapType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.MultisetType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.NullType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.RawType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.SmallIntType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.SymbolType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.TimestampType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.TimeType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.TinyIntType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.TypeInformationRawType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.VarBinaryType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.VarCharType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.YearMonthIntervalType
-
- getDefaultConversion() - 类 中的方法org.apache.flink.table.types.logical.ZonedTimestampType
-
- getDefaultDatabase() - 类 中的方法org.apache.flink.table.catalog.AbstractCatalog
-
- getDefaultDatabase() - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get the name of the default database for this catalog.
- getDefaultDatabase() - 类 中的方法org.apache.flink.table.descriptors.CatalogDescriptor
-
- getDefinitions() - 类 中的静态方法org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- getDescription() - 类 中的方法org.apache.flink.table.api.DataTypes.Field
-
- getDescription() - 接口 中的方法org.apache.flink.table.catalog.CatalogBaseTable
-
Get a brief description of the table or view.
- getDescription() - 接口 中的方法org.apache.flink.table.catalog.CatalogDatabase
-
Get a brief description of the database.
- getDescription() - 接口 中的方法org.apache.flink.table.catalog.CatalogFunction
-
Get a brief description of the function.
- getDescription() - 接口 中的方法org.apache.flink.table.catalog.CatalogPartition
-
Get a brief description of the database.
- getDescription() - 类 中的方法org.apache.flink.table.types.logical.RowType.RowField
-
- getDescription() - 类 中的方法org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- getDescription() - 类 中的方法org.apache.flink.table.types.logical.UserDefinedType
-
- getDetailedDescription() - 接口 中的方法org.apache.flink.table.catalog.CatalogBaseTable
-
Get a detailed description of the table or view.
- getDetailedDescription() - 接口 中的方法org.apache.flink.table.catalog.CatalogDatabase
-
Get a detailed description of the database.
- getDetailedDescription() - 接口 中的方法org.apache.flink.table.catalog.CatalogFunction
-
Get a detailed description of the function.
- getDetailedDescription() - 接口 中的方法org.apache.flink.table.catalog.CatalogPartition
-
Get a detailed description of the database.
- getDouble(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a double value under the given existing key.
- getDuration(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a java Duration
under the given existing key.
- getElementDataType() - 类 中的方法org.apache.flink.table.types.CollectionDataType
-
- getElementType() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- getElementType() - 类 中的方法org.apache.flink.table.types.logical.ArrayType
-
- getElementType() - 类 中的方法org.apache.flink.table.types.logical.MultisetType
-
- getExecType() - 类 中的方法org.apache.flink.table.functions.python.PythonEnv
-
- getExpandedQuery() - 接口 中的方法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.
- getExpectedArgument(FunctionDefinition, int) - 接口 中的方法org.apache.flink.table.types.inference.ArgumentTypeStrategy
-
Returns a summary of the function's expected argument at argumentPos
.
- getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
-
- getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
-
- getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
-
- getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
-
- getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
-
- getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
-
- getExpectedArgumentTypes() - 类 中的方法org.apache.flink.table.types.inference.TypeInferenceUtil.Result
-
- getExpectedSignatures(FunctionDefinition) - 接口 中的方法org.apache.flink.table.types.inference.InputTypeStrategy
-
Returns a summary of the function's expected signatures.
- getExpectedSignatures(FunctionDefinition) - 类 中的方法org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
-
- getExpectedSignatures(FunctionDefinition) - 类 中的方法org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
-
- getExpectedSignatures(FunctionDefinition) - 类 中的方法org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
-
- getExpectedSignatures(FunctionDefinition) - 类 中的方法org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
-
- getExpr() - 类 中的方法org.apache.flink.table.api.TableColumn
-
Returns computation expression of this column.
- getExpression(ResolvedFieldReference[]) - 接口 中的方法org.apache.flink.table.sources.FieldComputer
-
Returns the
Expression
that computes the value of the field.
- getFalseCount() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
-
- getFamilies() - 枚举 中的方法org.apache.flink.table.types.logical.LogicalTypeRoot
-
- getFieldCount() - 类 中的方法org.apache.flink.table.api.TableSchema
-
Returns the number of fields.
- getFieldCount() - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- getFieldDataType(int) - 类 中的方法org.apache.flink.table.api.TableSchema
-
Returns the specified data type for the given field index.
- getFieldDataType(String) - 类 中的方法org.apache.flink.table.api.TableSchema
-
Returns the specified data type for the given field name.
- getFieldDataTypes() - 类 中的方法org.apache.flink.table.api.TableSchema
-
Returns all field data types as an array.
- getFieldDataTypes() - 类 中的方法org.apache.flink.table.types.FieldsDataType
-
- getFieldIndex() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
-
- getFieldIndex(String) - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- getFieldMapping() - 接口 中的方法org.apache.flink.table.sources.DefinedFieldMapping
-
- getFieldName(int) - 类 中的方法org.apache.flink.table.api.TableSchema
-
Returns the specified name for the given field index.
- getFieldNames() - 类 中的方法org.apache.flink.table.api.TableSchema
-
Returns all field names as an array.
- getFieldNames() - 接口 中的方法org.apache.flink.table.sinks.TableSink
-
- getFieldNames() - 类 中的方法org.apache.flink.table.sinks.TableSinkBase
-
Returns the field names of the table to emit.
- getFieldNames() - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- getFields() - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- getFieldType(int) - 类 中的方法org.apache.flink.table.api.TableSchema
-
- getFieldType(String) - 类 中的方法org.apache.flink.table.api.TableSchema
-
- getFieldTypes() - 类 中的方法org.apache.flink.table.api.TableSchema
-
- getFieldTypes() - 接口 中的方法org.apache.flink.table.sinks.TableSink
-
- getFieldTypes() - 类 中的方法org.apache.flink.table.sinks.TableSinkBase
-
Returns the field types of the table to emit.
- getFileCount() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
- getFixedIndexedProperties(String, List<String>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns the property keys of fixed indexed properties.
- getFloat(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a float value under the given given existing key.
- getFractionalPrecision() - 类 中的方法org.apache.flink.table.types.logical.DayTimeIntervalType
-
- getFractionalPrecision(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- getFullName() - 类 中的方法org.apache.flink.table.catalog.ObjectPath
-
- getFunction(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get the function.
- getFunctionDefinition() - 类 中的方法org.apache.flink.table.expressions.CallExpression
-
- getFunctionDefinition(String) - 类 中的方法org.apache.flink.table.module.CoreModule
-
- getFunctionDefinition(String) - 接口 中的方法org.apache.flink.table.module.Module
-
- getFunctionDefinition() - 接口 中的方法org.apache.flink.table.types.inference.CallContext
-
Returns the function definition that defines the function currently being called.
- getFunctionDefinition() - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- getFunctionDefinition() - 类 中的方法org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- getFunctionDefinitionFactory() - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
- getFunctionIdentifier() - 类 中的方法org.apache.flink.table.expressions.CallExpression
-
- getFunctionLanguage() - 接口 中的方法org.apache.flink.table.catalog.CatalogFunction
-
Get the language used for the definition of function.
- getIdentifier() - 类 中的方法org.apache.flink.table.functions.FunctionIdentifier
-
- getImplementationClass() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- getIndexedProperty(String, String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns all properties under a given key that contains an index in between.
- getInputIndex() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
-
- getInputs() - 类 中的方法org.apache.flink.table.functions.python.PythonFunctionInfo
-
- getInputTypeStrategy() - 类 中的方法org.apache.flink.table.types.inference.TypeInference
-
- getInt(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns an integer value under the given existing key.
- getJobParameter(String, String) - 类 中的方法org.apache.flink.table.functions.FunctionContext
-
Gets the global job parameter value associated with the given key as a string.
- getKeyDataType() - 类 中的方法org.apache.flink.table.types.KeyValueDataType
-
- getKeySerializer() - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializer
-
- getKeyType() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- getKeyType() - 类 中的方法org.apache.flink.table.types.logical.MapType
-
- getKind() - 类 中的方法org.apache.flink.table.functions.AggregateFunction
-
- getKind() - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
-
- getKind() - 类 中的方法org.apache.flink.table.functions.AsyncTableFunction
-
- getKind() - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition
-
- getKind() - 接口 中的方法org.apache.flink.table.functions.FunctionDefinition
-
Returns the kind of function this definition describes.
- getKind() - 类 中的方法org.apache.flink.table.functions.ScalarFunction
-
- getKind() - 类 中的方法org.apache.flink.table.functions.ScalarFunctionDefinition
-
- getKind() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunction
-
- getKind() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
- getKind() - 类 中的方法org.apache.flink.table.functions.TableFunction
-
- getKind() - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
-
- getKind() - 类 中的方法org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- getKind() - 类 中的方法org.apache.flink.table.types.logical.TimestampType
-
- getKind() - 类 中的方法org.apache.flink.table.types.logical.ZonedTimestampType
-
- getLength() - 类 中的方法org.apache.flink.table.dataview.ListViewSerializer
-
- getLength() - 类 中的方法org.apache.flink.table.dataview.MapViewSerializer
-
- getLength() - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializer
-
- getLength() - 类 中的方法org.apache.flink.table.dataview.NullSerializer
-
- getLength() - 类 中的方法org.apache.flink.table.types.logical.BinaryType
-
- getLength() - 类 中的方法org.apache.flink.table.types.logical.CharType
-
- getLength(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- getLength() - 类 中的方法org.apache.flink.table.types.logical.VarBinaryType
-
- getLength() - 类 中的方法org.apache.flink.table.types.logical.VarCharType
-
- getListSerializer() - 类 中的方法org.apache.flink.table.dataview.ListViewSerializer
-
- getLogicalType() - 类 中的方法org.apache.flink.table.types.DataType
-
Returns the corresponding logical type.
- getLong(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a long value under the given existing key.
- getLookupFunction(String[]) - 接口 中的方法org.apache.flink.table.sources.LookupableTableSource
-
- getMapSerializer() - 类 中的方法org.apache.flink.table.dataview.MapViewSerializer
-
- getMax() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
-
- getMax() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
-
- getMax() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
-
- getMax() - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
-
- getMaxCount() - 接口 中的方法org.apache.flink.table.types.inference.ArgumentCount
-
Returns the maximum number of argument (inclusive) that a function can take.
- getMaxCount() - 类 中的方法org.apache.flink.table.types.inference.ConstantArgumentCount
-
- getMaxLen() - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
-
- getMaxLength() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
-
- getMaxLength() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
-
- getMaxValue() - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
-
已过时。
- getMemorySize(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a Flink MemorySize
under the given existing key.
- getMessage() - 异常错误 中的方法org.apache.flink.table.api.AmbiguousTableFactoryException
-
- getMessage() - 异常错误 中的方法org.apache.flink.table.api.NoMatchingTableFactoryException
-
- getMetricGroup() - 类 中的方法org.apache.flink.table.functions.FunctionContext
-
Returns the metric group for this parallel subtask.
- getMin() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
-
- getMin() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
-
- getMin() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
-
- getMin() - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
-
- getMinCount() - 接口 中的方法org.apache.flink.table.types.inference.ArgumentCount
-
Returns the minimum number of argument (inclusive) that a function can take.
- getMinCount() - 类 中的方法org.apache.flink.table.types.inference.ConstantArgumentCount
-
- getMinValue() - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
-
已过时。
- getName() - 接口 中的方法org.apache.flink.table.api.constraints.Constraint
-
- getName() - 类 中的方法org.apache.flink.table.api.DataTypes.Field
-
- getName() - 类 中的方法org.apache.flink.table.api.TableColumn
-
Returns name of this column.
- getName() - 类 中的方法org.apache.flink.table.catalog.AbstractCatalog
-
- getName() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
-
- getName() - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
-
- getName() - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition
-
- getName() - 类 中的方法org.apache.flink.table.functions.ScalarFunctionDefinition
-
- getName() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
- getName() - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
-
- getName() - 接口 中的方法org.apache.flink.table.types.inference.CallContext
-
Returns the function's name usually referencing the function in a catalog.
- getName() - 类 中的方法org.apache.flink.table.types.inference.Signature.Argument
-
- getName() - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- getName() - 类 中的方法org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- getName() - 类 中的方法org.apache.flink.table.types.logical.RowType.RowField
-
- getName() - 类 中的方法org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- getNamedArguments() - 类 中的方法org.apache.flink.table.types.inference.TypeInference
-
- getNames() - 类 中的方法org.apache.flink.table.functions.FunctionIdentifier
-
List of the component names of this function identifier.
- getNdv() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
-
- getNdv() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
-
- getNdv() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
-
- getNdv() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
-
- getNdv() - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
-
- getNestedSerializers(ListViewSerializer<T>) - 类 中的方法org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
- getNestedSerializers(MapViewSerializer<K, V>) - 类 中的方法org.apache.flink.table.dataview.MapViewSerializerSnapshot
-
- getNestedSerializers(NullAwareMapSerializer<K, V>) - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
-
- getNewInstance(K) - 类 中的方法org.apache.flink.table.utils.ThreadLocalCache
-
- getNullCount() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
-
- getNullCount() - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
-
- getObjectIdentifier() - 类 中的方法org.apache.flink.table.types.logical.DistinctType
-
- getObjectName() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
-
- getObjectName() - 类 中的方法org.apache.flink.table.catalog.ObjectPath
-
- getObjectName() - 类 中的方法org.apache.flink.table.catalog.UnresolvedIdentifier
-
- getOptionalArray(String, Function<String, E>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns all array elements under a given key if it exists.
- getOptionalBigDecimal(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a big decimal value under the given key if it exists.
- getOptionalBoolean(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a boolean value under the given key if it exists.
- getOptionalByte(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a byte value under the given key if it exists.
- getOptionalCharacter(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a character value under the given key if it exists.
- getOptionalClass(String, Class<T>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a class value under the given key if it exists.
- getOptionalDataType(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns the DataType under the given key if it exists.
- getOptionalDouble(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a double value under the given key if it exists.
- getOptionalDuration(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a Java Duration
under the given key if it exists.
- getOptionalFloat(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a float value under the given key if it exists.
- getOptionalInt(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns an integer value under the given key if it exists.
- getOptionalLong(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a long value under the given key if it exists.
- getOptionalMemorySize(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a Flink MemorySize
under the given key if it exists.
- getOptionalObjectIdentifier() - 类 中的方法org.apache.flink.table.types.logical.UserDefinedType
-
- getOptionalShort(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a short value under the given key if it exists.
- getOptionalString(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a string value under the given key if it exists.
- getOptionalTableSchema(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a table schema under the given key if it exists.
- getOptionalType(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns the type information under the given key if it exists.
- getOriginalQuery() - 接口 中的方法org.apache.flink.table.catalog.CatalogView
-
Original text of the view definition that also perserves the original formatting.
- getOriginatingClass() - 类 中的方法org.apache.flink.table.types.logical.RawType
-
- getOutputDataType() - 类 中的方法org.apache.flink.table.expressions.CallExpression
-
- getOutputDataType() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
-
- getOutputDataType() - 接口 中的方法org.apache.flink.table.expressions.ResolvedExpression
-
Returns the data type of the computation result.
- getOutputDataType() - 类 中的方法org.apache.flink.table.expressions.TypeLiteralExpression
-
- getOutputDataType() - 类 中的方法org.apache.flink.table.expressions.ValueLiteralExpression
-
- getOutputDataType() - 接口 中的方法org.apache.flink.table.types.inference.CallContext
-
Returns the inferred output data type of the function call.
- getOutputDataType() - 类 中的方法org.apache.flink.table.types.inference.TypeInferenceUtil.Result
-
- getOutputDataType() - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- getOutputDataType() - 类 中的方法org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- getOutputType() - 接口 中的方法org.apache.flink.table.sinks.TableSink
-
- getOutputTypeStrategy() - 类 中的方法org.apache.flink.table.types.inference.TypeInference
-
- getParameterTypes(Class<?>[]) - 类 中的方法org.apache.flink.table.functions.ScalarFunction
-
Returns TypeInformation
about the operands of the evaluation method with a given
signature.
- getParameterTypes(Class<?>[]) - 类 中的方法org.apache.flink.table.functions.TableFunction
-
Returns TypeInformation
about the operands of the evaluation method with a given
signature.
- getPartition(ObjectPath, CatalogPartitionSpec) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get a partition of the given table.
- getPartitionColumnStatistics(ObjectPath, CatalogPartitionSpec) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get the column statistics of a partition.
- getPartitionKeys() - 接口 中的方法org.apache.flink.table.catalog.CatalogTable
-
Get the partition keys of the table.
- getPartitions() - 接口 中的方法org.apache.flink.table.sources.PartitionableTableSource
-
- getPartitionSpec() - 类 中的方法org.apache.flink.table.catalog.CatalogPartitionSpec
-
Get the partition spec as key-value map.
- getPartitionStatistics(ObjectPath, CatalogPartitionSpec) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get the statistics of a partition.
- getPhysicalSchema(TableSchema) - 类 中的静态方法org.apache.flink.table.utils.TableSchemaUtils
-
Return
TableSchema
which consists of all physical columns.
- getPrecision() - 类 中的方法org.apache.flink.table.types.logical.DecimalType
-
- getPrecision() - 类 中的方法org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- getPrecision() - 类 中的方法org.apache.flink.table.types.logical.TimestampType
-
- getPrecision() - 类 中的方法org.apache.flink.table.types.logical.TimeType
-
- getPrecision(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns the precision of all types that define a precision implicitly or explicitly.
- getPrecision() - 类 中的方法org.apache.flink.table.types.logical.ZonedTimestampType
-
- getPrimaryKey() - 类 中的方法org.apache.flink.table.api.TableSchema
-
- getProctimeAttribute() - 接口 中的方法org.apache.flink.table.sources.DefinedProctimeAttribute
-
Returns the name of a processing time attribute or null if no processing time attribute is
present.
- getProducedDataType() - 接口 中的方法org.apache.flink.table.sources.TableSource
-
- getProperties() - 接口 中的方法org.apache.flink.table.catalog.CatalogBaseTable
-
Get the properties of the table.
- getProperties() - 接口 中的方法org.apache.flink.table.catalog.CatalogDatabase
-
Get a map of properties associated with the database.
- getProperties() - 接口 中的方法org.apache.flink.table.catalog.CatalogPartition
-
Get a map of properties associated with the partition.
- getProperties() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatistics
-
- getProperties() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
-
- getProperties() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
- getPropertiesWithPrefix(String) - 类 中的方法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.
- getPythonEnv() - 接口 中的方法org.apache.flink.table.functions.python.PythonFunction
-
Returns the Python execution environment.
- getPythonEnv() - 类 中的方法org.apache.flink.table.functions.python.SimplePythonFunction
-
- getPythonFunction() - 类 中的方法org.apache.flink.table.functions.python.PythonFunctionInfo
-
- getRawDataSize() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
- getRequirements() - 类 中的方法org.apache.flink.table.functions.AggregateFunction
-
- getRequirements() - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
-
- getRequirements() - 接口 中的方法org.apache.flink.table.functions.FunctionDefinition
-
Returns the set of requirements this definition demands.
- getRequirements() - 类 中的方法org.apache.flink.table.functions.ScalarFunctionDefinition
-
- getRequirements() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
- getRequirements() - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
-
- getResolution() - 类 中的方法org.apache.flink.table.types.logical.DayTimeIntervalType
-
- getResolution() - 类 中的方法org.apache.flink.table.types.logical.YearMonthIntervalType
-
- getResolvedChildren() - 类 中的方法org.apache.flink.table.expressions.CallExpression
-
- getResolvedChildren() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
-
- getResolvedChildren() - 接口 中的方法org.apache.flink.table.expressions.ResolvedExpression
-
- getResolvedChildren() - 类 中的方法org.apache.flink.table.expressions.TypeLiteralExpression
-
- getResolvedChildren() - 类 中的方法org.apache.flink.table.expressions.ValueLiteralExpression
-
- getResultType() - 类 中的方法org.apache.flink.table.functions.AsyncTableFunction
-
Returns the result type of the evaluation method with a given signature.
- getResultType(Class<?>[]) - 类 中的方法org.apache.flink.table.functions.ScalarFunction
-
Returns the result type of the evaluation method with a given signature.
- getResultType() - 类 中的方法org.apache.flink.table.functions.TableFunction
-
Returns the result type of the evaluation method with a given signature.
- getResultType() - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
-
- getResultType() - 类 中的方法org.apache.flink.table.functions.UserDefinedAggregateFunction
-
- getResultTypeInfo() - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
-
- getResultTypeInfo() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
- getReturnType() - 接口 中的方法org.apache.flink.table.sources.FieldComputer
-
Returns the result type of the expression.
- getReturnType() - 接口 中的方法org.apache.flink.table.sources.TableSource
-
- getReturnType() - 类 中的方法org.apache.flink.table.sources.tsextractors.TimestampExtractor
-
- getRowCount() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
The number of rows.
- getRowCount() - 类 中的方法org.apache.flink.table.plan.stats.TableStats
-
- getRowtimeAttribute() - 类 中的方法org.apache.flink.table.api.WatermarkSpec
-
Returns the name of rowtime attribute, it can be a nested field using dot separator.
- getRowtimeAttributeDescriptors() - 接口 中的方法org.apache.flink.table.sources.DefinedRowtimeAttributes
-
- getScalarFunction() - 类 中的方法org.apache.flink.table.functions.ScalarFunctionDefinition
-
- getScale() - 类 中的方法org.apache.flink.table.types.logical.DecimalType
-
- getScale(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns the scale of all types that define a scale implicitly or explicitly.
- getSchema() - 接口 中的方法org.apache.flink.table.catalog.CatalogBaseTable
-
Get the schema of the table.
- getSerializedPythonFunction() - 接口 中的方法org.apache.flink.table.functions.python.PythonFunction
-
Returns the serialized representation of the user-defined python function.
- getSerializedPythonFunction() - 类 中的方法org.apache.flink.table.functions.python.SimplePythonFunction
-
- getShort(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a short value under the given existing key.
- getSimpleName() - 类 中的方法org.apache.flink.table.functions.FunctionIdentifier
-
- getSourceType() - 类 中的方法org.apache.flink.table.types.logical.DistinctType
-
- getString(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a string value under the given existing key.
- getSuperType() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- getTable(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get a CatalogTable or CatalogView identified by tablePath.
- getTableAggregateFunction() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
- getTableColumn(int) - 类 中的方法org.apache.flink.table.api.TableSchema
-
Returns the
TableColumn
instance for the given field index.
- getTableColumn(String) - 类 中的方法org.apache.flink.table.api.TableSchema
-
Returns the
TableColumn
instance for the given field name.
- getTableColumns() - 类 中的方法org.apache.flink.table.api.TableSchema
-
- getTableColumnStatistics(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get the column statistics of a table.
- getTableFactory() - 接口 中的方法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.
- getTableFunction() - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
-
- getTableSchema(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns a table schema under the given existing key.
- getTableSchema() - 接口 中的方法org.apache.flink.table.sinks.TableSink
-
Returns the schema of the consumed table.
- getTableSchema() - 接口 中的方法org.apache.flink.table.sources.TableSource
-
- getTableStatistics(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get the statistics of a table.
- getTimestampExtractor() - 类 中的方法org.apache.flink.table.sources.RowtimeAttributeDescriptor
-
Returns the [[TimestampExtractor]] for the attribute.
- getTotalFields() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- getTotalFields() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- getTotalFields() - 类 中的方法org.apache.flink.table.typeutils.InternalTypeInfo
-
- getTotalFields() - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- getTotalSize() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
- getTrueCount() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
-
- getType() - 接口 中的方法org.apache.flink.table.api.constraints.Constraint
-
Tells what kind of constraint it is, e.g.
- getType() - 类 中的方法org.apache.flink.table.api.constraints.UniqueConstraint
-
- getType() - 类 中的方法org.apache.flink.table.api.TableColumn
-
Returns data type of this column.
- getType(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns the type information under the given existing key.
- getType() - 类 中的方法org.apache.flink.table.types.inference.Signature.Argument
-
- getType() - 类 中的方法org.apache.flink.table.types.logical.RowType.RowField
-
- getType() - 类 中的方法org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- getTypeAt(int) - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- getTypeClass() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- getTypeClass() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- getTypeClass() - 类 中的方法org.apache.flink.table.typeutils.InternalTypeInfo
-
- getTypeClass() - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- getTypedArguments() - 类 中的方法org.apache.flink.table.types.inference.TypeInference
-
- getTypeInference() - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition
-
Currently, the type inference is just exposed here.
- getTypeInformation() - 类 中的方法org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- getTypeInformation() - 类 中的方法org.apache.flink.table.types.logical.TypeInformationRawType
-
- getTypeRoot() - 类 中的方法org.apache.flink.table.types.logical.LogicalType
-
Returns the root of this type.
- getTypeSerializer() - 类 中的方法org.apache.flink.table.types.logical.RawType
-
- getUnresolvedIdentifier() - 类 中的方法org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- getValue(String, DescriptorProperties) - 类 中的静态方法org.apache.flink.table.descriptors.LiteralValueValidator
-
Gets the value according to the type and value strings.
- getValue(ACC) - 类 中的方法org.apache.flink.table.functions.AggregateFunction
-
Called every time when an aggregation result should be materialized.
- getValueAs(Class<T>) - 类 中的方法org.apache.flink.table.expressions.ValueLiteralExpression
-
Returns the value (excluding null) as an instance of the given class.
- getValueDataType() - 类 中的方法org.apache.flink.table.types.KeyValueDataType
-
- getValueSerializer() - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializer
-
- getValueType() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- getValueType() - 类 中的方法org.apache.flink.table.types.logical.MapType
-
- getVariableIndexedProperties(String, List<String>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns the property keys of variable indexed properties.
- getWatermarkExpr() - 类 中的方法org.apache.flink.table.api.WatermarkSpec
-
Returns the string representation of watermark generation expression.
- getWatermarkExprOutputType() - 类 中的方法org.apache.flink.table.api.WatermarkSpec
-
Returns the data type of the computation result of watermark generation expression.
- getWatermarkSpecs() - 类 中的方法org.apache.flink.table.api.TableSchema
-
Returns a list of the watermark specification which contains rowtime attribute
and watermark strategy expression.
- getWatermarkStrategy() - 类 中的方法org.apache.flink.table.sources.RowtimeAttributeDescriptor
-
Returns the [[WatermarkStrategy]] for the attribute.
- getYearPrecision(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- getYearPrecision() - 类 中的方法org.apache.flink.table.types.logical.YearMonthIntervalType
-
- GREATER_THAN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- GREATER_THAN_OR_EQUAL - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- IF - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- IN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- inAppendMode() - 类 中的方法org.apache.flink.table.descriptors.TableDescriptor
-
Declares how to perform the conversion between a dynamic table and an external connector.
- inferArgumentType(CallContext, int, boolean) - 接口 中的方法org.apache.flink.table.types.inference.ArgumentTypeStrategy
-
Main logic for inferring and validating an argument.
- inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
-
- inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
-
- inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
-
- inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
-
- inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
-
- inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
-
- inferInputTypes(CallContext, boolean) - 接口 中的方法org.apache.flink.table.types.inference.InputTypeStrategy
-
Main logic for inferring and validating the input arguments.
- inferInputTypes(CallContext, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
-
- inferInputTypes(CallContext, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
-
- inferInputTypes(CallContext, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
-
- inferInputTypes(CallContext, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
-
- inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.ExplicitTypeStrategy
-
- inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
-
- inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
-
- inferType(CallContext) - 接口 中的方法org.apache.flink.table.types.inference.TypeStrategy
-
Infers a type from the given function call.
- INIT_CAP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- InputGroup - org.apache.flink.table.annotation中的枚举
-
A list of commonly used pre-defined groups of similar types for accepting more than just one data
type as an input argument in
DataTypeHint
s.
- inputGroup - 类 中的变量org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
- InputTypeStrategies - org.apache.flink.table.types.inference中的类
-
Strategies for inferring and validating input arguments in a function call.
- inputTypeStrategy(InputTypeStrategy) - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
- InputTypeStrategy - org.apache.flink.table.types.inference中的接口
-
Strategy for inferring and validating input arguments in a function call.
- inputTypeStrategy(InputTypeStrategy) - 类 中的方法org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets the strategy for inferring and validating input arguments in a function call.
- inRetractMode() - 类 中的方法org.apache.flink.table.descriptors.TableDescriptor
-
Declares how to perform the conversion between a dynamic table and an external connector.
- INSTANCE - 类 中的静态变量org.apache.flink.table.dataview.NullSerializer
-
- INSTANCE - 类 中的静态变量org.apache.flink.table.module.CoreModule
-
- INSTANCE - 类 中的静态变量org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
-
- INSTANCE - 类 中的静态变量org.apache.flink.table.types.inference.transforms.LegacyDecimalTypeTransformation
-
- INSTANCE - 类 中的静态变量org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
-
- INT() - 类 中的静态方法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() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API integer or SQL INT/INTEGER type.
- InternalTypeInfo<T> - 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>) - 类 的构造器org.apache.flink.table.typeutils.InternalTypeInfo
-
- INTERVAL(DataTypes.Resolution) - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Data type of a temporal interval.
- INTERVAL(DataTypes.Resolution, DataTypes.Resolution) - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Data type of a temporal interval.
- INTERVAL_MILLIS() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API interval of milliseconds.
- INTERVAL_MILLIS - 类 中的静态变量org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- INTERVAL_MONTHS() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API interval of months.
- INTERVAL_MONTHS - 类 中的静态变量org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- IntType - 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) - 类 的构造器org.apache.flink.table.types.logical.IntType
-
- IntType() - 类 的构造器org.apache.flink.table.types.logical.IntType
-
- inUpsertMode() - 类 中的方法org.apache.flink.table.descriptors.TableDescriptor
-
Declares how to perform the conversion between a dynamic table and an external connector.
- IS_FALSE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- IS_GENERIC - 类 中的静态变量org.apache.flink.table.catalog.config.CatalogConfig
-
Flag to distinguish if a meta-object is generic Flink object or not.
- IS_NOT_FALSE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- IS_NOT_NULL - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- IS_NOT_TRUE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- IS_NULL - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- IS_TRUE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- isAllowAnyPattern(Class<?>) - 类 中的方法org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
Returns whether the given class is eligible for being treated as RAW type.
- isAllowRawGlobally() - 类 中的方法org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
Returns whether RAW types are allowed everywhere.
- isArgumentLiteral(int) - 接口 中的方法org.apache.flink.table.types.inference.CallContext
-
Returns whether the argument at the given position is a value literal.
- isArgumentLiteral(int) - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- isArgumentLiteral(int) - 类 中的方法org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- isArgumentNull(int) - 接口 中的方法org.apache.flink.table.types.inference.CallContext
-
Returns true
if the argument at the given position is a literal and null
,
false
otherwise.
- isArgumentNull(int) - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- isArgumentNull(int) - 类 中的方法org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- isAsyncEnabled() - 接口 中的方法org.apache.flink.table.sources.LookupableTableSource
-
Returns true if async lookup is enabled.
- isBasicType() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- isBasicType() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- isBasicType() - 类 中的方法org.apache.flink.table.typeutils.InternalTypeInfo
-
- isBasicType() - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- isCompositeType(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Checks if the given type is a composite type.
- isDeterministic() - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
-
- isDeterministic() - 接口 中的方法org.apache.flink.table.functions.FunctionDefinition
-
Returns information about the determinism of the function's results.
- isDeterministic() - 类 中的方法org.apache.flink.table.functions.ScalarFunctionDefinition
-
- isDeterministic() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
- isDeterministic() - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
-
- isEmpty() - 类 中的方法org.apache.flink.table.api.dataview.MapView
-
Returns true if the map view contains no key-value mappings, otherwise false.
- isEnforced() - 接口 中的方法org.apache.flink.table.api.constraints.Constraint
-
Constraints can either be enforced or non-enforced.
- isEventTime() - 类 中的方法org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
已过时。
- isFilterPushedDown() - 接口 中的方法org.apache.flink.table.sources.FilterableTableSource
-
Return the flag to indicate whether filter push down has been tried.
- isFinal() - 类 中的方法org.apache.flink.table.types.logical.UserDefinedType
-
- isForceAnyPattern(Class<?>) - 类 中的方法org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
Returns whether the given class must be treated as RAW type.
- isFormatNeeded() - 类 中的方法org.apache.flink.table.descriptors.ConnectorDescriptor
-
Returns if this connector requires a format descriptor.
- isGenerated() - 类 中的方法org.apache.flink.table.api.TableColumn
-
Returns if this column is a computed column that is generated from an expression.
- isGeneric() - 接口 中的方法org.apache.flink.table.catalog.CatalogFunction
-
Distinguish if the function is a generic function.
- isImmutableType() - 类 中的方法org.apache.flink.table.dataview.ListViewSerializer
-
- isImmutableType() - 类 中的方法org.apache.flink.table.dataview.MapViewSerializer
-
- isImmutableType() - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializer
-
- isImmutableType() - 类 中的方法org.apache.flink.table.dataview.NullSerializer
-
- isInstantiable() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- isKeyType() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- isKeyType() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- isKeyType() - 类 中的方法org.apache.flink.table.typeutils.InternalTypeInfo
-
- isKeyType() - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- isLimitPushedDown() - 接口 中的方法org.apache.flink.table.sources.LimitableTableSource
-
Return the flag to indicate whether limit push down has been tried.
- isNull() - 类 中的方法org.apache.flink.table.expressions.ValueLiteralExpression
-
- isNullable() - 类 中的方法org.apache.flink.table.types.logical.LogicalType
-
Returns whether a value of this type can be null
.
- isNullAware() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- isNullSerializer() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- isNullSerializer() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- isPartitioned() - 接口 中的方法org.apache.flink.table.catalog.CatalogTable
-
Check if the table is partitioned or not.
- isProctimeAttribute(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- isRowtimeAttribute(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- isSingleFieldInterval(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- isStructuredFieldMutable(Class<?>, Field) - 类 中的静态方法org.apache.flink.table.types.extraction.utils.ExtractionUtils
-
Checks if a field is mutable or immutable.
- isTimeAttribute(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- isTupleType() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- isTupleType() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- isTupleType() - 类 中的方法org.apache.flink.table.typeutils.InternalTypeInfo
-
- isTupleType() - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- isValidCount(int) - 接口 中的方法org.apache.flink.table.types.inference.ArgumentCount
-
- isValidCount(int) - 类 中的方法org.apache.flink.table.types.inference.ConstantArgumentCount
-
- isValue(String, String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Returns if a value under key is exactly equal to the given value.
- iterator() - 类 中的方法org.apache.flink.table.api.dataview.MapView
-
Returns an iterator over all entries of the map view.
- legacyDecimalToDefaultDecimal() - 类 中的静态方法org.apache.flink.table.types.inference.TypeTransformations
-
Returns a type transformation that transforms legacy decimal data type to DECIMAL(38, 18).
- LegacyDecimalTypeTransformation - org.apache.flink.table.types.inference.transforms中的类
-
This type transformation transforms the legacy decimal type (usually converted from
Types.BIG_DEC
) to DECIMAL(38, 18).
- LegacyDecimalTypeTransformation() - 类 的构造器org.apache.flink.table.types.inference.transforms.LegacyDecimalTypeTransformation
-
- legacyRawToTypeInfoRaw() - 类 中的静态方法org.apache.flink.table.types.inference.TypeTransformations
-
Returns a type transformation that transforms LEGACY('RAW', ...) type to the RAW(..., ?)
- LegacyRawTypeTransformation - org.apache.flink.table.types.inference.transforms中的类
-
This type transformation transforms the LEGACY('RAW', ...) type to the RAW(..., ?)
- LegacyRawTypeTransformation() - 类 的构造器org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
-
- LegacyTypeInfoDataTypeConverter - org.apache.flink.table.types.utils中的类
-
Converter between
TypeInformation
and
DataType
that reflects the behavior before
Flink 1.9.
- LegacyTypeInformationType<T> - 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>) - 类 的构造器org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- LESS_THAN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- LESS_THAN_OR_EQUAL - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- LIKE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- LimitableTableSource<T> - org.apache.flink.table.sources中的接口
-
- list - 类 中的变量org.apache.flink.table.api.dataview.ListView
-
- listDatabases() - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get the names of all databases in this catalog.
- listFunctions(String) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
List the names of all functions in the given database.
- listFunctions() - 类 中的方法org.apache.flink.table.module.CoreModule
-
- listFunctions() - 接口 中的方法org.apache.flink.table.module.Module
-
List names of all functions in this module.
- listPartitions(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get CatalogPartitionSpec of all partitions of the table.
- listPartitions(ObjectPath, CatalogPartitionSpec) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get CatalogPartitionSpec of all partitions that is under the given CatalogPartitionSpec in the table.
- listPartitionsByFilter(ObjectPath, List<Expression>) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get CatalogPartitionSpec of partitions by expression filters in the table.
- listTables(String) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get names of all tables and views under this database.
- ListView<T> - org.apache.flink.table.api.dataview中的类
-
A
ListView
provides List functionality for accumulators used by user-defined aggregate
functions
AggregateFunction
.
- ListView(TypeInformation<?>, List<T>) - 类 的构造器org.apache.flink.table.api.dataview.ListView
-
- ListView(TypeInformation<?>) - 类 的构造器org.apache.flink.table.api.dataview.ListView
-
Creates a list view for elements of the specified type.
- ListView() - 类 的构造器org.apache.flink.table.api.dataview.ListView
-
Creates a list view.
- listViews(String) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Get names of all views under this database.
- ListViewSerializer<T> - org.apache.flink.table.dataview中的类
-
A serializer for [[ListView]].
- ListViewSerializer(TypeSerializer<List<T>>) - 类 的构造器org.apache.flink.table.dataview.ListViewSerializer
-
- ListViewSerializerSnapshot<T> - org.apache.flink.table.dataview中的类
-
- ListViewSerializerSnapshot() - 类 的构造器org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
Constructor for read instantiation.
- ListViewSerializerSnapshot(ListViewSerializer<T>) - 类 的构造器org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
Constructor to create the snapshot for writing.
- ListViewTypeInfo<T> - org.apache.flink.table.dataview中的类
-
- ListViewTypeInfo(TypeInformation<T>, boolean) - 类 的构造器org.apache.flink.table.dataview.ListViewTypeInfo
-
- ListViewTypeInfo(TypeInformation<T>) - 类 的构造器org.apache.flink.table.dataview.ListViewTypeInfo
-
- ListViewTypeInfoFactory<T> - org.apache.flink.table.dataview中的类
-
- ListViewTypeInfoFactory() - 类 的构造器org.apache.flink.table.dataview.ListViewTypeInfoFactory
-
- LITERAL - 类 中的静态变量org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that checks if an argument is a literal.
- LITERAL_OR_NULL - 类 中的静态变量org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that checks if an argument is a literal or NULL.
- LiteralArgumentTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
-
Strategy that checks if an argument is a literal.
- LiteralArgumentTypeStrategy(boolean) - 类 的构造器org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
-
- LiteralValue - org.apache.flink.table.descriptors中的类
-
Descriptor for a literal value.
- LiteralValue() - 类 的构造器org.apache.flink.table.descriptors.LiteralValue
-
- LiteralValueValidator - org.apache.flink.table.descriptors中的类
-
- LiteralValueValidator(String) - 类 的构造器org.apache.flink.table.descriptors.LiteralValueValidator
-
- LN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- loadClass(String, ClassLoader) - 类 中的静态方法org.apache.flink.table.utils.EncodingUtils
-
- loadClass(String) - 类 中的静态方法org.apache.flink.table.utils.EncodingUtils
-
- LOCAL_DATE() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API LocalDate type.
- LOCAL_DATE_TIME() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API LocalDateTime type.
- LOCAL_TIME() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API LocalTime type.
- LOCAL_TIME - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- LOCAL_TIMESTAMP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- LocalZonedTimestampType - 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) - 类 的构造器org.apache.flink.table.types.logical.LocalZonedTimestampType
-
Internal constructor that allows attaching additional metadata about time attribute
properties.
- LocalZonedTimestampType(boolean, int) - 类 的构造器org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- LocalZonedTimestampType(int) - 类 的构造器org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- LocalZonedTimestampType() - 类 的构造器org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- LOG - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- LOG10 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- LOG2 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- logicalType - 类 中的变量org.apache.flink.table.types.DataType
-
- LogicalType - org.apache.flink.table.types.logical中的类
-
A logical type that describes the data type of a value.
- LogicalType(boolean, LogicalTypeRoot) - 类 的构造器org.apache.flink.table.types.logical.LogicalType
-
- LogicalTypeCasts - org.apache.flink.table.types.logical.utils中的类
-
- LogicalTypeChecks - org.apache.flink.table.types.logical.utils中的类
-
Utilities for checking
LogicalType
and avoiding a lot of type casting and repetitive work.
- LogicalTypeDataTypeConverter - org.apache.flink.table.types.utils中的类
-
- LogicalTypeDefaultVisitor<R> - org.apache.flink.table.types.logical.utils中的类
-
- LogicalTypeDefaultVisitor() - 类 的构造器org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- LogicalTypeDuplicator - org.apache.flink.table.types.logical.utils中的类
-
- LogicalTypeDuplicator() - 类 的构造器org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- LogicalTypeFamily - org.apache.flink.table.types.logical中的枚举
-
An enumeration of logical type families for clustering
LogicalTypeRoot
s into categories.
- LogicalTypeGeneralization - org.apache.flink.table.types.logical.utils中的类
-
Utilities for finding a common, more general
LogicalType
for a given set of types.
- LogicalTypeParser - org.apache.flink.table.types.logical.utils中的类
-
- LogicalTypeParser() - 类 的构造器org.apache.flink.table.types.logical.utils.LogicalTypeParser
-
- LogicalTypeRoot - org.apache.flink.table.types.logical中的枚举
-
An enumeration of logical type roots containing static information about logical data types.
- LogicalTypeUtils - org.apache.flink.table.types.logical.utils中的类
-
- LogicalTypeVisitor<R> - org.apache.flink.table.types.logical中的接口
-
- LONG() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API long or SQL BIGINT type.
- LookupableTableSource<T> - org.apache.flink.table.sources中的接口
-
A
TableSource
which supports for lookup accessing via key column(s).
- lookupDataType(String) - 接口 中的方法org.apache.flink.table.catalog.DataTypeLookup
-
Lookup a type by a fully or partially defined name.
- lookupDataType(UnresolvedIdentifier) - 接口 中的方法org.apache.flink.table.catalog.DataTypeLookup
-
Lookup a type by an unresolved identifier.
- LOWER - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- LPAD - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- LTRIM - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- parameter(String, String) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of literal type.
- parameter(TypeInformation<?>, String) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of literal type.
- parameter(boolean) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of BOOLEAN type.
- parameter(double) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of DOUBLE type.
- parameter(float) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of FLOAT type.
- parameter(int) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of INT type.
- parameter(String) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of VARCHAR type.
- parameter(long) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of BIGINT type.
- parameter(byte) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of TINYINT type.
- parameter(short) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of SMALLINT type.
- parameter(BigDecimal) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of DECIMAL type.
- parameter(ClassInstance) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of a class instance (i.e. a Java object with a public
constructor).
- parameterNames - 类 中的变量org.apache.flink.table.types.extraction.utils.ExtractionUtils.AssigningConstructor
-
- parameterString(String) - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Adds a constructor parameter value of literal type.
- parse(String, ClassLoader) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeParser
-
Parses a type string.
- parse(String) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeParser
-
Parses a type string.
- PartitionableTableSink - org.apache.flink.table.sinks中的接口
-
- PartitionableTableSource - org.apache.flink.table.sources中的接口
-
- PartitionAlreadyExistsException - org.apache.flink.table.catalog.exceptions中的异常错误
-
Exception for trying to create a partition that already exists.
- PartitionAlreadyExistsException(String, ObjectPath, CatalogPartitionSpec) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.PartitionAlreadyExistsException
-
- PartitionAlreadyExistsException(String, ObjectPath, CatalogPartitionSpec, Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.PartitionAlreadyExistsException
-
- partitionExists(ObjectPath, CatalogPartitionSpec) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Check whether a partition exists or not.
- PartitionNotExistException - org.apache.flink.table.catalog.exceptions中的异常错误
-
Exception for operation on a partition that doesn't exist.
- PartitionNotExistException(String, ObjectPath, CatalogPartitionSpec) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.PartitionNotExistException
-
- PartitionNotExistException(String, ObjectPath, CatalogPartitionSpec, Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.PartitionNotExistException
-
- PartitionSpecInvalidException - 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) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.PartitionSpecInvalidException
-
- PartitionSpecInvalidException(String, List<String>, ObjectPath, CatalogPartitionSpec, Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.PartitionSpecInvalidException
-
- path(String) - 类 中的方法org.apache.flink.table.descriptors.FileSystem
-
Sets the path to a file or directory in a file system.
- PI - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- PLUS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- POSITION - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- POWER - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.BigIntType
-
- PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.IntType
-
- PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.SmallIntType
-
- PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.TinyIntType
-
- PreserveWatermarks - org.apache.flink.table.sources.wmstrategies中的类
-
A strategy which indicates the watermarks should be preserved from the underlying datastream.
- PreserveWatermarks() - 类 的构造器org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
-
- primaryKey(String, List<String>) - 类 中的静态方法org.apache.flink.table.api.constraints.UniqueConstraint
-
Creates a non enforced ConstraintType#PRIMARY_KEY
constraint.
- primaryKey(String...) - 类 中的方法org.apache.flink.table.api.TableSchema.Builder
-
Creates a primary key constraint for a set of given columns.
- primaryKey(String, String[]) - 类 中的方法org.apache.flink.table.api.TableSchema.Builder
-
Creates a primary key constraint for a set of given columns.
- PRIMITIVE_ARRAY(TypeInformation<?>) - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Generates type information for an array consisting of Java primitive elements.
- proctime() - 类 中的方法org.apache.flink.table.descriptors.Schema
-
Specifies the previously defined field as a processing-time attribute.
- PROCTIME - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- PROCTIME_BATCH_MARKER - 类 中的静态变量org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
已过时。
- PROCTIME_INDICATOR - 类 中的静态变量org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
已过时。
- PROCTIME_STREAM_MARKER - 类 中的静态变量org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
已过时。
- ProjectableTableSource<T> - org.apache.flink.table.sources中的接口
-
Adds support for projection push-down to a
TableSource
.
- projectFields(int[]) - 接口 中的方法org.apache.flink.table.sources.ProjectableTableSource
-
Creates a copy of the
TableSource
that projects its output to the given field indexes.
- projectNestedFields(int[], String[][]) - 接口 中的方法org.apache.flink.table.sources.NestedFieldsProjectableTableSource
-
Creates a copy of the
TableSource
that projects its output to the given field indexes.
- put(K, V) - 类 中的方法org.apache.flink.table.api.dataview.MapView
-
Inserts a value for the given key into the map view.
- putAll(Map<K, V>) - 类 中的方法org.apache.flink.table.api.dataview.MapView
-
Inserts all mappings from the specified map to this map view.
- putBoolean(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds a boolean under the given key.
- putCharacter(String, char) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds a character under the given key.
- putClass(String, Class<?>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds a class under the given key.
- putIndexedFixedProperties(String, List<String>, List<List<String>>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds an indexed sequence of properties (with sub-properties) under a common key.
- putIndexedOptionalProperties(String, List<String>, List<List<String>>) - 类 中的方法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>>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds an indexed mapping of properties under a common key.
- putInt(String, int) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds an integer under the given key.
- putLong(String, long) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds a long under the given key.
- putMemorySize(String, MemorySize) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds a Flink MemorySize
under the given key.
- putProperties(Map<String, String>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds a set of properties.
- putProperties(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds a set of descriptor properties.
- putPropertiesWithPrefix(String, Map<String, String>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds a properties map by appending the given prefix to element keys with a dot.
- putString(String, String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds a string under the given key.
- putTableSchema(String, TableSchema) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Adds a table schema under the given key.
- PythonEnv - org.apache.flink.table.functions.python中的类
-
Python execution environments.
- PythonEnv(PythonEnv.ExecType) - 类 的构造器org.apache.flink.table.functions.python.PythonEnv
-
- PythonEnv.ExecType - org.apache.flink.table.functions.python中的枚举
-
The Execution type specifies how to execute the Python function.
- PythonFunction - org.apache.flink.table.functions.python中的接口
-
The base interface of a wrapper of a Python function.
- PythonFunctionInfo - org.apache.flink.table.functions.python中的类
-
PythonFunctionInfo contains the execution information of a Python function, such as:
the actual Python function, the input arguments, etc.
- PythonFunctionInfo(PythonFunction, Object[]) - 类 的构造器org.apache.flink.table.functions.python.PythonFunctionInfo
-
- ScalarFunction - org.apache.flink.table.functions中的类
-
Base class for a user-defined scalar function.
- ScalarFunction() - 类 的构造器org.apache.flink.table.functions.ScalarFunction
-
- ScalarFunctionDefinition - org.apache.flink.table.functions中的类
-
The function definition of an user-defined scalar function.
- ScalarFunctionDefinition(String, ScalarFunction) - 类 的构造器org.apache.flink.table.functions.ScalarFunctionDefinition
-
- Schema - org.apache.flink.table.descriptors中的类
-
Describes a schema of a table.
- Schema() - 类 的构造器org.apache.flink.table.descriptors.Schema
-
- SCHEMA - 类 中的静态变量org.apache.flink.table.descriptors.Schema
-
- schema(TableSchema) - 类 中的方法org.apache.flink.table.descriptors.Schema
-
Sets the schema with field names and the types.
- SCHEMA_DATA_TYPE - 类 中的静态变量org.apache.flink.table.descriptors.Schema
-
- SCHEMA_FROM - 类 中的静态变量org.apache.flink.table.descriptors.Schema
-
- SCHEMA_NAME - 类 中的静态变量org.apache.flink.table.descriptors.Schema
-
- SCHEMA_PROCTIME - 类 中的静态变量org.apache.flink.table.descriptors.Schema
-
- SCHEMA_TYPE - 类 中的静态变量org.apache.flink.table.descriptors.Schema
-
- SECOND() - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Resolution in seconds with 6 digits for fractional seconds by default.
- SECOND(int) - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Resolution in seconds and (possibly) fractional seconds.
- sequence(ArgumentTypeStrategy...) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a function signature like
f(STRING, NUMERIC)
using a sequence of
ArgumentTypeStrategy
s.
- sequence(String[], ArgumentTypeStrategy[]) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a named function signature like
f(s STRING, n NUMERIC)
using a sequence
of
ArgumentTypeStrategy
s.
- SequenceInputTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
-
Strategy for inferring and validating a function signature like
f(STRING, NUMERIC)
or
f(s STRING, n NUMERIC)
using a sequence of
ArgumentTypeStrategy
s.
- SequenceInputTypeStrategy(List<? extends ArgumentTypeStrategy>, List<String>) - 类 的构造器org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
-
- SerializationSchemaFactory<T> - org.apache.flink.table.factories中的接口
-
Factory for creating configured instances of SerializationSchema
.
- serialize(ListView<T>, DataOutputView) - 类 中的方法org.apache.flink.table.dataview.ListViewSerializer
-
- serialize(MapView<K, V>, DataOutputView) - 类 中的方法org.apache.flink.table.dataview.MapViewSerializer
-
- serialize(Map<K, V>, DataOutputView) - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializer
-
- serialize(Object, DataOutputView) - 类 中的方法org.apache.flink.table.dataview.NullSerializer
-
- setAvgLen(Double) - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats.Builder
-
- setCollector(Collector<T>) - 类 中的方法org.apache.flink.table.functions.TableFunction
-
Internal use.
- setExpectedArguments(List<DataType>) - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- setFinal(boolean) - 类 中的方法org.apache.flink.table.types.logical.StructuredType.Builder
-
- setInstantiable(boolean) - 类 中的方法org.apache.flink.table.types.logical.StructuredType.Builder
-
- setMax(Comparable<?>) - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats.Builder
-
- setMaxLen(Integer) - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats.Builder
-
- setMin(Comparable<?>) - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats.Builder
-
- setNdv(Long) - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats.Builder
-
- setNullable(boolean) - 类 中的方法org.apache.flink.table.types.logical.StructuredType.Builder
-
- setNullCount(Long) - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats.Builder
-
- setNullSerializer(boolean) - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- setNullSerializer(boolean) - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- setOverwrite(boolean) - 接口 中的方法org.apache.flink.table.sinks.OverwritableTableSink
-
Configures whether the insert should overwrite existing data or not.
- setStaticPartition(Map<String, String>) - 接口 中的方法org.apache.flink.table.sinks.PartitionableTableSink
-
Sets the static partition into the
TableSink
.
- SHA1 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SHA2 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SHA224 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SHA256 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SHA384 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SHA512 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SHORT() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API short or SQL SMALLINT type.
- SIGN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- Signature - org.apache.flink.table.types.inference中的类
-
Describes the signature of a function.
- Signature.Argument - org.apache.flink.table.types.inference中的类
-
Representation of a single argument in a signature.
- SIMILAR - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SimplePythonFunction - org.apache.flink.table.functions.python中的类
-
- SimplePythonFunction(byte[], PythonEnv) - 类 的构造器org.apache.flink.table.functions.python.SimplePythonFunction
-
- SIN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SINH - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SMALLINT() - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Data type of a 2-byte signed integer with values from -32,768 to 32,767.
- SmallIntType - org.apache.flink.table.types.logical中的类
-
Logical type of a 2-byte signed integer with values from -32,768 to 32,767.
- SmallIntType(boolean) - 类 的构造器org.apache.flink.table.types.logical.SmallIntType
-
- SmallIntType() - 类 的构造器org.apache.flink.table.types.logical.SmallIntType
-
- snapshotConfiguration() - 类 中的方法org.apache.flink.table.dataview.ListViewSerializer
-
- snapshotConfiguration() - 类 中的方法org.apache.flink.table.dataview.MapViewSerializer
-
- snapshotConfiguration() - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializer
-
- snapshotConfiguration() - 类 中的方法org.apache.flink.table.dataview.NullSerializer
-
- SQL_DATE() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API SQL date or SQL DATE type.
- SQL_TIME() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API SQL time or SQL TIME type.
- SQL_TIMESTAMP() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API SQL timestamp or SQL TIMESTAMP type.
- SQRT - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- STDDEV_POP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- STDDEV_SAMP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- STREAM_RECORD_TIMESTAMP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- StreamTableDescriptorValidator - org.apache.flink.table.descriptors中的类
-
Validator for StreamTableDescriptor
.
- StreamTableDescriptorValidator(boolean, boolean, boolean) - 类 的构造器org.apache.flink.table.descriptors.StreamTableDescriptorValidator
-
- STRING() - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Data type of a variable-length character string with defined maximum length.
- STRING() - 类 中的静态方法org.apache.flink.table.api.Types
-
已过时。
Returns type information for a Table API string or SQL VARCHAR type.
- StructuredAttribute(String, LogicalType, String) - 类 的构造器org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- StructuredAttribute(String, LogicalType) - 类 的构造器org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- StructuredType - org.apache.flink.table.types.logical中的类
-
Logical type of a user-defined object structured type.
- StructuredType.Builder - org.apache.flink.table.types.logical中的类
-
- StructuredType.StructuredAttribute - org.apache.flink.table.types.logical中的类
-
- StructuredType.StructuredComparision - org.apache.flink.table.types.logical中的枚举
-
Defines equality properties for scalar evaluation.
- SUBSTRING - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SUM - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SUM0 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- superType(StructuredType) - 类 中的方法org.apache.flink.table.types.logical.StructuredType.Builder
-
- supportedFormatProperties() - 类 中的方法org.apache.flink.table.factories.TableFormatFactoryBase
-
Format specific supported properties.
- supportedProperties() - 接口 中的方法org.apache.flink.table.factories.TableFactory
-
List of property keys that this factory can handle.
- supportedProperties() - 接口 中的方法org.apache.flink.table.factories.TableFormatFactory
-
List of format property keys that this factory can handle.
- supportedProperties() - 类 中的方法org.apache.flink.table.factories.TableFormatFactoryBase
-
- supportedProperties() - 类 中的方法org.apache.flink.table.module.CoreModuleFactory
-
- supportsExplicitCast(LogicalType, LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeCasts
-
Returns whether the source type can be casted to the target type.
- supportsImplicitCast(LogicalType, LogicalType) - 类 中的静态方法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<?>) - 类 中的方法org.apache.flink.table.types.logical.ArrayType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.BigIntType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.BinaryType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.BooleanType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.CharType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.DateType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.DayTimeIntervalType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.DecimalType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.DistinctType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.DoubleType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.FloatType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.IntType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- supportsInputConversion(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<?>) - 类 中的方法org.apache.flink.table.types.logical.MapType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.MultisetType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.NullType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.RawType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.SmallIntType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.SymbolType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.TimestampType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.TimeType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.TinyIntType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.TypeInformationRawType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.VarBinaryType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.VarCharType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.YearMonthIntervalType
-
- supportsInputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.ZonedTimestampType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.ArrayType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.BigIntType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.BinaryType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.BooleanType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.CharType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.DateType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.DayTimeIntervalType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.DecimalType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.DistinctType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.DoubleType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.FloatType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.IntType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- supportsOutputConversion(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<?>) - 类 中的方法org.apache.flink.table.types.logical.MapType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.MultisetType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.NullType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.RawType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.RowType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.SmallIntType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.StructuredType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.SymbolType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.TimestampType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.TimeType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.TinyIntType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.TypeInformationRawType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.VarBinaryType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.VarCharType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.YearMonthIntervalType
-
- supportsOutputConversion(Class<?>) - 类 中的方法org.apache.flink.table.types.logical.ZonedTimestampType
-
- supportsSchemaDerivation() - 接口 中的方法org.apache.flink.table.factories.TableFormatFactory
-
Flag to indicate if the given format supports deriving information from a schema.
- supportsSchemaDerivation() - 类 中的方法org.apache.flink.table.factories.TableFormatFactoryBase
-
- SurroundingInfo(String, FunctionDefinition, TypeInference, int, int) - 类 的构造器org.apache.flink.table.types.inference.TypeInferenceUtil.SurroundingInfo
-
- SymbolType<T extends TableSymbol> - org.apache.flink.table.types.logical中的类
-
Logical type for representing symbol values.
- SymbolType(boolean, Class<T>) - 类 的构造器org.apache.flink.table.types.logical.SymbolType
-
- SymbolType(Class<T>) - 类 的构造器org.apache.flink.table.types.logical.SymbolType
-
- TABLE_SCHEMA_DATA_TYPE - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
-
- TABLE_SCHEMA_EXPR - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
-
- TABLE_SCHEMA_NAME - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
-
- TABLE_SCHEMA_TYPE - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
-
- TableAggregateFunction<T,ACC> - org.apache.flink.table.functions中的类
-
Base class for user-defined table aggregates.
- TableAggregateFunction() - 类 的构造器org.apache.flink.table.functions.TableAggregateFunction
-
- TableAggregateFunction.RetractableCollector<T> - org.apache.flink.table.functions中的接口
-
Collects a record and forwards it.
- TableAggregateFunctionDefinition - org.apache.flink.table.functions中的类
-
The function definition of an user-defined table aggregate function.
- TableAggregateFunctionDefinition(String, TableAggregateFunction<?, ?>, TypeInformation<?>, TypeInformation<?>) - 类 的构造器org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
- TableAlreadyExistException - org.apache.flink.table.catalog.exceptions中的异常错误
-
Exception for trying to create a table (or view) that already exists.
- TableAlreadyExistException(String, ObjectPath) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.TableAlreadyExistException
-
- TableAlreadyExistException(String, ObjectPath, Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.TableAlreadyExistException
-
- TableColumn - org.apache.flink.table.api中的类
-
A table column represents a table column's structure with
column name, column data type and computation expression(if it is a computed column).
- TableConnectorUtil - org.apache.flink.table.util中的类
-
- TableConnectorUtil() - 类 的构造器org.apache.flink.table.util.TableConnectorUtil
-
已过时。
- TableConnectorUtils - org.apache.flink.table.utils中的类
-
Utilities for table sources and sinks.
- TableDescriptor<D extends TableDescriptor<D>> - org.apache.flink.table.descriptors中的类
-
Describes a table consisting of a connector (in a given update mode) and a format.
- TableDescriptor(ConnectorDescriptor) - 类 的构造器org.apache.flink.table.descriptors.TableDescriptor
-
- TableException - org.apache.flink.table.api中的异常错误
-
General Exception for all errors during table handling.
- TableException(String, Throwable) - 异常错误 的构造器org.apache.flink.table.api.TableException
-
- TableException(String) - 异常错误 的构造器org.apache.flink.table.api.TableException
-
- tableExists(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
-
Check if a table or view exists in this catalog.
- TableFactory - org.apache.flink.table.factories中的接口
-
A factory to create different table-related instances from string-based properties.
- TableFactoryService - org.apache.flink.table.factories中的类
-
Unified class to search for a
TableFactory
of provided type and properties.
- TableFactoryService() - 类 的构造器org.apache.flink.table.factories.TableFactoryService
-
- TableFormatFactory<T> - org.apache.flink.table.factories中的接口
-
A factory to create configured table format instances based on string-based properties.
- TableFormatFactoryBase<T> - org.apache.flink.table.factories中的类
-
- TableFormatFactoryBase(String, int, boolean) - 类 的构造器org.apache.flink.table.factories.TableFormatFactoryBase
-
- TableFunction<T> - org.apache.flink.table.functions中的类
-
Base class for a user-defined table function (UDTF).
- TableFunction() - 类 的构造器org.apache.flink.table.functions.TableFunction
-
- TableFunctionDefinition - org.apache.flink.table.functions中的类
-
The function definition of an user-defined table function.
- TableFunctionDefinition(String, TableFunction<?>, TypeInformation<?>) - 类 的构造器org.apache.flink.table.functions.TableFunctionDefinition
-
- TableNotExistException - org.apache.flink.table.api中的异常错误
-
Exception for an operation on a nonexistent table.
- TableNotExistException(String, String) - 异常错误 的构造器org.apache.flink.table.api.TableNotExistException
-
- TableNotExistException(String, String, Throwable) - 异常错误 的构造器org.apache.flink.table.api.TableNotExistException
-
- TableNotExistException - org.apache.flink.table.catalog.exceptions中的异常错误
-
Exception for trying to operate on a table (or view) that doesn't exist.
- TableNotExistException(String, ObjectPath) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.TableNotExistException
-
- TableNotExistException(String, ObjectPath, Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.TableNotExistException
-
- TableNotPartitionedException - org.apache.flink.table.catalog.exceptions中的异常错误
-
Exception for trying to operate partition on a non-partitioned table.
- TableNotPartitionedException(String, ObjectPath) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.TableNotPartitionedException
-
- TableNotPartitionedException(String, ObjectPath, Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.TableNotPartitionedException
-
- TablePartitionedException - org.apache.flink.table.catalog.exceptions中的异常错误
-
Exception for trying to operate non-partitioned on a partitioned table.
- TablePartitionedException(String, ObjectPath) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.TablePartitionedException
-
- TablePartitionedException(String, ObjectPath, Throwable) - 异常错误 的构造器org.apache.flink.table.catalog.exceptions.TablePartitionedException
-
- TableSchema - org.apache.flink.table.api中的类
-
A table schema that represents a table's structure with field names and data types.
- TableSchema(String[], TypeInformation<?>[]) - 类 的构造器org.apache.flink.table.api.TableSchema
-
- TableSchema.Builder - org.apache.flink.table.api中的类
-
- TableSchemaUtils - org.apache.flink.table.utils中的类
-
- TableSchemaUtils() - 类 的构造器org.apache.flink.table.utils.TableSchemaUtils
-
- TableSink<T> - org.apache.flink.table.sinks中的接口
-
A
TableSink
specifies how to emit a table to an external
system or location.
- TableSinkBase<T> - org.apache.flink.table.sinks中的类
-
- TableSinkBase() - 类 的构造器org.apache.flink.table.sinks.TableSinkBase
-
- TableSinkFactory<T> - 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> - org.apache.flink.table.sources中的接口
-
- TableSourceFactory<T> - 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 - org.apache.flink.table.sources中的类
-
- TableStats - org.apache.flink.table.plan.stats中的类
-
Table statistics.
- TableStats(long) - 类 的构造器org.apache.flink.table.plan.stats.TableStats
-
- TableStats(long, Map<String, ColumnStats>) - 类 的构造器org.apache.flink.table.plan.stats.TableStats
-
- TableSymbol - org.apache.flink.table.expressions中的接口
-
The base interface for all table symbols.
- TAN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TANH - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TEMPORAL_OVERLAPS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TemporalTableFunction - org.apache.flink.table.functions中的类
-
Class representing temporal table function over some history table.
- TemporalTableFunction() - 类 的构造器org.apache.flink.table.functions.TemporalTableFunction
-
- ThreadLocalCache<K,V> - org.apache.flink.table.utils中的类
-
Provides a thread local cache with a maximum cache size per thread.
- ThreadLocalCache() - 类 的构造器org.apache.flink.table.utils.ThreadLocalCache
-
- ThreadLocalCache(int) - 类 的构造器org.apache.flink.table.utils.ThreadLocalCache
-
- TIME(int) - 类 中的静态方法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() - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Data type of a time WITHOUT time zone TIME
with no fractional seconds by default.
- TIME_ATTRIBUTES - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TimeIndicatorTypeInfo - org.apache.flink.table.typeutils中的类
-
- TimeIndicatorTypeInfo(boolean) - 类 的构造器org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
已过时。
- TimeIntervalTypeInfo<T> - org.apache.flink.table.typeutils中的类
-
- TimeIntervalUnit - org.apache.flink.table.expressions中的枚举
-
Units for working with time intervals.
- TimePointUnit - org.apache.flink.table.expressions中的枚举
-
Units for working with points in time.
- TIMES - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TIMESTAMP(int) - 类 中的静态方法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() - 类 中的静态方法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 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TIMESTAMP_WITH_LOCAL_TIME_ZONE(int) - 类 中的静态方法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() - 类 中的静态方法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) - 类 中的静态方法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() - 类 中的静态方法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 - org.apache.flink.table.sources.tsextractors中的类
-
Provides an expression to extract the timestamp for a rowtime attribute.
- TimestampExtractor() - 类 的构造器org.apache.flink.table.sources.tsextractors.TimestampExtractor
-
- TimestampExtractorUtils - org.apache.flink.table.sources.tsextractors中的类
-
- TimestampKind - org.apache.flink.table.types.logical中的枚举
-
Internal timestamp kind for attaching time attribute metadata to timestamps with or without a
time zone.
- timestampsFromExtractor(TimestampExtractor) - 类 中的方法org.apache.flink.table.descriptors.Rowtime
-
Sets a custom timestamp extractor to be used for the rowtime attribute.
- timestampsFromField(String) - 类 中的方法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() - 类 中的方法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 - 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) - 类 的构造器org.apache.flink.table.types.logical.TimestampType
-
Internal constructor that allows attaching additional metadata about time attribute
properties.
- TimestampType(boolean, int) - 类 的构造器org.apache.flink.table.types.logical.TimestampType
-
- TimestampType(int) - 类 的构造器org.apache.flink.table.types.logical.TimestampType
-
- TimestampType() - 类 的构造器org.apache.flink.table.types.logical.TimestampType
-
- timeToSqlTypes() - 类 中的静态方法org.apache.flink.table.types.inference.TypeTransformations
-
Returns a type transformation that transforms data type to a new data type whose conversion
class is
Timestamp
/
Time
/
Date
if the original data type is TIMESTAMP/TIME/DATE.
- TimeType - 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) - 类 的构造器org.apache.flink.table.types.logical.TimeType
-
- TimeType(int) - 类 的构造器org.apache.flink.table.types.logical.TimeType
-
- TimeType() - 类 的构造器org.apache.flink.table.types.logical.TimeType
-
- TINYINT() - 类 中的静态方法org.apache.flink.table.api.DataTypes
-
Data type of a 1-byte signed integer with values from -128 to 127.
- TinyIntType - org.apache.flink.table.types.logical中的类
-
Logical type of a 1-byte signed integer with values from -128 to 127.
- TinyIntType(boolean) - 类 的构造器org.apache.flink.table.types.logical.TinyIntType
-
- TinyIntType() - 类 的构造器org.apache.flink.table.types.logical.TinyIntType
-
- TO_BASE64 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- toArgumentTypeStrategy() - 类 中的方法org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
- toCatalogProperties() - 类 中的方法org.apache.flink.table.descriptors.CatalogDescriptor
-
Converts this descriptor into a set of catalog properties.
- toClass(Type) - 类 中的静态方法org.apache.flink.table.types.extraction.utils.ExtractionUtils
-
Converts a
Type
to
Class
if possible,
null
otherwise.
- toConnectorProperties() - 类 中的方法org.apache.flink.table.descriptors.ConnectorDescriptor
-
Converts this descriptor into a set of connector properties.
- toConnectorProperties() - 类 中的方法org.apache.flink.table.descriptors.FileSystem
-
- toDataType(TypeInformation<?>) - 类 中的静态方法org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
-
- toDataType(LogicalType) - 类 中的静态方法org.apache.flink.table.types.utils.LogicalTypeDataTypeConverter
-
Returns the data type of a logical type without explicit conversions.
- toFormatProperties() - 类 中的方法org.apache.flink.table.descriptors.FormatDescriptor
-
Converts this descriptor into a set of format properties.
- toLegacyTypeInfo(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
-
- toLogicalType(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.LogicalTypeDataTypeConverter
-
Returns the logical type of a data type.
- toModuleProperties() - 类 中的方法org.apache.flink.table.descriptors.CoreModuleDescriptor
-
- toModuleProperties() - 类 中的方法org.apache.flink.table.descriptors.ModuleDescriptor
-
Converts this descriptor into a set of module properties.
- toNullable() - 类 中的静态方法org.apache.flink.table.types.inference.TypeTransformations
-
Returns a type transformation that transforms data type to nullable data type but keeps
other information unchanged.
- toObjectPath() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
-
- toProperties() - 接口 中的方法org.apache.flink.table.catalog.CatalogTable
-
Return a property map for table factory discovery purpose.
- toProperties() - 类 中的方法org.apache.flink.table.descriptors.CatalogDescriptor
-
- toProperties() - 类 中的方法org.apache.flink.table.descriptors.ClassInstance
-
Converts this descriptor into a set of properties.
- toProperties() - 类 中的方法org.apache.flink.table.descriptors.ConnectorDescriptor
-
- toProperties() - 接口 中的方法org.apache.flink.table.descriptors.Descriptor
-
Converts this descriptor into a set of properties.
- toProperties() - 类 中的方法org.apache.flink.table.descriptors.FormatDescriptor
-
- toProperties() - 类 中的方法org.apache.flink.table.descriptors.FunctionDescriptor
-
Converts this descriptor into a set of properties.
- toProperties() - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
- toProperties() - 类 中的方法org.apache.flink.table.descriptors.ModuleDescriptor
-
- toProperties() - 类 中的方法org.apache.flink.table.descriptors.Rowtime
-
Converts this descriptor into a set of properties.
- toProperties() - 类 中的方法org.apache.flink.table.descriptors.Schema
-
Converts this descriptor into a set of properties.
- toProperties() - 类 中的方法org.apache.flink.table.descriptors.TableDescriptor
-
Converts this descriptor into a set of properties.
- toProperties() - 类 中的方法org.apache.flink.table.sources.tsextractors.TimestampExtractor
-
This method is a default implementation that uses java serialization and it is discouraged.
- toProperties() - 类 中的方法org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
-
- toProperties() - 类 中的方法org.apache.flink.table.sources.wmstrategies.WatermarkStrategy
-
This method is a default implementation that uses java serialization and it is discouraged.
- toRowDataType() - 类 中的方法org.apache.flink.table.api.TableSchema
-
- toRowType() - 类 中的方法org.apache.flink.table.api.TableSchema
-
- toString() - 类 中的方法org.apache.flink.table.api.DataTypes.Resolution
-
- toString() - 类 中的方法org.apache.flink.table.api.TableSchema
-
- toString() - 类 中的方法org.apache.flink.table.api.WatermarkSpec
-
- toString() - 类 中的方法org.apache.flink.table.catalog.CatalogPartitionSpec
-
- toString() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
-
- toString() - 类 中的方法org.apache.flink.table.catalog.ObjectPath
-
- toString() - 类 中的方法org.apache.flink.table.catalog.UnresolvedIdentifier
-
- toString() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
-
- toString() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
-
- toString() - 类 中的方法org.apache.flink.table.descriptors.DescriptorBase
-
- toString() - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
- toString(String) - 类 中的静态方法org.apache.flink.table.descriptors.DescriptorProperties
-
- toString(String, String) - 类 中的静态方法org.apache.flink.table.descriptors.DescriptorProperties
-
- toString(Map<String, String>) - 类 中的静态方法org.apache.flink.table.descriptors.DescriptorProperties
-
- toString() - 类 中的方法org.apache.flink.table.expressions.CallExpression
-
- toString() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
-
- toString() - 类 中的方法org.apache.flink.table.expressions.TypeLiteralExpression
-
- toString() - 类 中的方法org.apache.flink.table.expressions.ValueLiteralExpression
-
- toString() - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
-
- toString() - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition
-
- toString() - 类 中的方法org.apache.flink.table.functions.FunctionIdentifier
-
- toString() - 类 中的方法org.apache.flink.table.functions.ScalarFunctionDefinition
-
- toString() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
- toString() - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
-
- toString() - 类 中的方法org.apache.flink.table.functions.UserDefinedFunction
-
Returns the name of the UDF that is used for plan explanation and logging.
- toString() - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
-
- toString() - 类 中的方法org.apache.flink.table.plan.stats.TableStats
-
- toString() - 类 中的方法org.apache.flink.table.types.DataType
-
- toString() - 类 中的方法org.apache.flink.table.types.logical.LogicalType
-
- toString() - 类 中的方法org.apache.flink.table.typeutils.InternalTypeInfo
-
- toString() - 类 中的方法org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
已过时。
- toString() - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
已过时。
- toTypeStrategy() - 类 中的方法org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
- transform(DataType) - 类 中的方法org.apache.flink.table.types.inference.transforms.DataTypeConversionClassTransformation
-
- transform(DataType) - 类 中的方法org.apache.flink.table.types.inference.transforms.LegacyDecimalTypeTransformation
-
- transform(DataType) - 类 中的方法org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
-
- transform(DataType) - 接口 中的方法org.apache.flink.table.types.inference.TypeTransformation
-
Transforms the given data type to a different data type.
- transform(DataType, TypeTransformation...) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
-
Transforms the given data type (can be nested) to a different data type using the given
transformations.
- transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - 类 中的方法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>) - 类 中的方法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 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TRUNCATE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TYPE - 类 中的静态变量org.apache.flink.table.descriptors.LiteralValueValidator
-
- TypeConversions - org.apache.flink.table.types.utils中的类
-
- typedArguments(List<DataType>) - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
- typedArguments(List<DataType>) - 类 中的方法org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets the list of argument types for specifying a fixed, not overloaded, not vararg input
signature explicitly.
- TypeInference - org.apache.flink.table.types.inference中的类
-
Provides logic for the type inference of function calls.
- TypeInference.Builder - org.apache.flink.table.types.inference中的类
-
- TypeInferenceUtil - org.apache.flink.table.types.inference中的类
-
Utility for performing type inference.
- TypeInferenceUtil.Result - org.apache.flink.table.types.inference中的类
-
The result of a type inference run.
- TypeInferenceUtil.SurroundingInfo - org.apache.flink.table.types.inference中的类
-
Information what the outer world (i.e. an outer wrapping call) expects from the current
function call.
- TypeInformationRawType<T> - org.apache.flink.table.types.logical中的类
-
Placeholder type of an arbitrary serialized type backed by TypeInformation
.
- TypeInformationRawType(boolean, TypeInformation<T>) - 类 的构造器org.apache.flink.table.types.logical.TypeInformationRawType
-
- TypeInformationRawType(TypeInformation<T>) - 类 的构造器org.apache.flink.table.types.logical.TypeInformationRawType
-
- TypeInformationRawType() - 类 的构造器org.apache.flink.table.types.logical.TypeInformationRawType
-
- TypeLiteralExpression - org.apache.flink.table.expressions中的类
-
Expression that wraps
DataType
as a literal.
- TypeLiteralExpression(DataType) - 类 的构造器org.apache.flink.table.expressions.TypeLiteralExpression
-
- TypeMappingUtils - org.apache.flink.table.utils中的类
-
- Types - org.apache.flink.table.api中的类
-
- TypeStrategies - org.apache.flink.table.types.inference中的类
-
Strategies for inferring an output or accumulator data type of a function call.
- TypeStrategy - org.apache.flink.table.types.inference中的接口
-
Strategy for inferring the data type of a function call.
- TypeStringUtils - org.apache.flink.table.utils中的类
-
- TypeStringUtils() - 类 的构造器org.apache.flink.table.utils.TypeStringUtils
-
已过时。
- TypeTransformation - org.apache.flink.table.types.inference中的接口
-
Transforms one data type to another.
- TypeTransformations - org.apache.flink.table.types.inference中的类
-
Transformations for transforming one data type to another.
- TypeTransformations() - 类 的构造器org.apache.flink.table.types.inference.TypeTransformations
-
- validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.CatalogDescriptorValidator
-
- validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
- validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.CoreModuleDescriptorValidator
-
- validate(DescriptorProperties) - 接口 中的方法org.apache.flink.table.descriptors.DescriptorValidator
-
Performs basic validation such as completeness tests.
- validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.FileSystemValidator
-
- validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.FormatDescriptorValidator
-
- validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.FunctionDescriptorValidator
-
- validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.HierarchyDescriptorValidator
-
- validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.ModuleDescriptorValidator
-
- validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.StreamTableDescriptorValidator
-
- validateArgumentFields(TypeInformation<?>[]) - 接口 中的方法org.apache.flink.table.sources.FieldComputer
-
Validates that the fields that the expression references have the correct types.
- validateArray(String, Consumer<String>, int) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates an array of values.
- validateArray(String, Consumer<String>, int, int) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates an array of values.
- validateBigDecimal(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a big decimal property.
- validateBigDecimal(String, boolean, BigDecimal, BigDecimal) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a big decimal property.
- validateBoolean(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates that a boolean value is present under the given key.
- validateByte(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a byte property.
- validateByte(String, boolean, byte) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a byte property.
- validateByte(String, boolean, byte, byte) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a byte property.
- validateDataType(String, String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a data type property.
- validateDouble(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a double property.
- validateDouble(String, boolean, double) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a double property.
- validateDouble(String, boolean, double, double) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a double property.
- validateDuration(String, boolean, int) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a Java Duration
.
- validateDuration(String, boolean, int, long) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a Java Duration
.
- validateDuration(String, boolean, int, long, long) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a Java Duration
.
- validateEnum(String, boolean, Map<String, Consumer<String>>) - 类 中的方法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>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates an enum property with a set of enum values.
- validateExclusion(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates that the given key is not included in these properties.
- validateFixedIndexedProperties(String, boolean, Map<String, Consumer<String>>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validation for fixed indexed properties.
- validateFloat(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a float property.
- validateFloat(String, boolean, float) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a float property.
- validateFloat(String, boolean, float, float) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a float property.
- validateInt(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates an integer property.
- validateInt(String, boolean, int) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates an integer property.
- validateInt(String, boolean, int, int) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates an integer property.
- validateLong(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates an long property.
- validateLong(String, boolean, long) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates an long property.
- validateLong(String, boolean, long, long) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates an long property.
- validateMemorySize(String, boolean, int) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a Flink MemorySize
.
- validateMemorySize(String, boolean, int, long) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a Flink MemorySize
.
- validateMemorySize(String, boolean, int, long, long) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a Flink MemorySize
.
- validatePrefixExclusion(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates that the given prefix is not included in these properties.
- validateShort(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a short property.
- validateShort(String, boolean, short) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a short property.
- validateShort(String, boolean, short, short) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a short property.
- validateString(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a string property.
- validateString(String, boolean, int) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a string property.
- validateString(String, boolean, int, int) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a string property.
- validateStructuredClass(Class<?>) - 类 中的静态方法org.apache.flink.table.types.extraction.utils.ExtractionUtils
-
Validates the characteristics of a class for a
StructuredType
such as accessibility.
- validateStructuredFieldReadability(Class<?>, Field) - 类 中的静态方法org.apache.flink.table.types.extraction.utils.ExtractionUtils
-
Validates if a field is properly readable either directly or through a getter.
- validateTableSchema(String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a table schema property.
- validateTableSource(TableSource<?>, TableSchema) - 类 中的静态方法org.apache.flink.table.sources.TableSourceValidation
-
Validates a TableSource.
- validateType(String, boolean, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates a type property.
- validateValue(String, String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
-
Validates that a certain value is present under the given key.
- validateWithPrefix(String, DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.ClassInstanceValidator
-
- validateWithPrefix(String, DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.HierarchyDescriptorValidator
-
Performs validation with a prefix for the keys.
- validateWithPrefix(String, DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.LiteralValueValidator
-
- ValidationException - org.apache.flink.table.api中的异常错误
-
Exception for all errors occurring during validation phase.
- ValidationException(String, Throwable) - 异常错误 的构造器org.apache.flink.table.api.ValidationException
-
- ValidationException(String) - 异常错误 的构造器org.apache.flink.table.api.ValidationException
-
- value(boolean) - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
Literal BOOLEAN value.
- value(int) - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
Literal INT value.
- value(double) - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
Literal DOUBLE value.
- value(float) - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
Literal FLOAT value.
- value(String) - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
Literal value either for an explicit VARCHAR type or automatically derived type.
- value(long) - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
Literal BIGINT value.
- value(byte) - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
Literal TINYINT value.
- value(short) - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
Literal SMALLINT value.
- value(BigDecimal) - 类 中的方法org.apache.flink.table.descriptors.LiteralValue
-
Literal DECIMAL value.
- VALUE - 类 中的静态变量org.apache.flink.table.descriptors.LiteralValueValidator
-
- ValueDataTypeConverter - org.apache.flink.table.types.utils中的类
-
Value-based data type extractor that supports extraction of clearly identifiable data types for
input conversion.
- ValueLiteralExpression - org.apache.flink.table.expressions中的类
-
Expression for constant literal values.
- ValueLiteralExpression(Object) - 类 的构造器org.apache.flink.table.expressions.ValueLiteralExpression
-
- ValueLiteralExpression(Object, DataType) - 类 的构造器org.apache.flink.table.expressions.ValueLiteralExpression
-
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.annotation.ExtractionVersion
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.annotation.HintFlag
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.annotation.InputGroup
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.api.constraints.Constraint.ConstraintType
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.catalog.FunctionLanguage
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.expressions.TimeIntervalUnit
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.expressions.TimePointUnit
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.functions.FunctionKind
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.functions.FunctionRequirement
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.functions.python.PythonEnv.ExecType
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.types.logical.LogicalTypeFamily
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.types.logical.LogicalTypeRoot
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.types.logical.StructuredType.StructuredComparision
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.types.logical.TimestampKind
-
返回带有指定名称的该类型的枚举常量。
- valueOf(String) - 枚举 中的静态方法org.apache.flink.table.types.logical.YearMonthIntervalType.YearMonthResolution
-
返回带有指定名称的该类型的枚举常量。
- values() - 枚举 中的静态方法org.apache.flink.table.annotation.ExtractionVersion
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.annotation.HintFlag
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.annotation.InputGroup
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.api.constraints.Constraint.ConstraintType
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 类 中的方法org.apache.flink.table.api.dataview.MapView
-
Returns all the values in the map view.
- values() - 枚举 中的静态方法org.apache.flink.table.catalog.FunctionLanguage
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.expressions.TimeIntervalUnit
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.expressions.TimePointUnit
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.functions.FunctionKind
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.functions.FunctionRequirement
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.functions.python.PythonEnv.ExecType
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.types.logical.LogicalTypeFamily
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.types.logical.LogicalTypeRoot
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.types.logical.StructuredType.StructuredComparision
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.types.logical.TimestampKind
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- values() - 枚举 中的静态方法org.apache.flink.table.types.logical.YearMonthIntervalType.YearMonthResolution
-
按照声明该枚举类型的常量的顺序, 返回
包含这些常量的数组。
- valueType - 类 中的变量org.apache.flink.table.api.dataview.MapView
-
- VAR_POP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- VAR_SAMP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- VARBINARY(int) - 类 中的静态方法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 - org.apache.flink.table.types.logical中的类
-
Logical type of a variable-length binary string (=a sequence of bytes).
- VarBinaryType(boolean, int) - 类 的构造器org.apache.flink.table.types.logical.VarBinaryType
-
- VarBinaryType(int) - 类 的构造器org.apache.flink.table.types.logical.VarBinaryType
-
- VarBinaryType() - 类 的构造器org.apache.flink.table.types.logical.VarBinaryType
-
- VARCHAR(int) - 类 中的静态方法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 - org.apache.flink.table.types.logical中的类
-
Logical type of a variable-length character string.
- VarCharType(boolean, int) - 类 的构造器org.apache.flink.table.types.logical.VarCharType
-
- VarCharType(int) - 类 的构造器org.apache.flink.table.types.logical.VarCharType
-
- VarCharType() - 类 的构造器org.apache.flink.table.types.logical.VarCharType
-
- varyingSequence(ArgumentTypeStrategy...) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a varying function signature like
f(INT, STRING, NUMERIC...)
using a
sequence of
ArgumentTypeStrategy
s.
- varyingSequence(String[], ArgumentTypeStrategy[]) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a varying named function signature like f(i INT, str STRING, num NUMERIC...)
- VaryingSequenceInputTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
-
Strategy for inferring and validating a varying function signature like f(INT, STRING, NUMERIC...)
- VaryingSequenceInputTypeStrategy(List<ArgumentTypeStrategy>, List<String>) - 类 的构造器org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
-
- version - 类 中的变量org.apache.flink.table.types.extraction.utils.DataTypeTemplate
-
- visit(CallExpression) - 类 中的方法org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(ValueLiteralExpression) - 类 中的方法org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(FieldReferenceExpression) - 类 中的方法org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(TypeLiteralExpression) - 类 中的方法org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(Expression) - 类 中的方法org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(CallExpression) - 接口 中的方法org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(ValueLiteralExpression) - 接口 中的方法org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(FieldReferenceExpression) - 接口 中的方法org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(TypeLiteralExpression) - 接口 中的方法org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(Expression) - 接口 中的方法org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(AtomicDataType) - 接口 中的方法org.apache.flink.table.types.DataTypeVisitor
-
- visit(CollectionDataType) - 接口 中的方法org.apache.flink.table.types.DataTypeVisitor
-
- visit(FieldsDataType) - 接口 中的方法org.apache.flink.table.types.DataTypeVisitor
-
- visit(KeyValueDataType) - 接口 中的方法org.apache.flink.table.types.DataTypeVisitor
-
- visit(CharType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(VarCharType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(BooleanType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(BinaryType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(VarBinaryType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(DecimalType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(TinyIntType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(SmallIntType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(IntType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(BigIntType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(FloatType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(DoubleType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(DateType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(TimeType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(TimestampType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(ZonedTimestampType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(LocalZonedTimestampType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(YearMonthIntervalType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(DayTimeIntervalType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(ArrayType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(MultisetType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(MapType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(RowType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(DistinctType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(StructuredType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(NullType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(RawType<?>) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(SymbolType<?>) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(LogicalType) - 接口 中的方法org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(CharType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(VarCharType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(BooleanType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(BinaryType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(VarBinaryType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(DecimalType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(TinyIntType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(SmallIntType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(IntType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(BigIntType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(FloatType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(DoubleType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(DateType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(TimeType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(TimestampType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(ZonedTimestampType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(LocalZonedTimestampType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(YearMonthIntervalType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(DayTimeIntervalType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(ArrayType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(MultisetType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(MapType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(RowType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(DistinctType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(StructuredType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(NullType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(RawType<?>) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(SymbolType<?>) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(LogicalType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(ArrayType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(MultisetType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(MapType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(RowType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(DistinctType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(StructuredType) - 类 中的方法org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(AtomicDataType) - 类 中的方法org.apache.flink.table.types.utils.DataTypeDefaultVisitor
-
- visit(CollectionDataType) - 类 中的方法org.apache.flink.table.types.utils.DataTypeDefaultVisitor
-
- visit(FieldsDataType) - 类 中的方法org.apache.flink.table.types.utils.DataTypeDefaultVisitor
-
- visit(KeyValueDataType) - 类 中的方法org.apache.flink.table.types.utils.DataTypeDefaultVisitor
-