跳过导航链接
A B C D E F G H I J K L M N O P R S T U V W Y Z 

A

ABS - 类 中的静态变量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
 
AbstractDataType<T extends AbstractDataType<T>> - org.apache.flink.table.types中的接口
Highest abstraction that describes the data type of a value in the table ecosystem.
accept(ExpressionVisitor<R>) - 类 中的方法org.apache.flink.table.expressions.AggregateExpression
 
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.SqlCallExpression
 
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
 
accumulate(Object, Object...) - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
accumulate(Object, Object...) - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
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
 
adaptArguments(TypeInference, CallContext, DataType) - 类 中的静态方法org.apache.flink.table.types.inference.TypeInferenceUtil
Adapts the call's argument if necessary.
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.
add(TableColumn) - 类 中的方法org.apache.flink.table.api.TableSchema.Builder
已过时。
Adds a TableColumn to this builder.
addAll(List<T>) - 类 中的方法org.apache.flink.table.api.dataview.ListView
Adds all of the elements of the specified list to this list view.
addContainedKind(RowKind) - 类 中的方法org.apache.flink.table.connector.ChangelogMode.Builder
 
AGG_DECIMAL_PLUS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
Special "+" operator used internally by SumAggFunction to implement SUM aggregation on a Decimal type.
AGG_DECIMAL_PLUS - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
See AggDecimalPlusTypeStrategy.
aggArg0(Function<LogicalType, LogicalType>, boolean) - 类 中的静态方法org.apache.flink.table.types.inference.TypeStrategies
Type strategy specific for aggregations that partially produce different nullability depending whether the result is grouped or not.
AGGREGATE_ACCUMULATE - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
AGGREGATE_MERGE - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
AGGREGATE_RETRACT - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
AggregateExpression - org.apache.flink.table.expressions中的类
Resolved and validated expression for calling an aggregate function.
AggregateExpression(FunctionDefinition, List<FieldReferenceExpression>, CallExpression, DataType, boolean, boolean, boolean) - 类 的构造器org.apache.flink.table.expressions.AggregateExpression
 
AggregateFunction<T,ACC> - org.apache.flink.table.functions中的类
Base class for a user-defined aggregate function.
AggregateFunction() - 类 的构造器org.apache.flink.table.functions.AggregateFunction
 
AggregateFunctionDefinition - org.apache.flink.table.functions中的类
A "marker" function definition of an user-defined aggregate function that uses the old type system stack.
AggregateFunctionDefinition(String, AggregateFunction<?, ?>, TypeInformation<?>, TypeInformation<?>) - 类 的构造器org.apache.flink.table.functions.AggregateFunctionDefinition
 
all() - 类 中的静态方法org.apache.flink.table.connector.ChangelogMode
Shortcut for a changelog that can contain all RowKinds.
allocateReuseBytes(int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
Allocate bytes that is only for temporary usage, it should not be stored in somewhere else.
allocateReuseChars(int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
 
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
Modifies 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
Strategy for a conjunction of multiple ArgumentTypeStrategys into one like f(NUMERIC && LITERAL).
AndArgumentTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Strategy for inferring and validating an argument using a conjunction of multiple ArgumentTypeStrategys into one like f(NUMERIC && LITERAL) Some ArgumentTypeStrategys 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() - 类 中的静态方法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
 
anyNull() - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
anyNull() - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
The bit is 1 when the field is null.
anyNull(int[]) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
anyNull() - 接口 中的方法org.apache.flink.table.data.binary.NullAwareGetters
If no field is null, return false.
anyNull(int[]) - 接口 中的方法org.apache.flink.table.data.binary.NullAwareGetters
For the input fields, if no field is null, return false.
appendRowFields(DataType, List<DataTypes.Field>) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Appends the given list of fields to an existing row data type.
applyAggregates(List<int[]>, List<AggregateExpression>, DataType) - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsAggregatePushDown
Provides a list of aggregate expressions and the grouping keys.
applyFilters(List<ResolvedExpression>) - 接口 中的方法org.apache.flink.table.connector.format.BulkDecodingFormat
Provides a list of filters in conjunctive form for filtering on a best-effort basis.
applyFilters(List<ResolvedExpression>) - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown
Provides a list of filters in conjunctive form.
applyLimit(long) - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsLimitPushDown
Provides the expected maximum number of produced records for limiting on a best-effort basis.
applyLimit(long) - 接口 中的方法org.apache.flink.table.sources.LimitableTableSource
已过时。
Check and push down the limit to the table source.
applyOverwrite(boolean) - 接口 中的方法org.apache.flink.table.connector.sink.abilities.SupportsOverwrite
Provides whether existing data should be overwritten or not.
applyPartitionPruning(List<Map<String, String>>) - 接口 中的方法org.apache.flink.table.sources.PartitionableTableSource
已过时。
Applies the remaining partitions to the table source.
applyPartitions(List<Map<String, String>>) - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsPartitionPushDown
Provides a list of remaining partitions.
applyPredicate(List<Expression>) - 接口 中的方法org.apache.flink.table.sources.FilterableTableSource
已过时。
Check and pick all predicates this table source can support.
applyProjection(int[][]) - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsProjectionPushDown
Provides the field index paths that should be used for a projection.
applyReadableMetadata(List<String>) - 接口 中的方法org.apache.flink.table.connector.format.DecodingFormat
Provides a list of metadata keys that the produced row must contain as appended metadata columns.
applyReadableMetadata(List<String>, DataType) - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsReadingMetadata
Provides a list of metadata keys that the produced RowData must contain as appended metadata columns.
applySourceWatermark() - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsSourceWatermark
Instructs the source to emit source-specific watermarks during runtime.
applyStaticPartition(Map<String, String>) - 接口 中的方法org.apache.flink.table.connector.sink.abilities.SupportsPartitioning
Provides the static part of a partition.
applyWatermark(WatermarkStrategy<RowData>) - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsWatermarkPushDown
Provides a WatermarkStrategy which defines how to generate Watermarks in the stream source.
applyWritableMetadata(List<String>) - 接口 中的方法org.apache.flink.table.connector.format.EncodingFormat
Provides a list of metadata keys that the consumed row will contain as appended metadata columns.
applyWritableMetadata(List<String>, DataType) - 接口 中的方法org.apache.flink.table.connector.sink.abilities.SupportsWritingMetadata
Provides a list of metadata keys that the consumed RowData will contain as appended metadata columns which must be persisted.
argument(ArgumentTypeStrategy) - 类 中的方法org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
Defines that we expect a single argument at the next position.
argument(int) - 类 中的静态方法org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the n-th input argument.
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(AbstractDataType<?>) - 类 中的静态方法org.apache.flink.table.api.DataTypes
Unresolved data type of an array of elements with same subtype.
ARRAY - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ARRAY - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
Strategy specific for BuiltInFunctionDefinitions.ARRAY.
ARRAY - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
See ArrayTypeStrategy.
ARRAY_ELEMENT - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ArrayData - org.apache.flink.table.data中的接口
Base interface of an internal data structure representing data of ArrayType.
ArrayData.ElementGetter - org.apache.flink.table.data中的接口
Accessor for getting the elements of an array during runtime.
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.api.TableColumn
已过时。
Returns a string that summarizes this column for printing to a console.
asSummaryString() - 类 中的方法org.apache.flink.table.api.WatermarkSpec
已过时。
 
asSummaryString() - 类 中的方法org.apache.flink.table.catalog.Column
Returns a string that summarizes this column for printing to a console.
asSummaryString() - 接口 中的方法org.apache.flink.table.catalog.Constraint
Prints the constraint in a readable way.
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.UniqueConstraint
Returns constraint's summary.
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.catalog.WatermarkSpec
 
asSummaryString() - 接口 中的方法org.apache.flink.table.connector.sink.DynamicTableSink
Returns a string that summarizes this sink for printing to a console or log.
asSummaryString() - 接口 中的方法org.apache.flink.table.connector.source.DynamicTableSource
Returns a string that summarizes this source for printing to a console or log.
asSummaryString() - 类 中的方法org.apache.flink.table.expressions.AggregateExpression
 
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.SqlCallExpression
 
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.StructuredType.StructuredAttribute
 
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
 
ASYNC_TABLE_EVAL - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
AsyncTableFunction<T> - org.apache.flink.table.functions中的类
Base class for a user-defined asynchronous table function.
AsyncTableFunction() - 类 的构造器org.apache.flink.table.functions.AsyncTableFunction
 
AsyncTableFunctionProvider<T> - org.apache.flink.table.connector.source中的接口
Provider of an AsyncTableFunction instance as a runtime implementation for LookupTableSource.
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
 

B

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

C

calculateBitSetWidthInBytes(int) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryRowData
 
calculateFixLengthPartSize(LogicalType) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryArrayData
It store real value when type is primitive.
calculateFixPartSizeInBytes(int) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryRowData
 
calculateHeaderInBytes(int) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryArrayData
 
CallContext - org.apache.flink.table.types.inference中的接口
Provides details about a function call during TypeInference.
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
 
canBeTimeAttributeType(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
 
canEqual(Object) - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
已过时。
 
canEqual(Object) - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
已过时。
 
canEqual(Object) - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
已过时。
 
CARDINALITY - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CAST - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CAST - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
See CastInputTypeStrategy.
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_TYPE - 类 中的静态变量org.apache.flink.table.catalog.CommonCatalogOptions
ConfigOption which is used during catalog discovery to match it against Factory.factoryIdentifier().
CatalogBaseTable - org.apache.flink.table.catalog中的接口
A common parent that describes the unresolved metadata of a table or view in a catalog.
CatalogBaseTable.TableKind - org.apache.flink.table.catalog中的枚举
The kind of CatalogBaseTable.
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
 
CatalogDatabase - org.apache.flink.table.catalog中的接口
Interface of a database in a catalog.
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.
CatalogFactory.Context - org.apache.flink.table.factories中的接口
Context provided when a catalog is created.
CatalogFactoryHelper(CatalogFactory, CatalogFactory.Context) - 类 的构造器org.apache.flink.table.factories.FactoryUtil.CatalogFactoryHelper
 
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
 
CatalogPropertiesUtil - org.apache.flink.table.catalog中的类
Utilities for de/serializing Catalog objects into a map of string properties.
CatalogTable - org.apache.flink.table.catalog中的接口
Represents the unresolved metadata of 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 the unresolved metadata of a view in a Catalog.
CEIL - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
ChangelogMode - org.apache.flink.table.connector中的类
The set of changes contained in a changelog.
ChangelogMode.Builder - org.apache.flink.table.connector中的类
Builder for configuring and creating instances of ChangelogMode.
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
 
checkOnlyPhysicalColumns(TableSchema) - 类 中的静态方法org.apache.flink.table.utils.TableSchemaUtils
Throws an exception if the given TableSchema contains any non-physical 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.
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.
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.
clear() - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
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 (implicit or explicit) 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
 
collectMethods(Class<?>, String) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Collects methods of the given name.
column(String, AbstractDataType<?>) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a physical column that is appended to this schema.
column(String, String) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a physical column that is appended to this schema.
Column - org.apache.flink.table.catalog中的类
Representation of a column in a ResolvedSchema.
Column.ComputedColumn - org.apache.flink.table.catalog中的类
Representation of a computed column.
Column.MetadataColumn - org.apache.flink.table.catalog中的类
Representation of a metadata column.
Column.PhysicalColumn - org.apache.flink.table.catalog中的类
Representation of a physical column.
columnByExpression(String, Expression) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a computed column that is appended to this schema.
columnByExpression(String, String) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a computed column that is appended to this schema.
columnByMetadata(String, AbstractDataType<?>) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
columnByMetadata(String, String) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
columnByMetadata(String, AbstractDataType<?>, boolean) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
columnByMetadata(String, AbstractDataType<?>, String) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
columnByMetadata(String, AbstractDataType<?>, String, boolean) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
columnByMetadata(String, String, String, boolean) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a metadata column that is appended to this schema.
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.
columnWidthsByType(List<Column>, int, String, String) - 类 中的静态方法org.apache.flink.table.utils.PrintUtils
Try to derive column width based on column types.
comment - 类 中的变量org.apache.flink.table.catalog.Column
 
COMMENT - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
COMMON - 类 中的静态变量org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns a common, least restrictive type of all arguments.
COMMON_ARG - 类 中的静态变量org.apache.flink.table.types.inference.InputTypeStrategies
Argument type strategy that checks and casts for a common, least restrictive type of all arguments.
COMMON_ARG_NULLABLE - 类 中的静态变量org.apache.flink.table.types.inference.InputTypeStrategies
Argument type strategy that checks and casts for a common, least restrictive type of all arguments.
CommonArgumentTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Argument type strategy that checks and casts for a common, least restrictive type of all arguments.
CommonArgumentTypeStrategy(boolean) - 类 的构造器org.apache.flink.table.types.inference.strategies.CommonArgumentTypeStrategy
 
CommonCatalogOptions - org.apache.flink.table.catalog中的类
A collection of ConfigOption which are consistently used in multiple catalogs.
CommonCatalogOptions() - 类 的构造器org.apache.flink.table.catalog.CommonCatalogOptions
 
CommonInputTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
An InputTypeStrategy that expects that all arguments have a common type.
CommonInputTypeStrategy(ArgumentCount) - 类 的构造器org.apache.flink.table.types.inference.strategies.CommonInputTypeStrategy
 
CommonModuleOptions - org.apache.flink.table.module中的类
A collection of ConfigOption which are consistently used in multiple modules.
CommonModuleOptions() - 类 的构造器org.apache.flink.table.module.CommonModuleOptions
 
commonType(int) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
An InputTypeStrategy that expects count arguments that have a common type.
CommonTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Type strategy that returns a common, least restrictive type of all arguments.
CommonTypeStrategy() - 类 的构造器org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
 
comparable(ConstantArgumentCount, StructuredType.StructuredComparison) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that checks all types are comparable with each other.
ComparableTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
An InputTypeStrategy that checks if all input arguments can be compared with each other with the minimal provided comparison.
ComparableTypeStrategy(ConstantArgumentCount, StructuredType.StructuredComparison) - 类 的构造器org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
 
compareTo(StringData) - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
Compares two strings lexicographically.
compareTo(DecimalData) - 类 中的方法org.apache.flink.table.data.DecimalData
 
compareTo(TimestampData) - 类 中的方法org.apache.flink.table.data.TimestampData
 
comparison(StructuredType.StructuredComparison) - 类 中的方法org.apache.flink.table.types.logical.StructuredType.Builder
 
COMPOSITE - 类 中的静态变量org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that checks that the argument has a composite type.
CompositeArgumentTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Strategy that checks that the argument has a composite type.
CompositeArgumentTypeStrategy() - 类 的构造器org.apache.flink.table.types.inference.strategies.CompositeArgumentTypeStrategy
 
compositeSequence() - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
An strategy that lets you apply other strategies for subsequences of the actual arguments.
computed(String, DataType, String) - 类 中的静态方法org.apache.flink.table.api.TableColumn
已过时。
Creates a computed column that is computed from the given SQL expression.
computed(String, ResolvedExpression) - 类 中的静态方法org.apache.flink.table.catalog.Column
Creates a computed column that is computed from the given ResolvedExpression.
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
已过时。
This method will be dropped in future versions. It is recommended to pass a static schema when instantiating the sink instead.
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 - 类 中的静态变量org.apache.flink.table.factories.FactoryUtil
 
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.
ConnectorDescriptorValidator - org.apache.flink.table.descriptors中的类
已过时。
ConnectorDescriptorValidator() - 类 的构造器org.apache.flink.table.descriptors.ConnectorDescriptorValidator
已过时。
 
ConstantArgumentCount - org.apache.flink.table.types.inference中的类
Helper class for ArgumentCount with constant boundaries.
ConstantFunctionContext - org.apache.flink.table.functions中的类
A FunctionContext for constant expression reduction.
ConstantFunctionContext(Configuration) - 类 的构造器org.apache.flink.table.functions.ConstantFunctionContext
 
Constraint - org.apache.flink.table.api.constraints中的接口
已过时。
Constraint - org.apache.flink.table.catalog中的接口
Integrity constraints, generally referred to simply as constraints, define the valid states of SQL-data by constraining the values in the base tables.
constraint(String, Function<List<DataType>, Boolean>) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that must fulfill a given constraint.
Constraint.ConstraintType - org.apache.flink.table.api.constraints中的枚举
已过时。
Type of the constraint.
Constraint.ConstraintType - org.apache.flink.table.catalog中的枚举
Type of the constraint.
ConstraintArgumentTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Strategy for an argument that must fulfill a given constraint.
ConstraintArgumentTypeStrategy(String, Function<List<DataType>, Boolean>) - 类 的构造器org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
 
constructor - 类 中的变量org.apache.flink.table.types.extraction.ExtractionUtils.AssigningConstructor
 
contains(K) - 类 中的方法org.apache.flink.table.api.dataview.MapView
Checks if the map view contains a value for a given key.
contains(RowKind) - 类 中的方法org.apache.flink.table.connector.ChangelogMode
 
contains(BinaryStringData) - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
Returns true if and only if this BinaryStringData contains the specified sequence of bytes values.
containsKey(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns if the given key is contained.
containsOnly(RowKind) - 类 中的方法org.apache.flink.table.connector.ChangelogMode
 
containsPhysicalColumnsOnly(TableSchema) - 类 中的静态方法org.apache.flink.table.utils.TableSchemaUtils
Returns true if there are only physical columns in the given TableSchema.
conversionClass - 类 中的变量org.apache.flink.table.types.DataType
 
conversionSet(String...) - 类 中的静态方法org.apache.flink.table.types.logical.LogicalType
 
convertStringToInternalValue(String, DataType) - 类 中的静态方法org.apache.flink.table.utils.PartitionPathUtils
Restore partition value from string and type.
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(Map<String, String>) - 接口 中的方法org.apache.flink.table.catalog.CatalogDatabase
Returns a copy of this CatalogDatabase with the given properties.
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(Map<String, String>) - 接口 中的方法org.apache.flink.table.catalog.CatalogTable
Returns a copy of this CatalogTable with given table options options.
copy(DataType) - 类 中的方法org.apache.flink.table.catalog.Column.ComputedColumn
 
copy(DataType) - 类 中的方法org.apache.flink.table.catalog.Column
Returns a copy of the column with a replaced DataType.
copy(DataType) - 类 中的方法org.apache.flink.table.catalog.Column.MetadataColumn
 
copy(DataType) - 类 中的方法org.apache.flink.table.catalog.Column.PhysicalColumn
 
copy() - 类 中的方法org.apache.flink.table.catalog.DefaultCatalogTable
 
copy(Map<String, String>) - 类 中的方法org.apache.flink.table.catalog.DefaultCatalogTable
 
copy() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
copy(Map<String, String>) - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
copy() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogView
 
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() - 接口 中的方法org.apache.flink.table.connector.sink.DynamicTableSink
Creates a copy of this instance during planning.
copy() - 接口 中的方法org.apache.flink.table.connector.source.DynamicTableSource
Creates a copy of this instance during planning.
copy() - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
copy(BinaryArrayData) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
copy() - 类 中的方法org.apache.flink.table.data.binary.BinaryMapData
 
copy(BinaryMapData) - 类 中的方法org.apache.flink.table.data.binary.BinaryMapData
 
copy() - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
copy(BinaryRowData) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
copy() - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
Copy a new BinaryStringData.
copy() - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
copy(RowData) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
copy() - 类 中的方法org.apache.flink.table.data.DecimalData
Returns a copy of this DecimalData object.
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
Returns a deep copy of the TableSink.
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
 
copyFromBytes(MemorySegment[], int, byte[], int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
Copy target segments from source byte[].
copyMultiSegmentsToBytes(MemorySegment[], int, byte[], int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
 
copyToBytes(MemorySegment[], int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
Copy segments to a new byte[].
copyToBytes(MemorySegment[], int, byte[], int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
Copy segments to target byte[].
copyToUnsafe(MemorySegment[], int, Object, int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
Copy segments to target unsafe pointer.
copyToView(MemorySegment[], int, int, DataOutputView) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
Copy bytes of segments to output view.
CoreModule - org.apache.flink.table.module中的类
Module of default core metadata in Flink.
CoreModuleFactory - org.apache.flink.table.module中的类
Factory for CoreModule.
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
 
create(ClassLoader) - 接口 中的静态方法org.apache.flink.table.connector.RuntimeConverter.Context
Creates a new instance of RuntimeConverter.Context.
createAccumulator() - 类 中的方法org.apache.flink.table.functions.ImperativeAggregateFunction
Creates and initializes the accumulator for this ImperativeAggregateFunction.
createAccumulator() - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
createAccumulator() - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
createAsyncTableFunction() - 接口 中的方法org.apache.flink.table.connector.source.AsyncTableFunctionProvider
Creates a AsyncTableFunction instance.
createCatalog(String, Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.CatalogFactory
已过时。
Use this#createCatalog(Context) instead and implement Factory instead of TableFactory.
createCatalog(CatalogFactory.Context) - 接口 中的方法org.apache.flink.table.factories.CatalogFactory
Creates and configures a Catalog using the given context.
createCatalog(String, Map<String, String>, ReadableConfig, ClassLoader) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Attempts to discover an appropriate catalog factory and creates an instance of the catalog.
createCatalogFactoryHelper(CatalogFactory, CatalogFactory.Context) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Creates a utility that helps validating options for a CatalogFactory.
createComparator(boolean, ExecutionConfig) - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
已过时。
 
createDatabase(String, CatalogDatabase, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
Create a database.
createDataStructureConverter(DataType) - 接口 中的方法org.apache.flink.table.connector.sink.DynamicTableSink.Context
Creates a converter for mapping between Flink's internal data structures and objects specified by the given DataType that can be passed into a runtime implementation.
createDataStructureConverter(DataType) - 接口 中的方法org.apache.flink.table.connector.source.DynamicTableSource.Context
Creates a converter for mapping between objects specified by the given DataType and Flink's internal data structures that can be passed into a runtime implementation.
createDataType(AbstractDataType<?>) - 接口 中的方法org.apache.flink.table.catalog.DataTypeFactory
Creates a type out of an AbstractDataType.
createDataType(String) - 接口 中的方法org.apache.flink.table.catalog.DataTypeFactory
Creates a type by a fully or partially defined name.
createDataType(UnresolvedIdentifier) - 接口 中的方法org.apache.flink.table.catalog.DataTypeFactory
Creates a type by a fully or partially defined identifier.
createDataType(Class<T>) - 接口 中的方法org.apache.flink.table.catalog.DataTypeFactory
Creates a type by analyzing the given class.
createDataType(TypeInformation<T>) - 接口 中的方法org.apache.flink.table.catalog.DataTypeFactory
Creates a type for the given TypeInformation.
createDecodingFormat(DynamicTableFactory.Context, ReadableConfig) - 接口 中的方法org.apache.flink.table.factories.BulkReaderFormatFactory
Creates a BulkDecodingFormat from the given context and format options.
createDecodingFormat(DynamicTableFactory.Context, ReadableConfig) - 接口 中的方法org.apache.flink.table.factories.DecodingFormatFactory
Creates a format from the given context and format options.
createDeserializationSchema(Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.DeserializationSchemaFactory
Creates and configures a DeserializationSchema using the given properties.
createDynamicTableSink(DynamicTableFactory.Context) - 接口 中的方法org.apache.flink.table.factories.DynamicTableSinkFactory
Creates a DynamicTableSink instance from a CatalogTable and additional context information.
createDynamicTableSource(DynamicTableFactory.Context) - 接口 中的方法org.apache.flink.table.factories.DynamicTableSourceFactory
Creates a DynamicTableSource instance from a CatalogTable and additional context information.
createElementGetter(LogicalType) - 接口 中的静态方法org.apache.flink.table.data.ArrayData
Creates an accessor for getting elements in an internal array data structure at the given position.
createEncodingFormat(DynamicTableFactory.Context, ReadableConfig) - 接口 中的方法org.apache.flink.table.factories.EncodingFormatFactory
Creates a format from the given context and format options.
createFieldGetter(LogicalType, int) - 接口 中的静态方法org.apache.flink.table.data.RowData
Creates an accessor for getting elements in an internal row data structure at the given position.
createFunction(ObjectPath, CatalogFunction, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
Create a function.
createFunctionDefinition(String, CatalogFunction) - 接口 中的方法org.apache.flink.table.factories.FunctionDefinitionFactory
Creates a FunctionDefinition from given CatalogFunction.
createInputFormat() - 接口 中的方法org.apache.flink.table.connector.source.InputFormatProvider
Creates an InputFormat instance.
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
 
createInvalidCallException(CallContext, ValidationException) - 类 中的静态方法org.apache.flink.table.types.inference.TypeInferenceUtil
Returns an exception for an invalid call to a function.
createInvalidInputException(TypeInference, CallContext, ValidationException) - 类 中的静态方法org.apache.flink.table.types.inference.TypeInferenceUtil
Returns an exception for invalid input arguments.
createMethodSignatureString(String, Class<?>[], Class<?>) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Creates a method signature string like int eval(Integer, String).
createModule(String, Map<String, String>, ReadableConfig, ClassLoader) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Discovers a matching module factory and creates an instance of it.
createModule(Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.ModuleFactory
已过时。
Use ModuleFactory.createModule(Context) instead and implement Factory instead of TableFactory.
createModule(ModuleFactory.Context) - 接口 中的方法org.apache.flink.table.factories.ModuleFactory
Creates and configures a Module.
createModule(ModuleFactory.Context) - 类 中的方法org.apache.flink.table.module.CoreModuleFactory
 
createModuleFactoryHelper(ModuleFactory, ModuleFactory.Context) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Creates a utility that helps validating options for a ModuleFactory.
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.table.dataview.ListViewSerializerSnapshot
已过时。
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.table.dataview.MapViewSerializerSnapshot
已过时。
 
createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - 类 中的方法org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
已过时。
 
createOutputFormat() - 接口 中的方法org.apache.flink.table.connector.sink.OutputFormatProvider
Creates an OutputFormat instance.
createPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
Create a partition.
createProctimeDataType() - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Returns a PROCTIME data type.
createRawDataType(Class<T>) - 接口 中的方法org.apache.flink.table.catalog.DataTypeFactory
Creates a RAW type for the given class in cases where no serializer is known and a generic serializer should be used.
createRawDataType(TypeInformation<T>) - 接口 中的方法org.apache.flink.table.catalog.DataTypeFactory
Creates a RAW type for the given TypeInformation.
createReader(FileSystemFormatFactory.ReaderContext) - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory
已过时。
Create InputFormat reader.
createRuntimeDecoder(DynamicTableSource.Context, DataType) - 接口 中的方法org.apache.flink.table.connector.format.DecodingFormat
Creates runtime decoder implementation that is configured to produce data of the given data type.
createRuntimeEncoder(DynamicTableSink.Context, DataType) - 接口 中的方法org.apache.flink.table.connector.format.EncodingFormat
Creates runtime encoder implementation that is configured to consume data of the given data type.
createSerializationSchema(Map<String, String>) - 接口 中的方法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.TimeIndicatorTypeInfo
已过时。
 
createSerializer(ExecutionConfig) - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
已过时。
 
createSink() - 接口 中的方法org.apache.flink.table.connector.sink.SinkProvider
Creates a Sink instance.
createSource() - 接口 中的方法org.apache.flink.table.connector.source.SourceProvider
Creates a Source instance.
createSpecializedFunction(String, FunctionDefinition, CallContext, ClassLoader, ReadableConfig) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Creates the runtime implementation of a FunctionDefinition as an instance of UserDefinedFunction.
createTable(ObjectPath, CatalogBaseTable, boolean) - 接口 中的方法org.apache.flink.table.catalog.Catalog
Creates a new table or view.
createTableFactoryHelper(DynamicTableFactory, DynamicTableFactory.Context) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Creates a utility that helps in discovering formats and validating all options for a DynamicTableFactory.
createTableFunction() - 接口 中的方法org.apache.flink.table.connector.source.TableFunctionProvider
Creates a TableFunction instance.
createTableSink(Catalog, ObjectIdentifier, ResolvedCatalogTable, ReadableConfig, ClassLoader, boolean) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Creates a DynamicTableSink from a CatalogTable.
createTableSink(Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.TableSinkFactory
已过时。
TableSinkFactory.Context contains more information, and already contains table schema too. Please use TableSinkFactory.createTableSink(Context) instead.
createTableSink(ObjectPath, CatalogTable) - 接口 中的方法org.apache.flink.table.factories.TableSinkFactory
已过时。
TableSinkFactory.Context contains more information, and already contains table schema too. Please use TableSinkFactory.createTableSink(Context) instead.
createTableSink(TableSinkFactory.Context) - 接口 中的方法org.apache.flink.table.factories.TableSinkFactory
Creates and configures a TableSink based on the given TableSinkFactory.Context.
createTableSource(Catalog, ObjectIdentifier, ResolvedCatalogTable, ReadableConfig, ClassLoader, boolean) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
createTableSource(Map<String, String>) - 接口 中的方法org.apache.flink.table.factories.TableSourceFactory
已过时。
TableSourceFactory.Context contains more information, and already contains table schema too. Please use TableSourceFactory.createTableSource(Context) instead.
createTableSource(ObjectPath, CatalogTable) - 接口 中的方法org.apache.flink.table.factories.TableSourceFactory
已过时。
TableSourceFactory.Context contains more information, and already contains table schema too. Please use TableSourceFactory.createTableSource(Context) instead.
createTableSource(TableSourceFactory.Context) - 接口 中的方法org.apache.flink.table.factories.TableSourceFactory
Creates and configures a TableSource based on the given TableSourceFactory.Context.
createTypeInfo(Type, Map<String, TypeInformation<?>>) - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfoFactory
已过时。
 
createTypeInfo(Type, Map<String, TypeInformation<?>>) - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfoFactory
已过时。
 
createTypeInformation(DataType) - 接口 中的方法org.apache.flink.table.connector.sink.DynamicTableSink.Context
Creates type information describing the internal data structures of the given DataType.
createTypeInformation(DataType) - 接口 中的方法org.apache.flink.table.connector.source.DynamicTableSource.Context
Creates type information describing the internal data structures of the given DataType.
createUnexpectedException(CallContext, Throwable) - 类 中的静态方法org.apache.flink.table.types.inference.TypeInferenceUtil
Returns an exception for an unexpected error during type inference.
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_ROW_TIMESTAMP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CURRENT_TIME - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CURRENT_TIMESTAMP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CURRENT_WATERMARK - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
CURRENT_WATERMARK - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
See CurrentWatermarkTypeStrategy.
CURRENT_WATERMARK - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
See CurrentWatermarkTypeStrategy.

D

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

E

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

F

Factory - org.apache.flink.table.factories中的接口
Base interface for all kind of factories that create object instances from a list of key-value pairs in Flink's Table & SQL API.
factoryIdentifier() - 接口 中的方法org.apache.flink.table.factories.CatalogFactory
 
factoryIdentifier() - 接口 中的方法org.apache.flink.table.factories.Factory
Returns a unique identifier among same factory interfaces.
factoryIdentifier() - 接口 中的方法org.apache.flink.table.factories.ModuleFactory
 
factoryIdentifier() - 类 中的方法org.apache.flink.table.module.CoreModuleFactory
 
FactoryUtil - org.apache.flink.table.factories中的类
Utility for working with Factorys.
FactoryUtil.CatalogFactoryHelper - org.apache.flink.table.factories中的类
Helper utility for validating all options for a CatalogFactory.
FactoryUtil.DefaultCatalogContext - org.apache.flink.table.factories中的类
Default implementation of CatalogFactory.Context.
FactoryUtil.DefaultDynamicTableContext - org.apache.flink.table.factories中的类
Default implementation of DynamicTableFactory.Context.
FactoryUtil.DefaultModuleContext - org.apache.flink.table.factories中的类
Default implementation of ModuleFactory.Context.
FactoryUtil.ModuleFactoryHelper - org.apache.flink.table.factories中的类
Helper utility for validating all options for a ModuleFactory.
FactoryUtil.TableFactoryHelper - org.apache.flink.table.factories中的类
Helper utility for discovering formats and validating all options for a DynamicTableFactory.
FamilyArgumentTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Strategy for an argument that corresponds to a given LogicalTypeFamily and nullability.
FamilyArgumentTypeStrategy(LogicalTypeFamily, Boolean) - 类 的构造器org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
 
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, AbstractDataType<?>) - 类 中的静态方法org.apache.flink.table.api.DataTypes
Unresolved field definition with field name and data type.
FIELD(String, AbstractDataType<?>, String) - 类 中的静态方法org.apache.flink.table.api.DataTypes
Unresolved field definition with field name, unresolved 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
已过时。
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSchema.Builder.field(String, DataType) instead which uses the new type system based on DataTypes. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.
field(String, DataType) - 类 中的方法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
已过时。
This method will be removed in future versions as it uses the old type system. Please use Schema.field(String, DataType) instead.
field(String, String) - 类 中的方法org.apache.flink.table.descriptors.Schema
已过时。
Adds a field with the field name and the type string.
FIELD_FORMAT_NO_DESCRIPTION - 类 中的静态变量org.apache.flink.table.types.logical.RowType.RowField
 
FIELD_FORMAT_NO_DESCRIPTION - 类 中的静态变量org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
FIELD_FORMAT_WITH_DESCRIPTION - 类 中的静态变量org.apache.flink.table.types.logical.RowType.RowField
 
FIELD_FORMAT_WITH_DESCRIPTION - 类 中的静态变量org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
 
FieldComputer<T> - org.apache.flink.table.sources中的接口
已过时。
This interface will not be supported in the new source design around DynamicTableSource. Use the concept of computed columns instead. See FLIP-95 for more information.
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 (i.e. row, structured, and distinct types).
FieldsDataType(LogicalType, Class<?>, List<DataType>) - 类 的构造器org.apache.flink.table.types.FieldsDataType
 
FieldsDataType(LogicalType, List<DataType>) - 类 的构造器org.apache.flink.table.types.FieldsDataType
 
FileSystemFormatFactory - org.apache.flink.table.factories中的接口
已过时。
This interface has been replaced by BulkReaderFormatFactory and BulkWriterFormatFactory.
FileSystemFormatFactory.ReaderContext - org.apache.flink.table.factories中的接口
已过时。
FileSystemValidator - org.apache.flink.table.descriptors中的类
已过时。
The legacy CSV connector has been replaced by FileSource / FileSink. It is kept only to support tests for the legacy connector stack.
FileSystemValidator() - 类 的构造器org.apache.flink.table.descriptors.FileSystemValidator
已过时。
 
fillPartitionValueForRecord(String[], DataType[], int[], List<String>, Path, String) - 类 中的静态方法org.apache.flink.table.utils.PartitionPathUtils
Extract partition value from path and fill to record.
FilterableTableSource<T> - org.apache.flink.table.sources中的接口
已过时。
This interface will not be supported in the new source design around DynamicTableSource. Use SupportsFilterPushDown instead. See FLIP-95 for more information.
find(MemorySegment[], int, int, MemorySegment[], int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
Find equal segments2 in segments1.
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.
findAdditionDecimalType(int, int, int, int) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal addition operation.
findAll(Class<T>, Map<String, String>) - 类 中的静态方法org.apache.flink.table.factories.TableFactoryService
Finds all table factories of the given class and property map.
findAvgAggType(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal average aggregation.
findCommonType(List<LogicalType>) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Returns the most common, more general LogicalType for a given set of types.
findDivisionDecimalType(int, int, int, int) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal division operation.
findModuloDecimalType(int, int, int, int) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal modulo operation.
findMultiplicationDecimalType(int, int, int, int) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal multiplication operation.
findRoundDecimalType(int, int, int) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal rounding operation.
findSumAggType(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeMerging
Finds the result type of a decimal sum aggregation.
finish() - 类 中的方法org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
Constructs the given strategy.
finishWithVarying(InputTypeStrategy) - 类 中的方法org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
Defines a common InputTypeStrategy for the next arguments.
first(TypeStrategy...) - 类 中的静态方法org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the first type that could be inferred.
FirstTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Type strategy that returns the first type that could be inferred.
FirstTypeStrategy(List<? extends TypeStrategy>) - 类 的构造器org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
 
FLATTEN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
flattenToDataTypes(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Returns the data types of the flat representation in the first level of the given data type.
flattenToNames(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Returns the names of the flat representation in the first level of the given data type.
flattenToNames(DataType, List<String>) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Returns the names of the flat representation in the first level of the given data type.
FLINK_PROPERTY_PREFIX - 类 中的静态变量org.apache.flink.table.catalog.CatalogPropertiesUtil
Globally reserved prefix for catalog properties.
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
 
forAggregateFunction(DataTypeFactory, Class<? extends AggregateFunction<?, ?>>) - 类 中的静态方法org.apache.flink.table.types.extraction.TypeInferenceExtractor
Extracts a type inference from a AggregateFunction.
forAsyncTableFunction(DataTypeFactory, Class<? extends AsyncTableFunction<?>>) - 类 中的静态方法org.apache.flink.table.types.extraction.TypeInferenceExtractor
Extracts a type inference from a AsyncTableFunction.
forceNullable(TypeStrategy) - 类 中的静态方法org.apache.flink.table.types.inference.TypeStrategies
Type strategy which forces the given to be nullable.
ForceNullableTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Forces a given type strategy to be nullable.
ForceNullableTypeStrategy(TypeStrategy) - 类 的构造器org.apache.flink.table.types.inference.strategies.ForceNullableTypeStrategy
 
Format - org.apache.flink.table.connector.format中的接口
Base interface for connector formats.
FORMAT - 类 中的静态变量org.apache.flink.table.factories.FactoryUtil
 
FORMAT - 类 中的静态变量org.apache.flink.table.factories.TableFactoryService
Prefix for format-related properties.
FORMAT - 类 中的静态变量org.apache.flink.table.types.logical.ArrayType
 
FORMAT - 类 中的静态变量org.apache.flink.table.types.logical.MapType
 
FORMAT - 类 中的静态变量org.apache.flink.table.types.logical.MultisetType
 
FORMAT - 类 中的静态变量org.apache.flink.table.types.logical.RawType
 
FORMAT - 类 中的静态变量org.apache.flink.table.types.logical.RowType
 
FORMAT - 类 中的静态变量org.apache.flink.table.types.logical.StructuredType
 
FORMAT_DERIVE_SCHEMA - 类 中的静态变量org.apache.flink.table.factories.TableFactoryService
Key for deriving the schema of the format from the table's schema.
FORMAT_PROPERTY_VERSION - 类 中的静态变量org.apache.flink.table.factories.TableFactoryService
Key for describing the property version.
FORMAT_SUFFIX - 类 中的静态变量org.apache.flink.table.factories.FactoryUtil
Suffix for keys of ConfigOption in case a connector requires multiple formats (e.g.
FORMAT_TYPE - 类 中的静态变量org.apache.flink.table.factories.TableFactoryService
Key for describing the type of the format.
forScalarFunction(DataTypeFactory, Class<? extends ScalarFunction>) - 类 中的静态方法org.apache.flink.table.types.extraction.TypeInferenceExtractor
Extracts a type inference from a ScalarFunction.
forTableAggregateFunction(DataTypeFactory, Class<? extends TableAggregateFunction<?, ?>>) - 类 中的静态方法org.apache.flink.table.types.extraction.TypeInferenceExtractor
Extracts a type inference from a TableAggregateFunction.
forTableFunction(DataTypeFactory, Class<? extends TableFunction<?>>) - 类 中的静态方法org.apache.flink.table.types.extraction.TypeInferenceExtractor
Extracts a type inference from a TableFunction.
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
 
fromAddress(MemorySegment[], int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryStringData
Creates a BinaryStringData instance from the given address (base and offset) and length.
fromBigDecimal(BigDecimal, int, int) - 类 中的静态方法org.apache.flink.table.data.DecimalData
Creates an instance of DecimalData from a BigDecimal and the given precision and scale.
fromBytes(byte[]) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryRawValueData
Creates a BinaryStringData instance from the given bytes.
fromBytes(byte[], int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryRawValueData
Creates a BinaryStringData instance from the given bytes with offset and number of bytes.
fromBytes(byte[]) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryStringData
Creates a BinaryStringData instance from the given UTF-8 bytes.
fromBytes(byte[], int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryStringData
Creates a BinaryStringData instance from the given UTF-8 bytes with offset and number of bytes.
fromBytes(byte[]) - 接口 中的静态方法org.apache.flink.table.data.RawValueData
Creates an instance of RawValueData from the given byte array.
fromBytes(byte[]) - 接口 中的静态方法org.apache.flink.table.data.StringData
Creates an instance of StringData from the given UTF-8 byte array.
fromBytes(byte[], int, int) - 接口 中的静态方法org.apache.flink.table.data.StringData
Creates an instance of StringData from the given UTF-8 byte array with offset and number of bytes.
fromClassToDataType(Class<?>) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
 
fromColumns(List<Schema.UnresolvedColumn>) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Adopts all columns from the given list.
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
已过时。
Please don't use this method anymore. It will be removed soon and we should not make the removal more painful.
fromDataTypeToLegacyInfo(DataType[]) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
已过时。
Please don't use this method anymore. It will be removed soon and we should not make the removal more painful.
fromEpochMillis(long) - 类 中的静态方法org.apache.flink.table.data.TimestampData
Creates an instance of TimestampData from milliseconds.
fromEpochMillis(long, int) - 类 中的静态方法org.apache.flink.table.data.TimestampData
Creates an instance of TimestampData from milliseconds and a nanos-of-millisecond.
fromFields(String[], AbstractDataType<?>[]) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Adopts the given field names and field data types as physical columns of the schema.
fromFields(List<String>, List<? extends AbstractDataType<?>>) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Adopts the given field names and field data types as physical columns of the schema.
fromInstant(Instant) - 类 中的静态方法org.apache.flink.table.data.TimestampData
Creates an instance of TimestampData from an instance of Instant.
fromLegacyInfoToDataType(TypeInformation<?>) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
已过时。
Please don't use this method anymore. It will be removed soon and we should not make the removal more painful.
fromLegacyInfoToDataType(TypeInformation<?>[]) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
已过时。
Please don't use this method anymore. It will be removed soon and we should not make the removal more painful.
fromLocalDateTime(LocalDateTime) - 类 中的静态方法org.apache.flink.table.data.TimestampData
Creates an instance of TimestampData from an instance of LocalDateTime.
fromLogicalToDataType(LogicalType) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
 
fromLogicalToDataType(LogicalType[]) - 类 中的静态方法org.apache.flink.table.types.utils.TypeConversions
 
fromObject(T) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryRawValueData
Creates a BinaryRawValueData instance from the given Java object.
fromObject(T) - 接口 中的静态方法org.apache.flink.table.data.RawValueData
Creates an instance of RawValueData from a Java object.
fromPrimitiveArray(boolean[]) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(byte[]) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(short[]) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(int[]) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(long[]) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(float[]) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryArrayData
 
fromPrimitiveArray(double[]) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryArrayData
 
fromProperties(Map<String, String>) - 接口 中的静态方法org.apache.flink.table.catalog.CatalogTable
Creates an instance of CatalogTable from a map of string properties that were previously created with ResolvedCatalogTable.toProperties().
fromResolvedSchema(ResolvedSchema) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Adopts all members from the given resolved schema.
fromResolvedSchema(ResolvedSchema) - 类 中的静态方法org.apache.flink.table.api.TableSchema
已过时。
Helps to migrate to the new ResolvedSchema to old API methods.
fromRowDataType(DataType) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Adopts all fields of the given row as physical columns of the schema.
fromSchema(Schema) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Adopts all members from the given unresolved schema.
fromString(String) - 类 中的静态方法org.apache.flink.table.catalog.ObjectPath
 
fromString(String) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryStringData
Creates a BinaryStringData instance from the given Java string.
fromString(String) - 接口 中的静态方法org.apache.flink.table.data.StringData
Creates an instance of StringData from the given String.
fromTimestamp(Timestamp) - 类 中的静态方法org.apache.flink.table.data.TimestampData
Creates an instance of TimestampData from an instance of Timestamp.
fromTypeInfo(TypeInformation<?>) - 类 中的静态方法org.apache.flink.table.api.TableSchema
已过时。
This method will be removed soon. Use DataTypes to declare types.
fromUnscaledBytes(byte[], int, int) - 类 中的静态方法org.apache.flink.table.data.DecimalData
Creates an instance of DecimalData from an unscaled byte array value and the given precision and scale.
fromUnscaledLong(long, int, int) - 类 中的静态方法org.apache.flink.table.data.DecimalData
Creates an instance of DecimalData from an unscaled long value and the given precision and scale.
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中的接口
A factory to create FunctionDefinition.
functionExists(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
Check whether a function exists or not.
FunctionHint - org.apache.flink.table.annotation中的注释类型
A hint that influences the reflection-based extraction of input types, accumulator types, and output types for constructing the TypeInference logic of a UserDefinedFunction.
FunctionHints - org.apache.flink.table.annotation中的注释类型
Helper annotation for repeatable FunctionHints.
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中的枚举
Categorizes the semantics of a FunctionDefinition.
FunctionLanguage - org.apache.flink.table.catalog中的枚举
Categorizes the language semantics of a CatalogFunction.
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中的枚举
Characteristics that a FunctionDefinition requires.

G

genBorderLine(int[]) - 类 中的静态方法org.apache.flink.table.utils.PrintUtils
 
generatePartitionPath(LinkedHashMap<String, String>) - 类 中的静态方法org.apache.flink.table.utils.PartitionPathUtils
Make partition path from partition spec.
generateRuntimeName(Class<?>, String[]) - 类 中的静态方法org.apache.flink.table.utils.TableConnectorUtils
Returns the table connector name used for logging and web UI.
generateSignature(TypeInference, String, FunctionDefinition) - 类 中的静态方法org.apache.flink.table.types.inference.TypeInferenceUtil
Generates a signature of the given FunctionDefinition.
GenericArrayData - org.apache.flink.table.data中的类
An internal data structure representing data of ArrayType.
GenericArrayData(Object[]) - 类 的构造器org.apache.flink.table.data.GenericArrayData
Creates an instance of GenericArrayData using the given Java array.
GenericArrayData(int[]) - 类 的构造器org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(long[]) - 类 的构造器org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(float[]) - 类 的构造器org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(double[]) - 类 的构造器org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(short[]) - 类 的构造器org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(byte[]) - 类 的构造器org.apache.flink.table.data.GenericArrayData
 
GenericArrayData(boolean[]) - 类 的构造器org.apache.flink.table.data.GenericArrayData
 
GenericMapData - org.apache.flink.table.data中的类
An internal data structure representing data of MapType or MultisetType.
GenericMapData(Map<?, ?>) - 类 的构造器org.apache.flink.table.data.GenericMapData
Creates an instance of GenericMapData using the given Java map.
GenericRowData - org.apache.flink.table.data中的类
An internal data structure representing data of RowType and other (possibly nested) structured types such as StructuredType.
GenericRowData(RowKind, int) - 类 的构造器org.apache.flink.table.data.GenericRowData
Creates an instance of GenericRowData with given kind and number of fields.
GenericRowData(int) - 类 的构造器org.apache.flink.table.data.GenericRowData
Creates an instance of GenericRowData with given number of fields.
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(Object) - 类 中的方法org.apache.flink.table.data.GenericMapData
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
GET - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
GET - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
See GetTypeStrategy.
get(K) - 类 中的方法org.apache.flink.table.utils.ThreadLocalCache
 
getAbstractDataType() - 类 中的方法org.apache.flink.table.api.DataTypes.AbstractField
 
getAbstractDataType() - 类 中的方法org.apache.flink.table.api.DataTypes.Field
 
getAbstractDataType() - 类 中的方法org.apache.flink.table.api.DataTypes.UnresolvedField
 
getAcceptedFilters() - 类 中的方法org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown.Result
 
getAccessedFields(TimestampExtractor, DataType, Function<String, String>) - 类 中的静态方法org.apache.flink.table.sources.tsextractors.TimestampExtractorUtils
Retrieves all field accesses needed for the given TimestampExtractor.
getAccumulatorDataType() - 类 中的方法org.apache.flink.table.types.inference.TypeInferenceUtil.Result
 
getAccumulatorType() - 类 中的方法org.apache.flink.table.functions.ImperativeAggregateFunction
已过时。
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getAccumulatorType() - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
getAccumulatorType() - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getAccumulatorTypeInfo() - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
 
getAccumulatorTypeInfo() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
getAccumulatorTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getAccumulatorTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>, TypeInformation<ACC>) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getAccumulatorTypeStrategy() - 类 中的方法org.apache.flink.table.types.inference.TypeInference
 
getAggregateFunction() - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
 
getArgs() - 类 中的方法org.apache.flink.table.expressions.AggregateExpression
 
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.CommonInputTypeStrategy
 
getArgumentCount() - 类 中的方法org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
 
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.SubsequenceInputTypeStrategy
 
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.data.binary.BinaryRowData
 
getArity() - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getArity() - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getArity() - 接口 中的方法org.apache.flink.table.data.RowData
Returns the number of fields in this row.
getArity() - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getArity() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
已过时。
 
getArity() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
已过时。
 
getArity() - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
已过时。
 
getArray(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the array value at the given position.
getArray(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getArray(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getArray(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getArray(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getArray(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getArray(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the array value at the given position.
getArray(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
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
已过时。
Gets the AsyncTableFunction which supports async lookup one key at a time.
getAtomicName(List<String>) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeUtils
Returns a unique name for an atomic type.
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.
getBinary(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the binary value at the given position.
getBinary(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getBinary(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getBinary(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getBinary(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getBinary(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getBinary(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the binary value at the given position.
getBinary(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getBinarySection() - 类 中的方法org.apache.flink.table.data.binary.LazyBinaryFormat
 
getBoolean(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the boolean value at the given position.
getBoolean(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getBoolean(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getBoolean(MemorySegment[], int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
get boolean from segments.
getBoolean(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getBoolean(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getBoolean(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getBoolean(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the boolean value at the given position.
getBoolean(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getBoolean(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns a boolean value under the given existing key.
getBuiltInClassLoader() - 接口 中的方法org.apache.flink.table.functions.SpecializedFunction.SpecializedContext
Returns the classloader used to resolve built-in functions.
getByte(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the byte value at the given position.
getByte(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getByte(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getByte(MemorySegment[], int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
get byte from segments.
getByte(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getByte(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getByte(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getByte(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the byte value at the given position.
getByte(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getByte(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns a byte value under the given existing key.
getBytes(MemorySegment[], int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
Maybe not copied, if want copy, please use copyTo.
getCachedFile(String) - 类 中的方法org.apache.flink.table.functions.ConstantFunctionContext
 
getCachedFile(String) - 类 中的方法org.apache.flink.table.functions.FunctionContext
Gets the local temporary file copy of a distributed cache files.
getCallContext() - 接口 中的方法org.apache.flink.table.functions.SpecializedFunction.SpecializedContext
Returns the context of the current call.
getCatalogName() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
 
getCatalogName() - 类 中的方法org.apache.flink.table.catalog.UnresolvedIdentifier
 
getCatalogTable() - 接口 中的方法org.apache.flink.table.factories.DynamicTableFactory.Context
Returns the resolved table information received from the Catalog.
getCatalogTable() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
getChangelogMode() - 接口 中的方法org.apache.flink.table.connector.format.Format
Returns the set of changes that a connector (and transitively the planner) can expect during runtime.
getChangelogMode(ChangelogMode) - 接口 中的方法org.apache.flink.table.connector.sink.DynamicTableSink
Returns the set of changes that the sink accepts during runtime.
getChangelogMode() - 接口 中的方法org.apache.flink.table.connector.source.ScanTableSource
Returns the set of changes that the planner can expect during runtime.
getCharacter(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns a character value under the given existing key.
getChildren() - 类 中的方法org.apache.flink.table.expressions.AggregateExpression
 
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.SqlCallExpression
 
getChildren() - 类 中的方法org.apache.flink.table.expressions.TypeLiteralExpression
 
getChildren() - 类 中的方法org.apache.flink.table.expressions.ValueLiteralExpression
 
getChildren() - 类 中的方法org.apache.flink.table.types.AtomicDataType
 
getChildren() - 类 中的方法org.apache.flink.table.types.CollectionDataType
 
getChildren() - 类 中的方法org.apache.flink.table.types.DataType
 
getChildren() - 类 中的方法org.apache.flink.table.types.FieldsDataType
 
getChildren() - 类 中的方法org.apache.flink.table.types.KeyValueDataType
 
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.
getClassLoader() - 接口 中的方法org.apache.flink.table.connector.RuntimeConverter.Context
Runtime classloader for loading user-defined classes.
getClassLoader() - 接口 中的方法org.apache.flink.table.factories.CatalogFactory.Context
Returns the class loader of the current session.
getClassLoader() - 接口 中的方法org.apache.flink.table.factories.DynamicTableFactory.Context
Returns the class loader of the current session.
getClassLoader() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
 
getClassLoader() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
getClassLoader() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultModuleContext
 
getClassLoader() - 接口 中的方法org.apache.flink.table.factories.ModuleFactory.Context
Returns the class loader of the current session.
getClassName() - 接口 中的方法org.apache.flink.table.catalog.CatalogFunction
Get the full name of the class backing the function.
getColumn(int) - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Returns the Column instance for the given column index.
getColumn(String) - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Returns the Column instance for the given column name.
getColumnCount() - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Returns the number of Columns of this schema.
getColumnDataTypes() - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Returns all column data types.
getColumnName() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
 
getColumnNames() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
 
getColumnNames() - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Returns all column names.
getColumns() - 类 中的方法org.apache.flink.table.api.constraints.UniqueConstraint
已过时。
List of column names for which the primary key was defined.
getColumns() - 类 中的方法org.apache.flink.table.api.Schema
 
getColumns() - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Returns all Columns of this schema.
getColumns() - 类 中的方法org.apache.flink.table.catalog.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.api.Schema.UnresolvedColumn
 
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.
getComment() - 类 中的方法org.apache.flink.table.catalog.Column
Returns the comment of this column.
getComment() - 类 中的方法org.apache.flink.table.catalog.DefaultCatalogTable
 
getComment() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
getComment() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogView
 
getComparison() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
 
getConfiguration() - 接口 中的方法org.apache.flink.table.factories.CatalogFactory.Context
Gives read-only access to the configuration of the current session.
getConfiguration() - 接口 中的方法org.apache.flink.table.factories.DynamicTableFactory.Context
Gives read-only access to the configuration of the current session.
getConfiguration() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
 
getConfiguration() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
getConfiguration() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultModuleContext
 
getConfiguration() - 接口 中的方法org.apache.flink.table.factories.ModuleFactory.Context
Gives read-only access to the configuration of the current session.
getConfiguration() - 接口 中的方法org.apache.flink.table.factories.TableSinkFactory.Context
 
getConfiguration() - 类 中的方法org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
getConfiguration() - 接口 中的方法org.apache.flink.table.factories.TableSourceFactory.Context
 
getConfiguration() - 类 中的方法org.apache.flink.table.factories.TableSourceFactoryContextImpl
 
getConfiguration() - 接口 中的方法org.apache.flink.table.functions.SpecializedFunction.SpecializedContext
Gives read-only access to the configuration of the current session.
getConstraintName() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedConstraint
 
getConsumedDataType() - 接口 中的方法org.apache.flink.table.sinks.TableSink
已过时。
Returns the data type consumed by this TableSink.
getContainedKinds() - 类 中的方法org.apache.flink.table.connector.ChangelogMode
 
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() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
 
getDataType() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
 
getDataType() - 类 中的方法org.apache.flink.table.catalog.Column
Returns the data type of this column.
getDataType(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns the DataType under the given existing key.
getDataType() - 接口 中的方法org.apache.flink.table.types.DataTypeQueryable
 
getDataType() - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
已过时。
 
getDataTypeFactory() - 接口 中的方法org.apache.flink.table.types.inference.CallContext
Enables to lookup types in a catalog and resolve RAW types.
getDataTypeFactory() - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
getDataTypeFactory() - 类 中的方法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
 
getDecimal(int, int, int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the decimal value at the given position.
getDecimal(int, int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getDecimal(int, int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getDecimal(int, int, int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getDecimal(int, int, int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getDecimal(int, int, int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getDecimal(int, int, int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the decimal value at the given position.
getDecimal(int, int, int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
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.
getDefaultPartName() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
The default partition name in case the dynamic partition column value is null/empty string.
getDefinitions() - 类 中的静态方法org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
getDescription() - 类 中的方法org.apache.flink.table.api.DataTypes.AbstractField
 
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.catalog.DefaultCatalogTable
 
getDescription() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
getDescription() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogView
 
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.
getDetailedDescription() - 类 中的方法org.apache.flink.table.catalog.DefaultCatalogTable
 
getDetailedDescription() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
getDetailedDescription() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogView
 
getDouble(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the double value at the given position.
getDouble(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getDouble(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getDouble(MemorySegment[], int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
get double from segments.
getDouble(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getDouble(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getDouble(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getDouble(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the double value at the given position.
getDouble(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
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
 
getElementOrNull(ArrayData, int) - 接口 中的方法org.apache.flink.table.data.ArrayData.ElementGetter
 
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.
getExpandedQuery() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogView
 
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.CommonArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.CompositeArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
 
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
 
getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.SymbolArgumentTypeStrategy
 
getExpectedArgument(FunctionDefinition, int) - 类 中的方法org.apache.flink.table.types.inference.strategies.TypeLiteralArgumentTypeStrategy
 
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.CommonInputTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - 类 中的方法org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
 
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.SubsequenceInputTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - 类 中的方法org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
 
getExpectedSignatures(FunctionDefinition) - 类 中的方法org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
getExpression() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedComputedColumn
 
getExpression() - 类 中的方法org.apache.flink.table.api.TableColumn.ComputedColumn
已过时。
 
getExpression() - 类 中的方法org.apache.flink.table.catalog.Column.ComputedColumn
 
getExpression(ResolvedFieldReference[]) - 接口 中的方法org.apache.flink.table.sources.FieldComputer
已过时。
Returns the Expression that computes the value of the field.
getExternalResourceInfos(String) - 类 中的方法org.apache.flink.table.functions.ConstantFunctionContext
 
getExternalResourceInfos(String) - 类 中的方法org.apache.flink.table.functions.FunctionContext
Get the external resource information.
getFactory() - 接口 中的方法org.apache.flink.table.catalog.Catalog
Returns a factory for creating instances from catalog objects.
getFalseCount() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
 
getFamilies() - 枚举 中的方法org.apache.flink.table.types.logical.LogicalTypeRoot
 
getField(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
Returns the field value at the given position.
getField(DataType, int) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Retrieves a nested field from a composite type at given position.
getField(DataType, String) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Retrieves a nested field from a composite type with given name.
getFieldCount() - 类 中的方法org.apache.flink.table.api.TableSchema
已过时。
Returns the number of fields.
getFieldCount() - 类 中的方法org.apache.flink.table.types.logical.RowType
 
getFieldCount(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Returns the field count of row and structured types.
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.
getFieldIndex() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
 
getFieldIndex(String) - 类 中的方法org.apache.flink.table.types.logical.RowType
 
getFieldMapping() - 接口 中的方法org.apache.flink.table.sources.DefinedFieldMapping
已过时。
Returns the mapping for the fields of the TableSource's TableSchema to the fields of its produced DataType.
getFieldName(int) - 类 中的方法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
已过时。
Use the field names of TableSink.getTableSchema() instead.
getFieldNames() - 类 中的方法org.apache.flink.table.sinks.TableSinkBase
Returns the field names of the table to emit.
getFieldNames() - 类 中的方法org.apache.flink.table.types.logical.RowType
 
getFieldNames(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Returns the field names of row and structured types.
getFieldOrNull(RowData) - 接口 中的方法org.apache.flink.table.data.RowData.FieldGetter
 
getFields() - 类 中的方法org.apache.flink.table.types.logical.RowType
 
getFieldType(int) - 类 中的方法org.apache.flink.table.api.TableSchema
已过时。
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSchema.getFieldDataType(int) instead which uses the new type system based on DataTypes. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.
getFieldType(String) - 类 中的方法org.apache.flink.table.api.TableSchema
已过时。
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSchema.getFieldDataType(String) instead which uses the new type system based on DataTypes. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.
getFieldTypes() - 类 中的方法org.apache.flink.table.api.TableSchema
已过时。
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSchema.getFieldDataTypes() instead which uses the new type system based on DataTypes. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.
getFieldTypes() - 接口 中的方法org.apache.flink.table.sinks.TableSink
已过时。
Use the field types of TableSink.getTableSchema() instead.
getFieldTypes() - 类 中的方法org.apache.flink.table.sinks.TableSinkBase
Returns the field types of the table to emit.
getFieldTypes(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeChecks
Returns the field types of row and structured types.
getFileCount() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
getFilterArg() - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunctionInfo
 
getFilterExpression() - 类 中的方法org.apache.flink.table.expressions.AggregateExpression
 
getFixedIndexedProperties(String, List<String>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns the property keys of fixed indexed properties.
getFixedLengthPartSize() - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getFloat(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the float value at the given position.
getFloat(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getFloat(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getFloat(MemorySegment[], int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
get float from segments.
getFloat(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getFloat(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getFloat(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getFloat(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the float value at the given position.
getFloat(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getFloat(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns a float value under the given given existing key.
getFormatFieldNames() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
Get field names without partition keys.
getFormatFieldTypes() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
Get field types without partition keys.
getFormatOptions() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
Options of this format.
getFormatPrefix(ConfigOption<String>, String) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Returns the required option prefix for options of the given format.
getFormatProjectFields() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
Mapping from non-partition project fields index to all project fields index.
getFormatRowType() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
RowType of table that excludes partition key fields.
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.AggregateExpression
 
getFunctionDefinition() - 类 中的方法org.apache.flink.table.expressions.CallExpression
 
getFunctionDefinition(String) - 类 中的方法org.apache.flink.table.module.CoreModule
 
getFunctionDefinition(String) - 接口 中的方法org.apache.flink.table.module.Module
Get an optional of FunctionDefinition by a given name.
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
Get an optional FunctionDefinitionFactory instance that's responsible for instantiating function definitions.
getFunctionIdentifier() - 类 中的方法org.apache.flink.table.expressions.CallExpression
 
getFunctionLanguage() - 接口 中的方法org.apache.flink.table.catalog.CatalogFunction
Get the language used for the definition of function.
getFunctionName() - 类 中的方法org.apache.flink.table.expressions.CallExpression
Returns a string representation of the call's function for logging or printing to a console.
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(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the integer value at the given position.
getInt(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getInt(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getInt(MemorySegment[], int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
get int from segments.
getInt(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getInt(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getInt(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getInt(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the integer value at the given position.
getInt(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getInt(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns an integer value under the given existing key.
getJavaObject() - 类 中的方法org.apache.flink.table.data.binary.LazyBinaryFormat
 
getJobParameter(String, String) - 类 中的方法org.apache.flink.table.functions.ConstantFunctionContext
 
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
 
getKeys() - 接口 中的方法org.apache.flink.table.connector.source.LookupTableSource.LookupContext
Returns an array of key index paths that should be used during the lookup.
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
 
getList() - 类 中的方法org.apache.flink.table.api.dataview.ListView
Returns the entire view's content as an instance of List.
getListSerializer() - 类 中的方法org.apache.flink.table.dataview.ListViewSerializer
已过时。
 
getLogicalType() - 类 中的方法org.apache.flink.table.types.DataType
Returns the corresponding logical type.
getLong(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the long value at the given position.
getLong(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getLong(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getLong(MemorySegment[], int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
get long from segments.
getLong(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getLong(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getLong(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getLong(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the long value at the given position.
getLong(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
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
已过时。
Gets the TableFunction which supports lookup one key at a time.
getLookupRuntimeProvider(LookupTableSource.LookupContext) - 接口 中的方法org.apache.flink.table.connector.source.LookupTableSource
Returns a provider of runtime implementation for reading the data.
getMap() - 类 中的方法org.apache.flink.table.api.dataview.MapView
Returns the entire view's content as an instance of Map.
getMap(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the map value at the given position.
getMap(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getMap(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getMap(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getMap(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getMap(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getMap(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the map value at the given position.
getMap(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
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
Returns null if this instance is constructed by ColumnStats.ColumnStats(Long, Long, Double, Integer, Number, Number).
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
 
getMetadataAlias() - 类 中的方法org.apache.flink.table.api.TableColumn.MetadataColumn
已过时。
 
getMetadataKey() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
 
getMetadataKey() - 类 中的方法org.apache.flink.table.catalog.Column.MetadataColumn
 
getMetricGroup() - 类 中的方法org.apache.flink.table.functions.ConstantFunctionContext
 
getMetricGroup() - 类 中的方法org.apache.flink.table.functions.FunctionContext
Returns the metric group for this parallel subtask.
getMillisecond() - 类 中的方法org.apache.flink.table.data.TimestampData
Returns the number of milliseconds since 1970-01-01 00:00:00.
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
Returns null if this instance is constructed by ColumnStats.ColumnStats(Long, Long, Double, Integer, Number, Number).
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.AbstractField
 
getName() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedColumn
 
getName() - 类 中的方法org.apache.flink.table.api.TableColumn
已过时。
Returns the name of this column.
getName() - 类 中的方法org.apache.flink.table.catalog.AbstractCatalog
 
getName() - 类 中的方法org.apache.flink.table.catalog.Column
Returns the name of this column.
getName() - 接口 中的方法org.apache.flink.table.catalog.Constraint
 
getName() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
 
getName() - 接口 中的方法org.apache.flink.table.factories.CatalogFactory.Context
Returns the name with which the catalog is created.
getName() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
 
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
 
getNanoOfMillisecond() - 类 中的方法org.apache.flink.table.data.TimestampData
Returns the number of nanoseconds (the nanoseconds within the milliseconds).
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.factories.DynamicTableFactory.Context
Returns the identifier of the table in the Catalog.
getObjectIdentifier() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
getObjectIdentifier() - 接口 中的方法org.apache.flink.table.factories.TableSinkFactory.Context
 
getObjectIdentifier() - 类 中的方法org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
getObjectIdentifier() - 接口 中的方法org.apache.flink.table.factories.TableSourceFactory.Context
 
getObjectIdentifier() - 类 中的方法org.apache.flink.table.factories.TableSourceFactoryContextImpl
 
getObjectIdentifier() - 类 中的方法org.apache.flink.table.types.logical.UserDefinedType
 
getObjectName() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
 
getObjectName() - 类 中的方法org.apache.flink.table.catalog.ObjectPath
 
getObjectName() - 类 中的方法org.apache.flink.table.catalog.UnresolvedIdentifier
 
getOffset() - 接口 中的方法org.apache.flink.table.data.binary.BinaryFormat
Gets the start offset of this binary data in the MemorySegments.
getOffset() - 类 中的方法org.apache.flink.table.data.binary.BinarySection
 
getOffset() - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
 
getOffset() - 类 中的方法org.apache.flink.table.data.binary.LazyBinaryFormat
 
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.
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.
getOptions() - 接口 中的方法org.apache.flink.table.catalog.CatalogBaseTable
Returns a map of string-based options.
getOptions() - 类 中的方法org.apache.flink.table.catalog.DefaultCatalogTable
 
getOptions() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
getOptions() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogView
 
getOptions() - 接口 中的方法org.apache.flink.table.factories.CatalogFactory.Context
Returns the options with which the catalog is created.
getOptions() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
 
getOptions() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultModuleContext
 
getOptions() - 接口 中的方法org.apache.flink.table.factories.ModuleFactory.Context
Returns the options with which the module is created.
getOrigin() - 接口 中的方法org.apache.flink.table.catalog.ResolvedCatalogBaseTable
Returns the original, unresolved metadata object from the Catalog.
getOrigin() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
getOrigin() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogView
 
getOriginalQuery() - 接口 中的方法org.apache.flink.table.catalog.CatalogView
Original text of the view definition that also preserves the original formatting.
getOriginalQuery() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogView
 
getOriginatingClass() - 类 中的方法org.apache.flink.table.types.logical.RawType
 
getOutputDataType() - 类 中的方法org.apache.flink.table.expressions.AggregateExpression
 
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
已过时。
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSink.getConsumedDataType() instead which uses the new type system based on DataTypes. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.
getOutputTypeStrategy() - 类 中的方法org.apache.flink.table.types.inference.TypeInference
 
getParallelism() - 接口 中的方法org.apache.flink.table.connector.ParallelismProvider
Returns the parallelism for this instance.
getParameterTypes(Class[]) - 类 中的方法org.apache.flink.table.functions.python.PythonScalarFunction
 
getParameterTypes(Class[]) - 类 中的方法org.apache.flink.table.functions.python.PythonTableFunction
 
getParameterTypes(Class<?>[]) - 类 中的方法org.apache.flink.table.functions.ScalarFunction
已过时。
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getParameterTypes(Class<?>[]) - 类 中的方法org.apache.flink.table.functions.TableFunction
已过时。
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getPartition(ObjectPath, CatalogPartitionSpec) - 接口 中的方法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.
getPartitionKeys() - 类 中的方法org.apache.flink.table.catalog.DefaultCatalogTable
 
getPartitionKeys() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
getPartitionKeys() - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns partition keys.
getPartitionKeys() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
Partition keys of the table.
getPartitions() - 接口 中的方法org.apache.flink.table.sources.PartitionableTableSource
已过时。
Returns all the partitions of this 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.
getPaths() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
Read paths.
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.Schema
 
getPrimaryKey() - 类 中的方法org.apache.flink.table.api.TableSchema
已过时。
 
getPrimaryKey() - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Returns the primary key if it has been defined.
getPrimaryKeyIndices(TableSchema) - 类 中的静态方法org.apache.flink.table.utils.TableSchemaUtils
Returns the field indices of primary key in the physical columns of this schema (not include computed columns or metadata columns).
getProctimeAttribute() - 接口 中的方法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
已过时。
Returns the DataType for the produced data of the TableSource.
getProjectFields() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
Project the fields of the reader returned.
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.
getPushedDownFilters() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
Pushed down filters, reader can try its best to filter records.
getPushedDownLimit() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
Limiting push-down to reader.
getPythonEnv() - 枚举 中的方法org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
 
getPythonEnv() - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
getPythonEnv() - 接口 中的方法org.apache.flink.table.functions.python.PythonFunction
Returns the Python execution environment.
getPythonEnv() - 类 中的方法org.apache.flink.table.functions.python.PythonScalarFunction
 
getPythonEnv() - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getPythonEnv() - 类 中的方法org.apache.flink.table.functions.python.PythonTableFunction
 
getPythonFunction() - 类 中的方法org.apache.flink.table.functions.python.PythonFunctionInfo
 
getPythonFunction(String, ReadableConfig, ClassLoader) - 枚举 中的静态方法org.apache.flink.table.functions.python.utils.PythonFunctionUtils
 
getPythonFunctionKind() - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
getPythonFunctionKind() - 接口 中的方法org.apache.flink.table.functions.python.PythonFunction
Returns the kind of the user-defined python function.
getPythonFunctionKind() - 类 中的方法org.apache.flink.table.functions.python.PythonScalarFunction
 
getPythonFunctionKind() - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getPythonFunctionKind() - 类 中的方法org.apache.flink.table.functions.python.PythonTableFunction
 
getRawDataSize() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogTableStatistics
 
getRawValue(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the raw value at the given position.
getRawValue(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getRawValue(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getRawValue(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getRawValue(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getRawValue(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getRawValue(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the raw value at the given position.
getRawValue(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getRemainingFilters() - 类 中的方法org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown.Result
 
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.AggregateExpression
 
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
 
getResolvedSchema() - 接口 中的方法org.apache.flink.table.catalog.ResolvedCatalogBaseTable
Returns a fully resolved and validated ResolvedSchema.
getResolvedSchema() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
getResolvedSchema() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogView
 
getResultType() - 类 中的方法org.apache.flink.table.functions.ImperativeAggregateFunction
已过时。
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getResultType() - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
getResultType(Class[]) - 类 中的方法org.apache.flink.table.functions.python.PythonScalarFunction
 
getResultType() - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getResultType() - 类 中的方法org.apache.flink.table.functions.python.PythonTableFunction
 
getResultType(Class<?>[]) - 类 中的方法org.apache.flink.table.functions.ScalarFunction
已过时。
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getResultType() - 类 中的方法org.apache.flink.table.functions.TableFunction
已过时。
This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated TableEnvironment.registerFunction(...) method. The new reflective extraction logic (possibly enriched with DataTypeHint and FunctionHint) should be powerful enough to cover most use cases. For advanced users, it is possible to override UserDefinedFunction.getTypeInference(DataTypeFactory).
getResultType() - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
 
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
已过时。
This method will be removed in future versions as it uses the old type system. It is recommended to use TableSource.getProducedDataType() instead which uses the new type system based on DataTypes. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.
getReturnType() - 类 中的方法org.apache.flink.table.sources.tsextractors.TimestampExtractor
已过时。
 
getReturnTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getReturnTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>, TypeInformation<T>) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getReturnTypeOfTableFunction(TableFunction<T>) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getReturnTypeOfTableFunction(TableFunction<T>, TypeInformation<T>) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
getRow(int, int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the row value at the given position.
getRow(int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getRow(int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getRow(int, int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getRow(int, int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getRow(int, int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getRow(int, int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the row value at the given position.
getRow(int, int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getRowCount() - 类 中的方法org.apache.flink.table.catalog.stats.CatalogTableStatistics
The number of rows.
getRowCount() - 类 中的方法org.apache.flink.table.plan.stats.TableStats
 
getRowKind() - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getRowKind() - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getRowKind() - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getRowKind() - 接口 中的方法org.apache.flink.table.data.RowData
Returns the kind of change that this row describes in a changelog.
getRowKind() - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getRowtimeAttribute() - 类 中的方法org.apache.flink.table.api.WatermarkSpec
已过时。
Returns the name of rowtime attribute, it can be a nested field using dot separator.
getRowtimeAttribute() - 类 中的方法org.apache.flink.table.catalog.WatermarkSpec
Returns the name of a rowtime attribute.
getRowtimeAttributeDescriptors() - 接口 中的方法org.apache.flink.table.sources.DefinedRowtimeAttributes
已过时。
Returns a list of RowtimeAttributeDescriptor for all rowtime attributes of the table.
getRuntimeClass() - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition
 
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.
getScanRuntimeProvider(ScanTableSource.ScanContext) - 接口 中的方法org.apache.flink.table.connector.source.ScanTableSource
Returns a provider of runtime implementation for reading the data.
getSchema() - 接口 中的方法org.apache.flink.table.catalog.CatalogBaseTable
已过时。
This method returns the deprecated TableSchema class. The old class was a hybrid of resolved and unresolved schema information. It has been replaced by the new Schema which is always unresolved and will be resolved by the framework later.
getSchema() - 接口 中的方法org.apache.flink.table.catalog.ResolvedCatalogBaseTable
已过时。
This method returns the deprecated TableSchema class. The old class was a hybrid of resolved and unresolved schema information. It has been replaced by the new ResolvedSchema which is resolved by the framework and accessible via ResolvedCatalogBaseTable.getResolvedSchema().
getSchema() - 接口 中的方法org.apache.flink.table.factories.FileSystemFormatFactory.ReaderContext
已过时。
Full schema of the table.
getSegments() - 接口 中的方法org.apache.flink.table.data.binary.BinaryFormat
Gets the underlying MemorySegments this binary format spans.
getSegments() - 类 中的方法org.apache.flink.table.data.binary.BinarySection
 
getSegments() - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
 
getSegments() - 类 中的方法org.apache.flink.table.data.binary.LazyBinaryFormat
 
getSerializedPythonFunction() - 枚举 中的方法org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
 
getSerializedPythonFunction() - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
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.PythonScalarFunction
 
getSerializedPythonFunction() - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getSerializedPythonFunction() - 类 中的方法org.apache.flink.table.functions.python.PythonTableFunction
 
getSerializerString() - 类 中的方法org.apache.flink.table.types.logical.RawType
Returns the serialized TypeSerializerSnapshot in Base64 encoding of this raw type.
getShort(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the short value at the given position.
getShort(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getShort(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getShort(MemorySegment[], int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
get short from segments.
getShort(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getShort(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getShort(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getShort(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the short value at the given position.
getShort(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getShort(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns a short value under the given existing key.
getSimpleName() - 类 中的方法org.apache.flink.table.functions.FunctionIdentifier
 
getSinkRuntimeProvider(DynamicTableSink.Context) - 接口 中的方法org.apache.flink.table.connector.sink.DynamicTableSink
Returns a provider of runtime implementation for writing the data.
getSizeInBytes() - 接口 中的方法org.apache.flink.table.data.binary.BinaryFormat
Gets the size in bytes of this binary data.
getSizeInBytes() - 类 中的方法org.apache.flink.table.data.binary.BinarySection
 
getSizeInBytes() - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
 
getSizeInBytes() - 类 中的方法org.apache.flink.table.data.binary.LazyBinaryFormat
 
getSourceType() - 类 中的方法org.apache.flink.table.types.logical.DistinctType
 
getSqlExpression() - 类 中的方法org.apache.flink.table.expressions.SqlCallExpression
 
getString(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the string value at the given position.
getString(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getString(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getString(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getString(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getString(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getString(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the string value at the given position.
getString(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
getString(String) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns a string value under the given existing key.
getStringDisplayWidth(String) - 类 中的静态方法org.apache.flink.table.utils.PrintUtils
 
getStructuredField(Class<?>, String) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Returns the field of a structured type.
getStructuredFieldGetter(Class<?>, Field) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Checks for a field getter of a structured type.
getStructuredFieldSetter(Class<?>, Field) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Checks for a field setters of a structured type.
getSuperType() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
 
getSymbolClass() - 类 中的方法org.apache.flink.table.types.logical.SymbolType
 
getTable(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
Returns a CatalogTable or CatalogView identified by the given ObjectPath.
getTable() - 接口 中的方法org.apache.flink.table.factories.TableSinkFactory.Context
 
getTable() - 类 中的方法org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
getTable() - 接口 中的方法org.apache.flink.table.factories.TableSourceFactory.Context
 
getTable() - 类 中的方法org.apache.flink.table.factories.TableSourceFactoryContextImpl
 
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
已过时。
Returns all the TableColumns for this table schema.
getTableColumnStatistics(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
Get the column statistics of a table.
getTableFactory() - 接口 中的方法org.apache.flink.table.catalog.Catalog
已过时。
Use Catalog.getFactory() for the new factory stack. The new factory stack uses the new table sources and sinks defined in FLIP-95 and a slightly different discovery mechanism.
getTableFunction() - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
 
getTableKind() - 接口 中的方法org.apache.flink.table.catalog.CatalogBaseTable
The kind of table this CatalogBaseTable describes.
getTableKind() - 接口 中的方法org.apache.flink.table.catalog.CatalogTable
 
getTableKind() - 接口 中的方法org.apache.flink.table.catalog.CatalogView
 
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
已过时。
Table schema is a logical description of a table and should not be part of the physical TableSource. Define schema when registering a Table either in DDL or in TableEnvironment#connect(...).
getTableStatistics(ObjectPath) - 接口 中的方法org.apache.flink.table.catalog.Catalog
Get the statistics of a table.
getTimestamp(int, int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the timestamp value at the given position.
getTimestamp(int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
getTimestamp(int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
getTimestamp(int, int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
getTimestamp(int, int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
getTimestamp(int, int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
getTimestamp(int, int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns the timestamp value at the given position.
getTimestamp(int, int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
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.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 the data type of this column.
getType() - 接口 中的方法org.apache.flink.table.catalog.Constraint
Tells what kind of constraint it is, e.g.
getType() - 类 中的方法org.apache.flink.table.catalog.UniqueConstraint
 
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.TimeIntervalTypeInfo
已过时。
 
getTypedArguments() - 类 中的方法org.apache.flink.table.types.inference.TypeInference
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.AggregateFunction
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.AggregateFunctionDefinition
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.AsyncTableFunction
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition
 
getTypeInference(DataTypeFactory) - 接口 中的方法org.apache.flink.table.functions.FunctionDefinition
Returns the logic for performing type inference of a call to this function definition.
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.python.PythonScalarFunction
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.python.PythonTableFunction
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.ScalarFunction
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.ScalarFunctionDefinition
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.TableAggregateFunction
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.TableFunction
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
 
getTypeInference(DataTypeFactory) - 类 中的方法org.apache.flink.table.functions.UserDefinedFunction
Returns the logic for performing type inference of a call to this function definition.
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
 
getUnresolvedSchema() - 接口 中的方法org.apache.flink.table.catalog.CatalogBaseTable
Returns the schema of the table or view.
getUnresolvedSchema() - 类 中的方法org.apache.flink.table.catalog.DefaultCatalogTable
 
getUnresolvedSchema() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
getUnresolvedSchema() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogView
 
getValue(ACC) - 类 中的方法org.apache.flink.table.functions.AggregateFunction
Called every time when an aggregation result should be materialized.
getValue(Object) - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
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.
getWatermarkExpression() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
 
getWatermarkExpression() - 类 中的方法org.apache.flink.table.catalog.WatermarkSpec
Returns the ResolvedExpression for watermark generation.
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.Schema
 
getWatermarkSpecs() - 类 中的方法org.apache.flink.table.api.TableSchema
已过时。
Returns a list of the watermark specification which contains rowtime attribute and watermark strategy expression.
getWatermarkSpecs() - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Returns a list of watermark specifications each consisting of a 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
 
GREATEST - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 

H

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

I

IDENTIFIER - 类 中的静态变量org.apache.flink.table.module.CoreModuleFactory
 
IF - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
IF_NULL - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
IF_NULL - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
See IfNullTypeStrategy.
ImperativeAggregateFunction<T,ACC> - org.apache.flink.table.functions中的类
Base class for user-defined AggregateFunction and TableAggregateFunction.
ImperativeAggregateFunction() - 类 的构造器org.apache.flink.table.functions.ImperativeAggregateFunction
 
IN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
indexOf(BinaryStringData, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
Returns the index within this string of the first occurrence of the specified substring, starting at the specified index.
inferArgumentType(CallContext, int, boolean) - 接口 中的方法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.CommonArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.CompositeArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
 
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
 
inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.SymbolArgumentTypeStrategy
 
inferArgumentType(CallContext, int, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.TypeLiteralArgumentTypeStrategy
 
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.CommonInputTypeStrategy
 
inferInputTypes(CallContext, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
 
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.SubsequenceInputTypeStrategy
 
inferInputTypes(CallContext, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
 
inferInputTypes(CallContext, boolean) - 类 中的方法org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
inferOutputType(CallContext, TypeStrategy) - 类 中的静态方法org.apache.flink.table.types.inference.TypeInferenceUtil
Infers an output type using the given TypeStrategy.
inferOutputType(DataTypeFactory) - 接口 中的方法org.apache.flink.table.types.inference.TypeInferenceUtil.SurroundingInfo
 
inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
 
inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.ExplicitTypeStrategy
 
inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
 
inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.ForceNullableTypeStrategy
 
inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
 
inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.MatchFamilyTypeStrategy
 
inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
 
inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.NullableIfArgsTypeStrategy
 
inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.UseArgumentTypeStrategy
 
inferType(CallContext) - 类 中的方法org.apache.flink.table.types.inference.strategies.VaryingStringTypeStrategy
 
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
 
InputFormatProvider - org.apache.flink.table.connector.source中的接口
Provider of an InputFormat instance as a runtime implementation for ScanTableSource.
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 DataTypeHints.
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.
insertOnly() - 类 中的静态方法org.apache.flink.table.connector.ChangelogMode
Shortcut for a simple RowKind.INSERT-only changelog.
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.LegacyRawTypeTransformation
 
INSTANCE - 类 中的静态变量org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
 
instantiateFunction(ClassLoader, ReadableConfig, String, CatalogFunction) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Instantiates a UserDefinedFunction from a CatalogFunction.
instantiateFunction(Class<? extends UserDefinedFunction>) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Instantiates a UserDefinedFunction assuming a JVM function with default constructor.
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.
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
 
IS_FALSE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
IS_GENERIC - 类 中的静态变量org.apache.flink.table.catalog.CatalogPropertiesUtil
Flag to distinguish if a meta-object is a 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
 
isApproximate() - 类 中的方法org.apache.flink.table.expressions.AggregateExpression
 
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
 
isAssignable(Class<?>, Class<?>, boolean) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Checks if one Class can be assigned to a variable of another Class.
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.TimeIntervalTypeInfo
已过时。
 
isBounded() - 接口 中的方法org.apache.flink.table.connector.sink.DynamicTableSink.Context
Returns whether a runtime implementation can expect a finite number of rows.
isBounded() - 接口 中的方法org.apache.flink.table.connector.source.ScanTableSource.ScanRuntimeProvider
Returns whether the data is bounded or not.
isBounded() - 接口 中的方法org.apache.flink.table.factories.TableSinkFactory.Context
It depends on whether the TableEnvironment execution mode is batch.
isBounded() - 类 中的方法org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
isCompact() - 类 中的方法org.apache.flink.table.data.DecimalData
Returns whether the decimal value is small enough to be stored in a long.
isCompact(int) - 类 中的静态方法org.apache.flink.table.data.DecimalData
Returns whether the decimal value is small enough to be stored in a long.
isCompact(int) - 类 中的静态方法org.apache.flink.table.data.TimestampData
Returns whether the timestamp data is small enough to be stored in a long of milliseconds.
isComparison() - 枚举 中的方法org.apache.flink.table.types.logical.StructuredType.StructuredComparison
 
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.BuiltInFunctionDefinition
 
isDeterministic() - 接口 中的方法org.apache.flink.table.functions.FunctionDefinition
Returns information about the determinism of the function's results.
isDeterministic() - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
isDeterministic() - 类 中的方法org.apache.flink.table.functions.python.PythonScalarFunction
 
isDeterministic() - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
isDeterministic() - 类 中的方法org.apache.flink.table.functions.python.PythonTableFunction
 
isDeterministic() - 类 中的方法org.apache.flink.table.functions.ScalarFunctionDefinition
 
isDeterministic() - 类 中的方法org.apache.flink.table.functions.TableAggregateFunctionDefinition
 
isDeterministic() - 类 中的方法org.apache.flink.table.functions.TableFunctionDefinition
 
isDistinct() - 类 中的方法org.apache.flink.table.expressions.AggregateExpression
 
isDistinct() - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunctionInfo
 
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.
isEnforced() - 接口 中的方法org.apache.flink.table.catalog.Constraint
Constraints can either be enforced or non-enforced.
isEquality() - 枚举 中的方法org.apache.flink.table.types.logical.StructuredType.StructuredComparison
 
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
 
isFullWidth(int) - 类 中的静态方法org.apache.flink.table.utils.PrintUtils
Check codePoint is FullWidth or not according to Unicode Standard version 12.0.0.
isGeneric() - 接口 中的方法org.apache.flink.table.catalog.CatalogFunction
Distinguish if the function is a generic function.
isGroupedAggregation() - 接口 中的方法org.apache.flink.table.types.inference.CallContext
Returns whether the function call happens as part of an aggregation that defines grouping columns.
isGroupedAggregation() - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
isGroupedAggregation() - 类 中的方法org.apache.flink.table.types.inference.utils.UnknownCallContext
 
isIgnoreNulls() - 类 中的方法org.apache.flink.table.expressions.AggregateExpression
 
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
 
isInFixedLengthPart(LogicalType) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryRowData
If it is a fixed-length field, we can call this BinaryRowData's setXX method for in-place updates.
isInstantiable() - 类 中的方法org.apache.flink.table.types.logical.StructuredType
 
isInternal(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Checks whether a given data type is an internal data structure.
isInvokable(Executable, Class<?>...) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Checks whether a method/constructor can be called with the given argument classes.
isKeyType() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
已过时。
 
isKeyType() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
已过时。
 
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.
isMutable(LogicalType) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryRowData
 
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.
isNullAt(int) - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns true if the element is null at the given position.
isNullAt(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
isNullAt(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
isNullAt(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
isNullAt(int) - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
isNullAt(int) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
isNullAt(int) - 接口 中的方法org.apache.flink.table.data.RowData
Returns true if the field is null at the given position.
isNullAt(int) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
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.
isPartitioned() - 类 中的方法org.apache.flink.table.catalog.DefaultCatalogTable
 
isPartitioned() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
isPersisted() - 类 中的方法org.apache.flink.table.api.TableColumn.ComputedColumn
已过时。
 
isPersisted() - 类 中的方法org.apache.flink.table.api.TableColumn
已过时。
Returns whether the given column is persisted in a sink operation.
isPersisted() - 类 中的方法org.apache.flink.table.api.TableColumn.MetadataColumn
已过时。
 
isPersisted() - 类 中的方法org.apache.flink.table.api.TableColumn.PhysicalColumn
已过时。
 
isPersisted() - 类 中的方法org.apache.flink.table.catalog.Column.ComputedColumn
 
isPersisted() - 类 中的方法org.apache.flink.table.catalog.Column
Returns whether the given column is persisted in a sink operation.
isPersisted() - 类 中的方法org.apache.flink.table.catalog.Column.MetadataColumn
 
isPersisted() - 类 中的方法org.apache.flink.table.catalog.Column.PhysicalColumn
 
isPhysical() - 类 中的方法org.apache.flink.table.api.TableColumn.ComputedColumn
已过时。
 
isPhysical() - 类 中的方法org.apache.flink.table.api.TableColumn
已过时。
Returns whether the given column is a physical column of a table; neither computed nor metadata.
isPhysical() - 类 中的方法org.apache.flink.table.api.TableColumn.MetadataColumn
已过时。
 
isPhysical() - 类 中的方法org.apache.flink.table.api.TableColumn.PhysicalColumn
已过时。
 
isPhysical() - 类 中的方法org.apache.flink.table.catalog.Column.ComputedColumn
 
isPhysical() - 类 中的方法org.apache.flink.table.catalog.Column
Returns whether the given column is a physical column of a table; neither computed nor metadata.
isPhysical() - 类 中的方法org.apache.flink.table.catalog.Column.MetadataColumn
 
isPhysical() - 类 中的方法org.apache.flink.table.catalog.Column.PhysicalColumn
 
isPrimitiveArray() - 类 中的方法org.apache.flink.table.data.GenericArrayData
Returns true if this is a primitive array.
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
 
isStructuredFieldDirectlyReadable(Field) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Checks whether a field is directly readable without a getter.
isStructuredFieldDirectlyWritable(Field) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Checks whether a field is directly writable without a setter or constructor.
isTemporary() - 接口 中的方法org.apache.flink.table.factories.DynamicTableFactory.Context
Whether the table is temporary.
isTemporary() - 类 中的方法org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
 
isTemporary() - 接口 中的方法org.apache.flink.table.factories.TableSinkFactory.Context
Whether the table is temporary.
isTemporary() - 类 中的方法org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
isTemporary() - 接口 中的方法org.apache.flink.table.factories.TableSourceFactory.Context
Whether the table is temporary.
isTemporary() - 类 中的方法org.apache.flink.table.factories.TableSourceFactoryContextImpl
 
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.TimeIntervalTypeInfo
已过时。
 
isValidCount(int) - 接口 中的方法org.apache.flink.table.types.inference.ArgumentCount
Enables custom validation of argument counts after ArgumentCount.getMinCount() and ArgumentCount.getMaxCount() have been validated.
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.
isVirtual() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
 
isVirtual() - 类 中的方法org.apache.flink.table.api.TableColumn.MetadataColumn
已过时。
 
isVirtual() - 类 中的方法org.apache.flink.table.catalog.Column.MetadataColumn
 
iterator() - 类 中的方法org.apache.flink.table.api.dataview.MapView
Returns an iterator over all entries of the map view.

J

JoinedRowData - org.apache.flink.table.data.utils中的类
An implementation of RowData which is backed by two concatenated RowData.
JoinedRowData() - 类 的构造器org.apache.flink.table.data.utils.JoinedRowData
Creates a new JoinedRowData of kind RowKind.INSERT, but without backing rows.
JoinedRowData(RowData, RowData) - 类 的构造器org.apache.flink.table.data.utils.JoinedRowData
Creates a new JoinedRowData of kind RowKind.INSERT backed by and .
JoinedRowData(RowKind, RowData, RowData) - 类 的构造器org.apache.flink.table.data.utils.JoinedRowData
Creates a new JoinedRowData of kind backed by and .
JSON_EXISTS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
JSON_VALUE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
JsonExistsOnError - org.apache.flink.table.api中的枚举
Behavior in case of errors for BuiltInFunctionDefinitions.JSON_EXISTS.
JsonValueOnEmptyOrError - org.apache.flink.table.api中的枚举

K

keyArray() - 类 中的方法org.apache.flink.table.data.binary.BinaryMapData
 
keyArray() - 类 中的方法org.apache.flink.table.data.GenericMapData
 
keyArray() - 接口 中的方法org.apache.flink.table.data.MapData
Returns an array view of the keys contained in this map.
keys() - 类 中的方法org.apache.flink.table.api.dataview.MapView
Returns all the keys in the map view.
keyType - 类 中的变量org.apache.flink.table.api.dataview.MapView
已过时。
KeyValueDataType - org.apache.flink.table.types中的类
A data type that contains a key and value data type (e.g.
KeyValueDataType(LogicalType, Class<?>, DataType, DataType) - 类 的构造器org.apache.flink.table.types.KeyValueDataType
 
KeyValueDataType(LogicalType, DataType, DataType) - 类 的构造器org.apache.flink.table.types.KeyValueDataType
 
kind(FunctionKind) - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
 

L

LazyBinaryFormat<T> - org.apache.flink.table.data.binary中的类
An abstract implementation fo BinaryFormat which is lazily serialized into binary or lazily deserialized into Java object.
LazyBinaryFormat() - 类 的构造器org.apache.flink.table.data.binary.LazyBinaryFormat
 
LazyBinaryFormat(MemorySegment[], int, int, T) - 类 的构造器org.apache.flink.table.data.binary.LazyBinaryFormat
 
LazyBinaryFormat(MemorySegment[], int, int) - 类 的构造器org.apache.flink.table.data.binary.LazyBinaryFormat
 
LazyBinaryFormat(T) - 类 的构造器org.apache.flink.table.data.binary.LazyBinaryFormat
 
LazyBinaryFormat(T, BinarySection) - 类 的构造器org.apache.flink.table.data.binary.LazyBinaryFormat
 
LEAST - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
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
 
legacyToNonLegacy() - 类 中的静态方法org.apache.flink.table.types.inference.TypeTransformations
Returns a type transformation that transforms LEGACY(...) type to a non-legacy type.
LegacyToNonLegacyTransformation - org.apache.flink.table.types.inference.transforms中的类
LegacyToNonLegacyTransformation() - 类 的构造器org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
 
LegacyTypeInfoDataTypeConverter - org.apache.flink.table.types.utils中的类
已过时。
Use DataTypeFactory.createDataType(TypeInformation) instead. Note that this method will not create legacy types anymore. It fully uses the new type system available only in the planner.
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中的接口
已过时。
This interface will not be supported in the new source design around DynamicTableSource. Use SupportsLimitPushDown instead. See FLIP-95 for more information.
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.
listPartitions() - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsPartitionPushDown
Returns a list of all partitions that a source can read if available.
listPartitionsByFilter(ObjectPath, List<Expression>) - 接口 中的方法org.apache.flink.table.catalog.Catalog
Get CatalogPartitionSpec of partitions by expression filters in the table.
listReadableMetadata() - 接口 中的方法org.apache.flink.table.connector.format.DecodingFormat
Returns the map of metadata keys and their corresponding data types that can be produced by this format for reading.
listReadableMetadata() - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsReadingMetadata
Returns the map of metadata keys and their corresponding data types that can be produced by this table source for reading.
listStatusWithoutHidden(FileSystem, Path) - 类 中的静态方法org.apache.flink.table.utils.PartitionPathUtils
List file status without hidden files.
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 DataView that provides List-like functionality in the accumulator of an AggregateFunction or TableAggregateFunction when large amounts of data are expected.
ListView() - 类 的构造器org.apache.flink.table.api.dataview.ListView
Creates a list view.
ListView(TypeInformation<?>) - 类 的构造器org.apache.flink.table.api.dataview.ListView
已过时。
This method uses the old type system. Please use a DataTypeHint instead if the reflective type extraction is not successful.
listViews(String) - 接口 中的方法org.apache.flink.table.catalog.Catalog
Get names of all views under this database.
ListViewSerializer<T> - org.apache.flink.table.dataview中的类
已过时。
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
已过时。
 
listWritableMetadata() - 接口 中的方法org.apache.flink.table.connector.format.EncodingFormat
Returns the map of metadata keys and their corresponding data types that can be consumed by this format for writing.
listWritableMetadata() - 接口 中的方法org.apache.flink.table.connector.sink.abilities.SupportsWritingMetadata
Returns the map of metadata keys and their corresponding data types that can be consumed by this table sink for writing.
LITERAL - 类 中的静态变量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
 
LITTLE_ENDIAN - 类 中的静态变量org.apache.flink.table.data.binary.BinaryRowData
 
LITTLE_ENDIAN - 类 中的静态变量org.apache.flink.table.data.binary.BinarySegmentUtils
Constant that flags the byte order.
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
 
localTimeToUnixDate(LocalTime) - 类 中的静态方法org.apache.flink.table.utils.TimestampStringUtils
 
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
 
logical(LogicalTypeRoot) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that corresponds to a given LogicalTypeRoot.
logical(LogicalTypeRoot, boolean) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that corresponds to a given LogicalTypeRoot and nullability.
logical(LogicalTypeFamily) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that corresponds to a given LogicalTypeFamily.
logical(LogicalTypeFamily, boolean) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for an argument that corresponds to a given LogicalTypeFamily and nullability.
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中的类
Utilities for casting LogicalType.
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中的类
A converter between LogicalType and DataType.
LogicalTypeDefaultVisitor<R> - org.apache.flink.table.types.logical.utils中的类
Implementation of LogicalTypeVisitor that redirects all calls to LogicalTypeDefaultVisitor.defaultMethod(LogicalType).
LogicalTypeDefaultVisitor() - 类 的构造器org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
 
LogicalTypeDuplicator - org.apache.flink.table.types.logical.utils中的类
Returns a deep copy of a LogicalType.
LogicalTypeDuplicator() - 类 的构造器org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
 
LogicalTypeFamily - org.apache.flink.table.types.logical中的枚举
An enumeration of logical type families for clustering LogicalTypeRoots into categories.
LogicalTypeMerging - org.apache.flink.table.types.logical.utils中的类
Utilities for merging multiple LogicalType.
LogicalTypeParser - org.apache.flink.table.types.logical.utils中的类
Parser for creating instances of LogicalType from a serialized string created with LogicalType.asSerializableString().
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中的类
Utilities for handling LogicalTypes.
LogicalTypeVisitor<R> - org.apache.flink.table.types.logical中的接口
The visitor definition of LogicalType.
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中的接口
已过时。
This interface will not be supported in the new source design around DynamicTableSource. Use LookupTableSource instead. See FLIP-95 for more information.
LookupTableSource - org.apache.flink.table.connector.source中的接口
A DynamicTableSource that looks up rows of an external storage system by one or more keys during runtime.
LookupTableSource.LookupContext - org.apache.flink.table.connector.source中的接口
Context for creating runtime implementation via a LookupTableSource.LookupRuntimeProvider.
LookupTableSource.LookupRuntimeProvider - org.apache.flink.table.connector.source中的接口
Provides actual runtime implementation for reading the data.
LOWER - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LOWERCASE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LPAD - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
LTRIM - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 

M

MAP(DataType, DataType) - 类 中的静态方法org.apache.flink.table.api.DataTypes
Data type of an associative array that maps keys (including NULL) to values (including NULL).
MAP(AbstractDataType<?>, AbstractDataType<?>) - 类 中的静态方法org.apache.flink.table.api.DataTypes
Unresolved data type of an associative array that maps keys (including NULL) to values (including NULL).
MAP(TypeInformation<K>, TypeInformation<V>) - 类 中的静态方法org.apache.flink.table.api.Types
已过时。
Generates type information for a Java HashMap.
MAP - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
MAP - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
See MapInputTypeStrategy.
MAP - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
See MapTypeStrategy.
MapData - org.apache.flink.table.data中的接口
Base interface of an internal data structure representing data of MapType or MultisetType.
mapping(Map<InputTypeStrategy, TypeStrategy>) - 类 中的静态方法org.apache.flink.table.types.inference.TypeStrategies
Type strategy that maps an InputTypeStrategy to a TypeStrategy if the input strategy infers identical types.
MappingTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Type strategy that maps an InputTypeStrategy to a TypeStrategy if the input strategy infers compatible types.
MappingTypeStrategy(Map<InputTypeStrategy, TypeStrategy>) - 类 的构造器org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
 
MapType - org.apache.flink.table.types.logical中的类
Logical type of an associative array that maps keys (including NULL) to values (including NULL).
MapType(boolean, LogicalType, LogicalType) - 类 的构造器org.apache.flink.table.types.logical.MapType
 
MapType(LogicalType, LogicalType) - 类 的构造器org.apache.flink.table.types.logical.MapType
 
MapView<K,V> - org.apache.flink.table.api.dataview中的类
A DataView that provides Map-like functionality in the accumulator of an AggregateFunction or TableAggregateFunction when large amounts of data are expected.
MapView() - 类 的构造器org.apache.flink.table.api.dataview.MapView
Creates a map view.
MapView(TypeInformation<?>, TypeInformation<?>) - 类 的构造器org.apache.flink.table.api.dataview.MapView
已过时。
This method uses the old type system. Please use a DataTypeHint instead if the reflective type extraction is not successful.
MapViewSerializer<K,V> - org.apache.flink.table.dataview中的类
已过时。
MapViewSerializer(TypeSerializer<Map<K, V>>) - 类 的构造器org.apache.flink.table.dataview.MapViewSerializer
已过时。
 
MapViewSerializerSnapshot<K,V> - org.apache.flink.table.dataview中的类
已过时。
MapViewSerializerSnapshot() - 类 的构造器org.apache.flink.table.dataview.MapViewSerializerSnapshot
已过时。
Constructor for read instantiation.
MapViewSerializerSnapshot(MapViewSerializer<K, V>) - 类 的构造器org.apache.flink.table.dataview.MapViewSerializerSnapshot
已过时。
Constructor to create the snapshot for writing.
MapViewTypeInfo<K,V> - org.apache.flink.table.dataview中的类
已过时。
MapViewTypeInfo(TypeInformation<K>, TypeInformation<V>, boolean, boolean) - 类 的构造器org.apache.flink.table.dataview.MapViewTypeInfo
已过时。
 
MapViewTypeInfo(TypeInformation<K>, TypeInformation<V>) - 类 的构造器org.apache.flink.table.dataview.MapViewTypeInfo
已过时。
 
MapViewTypeInfoFactory<K,V> - org.apache.flink.table.dataview中的类
已过时。
MapViewTypeInfoFactory() - 类 的构造器org.apache.flink.table.dataview.MapViewTypeInfoFactory
已过时。
 
matchFamily(int, LogicalTypeFamily) - 类 中的静态方法org.apache.flink.table.types.inference.TypeStrategies
Type strategy that returns the given argument if it is of the same logical type family.
MatchFamilyTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Type strategy that returns the given argument if it is of the same logical type family.
MatchFamilyTypeStrategy(int, LogicalTypeFamily) - 类 的构造器org.apache.flink.table.types.inference.strategies.MatchFamilyTypeStrategy
 
materialize(TypeSerializer<T>) - 类 中的方法org.apache.flink.table.data.binary.BinaryRawValueData
 
materialize(TypeSerializer<String>) - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
 
materialize(TypeSerializer<T>) - 类 中的方法org.apache.flink.table.data.binary.LazyBinaryFormat
Materialize java object to binary format.
MAX - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
MAX_COLUMN_WIDTH - 类 中的静态变量org.apache.flink.table.utils.PrintUtils
 
MAX_DAY_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.DayTimeIntervalType
 
MAX_FIX_PART_DATA_SIZE - 接口 中的静态变量org.apache.flink.table.data.binary.BinaryFormat
It decides whether to put data in FixLenPart or VarLenPart.
MAX_FRACTIONAL_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.DayTimeIntervalType
 
MAX_LENGTH - 类 中的静态变量org.apache.flink.table.types.logical.BinaryType
 
MAX_LENGTH - 类 中的静态变量org.apache.flink.table.types.logical.CharType
 
MAX_LENGTH - 类 中的静态变量org.apache.flink.table.types.logical.VarBinaryType
 
MAX_LENGTH - 类 中的静态变量org.apache.flink.table.types.logical.VarCharType
 
MAX_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.DecimalType
 
MAX_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.LocalZonedTimestampType
 
MAX_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.TimestampType
 
MAX_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.TimeType
 
MAX_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.YearMonthIntervalType
 
MAX_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.ZonedTimestampType
 
MD5 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
md5(String) - 类 中的静态方法org.apache.flink.table.utils.EncodingUtils
 
merge(ColumnStats) - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats
Merges two column stats.
merge(TableStats) - 类 中的方法org.apache.flink.table.plan.stats.TableStats
Merges two table stats.
metadata(String, DataType) - 类 中的静态方法org.apache.flink.table.api.TableColumn
已过时。
Creates a metadata column from metadata of the given column name.
metadata(String, DataType, boolean) - 类 中的静态方法org.apache.flink.table.api.TableColumn
已过时。
Creates a metadata column from metadata of the given column name.
metadata(String, DataType, String) - 类 中的静态方法org.apache.flink.table.api.TableColumn
已过时。
Creates a metadata column from metadata of the given alias.
metadata(String, DataType, String, boolean) - 类 中的静态方法org.apache.flink.table.api.TableColumn
已过时。
Creates a metadata column from metadata of the given column name or from metadata of the given alias (if not null).
metadata(String, DataType, String, boolean) - 类 中的静态方法org.apache.flink.table.catalog.Column
Creates a metadata column from metadata of the given column name or from metadata of the given key (if not null).
METADATA - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
MIN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
MIN_DAY_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.DayTimeIntervalType
 
MIN_FRACTIONAL_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.DayTimeIntervalType
 
MIN_LENGTH - 类 中的静态变量org.apache.flink.table.types.logical.BinaryType
 
MIN_LENGTH - 类 中的静态变量org.apache.flink.table.types.logical.CharType
 
MIN_LENGTH - 类 中的静态变量org.apache.flink.table.types.logical.VarBinaryType
 
MIN_LENGTH - 类 中的静态变量org.apache.flink.table.types.logical.VarCharType
 
MIN_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.DecimalType
 
MIN_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.LocalZonedTimestampType
 
MIN_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.TimestampType
 
MIN_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.TimeType
 
MIN_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.YearMonthIntervalType
 
MIN_PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.ZonedTimestampType
 
MIN_SCALE - 类 中的静态变量org.apache.flink.table.types.logical.DecimalType
 
MINUS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
Combines numeric subtraction and "datetime - interval" arithmetic.
MINUS_PREFIX - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
MINUTE() - 类 中的静态方法org.apache.flink.table.api.DataTypes
Resolution in minutes.
MISSING - 类 中的静态变量org.apache.flink.table.types.inference.TypeStrategies
Placeholder for a missing type strategy.
MissingTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Placeholder for a missing type strategy.
MissingTypeStrategy() - 类 的构造器org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
 
MOD - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
Module - org.apache.flink.table.module中的接口
Modules define a set of metadata, including functions, user defined types, operators, rules, etc.
MODULE_TYPE - 类 中的静态变量org.apache.flink.table.module.CommonModuleOptions
已过时。
This is only required for the legacy factory stack
ModuleException - org.apache.flink.table.module中的异常错误
Exception related to modules.
ModuleException(String) - 异常错误 的构造器org.apache.flink.table.module.ModuleException
Creates a new ModuleException.
ModuleException(String, Throwable) - 异常错误 的构造器org.apache.flink.table.module.ModuleException
Creates a new ModuleException.
ModuleFactory - org.apache.flink.table.factories中的接口
A factory to create configured module instances based on string-based properties.
ModuleFactory.Context - org.apache.flink.table.factories中的接口
Context provided when a module is created.
ModuleFactoryHelper(ModuleFactory, ModuleFactory.Context) - 类 的构造器org.apache.flink.table.factories.FactoryUtil.ModuleFactoryHelper
 
MONTH() - 类 中的静态方法org.apache.flink.table.api.DataTypes
Resolution in months.
MULTISET(DataType) - 类 中的静态方法org.apache.flink.table.api.DataTypes
Data type of a multiset (=bag).
MULTISET(AbstractDataType<?>) - 类 中的静态方法org.apache.flink.table.api.DataTypes
Unresolved data type of a multiset (=bag).
MULTISET(TypeInformation<E>) - 类 中的静态方法org.apache.flink.table.api.Types
已过时。
Generates type information for a Multiset.
MultisetType - org.apache.flink.table.types.logical中的类
Logical type of a multiset (=bag).
MultisetType(boolean, LogicalType) - 类 的构造器org.apache.flink.table.types.logical.MultisetType
 
MultisetType(LogicalType) - 类 的构造器org.apache.flink.table.types.logical.MultisetType
 

N

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

O

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

P

ParallelismProvider - org.apache.flink.table.connector中的接口
Parallelism provider for other connector providers.
parameterNames - 类 中的变量org.apache.flink.table.types.extraction.ExtractionUtils.AssigningConstructor
 
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.
PARTITION_KEYS - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
PartitionableTableSink - org.apache.flink.table.sinks中的接口
已过时。
This interface will not be supported in the new sink design around DynamicTableSink. Use SupportsPartitioning instead. See FLIP-95 for more information.
PartitionableTableSource - org.apache.flink.table.sources中的接口
已过时。
This interface will not be supported in the new source design around DynamicTableSource. Use SupportsPartitionPushDown instead. See FLIP-95 for more information.
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
 
PartitionPathUtils - org.apache.flink.table.utils中的类
Utils for file system.
PartitionPathUtils() - 类 的构造器org.apache.flink.table.utils.PartitionPathUtils
 
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
 
physical(String, DataType) - 类 中的静态方法org.apache.flink.table.api.TableColumn
已过时。
Creates a regular table column that represents physical data.
physical(String, DataType) - 类 中的静态方法org.apache.flink.table.catalog.Column
Creates a regular table column that represents physical data.
physical(List<String>, List<DataType>) - 类 中的静态方法org.apache.flink.table.catalog.ResolvedSchema
Shortcut for a resolved schema of only physical columns.
physical(String[], DataType[]) - 类 中的静态方法org.apache.flink.table.catalog.ResolvedSchema
Shortcut for a resolved schema of only physical columns.
PI - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
PLACEHOLDER_SYMBOL - 类 中的静态变量org.apache.flink.table.factories.FactoryUtil
The placeholder symbol to be used for keys of options which can be templated.
PLUS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
Combines numeric addition, "datetime + interval"/"interval + interval" arithmetic, and string concatenation.
pointTo(MemorySegment[], int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
pointTo(MemorySegment[], int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryMapData
 
pointTo(MemorySegment, int, int) - 类 中的方法org.apache.flink.table.data.binary.BinarySection
 
pointTo(MemorySegment[], int, int) - 类 中的方法org.apache.flink.table.data.binary.BinarySection
 
POSITION - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
POWER - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
precision() - 类 中的方法org.apache.flink.table.data.DecimalData
Returns the precision of this DecimalData.
PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.BigIntType
 
PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.DoubleType
 
PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.FloatType
 
PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.IntType
 
PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.SmallIntType
 
PRECISION - 类 中的静态变量org.apache.flink.table.types.logical.TinyIntType
 
prepareInstance(ReadableConfig, UserDefinedFunction) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Prepares a UserDefinedFunction instance for usage in the API.
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
 
PRIMARY_KEY_COLUMNS - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
PRIMARY_KEY_NAME - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
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.Schema.Builder
Declares a primary key constraint for a set of given columns.
primaryKey(List<String>) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a primary key constraint for a set of given columns.
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.
primaryKey(String, List<String>) - 类 中的静态方法org.apache.flink.table.catalog.UniqueConstraint
Creates a non enforced ConstraintType#PRIMARY_KEY constraint.
primaryKeyNamed(String, String...) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares a primary key constraint for a set of given columns.
primaryKeyNamed(String, List<String>) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares 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.
primitiveToWrapper(Class<?>) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Converts the specified primitive Class object to its corresponding wrapper Class object.
printAsTableauForm(ResolvedSchema, Iterator<Row>, PrintWriter, ZoneId) - 类 中的静态方法org.apache.flink.table.utils.PrintUtils
Displays the result in a tableau form.
printAsTableauForm(ResolvedSchema, Iterator<Row>, PrintWriter, int, String, boolean, boolean, ZoneId) - 类 中的静态方法org.apache.flink.table.utils.PrintUtils
Displays the result in a tableau form.
printSingleRow(int[], String[], PrintWriter) - 类 中的静态方法org.apache.flink.table.utils.PrintUtils
 
PrintUtils - org.apache.flink.table.utils中的类
Utilities for print formatting.
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中的接口
已过时。
This interface will not be supported in the new source design around DynamicTableSource. Use SupportsProjectionPushDown instead. See FLIP-95 for more information.
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.
projectRow(DataType, int[][]) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Projects a (possibly nested) row data type by returning a new data type that only includes fields of the given index paths.
projectRow(DataType, int[]) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Projects a (possibly nested) row data type by returning a new data type that only includes fields of the given indices.
projectSchema(TableSchema, int[][]) - 类 中的静态方法org.apache.flink.table.utils.TableSchemaUtils
Creates a new TableSchema with the projected fields from another TableSchema.
PROPERTY_VERSION - 类 中的静态变量org.apache.flink.table.factories.FactoryUtil
Describes the property version.
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.
putPartitionKeys(List<String>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Adds table partition keys.
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.
PythonAggregateFunction - org.apache.flink.table.functions.python中的类
The wrapper of user defined python aggregate function.
PythonAggregateFunction(String, byte[], DataType[], DataType, DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - 类 的构造器org.apache.flink.table.functions.python.PythonAggregateFunction
 
PythonAggregateFunctionInfo - org.apache.flink.table.functions.python中的类
PythonAggregateFunctionInfo contains the execution information of a Python aggregate function, such as: the actual Python aggregation function, the input arguments, the filter arg, the distinct flag, etc.
PythonAggregateFunctionInfo(PythonFunction, Object[], int, boolean) - 类 的构造器org.apache.flink.table.functions.python.PythonAggregateFunctionInfo
 
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
 
PythonFunctionKind - org.apache.flink.table.functions.python中的枚举
Categorizes the Python functions.
PythonFunctionUtils - org.apache.flink.table.functions.python.utils中的枚举
Utilities for creating PythonFunction from the fully qualified name of a Python function.
PythonScalarFunction - org.apache.flink.table.functions.python中的类
The wrapper of user defined python scalar function.
PythonScalarFunction(String, byte[], TypeInformation[], TypeInformation, PythonFunctionKind, boolean, boolean, PythonEnv) - 类 的构造器org.apache.flink.table.functions.python.PythonScalarFunction
 
PythonTableAggregateFunction - org.apache.flink.table.functions.python中的类
The wrapper of user defined python table aggregate function.
PythonTableAggregateFunction(String, byte[], DataType[], DataType, DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - 类 的构造器org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
PythonTableFunction - org.apache.flink.table.functions.python中的类
The wrapper of user defined python table function.
PythonTableFunction(String, byte[], TypeInformation[], RowTypeInfo, PythonFunctionKind, boolean, boolean, PythonEnv) - 类 的构造器org.apache.flink.table.functions.python.PythonTableFunction
 

R

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

S

SCALAR_EVAL - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
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中的类
A "marker" function definition of a user-defined scalar function that uses the old type system stack.
ScalarFunctionDefinition(String, ScalarFunction) - 类 的构造器org.apache.flink.table.functions.ScalarFunctionDefinition
 
scale() - 类 中的方法org.apache.flink.table.data.DecimalData
Returns the scale of this DecimalData.
ScanTableSource - org.apache.flink.table.connector.source中的接口
A DynamicTableSource that scans all rows from an external storage system during runtime.
ScanTableSource.ScanContext - org.apache.flink.table.connector.source中的接口
Context for creating runtime implementation via a ScanTableSource.ScanRuntimeProvider.
ScanTableSource.ScanRuntimeProvider - org.apache.flink.table.connector.source中的接口
Provides actual runtime implementation for reading the data.
Schema - org.apache.flink.table.api中的类
Schema of a table or view.
Schema - org.apache.flink.table.descriptors中的类
已过时。
This class was used for legacy connectors using Descriptor.
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.Builder - org.apache.flink.table.api中的类
A builder for constructing an immutable but still unresolved Schema.
Schema.UnresolvedColumn - org.apache.flink.table.api中的类
Super class for all kinds of columns in an unresolved schema.
Schema.UnresolvedComputedColumn - org.apache.flink.table.api中的类
Declaration of a computed column that will be resolved to Column.ComputedColumn during schema resolution.
Schema.UnresolvedConstraint - org.apache.flink.table.api中的类
Super class for all kinds of constraints in an unresolved schema.
Schema.UnresolvedMetadataColumn - org.apache.flink.table.api中的类
Declaration of a metadata column that will be resolved to Column.MetadataColumn during schema resolution.
Schema.UnresolvedPhysicalColumn - org.apache.flink.table.api中的类
Declaration of a physical column that will be resolved to Column.PhysicalColumn during schema resolution.
Schema.UnresolvedPrimaryKey - org.apache.flink.table.api中的类
Declaration of a primary key that will be resolved to UniqueConstraint during schema resolution.
Schema.UnresolvedWatermarkSpec - org.apache.flink.table.api中的类
Declaration of a watermark strategy that will be resolved to WatermarkSpec during schema resolution.
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
已过时。
Schema uses the legacy type key (e.g. schema.0.type = LONG) to store type information in prior v1.9. Since v1.10, Schema uses data type key (e.g. schema.0.data-type = BIGINT) to store types.
SchemaResolver - org.apache.flink.table.catalog中的接口
Resolves a Schema to a validated ResolvedSchema.
searchPartSpecAndPaths(FileSystem, Path, int) - 类 中的静态方法org.apache.flink.table.utils.PartitionPathUtils
Search all partitions in this path.
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.
segments - 类 中的变量org.apache.flink.table.data.binary.BinarySection
 
sequence(ArgumentTypeStrategy...) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a function signature like f(STRING, NUMERIC) using a sequence of ArgumentTypeStrategys.
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 ArgumentTypeStrategys.
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 ArgumentTypeStrategys.
SequenceInputTypeStrategy(List<? extends ArgumentTypeStrategy>, List<String>) - 类 的构造器org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
 
SerializationFormatFactory - org.apache.flink.table.factories中的接口
Factory for creating a EncodingFormat for SerializationSchema.
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
 
serializeCatalogTable(ResolvedCatalogTable) - 类 中的静态方法org.apache.flink.table.catalog.CatalogPropertiesUtil
Serializes the given ResolvedCatalogTable into a map of string properties.
setAvgLen(Double) - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats.Builder
 
setBoolean(int, boolean) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setBoolean(int, boolean) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setBoolean(MemorySegment[], int, boolean) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
set boolean from segments.
setBoolean(int, boolean) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
setBoolean(int, boolean) - 接口 中的方法org.apache.flink.table.data.binary.TypedSetters
 
setByte(int, byte) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setByte(int, byte) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setByte(MemorySegment[], int, byte) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
set byte from segments.
setByte(int, byte) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
setByte(int, byte) - 接口 中的方法org.apache.flink.table.data.binary.TypedSetters
 
setCollector(Collector<T>) - 类 中的方法org.apache.flink.table.functions.TableFunction
Internal use.
setDecimal(int, DecimalData, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setDecimal(int, DecimalData, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setDecimal(int, DecimalData, int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
setDecimal(int, DecimalData, int) - 接口 中的方法org.apache.flink.table.data.binary.TypedSetters
Set the decimal column value.
setDouble(int, double) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setDouble(int, double) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setDouble(MemorySegment[], int, double) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
set double from segments.
setDouble(int, double) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
setDouble(int, double) - 接口 中的方法org.apache.flink.table.data.binary.TypedSetters
 
setExpectedArguments(List<DataType>) - 类 中的方法org.apache.flink.table.types.inference.utils.AdaptedCallContext
 
setField(int, Object) - 类 中的方法org.apache.flink.table.data.GenericRowData
Sets the field value at the given position.
setFinal(boolean) - 类 中的方法org.apache.flink.table.types.logical.StructuredType.Builder
 
setFloat(int, float) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setFloat(int, float) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setFloat(MemorySegment[], int, float) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
set float from segments.
setFloat(int, float) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
setFloat(int, float) - 接口 中的方法org.apache.flink.table.data.binary.TypedSetters
 
setInputs(Object[]) - 类 中的方法org.apache.flink.table.functions.python.PythonFunctionInfo
 
setInstantiable(boolean) - 类 中的方法org.apache.flink.table.types.logical.StructuredType.Builder
 
setInt(int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setInt(int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setInt(MemorySegment[], int, int) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
set int from segments.
setInt(int, int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
setInt(int, int) - 接口 中的方法org.apache.flink.table.data.binary.TypedSetters
 
setJavaObject(T) - 类 中的方法org.apache.flink.table.data.binary.LazyBinaryFormat
Must be public as it is used during code generation.
setList(List<T>) - 类 中的方法org.apache.flink.table.api.dataview.ListView
Replaces the entire view's content with the content of the given List.
setLong(int, long) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setLong(int, long) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setLong(MemorySegment[], int, long) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
set long from segments.
setLong(int, long) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
setLong(int, long) - 接口 中的方法org.apache.flink.table.data.binary.TypedSetters
 
setMap(Map<K, V>) - 类 中的方法org.apache.flink.table.api.dataview.MapView
Replaces the entire view's content with the content of the given Map.
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
 
setNotNullAt(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setNullable(boolean) - 类 中的方法org.apache.flink.table.types.logical.StructuredType.Builder
 
setNullAt(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setNullAt(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setNullAt(int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
setNullAt(int) - 接口 中的方法org.apache.flink.table.data.binary.TypedSetters
 
setNullBoolean(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setNullByte(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setNullCount(Long) - 类 中的方法org.apache.flink.table.plan.stats.ColumnStats.Builder
 
setNullDouble(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setNullFloat(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setNullInt(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setNullLong(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setNullSerializer(boolean) - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
已过时。
 
setNullSerializer(boolean) - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
已过时。
 
setNullShort(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setOverwrite(boolean) - 接口 中的方法org.apache.flink.table.sinks.OverwritableTableSink
已过时。
Configures whether the insert should overwrite existing data or not.
setRowKind(RowKind) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setRowKind(RowKind) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
setRowKind(RowKind) - 类 中的方法org.apache.flink.table.data.GenericRowData
 
setRowKind(RowKind) - 接口 中的方法org.apache.flink.table.data.RowData
Sets the kind of change that this row describes in a changelog.
setRowKind(RowKind) - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
setShort(int, short) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setShort(int, short) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setShort(MemorySegment[], int, short) - 类 中的静态方法org.apache.flink.table.data.binary.BinarySegmentUtils
set short from segments.
setShort(int, short) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
setShort(int, short) - 接口 中的方法org.apache.flink.table.data.binary.TypedSetters
 
setStaticPartition(Map<String, String>) - 接口 中的方法org.apache.flink.table.sinks.PartitionableTableSink
已过时。
Sets the static partition into the TableSink.
setTimestamp(int, TimestampData, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
setTimestamp(int, TimestampData, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
setTimestamp(int, TimestampData, int) - 类 中的方法org.apache.flink.table.data.binary.NestedRowData
 
setTimestamp(int, TimestampData, int) - 接口 中的方法org.apache.flink.table.data.binary.TypedSetters
Set Timestamp value.
setTotalSize(int) - 类 中的方法org.apache.flink.table.data.binary.BinaryRowData
 
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
 
SIN - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SINH - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SINK_PARALLELISM - 类 中的静态变量org.apache.flink.table.factories.FactoryUtil
 
SinkProvider - org.apache.flink.table.connector.sink中的接口
Provider of a Sink instance as a runtime implementation for DynamicTableSink.
size() - 接口 中的方法org.apache.flink.table.data.ArrayData
Returns the number of elements in this array.
size() - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
size() - 类 中的方法org.apache.flink.table.data.binary.BinaryMapData
 
size() - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
size() - 类 中的方法org.apache.flink.table.data.GenericMapData
 
size() - 接口 中的方法org.apache.flink.table.data.MapData
Returns the number of key-value mappings in this map.
sizeInBytes - 类 中的变量org.apache.flink.table.data.binary.BinarySection
 
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
 
SOURCE_WATERMARK - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
SOURCE_WATERMARK - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
See SourceWatermarkTypeStrategy.
SourceProvider - org.apache.flink.table.connector.source中的接口
Provider of a Source instance as a runtime implementation for ScanTableSource.
specialize(SpecializedFunction.SpecializedContext) - 类 中的方法org.apache.flink.table.functions.BuiltInFunctionDefinition
 
specialize(SpecializedFunction.SpecializedContext) - 接口 中的方法org.apache.flink.table.functions.SpecializedFunction
Provides a runtime implementation that is specialized for the given call and session.
SpecializedFunction - org.apache.flink.table.functions中的接口
A FunctionDefinition that can provide a runtime implementation (i.e. the function's body) that is specialized for the given call and session.
SpecializedFunction.SpecializedContext - org.apache.flink.table.functions中的接口
Provides call and session information for the specialized function.
SpecificInputTypeStrategies - org.apache.flink.table.types.inference.strategies中的类
Entry point for specific input type strategies not covered in InputTypeStrategies.
SpecificTypeStrategies - org.apache.flink.table.types.inference.strategies中的类
Entry point for specific type strategies not covered in TypeStrategies.
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.
SqlCallExpression - org.apache.flink.table.expressions中的类
A call to a SQL expression.
SqlCallExpression(String) - 类 的构造器org.apache.flink.table.expressions.SqlCallExpression
 
SQRT - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
startsWith(BinaryStringData) - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
Tests if this BinaryStringData starts with the specified prefix.
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
 
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.
STRING_CONCAT - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
See StringConcatTypeStrategy.
StringData - org.apache.flink.table.data中的接口
An internal data structure representing data of CharType and VarCharType.
stripRowPrefix(DataType, String) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Removes a string prefix from the fields of the given row data type.
STRUCTURED(Class<T>, DataTypes.Field...) - 类 中的静态方法org.apache.flink.table.api.DataTypes
Data type of a user-defined object structured 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中的类
A builder for a StructuredType.
StructuredType.StructuredAttribute - org.apache.flink.table.types.logical中的类
Defines an attribute of a StructuredType.
StructuredType.StructuredComparison - org.apache.flink.table.types.logical中的枚举
Defines equality properties for scalar evaluation.
subsequence(InputTypeStrategy) - 类 中的方法org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
Defines a common InputTypeStrategy for the next arguments.
SubsequenceInputTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
An InputTypeStrategy that lets you apply other strategies for subsequences of the actual arguments.
SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder - org.apache.flink.table.types.inference.strategies中的类
SubsequenceStrategyBuilder() - 类 的构造器org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
 
substring(int, int) - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
Returns a binary string that is a substring of this binary string.
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.CatalogFactory
已过时。
Implement the Factory based stack instead.
supportedProperties() - 接口 中的方法org.apache.flink.table.factories.ModuleFactory
已过时。
Implement the Factory based stack instead.
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
 
SupportsAggregatePushDown - org.apache.flink.table.connector.source.abilities中的接口
Enables to push down the local aggregates into a ScanTableSource.
supportsAvoidingCast(LogicalType, LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeCasts
Returns whether the source type can be safely interpreted as the target type.
supportsAvoidingCast(List<LogicalType>, List<LogicalType>) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeCasts
supportsExplicitCast(LogicalType, LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeCasts
Returns whether the source type can be casted to the target type.
SupportsFilterPushDown - org.apache.flink.table.connector.source.abilities中的接口
Enables to push down filters into a ScanTableSource.
SupportsFilterPushDown.Result - org.apache.flink.table.connector.source.abilities中的类
Result of a filter push down.
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
 
SupportsLimitPushDown - org.apache.flink.table.connector.source.abilities中的接口
Enables to push down a limit (the expected maximum number of produced records) into a ScanTableSource.
supportsMetadataProjection() - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsReadingMetadata
Defines whether projections can be applied to metadata columns.
supportsNestedProjection() - 接口 中的方法org.apache.flink.table.connector.source.abilities.SupportsProjectionPushDown
Returns whether this source supports nested projection.
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
 
SupportsOverwrite - org.apache.flink.table.connector.sink.abilities中的接口
Enables to overwrite existing data in a DynamicTableSink.
SupportsPartitioning - org.apache.flink.table.connector.sink.abilities中的接口
Enables to write partitioned data in a DynamicTableSink.
SupportsPartitionPushDown - org.apache.flink.table.connector.source.abilities中的接口
Enables to pass available partitions to the planner and push down partitions into a ScanTableSource.
SupportsProjectionPushDown - org.apache.flink.table.connector.source.abilities中的接口
Enables to push down a (possibly nested) projection into a ScanTableSource.
SupportsReadingMetadata - org.apache.flink.table.connector.source.abilities中的接口
Interface for ScanTableSources that support reading metadata columns.
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
 
SupportsSourceWatermark - org.apache.flink.table.connector.source.abilities中的接口
Enables to fully rely on the watermark strategy provided by the ScanTableSource itself.
SupportsWatermarkPushDown - org.apache.flink.table.connector.source.abilities中的接口
Enables to push down a watermark strategy into a ScanTableSource.
SupportsWritingMetadata - org.apache.flink.table.connector.sink.abilities中的接口
Interface for DynamicTableSinks that support writing metadata columns.
symbol(Class<? extends Enum<? extends TableSymbol>>) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
Strategy for a symbol argument of a specific TableSymbol enum.
SymbolArgumentTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Strategy for a symbol argument of a specific TableSymbol enum.
SymbolArgumentTypeStrategy(Class<? extends Enum<? extends TableSymbol>>) - 类 的构造器org.apache.flink.table.types.inference.strategies.SymbolArgumentTypeStrategy
 
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
 

T

TABLE_AGGREGATE_ACCUMULATE - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TABLE_AGGREGATE_EMIT - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TABLE_AGGREGATE_EMIT_RETRACT - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TABLE_AGGREGATE_MERGE - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TABLE_AGGREGATE_RETRACT - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TABLE_EVAL - 类 中的静态变量org.apache.flink.table.functions.UserDefinedFunctionHelper
 
TableAggregateFunction<T,ACC> - org.apache.flink.table.functions中的类
Base class for a user-defined table aggregate function.
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中的类
A "marker" function definition of an user-defined table aggregate function that uses the old type system stack.
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中的类
已过时。
TableColumn.ComputedColumn - org.apache.flink.table.api中的类
已过时。
Representation of a computed column.
TableColumn.MetadataColumn - org.apache.flink.table.api中的类
已过时。
Representation of a metadata column.
TableColumn.PhysicalColumn - org.apache.flink.table.api中的类
已过时。
Representation of a physical column.
TableConnectorUtils - org.apache.flink.table.utils中的类
Utilities for table sources and sinks.
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中的类
Base class for TableFormatFactorys.
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.
TableFunction() - 类 的构造器org.apache.flink.table.functions.TableFunction
 
TableFunctionDefinition - org.apache.flink.table.functions中的类
A "marker" function definition of an user-defined table function that uses the old type system stack.
TableFunctionDefinition(String, TableFunction<?>, TypeInformation<?>) - 类 的构造器org.apache.flink.table.functions.TableFunctionDefinition
 
TableFunctionProvider<T> - org.apache.flink.table.connector.source中的接口
Provider of a TableFunction instance as a runtime implementation for LookupTableSource.
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中的类
已过时。
This class has been deprecated as part of FLIP-164. It has been replaced by two more dedicated classes Schema and ResolvedSchema. Use Schema for declaration in APIs. ResolvedSchema is offered by the framework after resolution and validation.
TableSchema(String[], TypeInformation<?>[]) - 类 的构造器org.apache.flink.table.api.TableSchema
已过时。
Use the TableSchema.Builder instead.
TableSchema.Builder - org.apache.flink.table.api中的类
已过时。
Builder for creating a TableSchema.
TableSchemaUtils - org.apache.flink.table.utils中的类
Utilities to TableSchema.
TableSchemaUtils() - 类 的构造器org.apache.flink.table.utils.TableSchemaUtils
 
TableSink<T> - org.apache.flink.table.sinks中的接口
已过时。
This interface has been replaced by DynamicTableSink. The new interface consumes internal data structures. See FLIP-95 for more information.
TableSinkBase<T> - org.apache.flink.table.sinks中的类
Base class for TableSink.
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.
TableSinkFactory.Context - org.apache.flink.table.factories中的接口
Context of table sink creation.
TableSinkFactoryContextImpl - org.apache.flink.table.factories中的类
Implementation of TableSinkFactory.Context.
TableSinkFactoryContextImpl(ObjectIdentifier, CatalogTable, ReadableConfig, boolean, boolean) - 类 的构造器org.apache.flink.table.factories.TableSinkFactoryContextImpl
 
TableSource<T> - org.apache.flink.table.sources中的接口
已过时。
This interface has been replaced by DynamicTableSource. The new interface produces internal data structures. See FLIP-95 for more information.
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.
TableSourceFactory.Context - org.apache.flink.table.factories中的接口
Context of table source creation.
TableSourceFactoryContextImpl - org.apache.flink.table.factories中的类
Implementation of TableSourceFactory.Context.
TableSourceFactoryContextImpl(ObjectIdentifier, CatalogTable, ReadableConfig, boolean) - 类 的构造器org.apache.flink.table.factories.TableSourceFactoryContextImpl
 
TableSourceValidation - org.apache.flink.table.sources中的类
Logic to validate TableSource types.
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.
takesRowAsInput() - 类 中的方法org.apache.flink.table.functions.python.PythonAggregateFunction
 
takesRowAsInput() - 接口 中的方法org.apache.flink.table.functions.python.PythonFunction
Returns Whether the Python function takes row as input instead of each columns of a row.
takesRowAsInput() - 类 中的方法org.apache.flink.table.functions.python.PythonScalarFunction
 
takesRowAsInput() - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
takesRowAsInput() - 类 中的方法org.apache.flink.table.functions.python.PythonTableFunction
 
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
 
TemporaryOperationListener - org.apache.flink.table.catalog中的接口
This interface is for a Catalog to listen on temporary object operations.
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中的类
已过时。
This class will be removed in future versions as it is used for the old type system. It is recommended to use DataTypes instead. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.
TimeIndicatorTypeInfo(boolean) - 类 的构造器org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
已过时。
 
TimeIntervalTypeInfo<T> - org.apache.flink.table.typeutils中的类
已过时。
This class will be removed in future versions as it is used for the old type system. It is recommended to use DataTypes instead. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.
TimeIntervalUnit - 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_LTZ(int) - 类 中的静态方法org.apache.flink.table.api.DataTypes
Data type of a timestamp WITH LOCAL time zone.
TIMESTAMP_LTZ() - 类 中的静态方法org.apache.flink.table.api.DataTypes
Data type of a timestamp WITH LOCAL time zone.
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.
TimestampData - org.apache.flink.table.data中的类
An internal data structure representing data of TimestampType and LocalZonedTimestampType.
TimestampExtractor - org.apache.flink.table.sources.tsextractors中的类
已过时。
This interface will not be supported in the new source design around DynamicTableSource. Use the concept of computed columns instead. See FLIP-95 for more information.
TimestampExtractor() - 类 的构造器org.apache.flink.table.sources.tsextractors.TimestampExtractor
已过时。
 
TimestampExtractorUtils - org.apache.flink.table.sources.tsextractors中的类
Utility methods for dealing with TimestampExtractor.
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.
TimestampStringUtils - org.apache.flink.table.utils中的类
Utils to represent a LocalDateTime to String, considered the precision.
TimestampStringUtils() - 类 的构造器org.apache.flink.table.utils.TimestampStringUtils
 
timestampToString(LocalDateTime, int) - 类 中的静态方法org.apache.flink.table.utils.TimestampStringUtils
 
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
 
timeToInternal(Time) - 类 中的静态方法org.apache.flink.table.utils.TimestampStringUtils
 
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(int) - 类 中的静态方法org.apache.flink.table.types.inference.ConstantArgumentCount
 
TO_BASE64 - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TO_INTERNAL_CLASS - 类 中的静态变量org.apache.flink.table.types.inference.TypeTransformations
Transformation that uses internal data structures for all conversion classes.
TO_TIMESTAMP_LTZ - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
toBigDecimal() - 类 中的方法org.apache.flink.table.data.DecimalData
Converts this DecimalData into an instance of BigDecimal.
toBooleanArray() - 接口 中的方法org.apache.flink.table.data.ArrayData
 
toBooleanArray() - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
toBooleanArray() - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
toByteArray() - 接口 中的方法org.apache.flink.table.data.ArrayData
 
toByteArray() - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
toByteArray() - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
toBytes(TypeSerializer<T>) - 类 中的方法org.apache.flink.table.data.binary.BinaryRawValueData
 
toBytes() - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
 
toBytes(TypeSerializer<T>) - 接口 中的方法org.apache.flink.table.data.RawValueData
Converts this RawValueData into a byte array.
toBytes() - 接口 中的方法org.apache.flink.table.data.StringData
Converts this StringData object to a UTF-8 byte array.
toDataType(DataTypeFactory) - 类 中的方法org.apache.flink.table.types.UnresolvedDataType
Converts this instance to a resolved DataType possibly enriched with additional nullability and conversion class information.
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.
toDataType(DataTypeFactory, TypeInformation<?>) - 类 中的静态方法org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
Converts the given TypeInformation into DataType.
toDataType(DataTypeFactory, TypeInformation<?>, boolean) - 类 中的静态方法org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
Converts the given TypeInformation into DataType but allows to make all fields nullable independent of the nullability in the serialization stack.
toDoubleArray() - 接口 中的方法org.apache.flink.table.data.ArrayData
 
toDoubleArray() - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
toDoubleArray() - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
toExternal(Object) - 接口 中的方法org.apache.flink.table.connector.sink.DynamicTableSink.DataStructureConverter
Converts the given internal structure into an external object.
toFloatArray() - 接口 中的方法org.apache.flink.table.data.ArrayData
 
toFloatArray() - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
toFloatArray() - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
toInstant() - 类 中的方法org.apache.flink.table.data.TimestampData
Converts this TimestampData object to a Instant.
toIntArray() - 接口 中的方法org.apache.flink.table.data.ArrayData
 
toIntArray() - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
toIntArray() - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
toInternal(Object) - 接口 中的方法org.apache.flink.table.connector.source.DynamicTableSource.DataStructureConverter
Converts the given object into an internal data structure.
toInternalConversionClass(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeUtils
Returns the conversion class for the given LogicalType that is used by the table runtime as internal data structure.
toInternalDataType(LogicalType) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Creates a DataType from the given LogicalType with internal data structures.
toInternalDataType(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Creates a DataType from the given DataType with internal data structures.
toJavaMap(LogicalType, LogicalType) - 类 中的方法org.apache.flink.table.data.binary.BinaryMapData
 
toLegacyTypeInfo(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
已过时。
 
toList() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
List of the component names of this object identifier.
toList() - 类 中的方法org.apache.flink.table.functions.FunctionIdentifier
List of the component names of this function identifier.
toLocalDateTime() - 类 中的方法org.apache.flink.table.data.TimestampData
Converts this TimestampData object to a LocalDateTime.
toLogicalType(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.LogicalTypeDataTypeConverter
Returns the logical type of a data type.
toLongArray() - 接口 中的方法org.apache.flink.table.data.ArrayData
 
toLongArray() - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
toLongArray() - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
toLowerCase() - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
Converts all of the characters in this BinaryStringData to lower case.
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.
toObject(TypeSerializer<T>) - 类 中的方法org.apache.flink.table.data.binary.BinaryRawValueData
 
toObject(TypeSerializer<T>) - 接口 中的方法org.apache.flink.table.data.RawValueData
Converts this RawValueData into a Java object.
toObjectArray(LogicalType) - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
toObjectArray() - 类 中的方法org.apache.flink.table.data.GenericArrayData
Converts this GenericArrayData into an array of Java Object.
toObjectPath() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
 
toPersistedRowDataType() - 类 中的方法org.apache.flink.table.api.TableSchema
已过时。
Converts all persisted columns of this schema into a (possibly nested) row data type.
toPhysicalRowDataType() - 类 中的方法org.apache.flink.table.api.TableSchema
已过时。
Converts all physical columns of this schema into a (possibly nested) row data type.
toPhysicalRowDataType() - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Converts all physical columns of this schema into a (possibly nested) row data type.
toProperties() - 接口 中的方法org.apache.flink.table.catalog.CatalogTable
已过时。
Only a ResolvedCatalogTable is serializable to properties.
toProperties() - 类 中的方法org.apache.flink.table.catalog.DefaultCatalogTable
 
toProperties() - 类 中的方法org.apache.flink.table.catalog.ResolvedCatalogTable
 
toProperties() - 接口 中的方法org.apache.flink.table.descriptors.Descriptor
已过时。
Converts this descriptor into a set of properties.
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.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
已过时。
Converts all columns of this schema into a (possibly nested) row data type.
toRowType() - 类 中的方法org.apache.flink.table.api.TableSchema
已过时。
toRowType(LogicalType) - 类 中的静态方法org.apache.flink.table.types.logical.utils.LogicalTypeUtils
Converts any logical type to a row type.
toSchema() - 类 中的方法org.apache.flink.table.api.TableSchema
已过时。
Helps to migrate to the new Schema class.
toShortArray() - 接口 中的方法org.apache.flink.table.data.ArrayData
 
toShortArray() - 类 中的方法org.apache.flink.table.data.binary.BinaryArrayData
 
toShortArray() - 类 中的方法org.apache.flink.table.data.GenericArrayData
 
toSinkRowDataType() - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Converts all persisted columns of this schema into a (possibly nested) row data type.
toSourceRowDataType() - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
Converts all columns of this schema into a (possibly nested) row data type.
toString() - 类 中的方法org.apache.flink.table.api.DataTypes.AbstractField
 
toString() - 类 中的方法org.apache.flink.table.api.DataTypes.Resolution
 
toString() - 类 中的方法org.apache.flink.table.api.Schema
 
toString() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedColumn
 
toString() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedComputedColumn
 
toString() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedConstraint
 
toString() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
 
toString() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
 
toString() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
 
toString() - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
 
toString() - 类 中的方法org.apache.flink.table.api.TableColumn
已过时。
 
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.Column
 
toString() - 类 中的方法org.apache.flink.table.catalog.ObjectIdentifier
 
toString() - 类 中的方法org.apache.flink.table.catalog.ObjectPath
 
toString() - 类 中的方法org.apache.flink.table.catalog.ResolvedSchema
 
toString() - 类 中的方法org.apache.flink.table.catalog.UnresolvedIdentifier
 
toString() - 类 中的方法org.apache.flink.table.catalog.WatermarkSpec
 
toString() - 类 中的方法org.apache.flink.table.connector.ChangelogMode
 
toString() - 类 中的方法org.apache.flink.table.data.binary.BinaryRawValueData
 
toString() - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
 
toString() - 类 中的方法org.apache.flink.table.data.DecimalData
 
toString() - 类 中的方法org.apache.flink.table.data.GenericRowData
 
toString() - 接口 中的方法org.apache.flink.table.data.StringData
Converts this StringData object to a String.
toString() - 类 中的方法org.apache.flink.table.data.TimestampData
 
toString() - 类 中的方法org.apache.flink.table.data.utils.JoinedRowData
 
toString() - 类 中的方法org.apache.flink.table.dataview.ListViewTypeInfo
已过时。
 
toString() - 类 中的方法org.apache.flink.table.dataview.MapViewTypeInfo
已过时。
 
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.AggregateExpression
 
toString() - 类 中的方法org.apache.flink.table.expressions.CallExpression
 
toString() - 类 中的方法org.apache.flink.table.expressions.FieldReferenceExpression
 
toString() - 类 中的方法org.apache.flink.table.expressions.SqlCallExpression
 
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.python.PythonAggregateFunction
 
toString() - 类 中的方法org.apache.flink.table.functions.python.PythonScalarFunction
 
toString() - 类 中的方法org.apache.flink.table.functions.python.PythonTableAggregateFunction
 
toString() - 类 中的方法org.apache.flink.table.functions.python.PythonTableFunction
 
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.types.UnresolvedDataType
 
toString() - 类 中的方法org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
已过时。
 
toString() - 类 中的方法org.apache.flink.table.typeutils.TimeIntervalTypeInfo
已过时。
 
toTimestamp() - 类 中的方法org.apache.flink.table.data.TimestampData
Converts this TimestampData object to a Timestamp.
toUnscaledBytes() - 类 中的方法org.apache.flink.table.data.DecimalData
Returns a byte array describing the unscaled value of this DecimalData.
toUnscaledLong() - 类 中的方法org.apache.flink.table.data.DecimalData
Returns a long describing the unscaled value of this DecimalData.
toUpperCase() - 类 中的方法org.apache.flink.table.data.binary.BinaryStringData
Converts all of the characters in this BinaryStringData to upper case.
transform(DataType) - 类 中的方法org.apache.flink.table.types.inference.transforms.DataTypeConversionClassTransformation
 
transform(DataType) - 类 中的方法org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
 
transform(DataType) - 类 中的方法org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
 
transform(DataTypeFactory, DataType) - 类 中的方法org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
 
transform(DataType) - 接口 中的方法org.apache.flink.table.types.inference.TypeTransformation
Transforms the given data type to a different data type.
transform(DataTypeFactory, 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 to a different data type using the given transformations.
transform(DataTypeFactory, DataType, TypeTransformation...) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
Transforms the given data type 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.data.binary.BinaryStringData
Returns a string whose value is this string, with any leading and trailing whitespace removed.
TRIM - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TRUNCATE - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TWO_EQUALS_COMPARABLE - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
Strategy that checks all types are equals comparable with each other.
TWO_FULLY_COMPARABLE - 类 中的静态变量org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
Strategy that checks all types are fully comparable with each other.
TYPE - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
TYPE_LITERAL - 类 中的静态变量org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that checks if an argument is a type literal.
TYPE_OF - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
TypeConversions - org.apache.flink.table.types.utils中的类
Conversion hub for interoperability of Class, TypeInformation, DataType, and LogicalType.
typedArguments(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.
typedArguments(DataType...) - 类 中的方法org.apache.flink.table.types.inference.TypeInference.Builder
 
TypedSetters - org.apache.flink.table.data.binary中的接口
Provide type specialized setters to reduce if/else and eliminate box and unbox.
TypeInference - org.apache.flink.table.types.inference中的类
Provides logic for the type inference of function calls.
TypeInference.Builder - org.apache.flink.table.types.inference中的类
Builder for configuring and creating instances of TypeInference.
TypeInferenceExtractor - org.apache.flink.table.types.extraction中的类
Reflection-based utility for extracting a TypeInference from a supported subclass of UserDefinedFunction.
TypeInferenceExtractor() - 类 的构造器org.apache.flink.table.types.extraction.TypeInferenceExtractor
 
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.
TypeInfoDataTypeConverter - org.apache.flink.table.types.utils中的类
Converter from TypeInformation to DataType.
TypeInfoDataTypeConverter() - 类 的构造器org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
 
TypeInformationRawType<T> - org.apache.flink.table.types.logical中的类
已过时。
Use RawType instead.
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
已过时。
 
TypeLiteralArgumentTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Strategy that checks if an argument is a type literal.
TypeLiteralArgumentTypeStrategy() - 类 的构造器org.apache.flink.table.types.inference.strategies.TypeLiteralArgumentTypeStrategy
 
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中的类
Utility methods for dealing with field types in TableSource and TableSink.
Types - org.apache.flink.table.api中的类
已过时。
This class will be removed in future versions as it uses the old type system. It is recommended to use DataTypes instead which uses the new type system based on instances of DataType. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.
TypeStrategies - 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中的类
已过时。
This utility is based on TypeInformation. However, the Table & SQL API is currently updated to use DataTypes based on LogicalTypes. Use LogicalTypeParser instead.
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.

U

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

V

validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.ConnectorDescriptorValidator
已过时。
 
validate(DescriptorProperties) - 接口 中的方法org.apache.flink.table.descriptors.DescriptorValidator
已过时。
Performs basic validation such as completeness tests.
validate(DescriptorProperties) - 类 中的方法org.apache.flink.table.descriptors.FileSystemValidator
已过时。
 
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.
validateClass(Class<? extends UserDefinedFunction>) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Validates a UserDefinedFunction class for usage in the API.
validateClassForRuntime(Class<? extends UserDefinedFunction>, String, Class<?>[], Class<?>, String) - 类 中的静态方法org.apache.flink.table.functions.UserDefinedFunctionHelper
Validates a UserDefinedFunction class for usage in the runtime.
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.
validateFactoryOptions(Factory, ReadableConfig) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Validates the required and optional ConfigOptions of a factory.
validateFactoryOptions(Set<ConfigOption<?>>, Set<ConfigOption<?>>, ReadableConfig) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Validates the required options and optional options.
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.
validateInputDataType(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
The DataType class can only partially verify the conversion class.
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.
validateOutputDataType(DataType) - 类 中的静态方法org.apache.flink.table.types.utils.DataTypeUtils
The DataType class can only partially verify the conversion class.
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.ExtractionUtils
Validates the characteristics of a class for a StructuredType such as accessibility.
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.
validateUnconsumedKeys(String, Set<String>, Set<String>, Set<String>) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Validates unconsumed option keys.
validateUnconsumedKeys(String, Set<String>, Set<String>) - 类 中的静态方法org.apache.flink.table.factories.FactoryUtil
Validates unconsumed option keys.
validateValue(String, String, boolean) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Validates that a certain value is present under the given key.
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
 
valueArray() - 类 中的方法org.apache.flink.table.data.binary.BinaryMapData
 
valueArray() - 类 中的方法org.apache.flink.table.data.GenericMapData
 
valueArray() - 接口 中的方法org.apache.flink.table.data.MapData
Returns an array view of the values contained in this map.
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.api.JsonExistsOnError
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.table.api.JsonValueOnEmptyOrError
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.table.catalog.CatalogBaseTable.TableKind
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.table.catalog.Constraint.ConstraintType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.table.catalog.FunctionLanguage
返回带有指定名称的该类型的枚举常量。
valueOf(BinaryArrayData, BinaryArrayData) - 类 中的静态方法org.apache.flink.table.data.binary.BinaryMapData
 
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.BuiltInPythonAggregateFunction
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.table.functions.python.PythonEnv.ExecType
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.table.functions.python.PythonFunctionKind
返回带有指定名称的该类型的枚举常量。
valueOf(String) - 枚举 中的静态方法org.apache.flink.table.functions.python.utils.PythonFunctionUtils
返回带有指定名称的该类型的枚举常量。
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.StructuredComparison
返回带有指定名称的该类型的枚举常量。
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.api.JsonExistsOnError
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.table.api.JsonValueOnEmptyOrError
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.table.catalog.CatalogBaseTable.TableKind
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.table.catalog.Constraint.ConstraintType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
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.BuiltInPythonAggregateFunction
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.table.functions.python.PythonEnv.ExecType
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.table.functions.python.PythonFunctionKind
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
values() - 枚举 中的静态方法org.apache.flink.table.functions.python.utils.PythonFunctionUtils
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
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.StructuredComparison
按照声明该枚举类型的常量的顺序, 返回 包含这些常量的数组。
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 ArgumentTypeStrategys.
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...) using a sequence of ArgumentTypeStrategys.
VaryingSequenceInputTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Strategy for inferring and validating a varying function signature like f(INT, STRING, NUMERIC...) or f(i INT, str STRING, num NUMERIC...) using a sequence of ArgumentTypeStrategys.
VaryingSequenceInputTypeStrategy(List<ArgumentTypeStrategy>, List<String>) - 类 的构造器org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
 
varyingString(TypeStrategy) - 类 中的静态方法org.apache.flink.table.types.inference.TypeStrategies
A type strategy that ensures that the result type is either LogicalTypeRoot.VARCHAR or LogicalTypeRoot.VARBINARY from their corresponding non-varying roots.
VaryingStringTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
A type strategy that ensures that the result type is either LogicalTypeRoot.VARCHAR or LogicalTypeRoot.VARBINARY from their corresponding non-varying roots.
VaryingStringTypeStrategy(TypeStrategy) - 类 的构造器org.apache.flink.table.types.inference.strategies.VaryingStringTypeStrategy
 
VIRTUAL - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
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
 

W

watermark(String, Expression) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares that the given column should serve as an event-time (i.e. rowtime) attribute and specifies a corresponding watermark strategy as an expression.
watermark(String, String) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Declares that the given column should serve as an event-time (i.e. rowtime) attribute and specifies a corresponding watermark strategy as an expression.
watermark(String, String, DataType) - 类 中的方法org.apache.flink.table.api.TableSchema.Builder
已过时。
Specifies the previously defined field as an event-time attribute and specifies the watermark strategy.
watermark(WatermarkSpec) - 类 中的方法org.apache.flink.table.api.TableSchema.Builder
已过时。
Adds the given WatermarkSpec to this builder.
WATERMARK - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
WATERMARK_ROWTIME - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
WATERMARK_STRATEGY - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
WATERMARK_STRATEGY_DATA_TYPE - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
WATERMARK_STRATEGY_EXPR - 类 中的静态变量org.apache.flink.table.descriptors.DescriptorProperties
已过时。
 
watermarksFromSource() - 类 中的方法org.apache.flink.table.descriptors.Rowtime
已过时。
Sets a built-in watermark strategy which indicates the watermarks should be preserved from the underlying DataStream API and thus preserves the assigned watermarks from the source.
watermarksFromStrategy(WatermarkStrategy) - 类 中的方法org.apache.flink.table.descriptors.Rowtime
已过时。
Sets a custom watermark strategy to be used for the rowtime attribute.
WatermarkSpec - org.apache.flink.table.api中的类
已过时。
WatermarkSpec(String, String, DataType) - 类 的构造器org.apache.flink.table.api.WatermarkSpec
已过时。
 
WatermarkSpec - org.apache.flink.table.catalog中的类
Representation of a watermark specification in a ResolvedSchema.
watermarksPeriodicAscending() - 类 中的方法org.apache.flink.table.descriptors.Rowtime
已过时。
Sets a built-in watermark strategy for ascending rowtime attributes.
watermarksPeriodicBounded(long) - 类 中的方法org.apache.flink.table.descriptors.Rowtime
已过时。
Sets a built-in watermark strategy for rowtime attributes which are out-of-order by a bounded time interval.
WatermarkStrategy - org.apache.flink.table.sources.wmstrategies中的类
Provides a strategy to generate watermarks for a rowtime attribute.
WatermarkStrategy() - 类 的构造器org.apache.flink.table.sources.wmstrategies.WatermarkStrategy
 
WILDCARD - 类 中的静态变量org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that does not perform any modification or validation of the input.
WildcardInputTypeStrategy - org.apache.flink.table.types.inference.strategies中的类
Strategy that does not perform any modification or validation of the input.
WildcardInputTypeStrategy(ArgumentCount) - 类 的构造器org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
WildcardInputTypeStrategy() - 类 的构造器org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
 
wildcardWithCount(ArgumentCount) - 类 中的静态方法org.apache.flink.table.types.inference.InputTypeStrategies
Strategy that does not perform any modification or validation of the input.
WINDOW_END - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
WINDOW_PROPERTIES - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
WINDOW_START - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
WITH_COLUMNS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
withComment(String) - 类 中的方法org.apache.flink.table.api.Schema.Builder
Apply comment to the previous column.
withComment(String) - 类 中的方法org.apache.flink.table.api.Schema.UnresolvedComputedColumn
 
withComment(String) - 类 中的方法org.apache.flink.table.catalog.Column.ComputedColumn
 
withComment(String) - 类 中的方法org.apache.flink.table.catalog.Column.MetadataColumn
 
withComment(String) - 类 中的方法org.apache.flink.table.catalog.Column.PhysicalColumn
 
withComment(String) - 类 中的方法org.apache.flink.table.catalog.Column
Add the comment to the column and return the new object.
withNullability(String, Object...) - 类 中的方法org.apache.flink.table.types.logical.LogicalType
 
WITHOUT_COLUMNS - 类 中的静态变量org.apache.flink.table.functions.BuiltInFunctionDefinitions
 
withoutKeys(List<String>) - 类 中的方法org.apache.flink.table.descriptors.DescriptorProperties
已过时。
Returns a new properties instance with the given keys removed.
wrapperToPrimitive(Class<?>) - 类 中的静态方法org.apache.flink.table.types.extraction.ExtractionUtils
Converts the specified wrapper class to its corresponding primitive class.
writeTypeInfo(TypeInformation<?>) - 类 中的静态方法org.apache.flink.table.utils.TypeStringUtils
已过时。
 

Y

YEAR(int) - 类 中的静态方法org.apache.flink.table.api.DataTypes
Resolution in years.
YEAR() - 类 中的静态方法org.apache.flink.table.api.DataTypes
Resolution in years with 2 digits for the number of years by default.
YearMonthIntervalType - org.apache.flink.table.types.logical中的类
Logical type for a group of year-month interval types.
YearMonthIntervalType(boolean, YearMonthIntervalType.YearMonthResolution, int) - 类 的构造器org.apache.flink.table.types.logical.YearMonthIntervalType
 
YearMonthIntervalType(YearMonthIntervalType.YearMonthResolution, int) - 类 的构造器org.apache.flink.table.types.logical.YearMonthIntervalType
 
YearMonthIntervalType(YearMonthIntervalType.YearMonthResolution) - 类 的构造器org.apache.flink.table.types.logical.YearMonthIntervalType
 
YearMonthIntervalType.YearMonthResolution - org.apache.flink.table.types.logical中的枚举
Supported resolutions of this type.

Z

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

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