A B C D E F G H I J K L M N O P Q R S T U V W Y Z
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- abort() - Method in interface org.apache.flink.table.catalog.StagedTable
-
This method will be called when the job is failed or is canceled.
- ABS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ABSENT - org.apache.flink.table.api.JsonOnNull
-
Omit this key from the resulting JSON.
- AbstractCatalog - Class in org.apache.flink.table.catalog
-
Abstract class for catalogs.
- AbstractCatalog(String, String) - Constructor for class org.apache.flink.table.catalog.AbstractCatalog
- AbstractCatalogStore - Class in org.apache.flink.table.catalog
-
The AbstractCatalogStore class is an abstract base class for implementing a catalog store.
- AbstractCatalogStore() - Constructor for class org.apache.flink.table.catalog.AbstractCatalogStore
- AbstractDataType<T extends AbstractDataType<T>> - Interface in org.apache.flink.table.types
-
Highest abstraction that describes the data type of a value in the table ecosystem.
- AbstractHeapVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
Heap vector that nullable shared structure.
- AbstractHeapVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- AbstractWritableVector - Class in org.apache.flink.table.data.columnar.vector.writable
-
Contains the shared structure for
ColumnVector
s, including NULL information and dictionary. - AbstractWritableVector() - Constructor for class org.apache.flink.table.data.columnar.vector.writable.AbstractWritableVector
- accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.AggregateExpression
- accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.CallExpression
- accept(ExpressionVisitor<R>) - Method in interface org.apache.flink.table.expressions.Expression
- accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.SqlCallExpression
- accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
- accept(ExpressionVisitor<R>) - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
- accept(DataTypeVisitor<R>) - Method in class org.apache.flink.table.types.AtomicDataType
- accept(DataTypeVisitor<R>) - Method in class org.apache.flink.table.types.CollectionDataType
- accept(DataTypeVisitor<R>) - Method in class org.apache.flink.table.types.DataType
- accept(DataTypeVisitor<R>) - Method in class org.apache.flink.table.types.FieldsDataType
- accept(DataTypeVisitor<R>) - Method in class org.apache.flink.table.types.KeyValueDataType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.ArrayType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.BigIntType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.BinaryType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.BooleanType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.CharType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DateType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DecimalType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DistinctType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DoubleType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.FloatType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.IntType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.LogicalType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.MapType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.MultisetType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.NullType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.RawType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.RowType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.SmallIntType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.StructuredType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.SymbolType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TimestampType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TimeType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TinyIntType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.VarBinaryType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.VarCharType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- accumulate(Object, Object...) - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- accumulate(Object, Object...) - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- accumulator() - Method in annotation type org.apache.flink.table.annotation.FunctionHint
-
Explicitly defines the intermediate result type (i.e. state entry) that an aggregating function uses as its accumulator.
- accumulatorTypeStrategy(TypeStrategy) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets the strategy for inferring the intermediate accumulator data type of an aggregate function call.
- ACOS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ACTIVATED - org.apache.flink.table.catalog.CatalogMaterializedTable.RefreshStatus
- adaptArguments(TypeInference, CallContext, DataType) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
-
Adapts the call's argument if necessary.
- AdaptedCallContext - Class in org.apache.flink.table.types.inference.utils
-
Helper context that deals with adapted arguments.
- AdaptedCallContext(CallContext, DataType) - Constructor for class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- add(Column) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to add the column at last.
- add(Column, TableChange.ColumnPosition) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to add the column with specified position.
- add(TableDistribution) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to add a distribution.
- add(UniqueConstraint) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to add a unique constraint.
- add(WatermarkSpec) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to add a watermark.
- add(TableColumn) - Method in class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.Adds a
TableColumn
to this builder. - add(T) - Method in class org.apache.flink.table.api.dataview.ListView
-
Adds the given value to the list.
- addAll(List<T>) - Method in class org.apache.flink.table.api.dataview.ListView
-
Adds all of the elements of the specified list to this list view.
- addContainedKind(RowKind) - Method in class org.apache.flink.table.connector.ChangelogMode.Builder
- addMonths(int, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Adds a given number of months to a date, represented as the number of days since the epoch.
- addMonths(long, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Adds a given number of months to a timestamp, represented as the number of milliseconds since the epoch.
- after(String) - Static method in interface org.apache.flink.table.catalog.TableChange.ColumnPosition
-
Get the position to place the column after the specified column.
- AGG_DECIMAL_MINUS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
Special "-" operator used internally for implementing SUM/AVG aggregations (with and without retractions) on a Decimal type.
- AGG_DECIMAL_PLUS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
Special "+" operator used internally for implementing SUM/AVG aggregations (with and without retractions) on a Decimal type.
- AGG_DECIMAL_PLUS - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
AggDecimalPlusTypeStrategy
. - aggArg0(Function<LogicalType, LogicalType>, boolean) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy specific for aggregations that partially produce different nullability depending whether the result is grouped or not.
- AGGREGATE - org.apache.flink.table.functions.FunctionKind
- AGGREGATE_ACCUMULATE - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- AGGREGATE_MERGE - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- AGGREGATE_RETRACT - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- AggregateExpression - Class in org.apache.flink.table.expressions
-
Resolved and validated expression for calling an aggregate function.
- AggregateExpression(FunctionDefinition, List<FieldReferenceExpression>, CallExpression, DataType, boolean, boolean, boolean) - Constructor for class org.apache.flink.table.expressions.AggregateExpression
- AggregateFunction<T,ACC> - Class in org.apache.flink.table.functions
-
Base class for a user-defined aggregate function.
- AggregateFunction() - Constructor for class org.apache.flink.table.functions.AggregateFunction
- AggregateFunctionDefinition - Class in org.apache.flink.table.functions
-
Deprecated.Non-legacy functions can simply omit this wrapper for declarations.
- AggregateFunctionDefinition(String, AggregateFunction<?, ?>, TypeInformation<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- alignGroupName(String) - Method in class org.apache.flink.table.watermark.WatermarkParams.WatermarkParamsBuilder
- alignMaxDrift(Duration) - Method in class org.apache.flink.table.watermark.WatermarkParams.WatermarkParamsBuilder
- alignUpdateInterval(Duration) - Method in class org.apache.flink.table.watermark.WatermarkParams.WatermarkParamsBuilder
- alignWatermarkEnabled() - Method in class org.apache.flink.table.watermark.WatermarkParams
- all() - Static method in class org.apache.flink.table.connector.ChangelogMode
-
Shortcut for a changelog that can contain all
RowKind
s. - all(DataType) - Static method in class org.apache.flink.table.connector.Projection
-
Create a
Projection
of all the fields in the provideddataType
. - ALL_ROWS - org.apache.flink.table.connector.sink.abilities.SupportsRowLevelUpdate.RowLevelUpdateMode
- allocateReuseBytes(int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Allocate bytes that is only for temporary usage, it should not be stored in somewhere else.
- allocateReuseChars(int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
- allOptions - Variable in class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
- allowRawGlobally() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
Defines that a RAW data type may be used for all classes that cannot be mapped to any SQL-like data type or cause an error.
- allowRawPattern() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
Defines that a RAW data type may be used for all classes that cannot be mapped to any SQL-like data type or cause an error if their class name starts with or is equal to one of the given patterns.
- alterDatabase(String, CatalogDatabase, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Modify an existing database.
- alterFunction(ObjectPath, CatalogFunction, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Modify an existing function.
- alterModel(ObjectPath, CatalogModel, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Modifies an existing model.
- alterPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Alter a partition.
- alterPartitionColumnStatistics(ObjectPath, CatalogPartitionSpec, CatalogColumnStatistics, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Update the column statistics of a table partition.
- alterPartitionStatistics(ObjectPath, CatalogPartitionSpec, CatalogTableStatistics, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Update the statistics of a table partition.
- alterTable(ObjectPath, CatalogBaseTable, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Modifies an existing table or view.
- alterTable(ObjectPath, CatalogBaseTable, List<TableChange>, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Modifies an existing table or view.
- alterTableColumnStatistics(ObjectPath, CatalogColumnStatistics, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Update the column statistics of a table.
- alterTableStatistics(ObjectPath, CatalogTableStatistics, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Update the statistics of a table.
- AmbiguousTableFactoryException - Exception in org.apache.flink.table.api
-
Deprecated.This exception is considered internal and has been erroneously placed in the *.api package. It is replaced by
AmbiguousTableFactoryException
and should not be used directly anymore. - AmbiguousTableFactoryException - Exception in org.apache.flink.table.factories
-
Exception for finding more than one
TableFactory
for the given properties. - AmbiguousTableFactoryException(List<? extends TableFactory>, Class<? extends TableFactory>, List<TableFactory>, Map<String, String>) - Constructor for exception org.apache.flink.table.api.AmbiguousTableFactoryException
-
Deprecated.
- AmbiguousTableFactoryException(List<? extends TableFactory>, Class<? extends TableFactory>, List<TableFactory>, Map<String, String>) - Constructor for exception org.apache.flink.table.factories.AmbiguousTableFactoryException
- AmbiguousTableFactoryException(List<? extends TableFactory>, Class<? extends TableFactory>, List<TableFactory>, Map<String, String>, Throwable) - Constructor for exception org.apache.flink.table.api.AmbiguousTableFactoryException
-
Deprecated.
- AmbiguousTableFactoryException(List<? extends TableFactory>, Class<? extends TableFactory>, List<TableFactory>, Map<String, String>, Throwable) - Constructor for exception org.apache.flink.table.factories.AmbiguousTableFactoryException
- and(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a conjunction of multiple
ArgumentTypeStrategy
s into one likef(NUMERIC && LITERAL)
. - AND - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- AndArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for inferring and validating an argument using a conjunction of multiple
ArgumentTypeStrategy
s into one likef(NUMERIC && LITERAL)
- AndArgumentTypeStrategy(List<? extends ArgumentTypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
- anonymous(FunctionDefinition, List<ResolvedExpression>, DataType) - Static method in class org.apache.flink.table.expressions.CallExpression
-
Creates a
CallExpression
to an anonymous function that has been declared inline without aFunctionIdentifier
. - any() - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
- ANY - org.apache.flink.table.annotation.InputGroup
-
Enables input wildcards.
- ANY - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for an argument that can be of any type.
- AnyArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for an argument that can be of any type.
- AnyArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
- anyNull() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- anyNull() - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
The bit is 1 when the field is null.
- anyNull() - Method in interface org.apache.flink.table.data.binary.NullAwareGetters
-
If no field is null, return false.
- anyNull(int[]) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- anyNull(int[]) - Method in interface org.apache.flink.table.data.binary.NullAwareGetters
-
For the input fields, if no field is null, return false.
- appendBytes(int, byte[], int, int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapBytesVector
- appendBytes(int, byte[], int, int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableBytesVector
-
Append byte[] at rowId with the provided value.
- appendRowFields(DataType, List<DataTypes.Field>) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Appends the given list of fields to an existing row data type.
- applyAggregates(List<int[]>, List<AggregateExpression>, DataType) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsAggregatePushDown
-
Provides a list of aggregate expressions and the grouping keys.
- applyChange(CatalogDescriptor) - Method in interface org.apache.flink.table.catalog.CatalogChange
-
Generate a new CatalogDescriptor after applying the change to the given descriptor.
- applyChange(CatalogDescriptor) - Method in class org.apache.flink.table.catalog.CatalogChange.CatalogCommentChange
- applyChange(CatalogDescriptor) - Method in class org.apache.flink.table.catalog.CatalogChange.CatalogConfigurationChange
- applyDeleteFilters(List<ResolvedExpression>) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsDeletePushDown
-
Provides a list of filters specified by
WHERE
clause in conjunctive form and return the acceptance status to planner during planning phase. - applyDynamicFiltering(List<String>) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsDynamicFiltering
-
Applies the candidate filter fields into the table source.
- applyFilters(List<ResolvedExpression>) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown
-
Provides a list of filters in conjunctive form.
- applyLimit(long) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsLimitPushDown
-
Provides the expected maximum number of produced records for limiting on a best-effort basis.
- applyLimit(long) - Method in interface org.apache.flink.table.legacy.sources.LimitableTableSource
-
Deprecated.Check and push down the limit to the table source.
- applyOverwrite(boolean) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsOverwrite
-
Provides whether existing data should be overwritten or not.
- applyPartitionPruning(List<Map<String, String>>) - Method in interface org.apache.flink.table.legacy.sources.PartitionableTableSource
-
Deprecated.Applies the remaining partitions to the table source.
- applyPartitions(List<Map<String, String>>) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsPartitionPushDown
-
Provides a list of remaining partitions.
- applyPredicate(List<Expression>) - Method in interface org.apache.flink.table.legacy.sources.FilterableTableSource
-
Deprecated.Check and pick all predicates this table source can support.
- applyProjection(int[][], DataType) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsProjectionPushDown
-
Provides the field index paths that should be used for a projection.
- applyReadableMetadata(List<String>) - Method in interface org.apache.flink.table.connector.format.DecodingFormat
-
Provides a list of metadata keys that the produced row must contain as appended metadata columns.
- applyReadableMetadata(List<String>, DataType) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsReadingMetadata
-
Provides a list of metadata keys that the produced
RowData
must contain as appended metadata columns. - applyRowLevelDelete(RowLevelModificationScanContext) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsRowLevelDelete
-
Applies row-level delete with
RowLevelModificationScanContext
, and return aSupportsRowLevelDelete.RowLevelDeleteInfo
. - applyRowLevelModificationScan(SupportsRowLevelModificationScan.RowLevelModificationType, RowLevelModificationScanContext) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsRowLevelModificationScan
-
Applies the type of row-level modification and the previous
RowLevelModificationScanContext
returned by previous table source scan, return a newRowLevelModificationScanContext
. - applyRowLevelUpdate(List<Column>, RowLevelModificationScanContext) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsRowLevelUpdate
-
Applies row-level update with providing the updated columns and
RowLevelModificationScanContext
, and returnSupportsRowLevelUpdate.RowLevelUpdateInfo
. - applySourceWatermark() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsSourceWatermark
-
Instructs the source to emit source-specific watermarks during runtime.
- applyStaging(SupportsStaging.StagingContext) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsStaging
-
Provides a
SupportsStaging.StagingContext
for the sink modification and return aStagedTable
. - applyStaticPartition(Map<String, String>) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsPartitioning
-
Provides the static part of a partition.
- applyWatermark(WatermarkStrategy<RowData>) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsWatermarkPushDown
-
Provides a
WatermarkStrategy
which defines how to generateWatermark
s in the stream source. - applyWritableMetadata(List<String>) - Method in interface org.apache.flink.table.connector.format.EncodingFormat
-
Provides a list of metadata keys that the consumed row will contain as appended metadata columns.
- applyWritableMetadata(List<String>, DataType) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsWritingMetadata
-
Provides a list of metadata keys that the consumed
RowData
will contain as appended metadata columns which must be persisted. - APPROXIMATE_NUMERIC - org.apache.flink.table.types.logical.LogicalTypeFamily
- ARCHIVE - org.apache.flink.table.resource.ResourceType
- areComparable(LogicalType, LogicalType, StructuredType.StructuredComparison) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- argument() - Method in annotation type org.apache.flink.table.annotation.FunctionHint
-
Deprecated.Use
FunctionHint.arguments()
instead. - argument() - Method in annotation type org.apache.flink.table.annotation.ProcedureHint
-
Deprecated.Use
ProcedureHint.arguments()
instead. - argument(int) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy that returns the n-th input argument.
- argument(int, Function<DataType, Optional<DataType>>) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy that returns the n-th input argument, mapping it.
- argument(String, ArgumentTypeStrategy) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
-
Defines that we expect a single named argument at the next position.
- argument(ArgumentTypeStrategy) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
-
Defines that we expect a single argument at the next position.
- ArgumentCount - Interface in org.apache.flink.table.types.inference
-
Defines the count of accepted arguments (including open intervals) that a function can take.
- ArgumentHint - Annotation Type in org.apache.flink.table.annotation
-
A hint that provides additional information about an argument.
- ArgumentMappingTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that returns the n-th input argument, mapping it with the provided function.
- ArgumentMappingTypeStrategy(int, Function<DataType, Optional<DataType>>) - Constructor for class org.apache.flink.table.types.inference.strategies.ArgumentMappingTypeStrategy
- argumentNames() - Method in annotation type org.apache.flink.table.annotation.FunctionHint
-
Deprecated.Use
FunctionHint.arguments()
instead. - argumentNames() - Method in annotation type org.apache.flink.table.annotation.ProcedureHint
-
Deprecated.Use
ProcedureHint.arguments()
instead. - arguments() - Method in annotation type org.apache.flink.table.annotation.FunctionHint
-
Explicitly lists the arguments that a function takes as input.
- arguments() - Method in annotation type org.apache.flink.table.annotation.ProcedureHint
-
Explicitly lists the arguments that a procedure takes as input.
- ArgumentTrait - Enum in org.apache.flink.table.annotation
-
Declares traits for
ArgumentHint
. - ArgumentTypeStrategy - Interface in org.apache.flink.table.types.inference
-
Strategy for inferring and validating a single input argument type of a function call.
- ARRAY - org.apache.flink.table.api.JsonType
- ARRAY - org.apache.flink.table.types.logical.LogicalTypeRoot
- ARRAY - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
Strategy specific for
BuiltInFunctionDefinitions.ARRAY
. - ARRAY - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
ArrayTypeStrategy
. - ARRAY(AbstractDataType<?>) - Static method in class org.apache.flink.table.api.DataTypes
-
Unresolved data type of an array of elements with same subtype.
- ARRAY(DataType) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of an array of elements with same subtype.
- ARRAY_AGG - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_APPEND - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_APPEND_PREPEND - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
- ARRAY_CONCAT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_CONTAINS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_DISTINCT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_ELEMENT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_ELEMENT - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
Type strategy specific for array element.
- ARRAY_ELEMENT_ARG - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
Argument type derived from the array element type.
- ARRAY_EXCEPT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_FULLY_COMPARABLE - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
Argument type representing the array is comparable.
- ARRAY_INTERSECT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_JOIN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_MAX - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_MIN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_POSITION - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_PREPEND - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_REMOVE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_REVERSE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_SLICE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_SORT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ARRAY_UNION - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ArrayAppendPrependTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that returns a
DataTypes.ARRAY(DataType)
with element type equal to the type of the first argument if it's not nullable or element to add is not nullable, otherwise it returnsDataTypes.ARRAY(DataType)
with type equal to the type of the element to add to array. - ArrayAppendPrependTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.ArrayAppendPrependTypeStrategy
- ArrayColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Array column vector.
- ArrayComparableElementArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
ArgumentTypeStrategy
that checks if the input argument is an ARRAY type and check whether its' elements are comparable. - ArrayComparableElementArgumentTypeStrategy(StructuredType.StructuredComparison) - Constructor for class org.apache.flink.table.types.inference.strategies.ArrayComparableElementArgumentTypeStrategy
- ArrayData - Interface in org.apache.flink.table.data
-
Base interface of an internal data structure representing data of
ArrayType
. - ArrayData.ElementGetter - Interface in org.apache.flink.table.data
-
Accessor for getting the elements of an array during runtime.
- ArrayElementTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Returns the element of an
LogicalTypeFamily.COLLECTION
type. - ArrayElementTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.ArrayElementTypeStrategy
- ArrayOfStringArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for an argument that must be an array of strings.
- ArrayOfStringArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.ArrayOfStringArgumentTypeStrategy
- ArrayType - Class in org.apache.flink.table.types.logical
-
Logical type of an array of elements with same subtype.
- ArrayType(boolean, LogicalType) - Constructor for class org.apache.flink.table.types.logical.ArrayType
- ArrayType(LogicalType) - Constructor for class org.apache.flink.table.types.logical.ArrayType
- AS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- AS - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Special sql syntax for AS.
- ASCII - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ASIN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- asMap() - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns the properties as a map copy.
- asPrefixedMap(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns the properties as a map copy with a prefix key.
- asSerializableString() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
-
Returns a string that fully serializes this instance.
- asSerializableString() - Method in class org.apache.flink.table.expressions.CallExpression
- asSerializableString() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- asSerializableString() - Method in interface org.apache.flink.table.expressions.ResolvedExpression
-
Returns a string that fully serializes this instance.
- asSerializableString() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
- asSerializableString() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
- asSerializableString() - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- asSerializableString() - Method in class org.apache.flink.table.types.logical.ArrayType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.BigIntType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.BinaryType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.BooleanType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.CharType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.DateType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.DecimalType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.DoubleType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.FloatType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.IntType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns a string that fully serializes this instance.
- asSerializableString() - Method in class org.apache.flink.table.types.logical.MapType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.MultisetType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.NullType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.RawType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.RowType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.RowType.RowField
- asSerializableString() - Method in class org.apache.flink.table.types.logical.SmallIntType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.SymbolType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.TimestampType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.TimeType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.TinyIntType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.UserDefinedType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.VarBinaryType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.VarCharType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- asSerializableString() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- asSummaryString() - Method in class org.apache.flink.table.catalog.Column
-
Returns a string that summarizes this column for printing to a console.
- asSummaryString() - Method in interface org.apache.flink.table.catalog.Constraint
-
Prints the constraint in a readable way.
- asSummaryString() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
-
Returns a string that summarizes this instance for printing to a console or log.
- asSummaryString() - Method in class org.apache.flink.table.catalog.UniqueConstraint
-
Returns constraint's summary.
- asSummaryString() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
-
Returns a string that summarizes this instance for printing to a console or log.
- asSummaryString() - Method in class org.apache.flink.table.catalog.WatermarkSpec
- asSummaryString() - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
-
Returns a string that summarizes this sink for printing to a console or log.
- asSummaryString() - Method in interface org.apache.flink.table.connector.source.DynamicTableSource
-
Returns a string that summarizes this source for printing to a console or log.
- asSummaryString() - Method in class org.apache.flink.table.expressions.AggregateExpression
- asSummaryString() - Method in class org.apache.flink.table.expressions.CallExpression
- asSummaryString() - Method in interface org.apache.flink.table.expressions.Expression
-
Returns a string that summarizes this expression for printing to a console.
- asSummaryString() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- asSummaryString() - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- asSummaryString() - Method in class org.apache.flink.table.expressions.SqlCallExpression
- asSummaryString() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
- asSummaryString() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
- asSummaryString() - Method in class org.apache.flink.table.functions.FunctionIdentifier
-
Returns a string that summarizes this instance for printing to a console or log.
- asSummaryString() - Method in interface org.apache.flink.table.legacy.api.constraints.Constraint
-
Deprecated.Prints the constraint in a readable way.
- asSummaryString() - Method in class org.apache.flink.table.legacy.api.constraints.UniqueConstraint
-
Deprecated.Returns constraint's summary.
- asSummaryString() - Method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Returns a string that summarizes this column for printing to a console.
- asSummaryString() - Method in class org.apache.flink.table.legacy.api.WatermarkSpec
-
Deprecated.
- asSummaryString() - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- asSummaryString() - Method in class org.apache.flink.table.refresh.ContinuousRefreshHandler
- asSummaryString() - Method in interface org.apache.flink.table.refresh.RefreshHandler
-
Returns a string that summarizes this refresh handler meta information for printing to a console or log.
- asSummaryString() - Method in class org.apache.flink.table.types.logical.ArrayType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.BinaryType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.CharType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns a string that summarizes this type for printing to a console.
- asSummaryString() - Method in class org.apache.flink.table.types.logical.MapType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.MultisetType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.RawType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.RowType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.RowType.RowField
- asSummaryString() - Method in class org.apache.flink.table.types.logical.StructuredType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- asSummaryString() - Method in class org.apache.flink.table.types.logical.SymbolType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.TimestampType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.VarBinaryType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.VarCharType
- asSummaryString() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- ASYNC_SCALAR - org.apache.flink.table.functions.FunctionKind
- ASYNC_SCALAR_EVAL - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- ASYNC_TABLE - org.apache.flink.table.functions.FunctionKind
- ASYNC_TABLE_EVAL - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- asyncLookup(RowData) - Method in class org.apache.flink.table.functions.AsyncLookupFunction
-
Asynchronously lookup rows matching the lookup keys.
- AsyncLookupFunction - Class in org.apache.flink.table.functions
-
A wrapper class of
AsyncTableFunction
for asynchronously lookup rows matching the lookup keys from external system. - AsyncLookupFunction() - Constructor for class org.apache.flink.table.functions.AsyncLookupFunction
- AsyncLookupFunctionProvider - Interface in org.apache.flink.table.connector.source.lookup
-
A provider for creating
AsyncLookupFunction
. - AsyncScalarFunction - Class in org.apache.flink.table.functions
-
Base class for a user-defined scalar function which returns results asynchronously.
- AsyncScalarFunction() - Constructor for class org.apache.flink.table.functions.AsyncScalarFunction
- AsyncTableFunction<T> - Class in org.apache.flink.table.functions
-
Base class for a user-defined asynchronous table function.
- AsyncTableFunction() - Constructor for class org.apache.flink.table.functions.AsyncTableFunction
- AsyncTableFunctionProvider<T> - Interface in org.apache.flink.table.legacy.connector.source
-
Deprecated.Please use
AsyncLookupFunctionProvider
to implement asynchronous lookup table. - AT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ATAN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ATAN2 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- AtomicDataType - Class in org.apache.flink.table.types
-
A data type that does not contain further data types (e.g.
- AtomicDataType(LogicalType) - Constructor for class org.apache.flink.table.types.AtomicDataType
- AtomicDataType(LogicalType, Class<?>) - Constructor for class org.apache.flink.table.types.AtomicDataType
- attributes(List<StructuredType.StructuredAttribute>) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
- AUTOMATIC - org.apache.flink.table.catalog.CatalogMaterializedTable.LogicalRefreshMode
-
The refresh pipeline mode is determined by freshness of materialized table, either
CatalogMaterializedTable.RefreshMode.FULL
orCatalogMaterializedTable.RefreshMode.CONTINUOUS
. - AVG - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- AVG - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
B
- begin() - Method in interface org.apache.flink.table.catalog.StagedTable
-
This method will be called when the job is started.
- between(int, int) - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
- BETWEEN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- BIGINT - org.apache.flink.table.types.logical.LogicalTypeRoot
- BIGINT() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of an 8-byte signed integer with values from -9,223,372,036,854,775,808 to 9,223,372,036,854,775,807.
- BigIntType - Class in org.apache.flink.table.types.logical
-
Logical type of an 8-byte signed integer with values from -9,223,372,036,854,775,808 to 9,223,372,036,854,775,807.
- BigIntType() - Constructor for class org.apache.flink.table.types.logical.BigIntType
- BigIntType(boolean) - Constructor for class org.apache.flink.table.types.logical.BigIntType
- BIN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- BINARY - org.apache.flink.table.types.logical.LogicalTypeRoot
- BINARY(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a fixed-length binary string (=a sequence of bytes)
BINARY(n)
wheren
is the number of bytes. - BINARY_OP - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Binary operator syntax, as in "x - y".
- BINARY_STRING - org.apache.flink.table.types.logical.LogicalTypeFamily
- BinaryArrayData - Class in org.apache.flink.table.data.binary
-
A binary implementation of
ArrayData
which is backed byMemorySegment
s. - BinaryArrayData() - Constructor for class org.apache.flink.table.data.binary.BinaryArrayData
- BinaryFormat - Interface in org.apache.flink.table.data.binary
-
Binary format spanning
MemorySegment
s. - BinaryMapData - Class in org.apache.flink.table.data.binary
-
[4 byte(keyArray size in bytes)] + [Key BinaryArray] + [Value BinaryArray].
- BinaryMapData() - Constructor for class org.apache.flink.table.data.binary.BinaryMapData
- BinaryRawValueData<T> - Class in org.apache.flink.table.data.binary
-
A lazily binary implementation of
RawValueData
which is backed byMemorySegment
s and genericObject
. - BinaryRawValueData(MemorySegment[], int, int) - Constructor for class org.apache.flink.table.data.binary.BinaryRawValueData
- BinaryRawValueData(MemorySegment[], int, int, T) - Constructor for class org.apache.flink.table.data.binary.BinaryRawValueData
- BinaryRawValueData(T) - Constructor for class org.apache.flink.table.data.binary.BinaryRawValueData
- BinaryRowData - Class in org.apache.flink.table.data.binary
-
An implementation of
RowData
which is backed byMemorySegment
instead of Object. - BinaryRowData(int) - Constructor for class org.apache.flink.table.data.binary.BinaryRowData
- BinarySection - Class in org.apache.flink.table.data.binary
-
A basic implementation of
BinaryFormat
which describe a section of memory. - BinarySection() - Constructor for class org.apache.flink.table.data.binary.BinarySection
- BinarySection(MemorySegment[], int, int) - Constructor for class org.apache.flink.table.data.binary.BinarySection
- BinarySegmentUtils - Class in org.apache.flink.table.data.binary
-
Utilities for binary data segments which heavily uses
MemorySegment
. - BinaryStringData - Class in org.apache.flink.table.data.binary
- BinaryStringData() - Constructor for class org.apache.flink.table.data.binary.BinaryStringData
- BinaryStringData(String) - Constructor for class org.apache.flink.table.data.binary.BinaryStringData
- BinaryStringData(MemorySegment[], int, int) - Constructor for class org.apache.flink.table.data.binary.BinaryStringData
- BinaryStringData(MemorySegment[], int, int, String) - Constructor for class org.apache.flink.table.data.binary.BinaryStringData
- BinaryType - Class in org.apache.flink.table.types.logical
-
Logical type of a fixed-length binary string (=a sequence of bytes).
- BinaryType() - Constructor for class org.apache.flink.table.types.logical.BinaryType
- BinaryType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.BinaryType
- BinaryType(int) - Constructor for class org.apache.flink.table.types.logical.BinaryType
- bitGet(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
read bit from segments.
- bitGet(MemorySegment, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
read bit.
- bitSet(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set bit from segments.
- bitSet(MemorySegment, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set bit.
- bitUnSet(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
unset bit from segments.
- bitUnSet(MemorySegment, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
unset bit.
- blankString(int) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
-
Creates a
BinaryStringData
instance that contains `length` spaces. - BOOLEAN - org.apache.flink.table.types.logical.LogicalTypeRoot
- BOOLEAN() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a boolean with a (possibly) three-valued logic of
TRUE, FALSE, UNKNOWN
. - BOOLEAN() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API boolean or SQL BOOLEAN type.
- BooleanColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Boolean column vector.
- BooleanType - Class in org.apache.flink.table.types.logical
-
Logical type of a boolean with a (possibly) three-valued logic of
TRUE, FALSE, UNKNOWN
. - BooleanType() - Constructor for class org.apache.flink.table.types.logical.BooleanType
- BooleanType(boolean) - Constructor for class org.apache.flink.table.types.logical.BooleanType
- bridgedTo() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
Adds a hint that data should be represented using the given class when entering or leaving the table ecosystem.
- bridgedTo(Class<?>) - Method in interface org.apache.flink.table.types.AbstractDataType
-
Adds a hint that data should be represented using the given class when entering or leaving the table ecosystem.
- bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.AtomicDataType
- bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.CollectionDataType
- bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.FieldsDataType
- bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.KeyValueDataType
- bridgedTo(Class<?>) - Method in class org.apache.flink.table.types.UnresolvedDataType
- BTRIM - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- buffer - Variable in class org.apache.flink.table.data.columnar.vector.heap.HeapBytesVector
-
buffer to use when actually copying in data.
- build() - Method in class org.apache.flink.table.api.Schema.Builder
-
Returns an instance of an unresolved
Schema
. - build() - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- build() - Method in class org.apache.flink.table.catalog.CatalogStoreHolder.Builder
- build() - Method in class org.apache.flink.table.catalog.CatalogTable.Builder
- build() - Method in class org.apache.flink.table.connector.ChangelogMode.Builder
- build() - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache.Builder
-
Creates the cache.
- build() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
- build() - Method in class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.Returns a
TableSchema
instance. - build() - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
- build() - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
- build() - Method in class org.apache.flink.table.types.logical.DistinctType.Builder
- build() - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
- build() - Method in class org.apache.flink.table.watermark.WatermarkParams.WatermarkParamsBuilder
- builder() - Static method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.
- builder() - Static method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
- builder() - Static method in class org.apache.flink.table.watermark.WatermarkParams
- Builder() - Constructor for class org.apache.flink.table.catalog.CatalogStoreHolder.Builder
- Builder() - Constructor for class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache.Builder
- Builder() - Constructor for class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
- Builder() - Constructor for class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.
- Builder() - Constructor for class org.apache.flink.table.plan.stats.ColumnStats.Builder
- Builder() - Constructor for class org.apache.flink.table.types.inference.TypeInference.Builder
- Builder(Class<?>) - Constructor for class org.apache.flink.table.types.logical.StructuredType.Builder
- Builder(ObjectIdentifier) - Constructor for class org.apache.flink.table.types.logical.StructuredType.Builder
- Builder(ObjectIdentifier, Class<?>) - Constructor for class org.apache.flink.table.types.logical.StructuredType.Builder
- Builder(ObjectIdentifier, LogicalType) - Constructor for class org.apache.flink.table.types.logical.DistinctType.Builder
- builderWithGivenSchema(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
-
Creates a builder with given table schema.
- BuiltInFunctionDefinition - Class in org.apache.flink.table.functions
-
Definition of a built-in function.
- BuiltInFunctionDefinition.Builder - Class in org.apache.flink.table.functions
-
Builder for fluent definition of built-in functions.
- BuiltInFunctionDefinitions - Class in org.apache.flink.table.functions
-
Dictionary of function definitions for all built-in functions.
- BuiltInFunctionDefinitions() - Constructor for class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- BuiltInPythonAggregateFunction - Enum in org.apache.flink.table.functions.python
-
The list of the built-in aggregate functions which can be mixed with the Python UDAF.
- bulkGetPartitionColumnStatistics(ObjectPath, List<CatalogPartitionSpec>) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get a list of column statistics for given partitions.
- bulkGetPartitionStatistics(ObjectPath, List<CatalogPartitionSpec>) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get a list of statistics of given partitions.
- BYTE() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API byte or SQL TINYINT type.
- BYTE_ARRAY_OFFSET - Static variable in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- byteAt(int) - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Returns the
byte
value at the specified index. - ByteColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Byte column vector.
- Bytes(byte[], int, int) - Constructor for class org.apache.flink.table.data.columnar.vector.BytesColumnVector.Bytes
- BYTES() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a variable-length binary string (=a sequence of bytes) with defined maximum length.
- BytesColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Bytes column vector to get
BytesColumnVector.Bytes
, it include original data and offset and length. - BytesColumnVector.Bytes - Class in org.apache.flink.table.data.columnar.vector
-
Bytes data.
C
- CACHE_TYPE - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- cacheMissingKey(boolean) - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache.Builder
-
Specifies whether to cache empty value into the cache.
- CacheReloadTrigger - Interface in org.apache.flink.table.connector.source.lookup.cache.trigger
-
Customized trigger for reloading lookup table entries.
- CacheReloadTrigger.Context - Interface in org.apache.flink.table.connector.source.lookup.cache.trigger
-
Context of
CacheReloadTrigger
for getting information about times and triggering reload. - calculateBitSetWidthInBytes(int) - Static method in class org.apache.flink.table.data.binary.BinaryRowData
- calculateFixLengthPartSize(LogicalType) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
-
It store real value when type is primitive.
- calculateFixPartSizeInBytes(int) - Static method in class org.apache.flink.table.data.binary.BinaryRowData
- calculateHeaderInBytes(int) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
- CallContext - Interface in org.apache.flink.table.types.inference
-
Provides details about a function call during
TypeInference
. - CallExpression - Class in org.apache.flink.table.expressions
-
Resolved and validated call expression for calling a function.
- CallExpression(boolean, FunctionIdentifier, FunctionDefinition, List<ResolvedExpression>, DataType) - Constructor for class org.apache.flink.table.expressions.CallExpression
- callSyntax(String, SqlCallSyntax) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Overwrites the syntax used for unparsing a function into a SQL string.
- callSyntax(SqlCallSyntax) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Overwrites the syntax used for unparsing a function into a SQL string.
- canBeTimeAttributeType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- canEqual(Object) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- canEqual(Object) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- canEqual(Object) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- CARDINALITY - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- cast(IN) - Method in interface org.apache.flink.table.data.utils.CastExecutor
-
Cast the input value.
- CAST - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CAST - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Special sql syntax for CAST operators (CAST, TRY_CAST, REINTERPRET_CAST).
- CAST - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
See
CastInputTypeStrategy
. - CastExecutor<IN,OUT> - Interface in org.apache.flink.table.data.utils
-
Interface to model a function that performs the casting of a value from one type to another.
- Catalog - Interface in org.apache.flink.table.catalog
-
This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.
- CATALOG_TYPE - Static variable in class org.apache.flink.table.catalog.CommonCatalogOptions
-
ConfigOption
which is used during catalog discovery to match it againstFactory.factoryIdentifier()
. - CatalogBaseTable - Interface in org.apache.flink.table.catalog
-
A common parent that describes the unresolved metadata of a table or view in a catalog.
- CatalogBaseTable.TableKind - Enum in org.apache.flink.table.catalog
-
The kind of
CatalogBaseTable
. - CatalogChange - Interface in org.apache.flink.table.catalog
-
CatalogChange
represents the modification of the catalog. - CatalogChange.CatalogCommentChange - Class in org.apache.flink.table.catalog
-
A catalog change to modify the comment.
- CatalogChange.CatalogConfigurationChange - Class in org.apache.flink.table.catalog
-
A catalog change to modify the catalog configuration.
- CatalogColumnStatistics - Class in org.apache.flink.table.catalog.stats
-
Column statistics of a table or partition.
- CatalogColumnStatistics(Map<String, CatalogColumnStatisticsDataBase>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
- CatalogColumnStatistics(Map<String, CatalogColumnStatisticsDataBase>, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
- CatalogColumnStatisticsDataBase - Class in org.apache.flink.table.catalog.stats
-
Column statistics value base class.
- CatalogColumnStatisticsDataBase(Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
- CatalogColumnStatisticsDataBase(Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
- CatalogColumnStatisticsDataBinary - Class in org.apache.flink.table.catalog.stats
-
Column statistics value of binary type.
- CatalogColumnStatisticsDataBinary(Long, Double, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
- CatalogColumnStatisticsDataBinary(Long, Double, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
- CatalogColumnStatisticsDataBoolean - Class in org.apache.flink.table.catalog.stats
-
Column statistics value of boolean type.
- CatalogColumnStatisticsDataBoolean(Long, Long, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
- CatalogColumnStatisticsDataBoolean(Long, Long, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
- CatalogColumnStatisticsDataDate - Class in org.apache.flink.table.catalog.stats
-
Column statistics value of date type.
- CatalogColumnStatisticsDataDate(Date, Date, Long, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
- CatalogColumnStatisticsDataDate(Date, Date, Long, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
- CatalogColumnStatisticsDataDouble - Class in org.apache.flink.table.catalog.stats
-
Column statistics value of double type.
- CatalogColumnStatisticsDataDouble(Double, Double, Long, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
- CatalogColumnStatisticsDataDouble(Double, Double, Long, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
- CatalogColumnStatisticsDataLong - Class in org.apache.flink.table.catalog.stats
-
Column statistics value of long type.
- CatalogColumnStatisticsDataLong(Long, Long, Long, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
- CatalogColumnStatisticsDataLong(Long, Long, Long, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
- CatalogColumnStatisticsDataString - Class in org.apache.flink.table.catalog.stats
-
Column statistics value of string type.
- CatalogColumnStatisticsDataString(Long, Double, Long, Long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
- CatalogColumnStatisticsDataString(Long, Double, Long, Long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
- CatalogCommentChange(String) - Constructor for class org.apache.flink.table.catalog.CatalogChange.CatalogCommentChange
- CatalogConfigurationChange(Consumer<Configuration>) - Constructor for class org.apache.flink.table.catalog.CatalogChange.CatalogConfigurationChange
- CatalogDatabase - Interface in org.apache.flink.table.catalog
-
Interface of a database in a catalog.
- CatalogDescriptor - Class in org.apache.flink.table.catalog
-
Describes a
Catalog
with the catalog name and configuration. - CatalogException - Exception in org.apache.flink.table.catalog.exceptions
-
A catalog-related, runtime exception.
- CatalogException(String) - Constructor for exception org.apache.flink.table.catalog.exceptions.CatalogException
- CatalogException(String, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.CatalogException
- CatalogException(Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.CatalogException
- CatalogFactory - Interface in org.apache.flink.table.factories
-
A factory to create configured catalog instances based on string-based properties.
- CatalogFactory.Context - Interface in org.apache.flink.table.factories
-
Context provided when a catalog is created.
- CatalogFactoryHelper(CatalogFactory, CatalogFactory.Context) - Constructor for class org.apache.flink.table.factories.FactoryUtil.CatalogFactoryHelper
- CatalogFunction - Interface in org.apache.flink.table.catalog
-
Interface for a function in a catalog.
- CatalogMaterializedTable - Interface in org.apache.flink.table.catalog
-
Represents the unresolved metadata of a materialized table in a
Catalog
. - CatalogMaterializedTable.Builder - Class in org.apache.flink.table.catalog
-
Builder for configuring and creating instances of
CatalogMaterializedTable
. - CatalogMaterializedTable.LogicalRefreshMode - Enum in org.apache.flink.table.catalog
-
The logical refresh mode of materialized table.
- CatalogMaterializedTable.RefreshMode - Enum in org.apache.flink.table.catalog
-
The physical refresh mode of materialized table.
- CatalogMaterializedTable.RefreshStatus - Enum in org.apache.flink.table.catalog
-
Background refresh pipeline status of materialized table.
- CatalogModel - Interface in org.apache.flink.table.catalog
-
Interface for a model in a catalog.
- CatalogNotExistException - Exception in org.apache.flink.table.api
-
Exception for an operation on a nonexistent catalog.
- CatalogNotExistException(String) - Constructor for exception org.apache.flink.table.api.CatalogNotExistException
- CatalogNotExistException(String, Throwable) - Constructor for exception org.apache.flink.table.api.CatalogNotExistException
- CatalogPartition - Interface in org.apache.flink.table.catalog
-
Represents a partition object in catalog.
- CatalogPartitionSpec - Class in org.apache.flink.table.catalog
-
Represents a partition spec object in catalog.
- CatalogPartitionSpec(Map<String, String>) - Constructor for class org.apache.flink.table.catalog.CatalogPartitionSpec
- CatalogPropertiesUtil - Class in org.apache.flink.table.catalog
-
Utilities for de/serializing
Catalog
objects into a map of string properties. - catalogStore() - Method in class org.apache.flink.table.catalog.CatalogStoreHolder
- catalogStore(CatalogStore) - Method in class org.apache.flink.table.catalog.CatalogStoreHolder.Builder
- CatalogStore - Interface in org.apache.flink.table.catalog
-
Represents the storage where persists all
Catalog
s. - CatalogStoreFactory - Interface in org.apache.flink.table.factories
-
A factory to create configured catalog store instances based on string-based properties.
- CatalogStoreFactory.Context - Interface in org.apache.flink.table.factories
-
Context provided when a catalog store is created.
- CatalogStoreFactoryHelper(CatalogStoreFactory, CatalogStoreFactory.Context) - Constructor for class org.apache.flink.table.factories.FactoryUtil.CatalogStoreFactoryHelper
- CatalogStoreHolder - Class in org.apache.flink.table.catalog
-
A holder for a
CatalogStore
instance and the necessary information for creating and initializingCatalog
instances, including aCatalogStoreFactory
, aReadableConfig
instance, and aClassLoader
instance. - CatalogStoreHolder.Builder - Class in org.apache.flink.table.catalog
-
Builder for a fluent definition of a
CatalogStoreHolder
. - CatalogTable - Interface in org.apache.flink.table.catalog
-
Represents the unresolved metadata of a table in a
Catalog
. - CatalogTable.Builder - Class in org.apache.flink.table.catalog
-
Builder for configuring and creating instances of
CatalogTable
. - CatalogTableStatistics - Class in org.apache.flink.table.catalog.stats
-
Statistics for a non-partitioned table or a partition of a partitioned table.
- CatalogTableStatistics(long, int, long, long) - Constructor for class org.apache.flink.table.catalog.stats.CatalogTableStatistics
- CatalogTableStatistics(long, int, long, long, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.stats.CatalogTableStatistics
- CatalogView - Interface in org.apache.flink.table.catalog
-
Represents the unresolved metadata of a view in a
Catalog
. - CEIL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CENTURY - org.apache.flink.table.expressions.TimeIntervalUnit
- CENTURY - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- CENTURY - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- changelogMode() - Method in interface org.apache.flink.table.functions.TableSemantics
-
Actual changelog mode for the passed table.
- ChangelogMode - Class in org.apache.flink.table.connector
-
The set of changes contained in a changelog.
- ChangelogMode.Builder - Class in org.apache.flink.table.connector
-
Builder for configuring and creating instances of
ChangelogMode
. - CHAR - org.apache.flink.table.types.logical.LogicalTypeRoot
- CHAR(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a fixed-length character string
CHAR(n)
wheren
is the number of code points. - CHAR_LENGTH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CHARACTER_STRING - org.apache.flink.table.types.logical.LogicalTypeFamily
- CharType - Class in org.apache.flink.table.types.logical
-
Logical type of a fixed-length character string.
- CharType() - Constructor for class org.apache.flink.table.types.logical.CharType
- CharType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.CharType
- CharType(int) - Constructor for class org.apache.flink.table.types.logical.CharType
- checkOnlyPhysicalColumns(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
-
Throws an exception if the given
TableSchema
contains any non-physical columns. - checkOpenState() - Method in class org.apache.flink.table.catalog.AbstractCatalogStore
-
Checks whether the catalog store is currently open.
- checkPhysicalLogicalTypeCompatible(LogicalType, LogicalType, String, String, boolean) - Static method in class org.apache.flink.table.utils.TypeMappingUtils
-
Checks whether the given physical field type and logical field type are compatible at the edges of the table ecosystem.
- checkWatermarkOptions(ReadableConfig) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Check watermark-related options and return error messages.
- CHR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ClassDataTypeConverter - Class in org.apache.flink.table.types.utils
-
Class-based data type extractor that supports extraction of clearly identifiable data types for input and output conversion.
- classForName(String, boolean, ClassLoader) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Similar to
Class.forName(String, boolean, ClassLoader)
but resolves primitive names as well. - classloader(ClassLoader) - Method in class org.apache.flink.table.catalog.CatalogStoreHolder.Builder
- classLoader() - Method in class org.apache.flink.table.catalog.CatalogStoreHolder
- clear() - Method in interface org.apache.flink.table.api.dataview.DataView
-
Clears the
DataView
and removes all data. - clear() - Method in class org.apache.flink.table.api.dataview.ListView
-
Removes all of the elements from this list view.
- clear() - Method in class org.apache.flink.table.api.dataview.MapView
-
Removes all entries of this map.
- clear() - Method in class org.apache.flink.table.data.binary.BinaryRowData
- close() - Method in class org.apache.flink.table.catalog.AbstractCatalogStore
-
Closes the catalog store.
- close() - Method in interface org.apache.flink.table.catalog.Catalog
-
Close the catalog when it is no longer needed and release any resource that it might be holding.
- close() - Method in interface org.apache.flink.table.catalog.CatalogStore
-
Close the catalog store when it is no longer needed and release any resource that it might be holding.
- close() - Method in class org.apache.flink.table.catalog.CatalogStoreHolder
- close() - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache
- close() - Method in class org.apache.flink.table.connector.source.lookup.cache.trigger.PeriodicCacheReloadTrigger
- close() - Method in class org.apache.flink.table.connector.source.lookup.cache.trigger.TimedCacheReloadTrigger
- close() - Method in interface org.apache.flink.table.factories.CatalogStoreFactory
-
Close the CatalogStoreFactory.
- close() - Method in interface org.apache.flink.table.functions.SpecializedFunction.ExpressionEvaluator
-
Closes the runtime implementation for expression evaluation.
- close() - Method in class org.apache.flink.table.functions.UserDefinedFunction
-
Tear-down method for user-defined function.
- close() - Method in interface org.apache.flink.table.workflow.WorkflowScheduler
-
Close this workflow scheduler when it is no longer needed and release any resource that it might be holding.
- COALESCE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- collect(T) - Method in class org.apache.flink.table.functions.ProcessTableFunction
-
Emits an (implicit or explicit) output row.
- collect(T) - Method in class org.apache.flink.table.functions.TableFunction
-
Emits an (implicit or explicit) output row.
- COLLECT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- COLLECT - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
CollectTypeStrategy
. - COLLECTION - org.apache.flink.table.types.logical.LogicalTypeFamily
- COLLECTION_CTOR - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Function syntax for collection ctors, such as ARRAY[1, 2, 3] or MAP['a', 1, 'b', 2].
- CollectionDataType - Class in org.apache.flink.table.types
-
A data type that contains an element type (e.g.
- CollectionDataType(LogicalType, Class<?>, DataType) - Constructor for class org.apache.flink.table.types.CollectionDataType
- CollectionDataType(LogicalType, DataType) - Constructor for class org.apache.flink.table.types.CollectionDataType
- collectMethods(Class<?>, String) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Collects methods of the given name.
- CollectTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that returns a
DataTypes.MULTISET(DataType)
with element type equal to the type of the first argument. - CollectTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.CollectTypeStrategy
- column() - Method in class org.apache.flink.table.catalog.TableChange.After
- column(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a physical column that is appended to this schema.
- column(String, AbstractDataType<?>) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a physical column that is appended to this schema.
- Column - Class in org.apache.flink.table.catalog
-
Representation of a column in a
ResolvedSchema
. - Column.ComputedColumn - Class in org.apache.flink.table.catalog
-
Representation of a computed column.
- Column.MetadataColumn - Class in org.apache.flink.table.catalog
-
Representation of a metadata column.
- Column.PhysicalColumn - Class in org.apache.flink.table.catalog
-
Representation of a physical column.
- ColumnarArrayData - Class in org.apache.flink.table.data.columnar
-
Columnar array to support access to vector column data.
- ColumnarArrayData(ColumnVector, int, int) - Constructor for class org.apache.flink.table.data.columnar.ColumnarArrayData
- ColumnarMapData - Class in org.apache.flink.table.data.columnar
-
Columnar map to support access to vector column data.
- ColumnarMapData(ColumnVector, ColumnVector, int, int) - Constructor for class org.apache.flink.table.data.columnar.ColumnarMapData
- ColumnarRowData - Class in org.apache.flink.table.data.columnar
-
Columnar row to support access to vector column data.
- ColumnarRowData() - Constructor for class org.apache.flink.table.data.columnar.ColumnarRowData
- ColumnarRowData(VectorizedColumnBatch) - Constructor for class org.apache.flink.table.data.columnar.ColumnarRowData
- ColumnarRowData(VectorizedColumnBatch, int) - Constructor for class org.apache.flink.table.data.columnar.ColumnarRowData
- columnByExpression(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a computed column that is appended to this schema.
- columnByExpression(String, Expression) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a computed column that is appended to this schema.
- columnByMetadata(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columnByMetadata(String, String, String, boolean) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columnByMetadata(String, AbstractDataType<?>) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columnByMetadata(String, AbstractDataType<?>, boolean) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columnByMetadata(String, AbstractDataType<?>, String) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columnByMetadata(String, AbstractDataType<?>, String, boolean) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columns - Variable in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- ColumnStats - Class in org.apache.flink.table.plan.stats
-
Column statistics.
- ColumnStats(Long, Long, Double, Integer, Comparable<?>, Comparable<?>) - Constructor for class org.apache.flink.table.plan.stats.ColumnStats
- ColumnStats.Builder - Class in org.apache.flink.table.plan.stats
-
ColumnStats builder.
- ColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Nullable column vector.
- comment - Variable in class org.apache.flink.table.catalog.Column
- comment(String) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- comment(String) - Method in class org.apache.flink.table.catalog.CatalogTable.Builder
- COMMENT - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- commit() - Method in interface org.apache.flink.table.catalog.StagedTable
-
This method will be called when the job succeeds.
- COMMON - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy that returns a common, least restrictive type of all arguments.
- COMMON_ARG - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Argument type strategy that checks and casts for a common, least restrictive type of all arguments.
- COMMON_ARG_NULLABLE - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Argument type strategy that checks and casts for a common, least restrictive type of all arguments.
- CommonArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Argument type strategy that checks and casts for a common, least restrictive type of all arguments.
- CommonArgumentTypeStrategy(boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.CommonArgumentTypeStrategy
- CommonArrayInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
InputTypeStrategy
that expects that all arguments have a common array type. - CommonArrayInputTypeStrategy(ArgumentCount) - Constructor for class org.apache.flink.table.types.inference.strategies.CommonArrayInputTypeStrategy
- commonArrayType(int) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
An
InputTypeStrategy
that expectscount
arguments that have a common array type. - CommonCatalogOptions - Class in org.apache.flink.table.catalog
-
A collection of
ConfigOption
which are consistently used in multiple catalogs. - CommonCatalogOptions() - Constructor for class org.apache.flink.table.catalog.CommonCatalogOptions
- CommonCollectionInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
InputTypeStrategy
that expects that all arguments have a common type. - CommonCollectionInputTypeStrategy(ArgumentCount, String, LogicalTypeRoot) - Constructor for class org.apache.flink.table.types.inference.strategies.CommonCollectionInputTypeStrategy
- CommonInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
InputTypeStrategy
that expects that all arguments have a common type. - CommonInputTypeStrategy(ArgumentCount) - Constructor for class org.apache.flink.table.types.inference.strategies.CommonInputTypeStrategy
- CommonMapInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
InputTypeStrategy
that expects that all arguments have a common map type. - CommonMapInputTypeStrategy(ArgumentCount) - Constructor for class org.apache.flink.table.types.inference.strategies.CommonMapInputTypeStrategy
- commonMapType(int) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
An
InputTypeStrategy
that expectsminCount
arguments that have a common map type. - CommonModuleOptions - Class in org.apache.flink.table.module
-
A collection of
ConfigOption
which are consistently used in multiple modules. - CommonModuleOptions() - Constructor for class org.apache.flink.table.module.CommonModuleOptions
- commonMultipleArrayType(int) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
An
InputTypeStrategy
that expectsminCount
arguments that have a common array type. - commonRange(ArgumentCount) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy that returns a common, least restrictive type of selected arguments.
- commonType(int) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
An
InputTypeStrategy
that expectscount
arguments that have a common type. - CommonTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that returns a common, least restrictive type of selected arguments.
- CommonTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
- CommonTypeStrategy(ArgumentCount) - Constructor for class org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
- comparable(ConstantArgumentCount, StructuredType.StructuredComparison) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that checks all types are comparable with each other.
- ComparableTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
InputTypeStrategy
that checks if all input arguments can be compared with each other with the minimal provided comparison. - ComparableTypeStrategy(ConstantArgumentCount, StructuredType.StructuredComparison) - Constructor for class org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
- compareTo(DecimalData) - Method in class org.apache.flink.table.data.DecimalData
- compareTo(StringData) - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Compares two strings lexicographically.
- compareTo(TimestampData) - Method in class org.apache.flink.table.data.TimestampData
- comparison(StructuredType.StructuredComparison) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
- complement(int) - Method in class org.apache.flink.table.connector.Projection
-
Complement this projection.
- complement(DataType) - Method in class org.apache.flink.table.connector.Projection
-
Like
Projection.complement(int)
, using thedataType
fields count. - COMPOSITE - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that checks that the argument has a composite type.
- CompositeArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy that checks that the argument has a composite type.
- CompositeArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.CompositeArgumentTypeStrategy
- compositeSequence() - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
An strategy that lets you apply other strategies for subsequences of the actual arguments.
- computed(String, ResolvedExpression) - Static method in class org.apache.flink.table.catalog.Column
-
Creates a computed column that is computed from the given
ResolvedExpression
. - computed(String, DataType, String) - Static method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Creates a computed column that is computed from the given SQL expression.
- computePhysicalIndices(List<TableColumn>, DataType, Function<String, String>) - Static method in class org.apache.flink.table.utils.TypeMappingUtils
-
Computes indices of physical fields corresponding to the selected logical fields of a
TableSchema
. - computePhysicalIndicesOrTimeAttributeMarkers(TableSource<?>, List<TableColumn>, boolean, Function<String, String>) - Static method in class org.apache.flink.table.utils.TypeMappingUtils
-
Computes indices of physical fields corresponding to the selected logical fields of a
TableSchema
. - CONCAT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CONCAT_WS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CONDITIONAL_ARRAY - org.apache.flink.table.api.JsonQueryWrapper
- config() - Method in class org.apache.flink.table.catalog.CatalogStoreHolder
- config(ReadableConfig) - Method in class org.apache.flink.table.catalog.CatalogStoreHolder.Builder
- configure(String[], TypeInformation<?>[]) - Method in interface org.apache.flink.table.legacy.sinks.TableSink
-
Deprecated.This method will be dropped in future versions. It is recommended to pass a static schema when instantiating the sink instead.
- configure(String[], TypeInformation<?>[]) - Method in class org.apache.flink.table.sinks.TableSinkBase
-
Deprecated.Returns a copy of this
TableSink
configured with the field names and types of the table to emit. - configurePartitionGrouping(boolean) - Method in interface org.apache.flink.table.legacy.sinks.PartitionableTableSink
-
Deprecated.If returns true, sink can trust all records will definitely be grouped by partition fields before consumed by the
TableSink
, i.e. 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 - Static variable in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
Deprecated.Prefix for connector-related properties.
- CONNECTOR - Static variable in class org.apache.flink.table.factories.FactoryUtil
- CONNECTOR_PATH - Static variable in class org.apache.flink.table.descriptors.FileSystemValidator
-
Deprecated.
- CONNECTOR_PROPERTY_VERSION - Static variable in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
Deprecated.Key for describing the property version.
- CONNECTOR_TYPE - Static variable in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
Deprecated.Key for describing the type of the connector.
- CONNECTOR_TYPE_VALUE - Static variable in class org.apache.flink.table.descriptors.FileSystemValidator
-
Deprecated.
- CONNECTOR_VERSION - Static variable in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
Deprecated.Key for describing the version of the connector.
- ConnectorDescriptorValidator - Class in org.apache.flink.table.descriptors
-
Deprecated.
- ConnectorDescriptorValidator() - Constructor for class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
Deprecated.
- ConstantArgumentCount - Class in org.apache.flink.table.types.inference
-
Helper class for
ArgumentCount
with constant boundaries. - constraint(String, Predicate<List<DataType>>) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for an argument that must fulfill a given constraint.
- Constraint - Interface in org.apache.flink.table.catalog
-
Integrity constraints, generally referred to simply as constraints, define the valid states of SQL-data by constraining the values in the base tables.
- Constraint - Interface in org.apache.flink.table.legacy.api.constraints
-
Deprecated.See
ResolvedSchema
andConstraint
. - Constraint.ConstraintType - Enum in org.apache.flink.table.catalog
-
Type of the constraint.
- Constraint.ConstraintType - Enum in org.apache.flink.table.legacy.api.constraints
-
Deprecated.Type of the constraint.
- ConstraintArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for an argument that must fulfill a given constraint.
- ConstraintArgumentTypeStrategy(String, Predicate<List<DataType>>) - Constructor for class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
- CONSTRUCTED - org.apache.flink.table.types.logical.LogicalTypeFamily
- constructor - Variable in class org.apache.flink.table.types.extraction.ExtractionUtils.AssigningConstructor
- consumedOptionKeys - Variable in class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
- contains(String) - Method in interface org.apache.flink.table.catalog.CatalogStore
-
Return whether the catalog exists in the catalog store.
- contains(K) - Method in class org.apache.flink.table.api.dataview.MapView
-
Checks if the map view contains a value for a given key.
- contains(BinaryStringData) - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Returns true if and only if this BinaryStringData contains the specified sequence of bytes values.
- contains(RowData) - Method in class org.apache.flink.table.connector.source.DynamicFilteringData
-
Returns true if the dynamic filtering data contains the specific row.
- contains(RowKind) - Method in class org.apache.flink.table.connector.ChangelogMode
- containsKey(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns if the given key is contained.
- containsOnly(RowKind) - Method in class org.apache.flink.table.connector.ChangelogMode
- containsPhysicalColumnsOnly(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
-
Returns true if there are only physical columns in the given
TableSchema
. - CONTINUOUS - org.apache.flink.table.catalog.CatalogMaterializedTable.LogicalRefreshMode
-
The refresh pipeline will be executed in continuous mode, corresponding to
CatalogMaterializedTable.RefreshMode.CONTINUOUS
. - CONTINUOUS - org.apache.flink.table.catalog.CatalogMaterializedTable.RefreshMode
- ContinuousRefreshHandler - Class in org.apache.flink.table.refresh
-
Embedded continuous refresh handler of Flink streaming job for materialized table.
- ContinuousRefreshHandler(String, String, String) - Constructor for class org.apache.flink.table.refresh.ContinuousRefreshHandler
- ContinuousRefreshHandler(String, String, String, String) - Constructor for class org.apache.flink.table.refresh.ContinuousRefreshHandler
- ContinuousRefreshHandlerSerializer - Class in org.apache.flink.table.refresh
-
Serializer for
ContinuousRefreshHandler
. - ContinuousRefreshHandlerSerializer() - Constructor for class org.apache.flink.table.refresh.ContinuousRefreshHandlerSerializer
- conversionClass - Variable in class org.apache.flink.table.types.DataType
- conversionSet(String...) - Static method in class org.apache.flink.table.types.logical.LogicalType
- convert(RowData) - Method in interface org.apache.flink.table.utils.print.RowDataToStringConverter
- CONVERT_TZ - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- convertFreshnessToCron(IntervalFreshness) - Static method in class org.apache.flink.table.utils.IntervalFreshnessUtils
-
This is an util method that is used to convert the freshness of materialized table to cron expression in full refresh mode.
- convertFreshnessToDuration(IntervalFreshness) - Static method in class org.apache.flink.table.utils.IntervalFreshnessUtils
- convertStringToInternalValue(String, DataType) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
-
Restore partition value from string and type.
- convertTz(String, String, String) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Convert datetime string from a time zone to another time zone.
- coPartitionArgs() - Method in interface org.apache.flink.table.functions.TableSemantics
-
Returns information about which passed tables are co-partitioned with the passed table.
- copy() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
Get a deep copy of the CatalogBaseTable instance.
- copy() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
-
Get a deep copy of the CatalogDatabase instance.
- copy() - Method in interface org.apache.flink.table.catalog.CatalogFunction
-
Create a deep copy of the function.
- copy() - Method in interface org.apache.flink.table.catalog.CatalogModel
-
Get a deep copy of the CatalogModel instance.
- copy() - Method in interface org.apache.flink.table.catalog.CatalogPartition
-
Get a deep copy of the CatalogPartition instance.
- copy() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- copy() - Method in class org.apache.flink.table.catalog.DefaultCatalogModel
- copy() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- copy() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- copy() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- copy() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- copy() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
-
Create a deep copy of "this" instance.
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
-
Create a deep copy of "this" instance.
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
Create a deep copy of "this" instance.
- copy() - Method in class org.apache.flink.table.catalog.stats.Date
- copy() - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
-
Creates a copy of this instance during planning.
- copy() - Method in interface org.apache.flink.table.connector.source.DynamicTableSource
-
Creates a copy of this instance during planning.
- copy() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- copy() - Method in class org.apache.flink.table.data.binary.BinaryMapData
- copy() - Method in class org.apache.flink.table.data.binary.BinaryRowData
- copy() - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Copy a new
BinaryStringData
. - copy() - Method in class org.apache.flink.table.data.binary.NestedRowData
- copy() - Method in class org.apache.flink.table.data.DecimalData
-
Returns a copy of this
DecimalData
object. - copy() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns a deep copy of the table schema.
- copy() - Method in class org.apache.flink.table.plan.stats.ColumnStats
-
Create a deep copy of "this" instance.
- copy() - Method in class org.apache.flink.table.plan.stats.TableStats
-
Create a deep copy of "this" instance.
- copy() - Method in class org.apache.flink.table.sinks.TableSinkBase
-
Deprecated.Returns a deep copy of the
TableSink
. - copy() - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns a deep copy of this type.
- copy() - Method in class org.apache.flink.table.types.logical.RowType.RowField
- copy() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- copy(boolean) - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- copy(boolean) - Method in class org.apache.flink.table.types.logical.ArrayType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.BigIntType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.BinaryType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.BooleanType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.CharType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.DateType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.DecimalType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.DistinctType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.DoubleType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.FloatType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.IntType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns a deep copy of this type with possibly different nullability.
- copy(boolean) - Method in class org.apache.flink.table.types.logical.MapType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.MultisetType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.NullType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.RawType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.RowType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.SmallIntType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.SymbolType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.TimestampType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.TimeType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.TinyIntType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.VarBinaryType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.VarCharType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- copy(boolean) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- copy(Object) - Method in class org.apache.flink.table.dataview.NullSerializer
- copy(Object, Object) - Method in class org.apache.flink.table.dataview.NullSerializer
- copy(Map<String, String>) - Method in interface org.apache.flink.table.catalog.CatalogDatabase
-
Returns a copy of this
CatalogDatabase
with the given properties. - copy(Map<String, String>) - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Returns a copy of this
CatalogMaterializedTable
with given table optionsoptions
. - copy(Map<String, String>) - Method in interface org.apache.flink.table.catalog.CatalogModel
-
Copy the input model options into the CatalogModel instance.
- copy(Map<String, String>) - Method in interface org.apache.flink.table.catalog.CatalogTable
-
Returns a copy of this
CatalogTable
with given table optionsoptions
. - copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.DefaultCatalogModel
- copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- copy(Map<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- copy(Map<K, V>, Map<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.NullSerializer
- copy(ListView<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- copy(ListView<T>, ListView<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- copy(MapView<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- copy(MapView<K, V>, MapView<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- copy(CatalogMaterializedTable.RefreshStatus, String, byte[]) - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Returns a copy of this
CatalogDynamicTable
with given refresh info. - copy(CatalogMaterializedTable.RefreshStatus, String, byte[]) - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- copy(CatalogMaterializedTable.RefreshStatus, String, byte[]) - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- copy(BinaryArrayData) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- copy(BinaryMapData) - Method in class org.apache.flink.table.data.binary.BinaryMapData
- copy(BinaryRowData) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- copy(RowData) - Method in class org.apache.flink.table.data.binary.NestedRowData
- copy(DataType) - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
- copy(DataType) - Method in class org.apache.flink.table.catalog.Column
-
Returns a copy of the column with a replaced
DataType
. - copy(DataType) - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
- copy(DataType) - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
- copyFromBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Copy target segments from source byte[].
- copyMultiSegmentsToBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
- copyToBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Copy segments to target byte[].
- copyToBytes(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Copy segments to a new byte[].
- copyToUnsafe(MemorySegment[], int, Object, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Copy segments to target unsafe pointer.
- copyToView(MemorySegment[], int, int, DataOutputView) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Copy bytes of segments to output view.
- CoreModule - Class in org.apache.flink.table.module
-
Module of default core metadata in Flink.
- CoreModuleFactory - Class in org.apache.flink.table.module
-
Factory for
CoreModule
. - CoreModuleFactory() - Constructor for class org.apache.flink.table.module.CoreModuleFactory
- COS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- COSH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- COT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- COUNT - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- COUNT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- COUNT1 - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- create(ClassLoader) - Static method in interface org.apache.flink.table.connector.RuntimeConverter.Context
-
Creates a new instance of
RuntimeConverter.Context
. - CREATE_OR_REPLACE_TABLE_AS - org.apache.flink.table.connector.sink.abilities.SupportsStaging.StagingPurpose
- CREATE_TABLE_AS - org.apache.flink.table.connector.sink.abilities.SupportsStaging.StagingPurpose
- CREATE_TABLE_AS_IF_NOT_EXISTS - org.apache.flink.table.connector.sink.abilities.SupportsStaging.StagingPurpose
- createAccumulator() - Method in class org.apache.flink.table.functions.ImperativeAggregateFunction
-
Creates and initializes the accumulator for this
ImperativeAggregateFunction
. - createAccumulator() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- createAccumulator() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- createAsyncLookupFunction() - Method in interface org.apache.flink.table.connector.source.lookup.AsyncLookupFunctionProvider
-
Creates an
AsyncLookupFunction
instance. - createAsyncTableFunction() - Method in interface org.apache.flink.table.legacy.connector.source.AsyncTableFunctionProvider
-
Deprecated.Creates a
AsyncTableFunction
instance. - createCatalog(String, Map<String, String>, ReadableConfig, ClassLoader) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Attempts to discover an appropriate catalog factory and creates an instance of the catalog.
- createCatalog(CatalogFactory.Context) - Method in interface org.apache.flink.table.factories.CatalogFactory
-
Creates and configures a
Catalog
using the given context. - createCatalogFactoryHelper(CatalogFactory, CatalogFactory.Context) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Creates a utility that helps validating options for a
CatalogFactory
. - createCatalogStore() - Method in interface org.apache.flink.table.factories.CatalogStoreFactory
-
Creates a
CatalogStore
instance from context information. - createCatalogStoreFactoryHelper(CatalogStoreFactory, CatalogStoreFactory.Context) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Creates a utility that helps validating options for a
CatalogStoreFactory
. - createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- createDatabase(String, CatalogDatabase, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Create a database.
- createDataStructureConverter(DataType) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
-
Creates a converter for mapping between Flink's internal data structures and objects specified by the given
DataType
that can be passed into a runtime implementation. - createDataStructureConverter(DataType) - Method in interface org.apache.flink.table.connector.source.DynamicTableSource.Context
-
Creates a converter for mapping between objects specified by the given
DataType
and Flink's internal data structures that can be passed into a runtime implementation. - createDataType(Class<T>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a type by analyzing the given class.
- createDataType(String) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a type by a fully or partially defined name.
- createDataType(TypeInformation<T>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a type for the given
TypeInformation
. - createDataType(UnresolvedIdentifier) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a type by a fully or partially defined identifier.
- createDataType(AbstractDataType<?>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a type out of an
AbstractDataType
. - createDecodingFormat(DynamicTableFactory.Context, ReadableConfig) - Method in interface org.apache.flink.table.factories.DecodingFormatFactory
-
Creates a format from the given context and format options.
- createDynamicTableSink(DynamicTableFactory.Context) - Method in interface org.apache.flink.table.factories.DynamicTableSinkFactory
-
Creates a
DynamicTableSink
instance from aCatalogTable
and additional context information. - createDynamicTableSink(DynamicTableSinkFactory, ObjectIdentifier, ResolvedCatalogTable, Map<String, String>, ReadableConfig, ClassLoader, boolean) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Creates a
DynamicTableSink
from aCatalogTable
. - createDynamicTableSource(DynamicTableFactory.Context) - Method in interface org.apache.flink.table.factories.DynamicTableSourceFactory
-
Creates a
DynamicTableSource
instance from aCatalogTable
and additional context information. - createDynamicTableSource(DynamicTableSourceFactory, ObjectIdentifier, ResolvedCatalogTable, Map<String, String>, ReadableConfig, ClassLoader, boolean) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Creates a
DynamicTableSource
from aCatalogTable
. - createElementGetter(LogicalType) - Static method in interface org.apache.flink.table.data.ArrayData
-
Creates an accessor for getting elements in an internal array data structure at the given position.
- createEncodingFormat(DynamicTableFactory.Context, ReadableConfig) - Method in interface org.apache.flink.table.factories.EncodingFormatFactory
-
Creates a format from the given context and format options.
- createEvaluator(String, DataType, DataTypes.Field...) - Method in interface org.apache.flink.table.functions.SpecializedFunction.ExpressionEvaluatorFactory
-
Shorthand for
createEvaluator(callSql("..."), ...)
. - createEvaluator(Expression, DataType, DataTypes.Field...) - Method in interface org.apache.flink.table.functions.SpecializedFunction.ExpressionEvaluatorFactory
-
Creates a serializable factory that can be passed into a
UserDefinedFunction
for evaluating anExpression
during runtime. - createEvaluator(BuiltInFunctionDefinition, DataType, DataType...) - Method in interface org.apache.flink.table.functions.SpecializedFunction.ExpressionEvaluatorFactory
-
Creates a serializable factory that can be passed into a
UserDefinedFunction
for evaluating aBuiltInFunctionDefinition
during runtime. - createFieldGetter(LogicalType, int) - Static method in interface org.apache.flink.table.data.RowData
-
Creates an accessor for getting elements in an internal row data structure at the given position.
- createFunction(ObjectPath, CatalogFunction, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Create a function.
- createFunctionDefinition(String, CatalogFunction, FunctionDefinitionFactory.Context) - Method in interface org.apache.flink.table.factories.FunctionDefinitionFactory
-
Creates a
FunctionDefinition
from givenCatalogFunction
with the givenFunctionDefinitionFactory.Context
containing the class loader of the current session, which is useful when it's needed to load class from class name. - createInputFormat() - Method in interface org.apache.flink.table.connector.source.InputFormatProvider
-
Creates an
InputFormat
instance. - createInstance() - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- createInstance() - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- createInstance() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- createInstance() - Method in class org.apache.flink.table.dataview.NullSerializer
- createInvalidCallException(CallContext, ValidationException) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
-
Returns an exception for an invalid call to a function.
- createInvalidInputException(TypeInference, CallContext, ValidationException) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
-
Returns an exception for invalid input arguments.
- createLogicalType(String) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a
LogicalType
by a fully or partially defined name. - createLogicalType(UnresolvedIdentifier) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a
LogicalType
from anUnresolvedIdentifier
for resolving user-defined types (seeDistinctType
andStructuredType
). - createLookupFunction() - Method in interface org.apache.flink.table.connector.source.lookup.LookupFunctionProvider
-
Creates an
LookupFunction
instance. - createMethodSignatureString(String, Class<?>[], Class<?>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Creates a method signature string like
int eval(Integer, String)
. - createModel(ObjectPath, CatalogModel, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Creates a new model.
- createModule(String, Map<String, String>, ReadableConfig, ClassLoader) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Discovers a matching module factory and creates an instance of it.
- createModule(ModuleFactory.Context) - Method in interface org.apache.flink.table.factories.ModuleFactory
-
Creates and configures a
Module
. - createModule(ModuleFactory.Context) - Method in class org.apache.flink.table.module.CoreModuleFactory
- createModuleFactoryHelper(ModuleFactory, ModuleFactory.Context) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Creates a utility that helps validating options for a
ModuleFactory
. - createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
Deprecated.
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.dataview.MapViewSerializerSnapshot
-
Deprecated.
- createOuterSerializerWithNestedSerializers(TypeSerializer<?>[]) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
-
Deprecated.
- createOutputFormat() - Method in interface org.apache.flink.table.connector.sink.OutputFormatProvider
-
Creates an
OutputFormat
instance. - createPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Create a partition.
- CreatePeriodicRefreshWorkflow - Class in org.apache.flink.table.workflow
-
CreateRefreshWorkflow
provides the related information to create periodic refresh workflow ofCatalogMaterializedTable
. - CreatePeriodicRefreshWorkflow(ObjectIdentifier, String, String, Map<String, String>, Map<String, String>, String) - Constructor for class org.apache.flink.table.workflow.CreatePeriodicRefreshWorkflow
- createProctimeDataType() - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Returns a PROCTIME data type.
- createRawDataType(Class<T>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a RAW type for the given class in cases where no serializer is known and a generic serializer should be used.
- createRawDataType(TypeInformation<T>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a RAW type for the given
TypeInformation
. - createRefreshWorkflow(CreateRefreshWorkflow) - Method in interface org.apache.flink.table.workflow.WorkflowScheduler
-
Create a refresh workflow in specific scheduler service for the materialized table, return a
RefreshHandler
instance which can locate the refresh workflow detail information. - CreateRefreshWorkflow - Interface in org.apache.flink.table.workflow
-
CreateRefreshWorkflow
provides the related information to create refresh workflow ofCatalogMaterializedTable
. - createRuntimeDecoder(DynamicTableSource.Context, DataType) - Method in interface org.apache.flink.table.connector.format.DecodingFormat
-
Creates runtime decoder implementation that is configured to produce data of the given data type.
- createRuntimeDecoder(DynamicTableSource.Context, DataType) - Method in interface org.apache.flink.table.connector.format.ProjectableDecodingFormat
- createRuntimeDecoder(DynamicTableSource.Context, DataType, int[][]) - Method in interface org.apache.flink.table.connector.format.ProjectableDecodingFormat
-
Creates runtime decoder implementation that is configured to produce data of type
Projection.of(projections).project(physicalDataType)
. - createRuntimeEncoder(DynamicTableSink.Context, DataType) - Method in interface org.apache.flink.table.connector.format.EncodingFormat
-
Creates runtime encoder implementation that is configured to consume data of the given data type.
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- createSink() - Method in interface org.apache.flink.table.connector.sink.SinkV2Provider
- createSource() - Method in interface org.apache.flink.table.connector.source.SourceProvider
-
Creates a
Source
instance. - createSpecializedFunction(String, FunctionDefinition, CallContext, ClassLoader, ReadableConfig, SpecializedFunction.ExpressionEvaluatorFactory) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Creates the runtime implementation of a
FunctionDefinition
as an instance ofUserDefinedFunction
. - createTable(ObjectPath, CatalogBaseTable, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Creates a new table or view.
- createTableFactoryHelper(DynamicTableFactory, DynamicTableFactory.Context) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Creates a utility that helps in discovering formats, merging options with
DynamicTableFactory.Context.getEnrichmentOptions()
and validating them all for aDynamicTableFactory
. - createTableFunction() - Method in interface org.apache.flink.table.legacy.connector.source.TableFunctionProvider
-
Deprecated.Creates a
TableFunction
instance. - createTableSink(Map<String, String>) - Method in interface org.apache.flink.table.legacy.factories.TableSinkFactory
-
Deprecated.
TableSinkFactory.Context
contains more information, and already contains table schema too. Please useTableSinkFactory.createTableSink(Context)
instead. - createTableSink(ObjectPath, CatalogTable) - Method in interface org.apache.flink.table.legacy.factories.TableSinkFactory
-
Deprecated.
TableSinkFactory.Context
contains more information, and already contains table schema too. Please useTableSinkFactory.createTableSink(Context)
instead. - createTableSink(TableSinkFactory.Context) - Method in interface org.apache.flink.table.legacy.factories.TableSinkFactory
-
Deprecated.Creates and configures a
TableSink
based on the givenTableSinkFactory.Context
. - createTableSource(Map<String, String>) - Method in interface org.apache.flink.table.legacy.factories.TableSourceFactory
-
Deprecated.
TableSourceFactory.Context
contains more information, and already contains table schema too. Please useTableSourceFactory.createTableSource(Context)
instead. - createTableSource(ObjectPath, CatalogTable) - Method in interface org.apache.flink.table.legacy.factories.TableSourceFactory
-
Deprecated.
TableSourceFactory.Context
contains more information, and already contains table schema too. Please useTableSourceFactory.createTableSource(Context)
instead. - createTableSource(TableSourceFactory.Context) - Method in interface org.apache.flink.table.legacy.factories.TableSourceFactory
-
Deprecated.Creates and configures a
TableSource
based on the givenTableSourceFactory.Context
. - createTypeInformation(DataType) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
-
Creates type information describing the internal data structures of the given
DataType
. - createTypeInformation(DataType) - Method in interface org.apache.flink.table.connector.source.DynamicTableSource.Context
-
Creates type information describing the internal data structures of the given
DataType
. - createTypeInformation(LogicalType) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
-
Creates type information describing the internal data structures of the given
LogicalType
. - createTypeInformation(LogicalType) - Method in interface org.apache.flink.table.connector.source.DynamicTableSource.Context
-
Creates type information describing the internal data structures of the given
LogicalType
. - createUnexpectedException(CallContext, Throwable) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
-
Returns an exception for an unexpected error during type inference.
- createWorkflowScheduler(Configuration, ClassLoader) - Static method in class org.apache.flink.table.factories.WorkflowSchedulerFactoryUtil
-
Attempts to discover the appropriate workflow scheduler factory and creates the instance of the scheduler.
- createWorkflowScheduler(WorkflowSchedulerFactory.Context) - Method in interface org.apache.flink.table.factories.WorkflowSchedulerFactory
-
Create a workflow scheduler instance which interacts with external scheduler service.
- createWorkflowSchedulerFactoryHelper(WorkflowSchedulerFactory, WorkflowSchedulerFactory.Context) - Static method in class org.apache.flink.table.factories.WorkflowSchedulerFactoryUtil
-
Creates a utility that helps to validate options for a
WorkflowSchedulerFactory
. - CURRENT_DATABASE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CURRENT_DATE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CURRENT_RANGE - org.apache.flink.table.api.OverWindowRange
- CURRENT_ROW - org.apache.flink.table.api.OverWindowRange
- CURRENT_ROW_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CURRENT_TIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CURRENT_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CURRENT_WATERMARK - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- CURRENT_WATERMARK - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
See
CurrentWatermarkInputTypeStrategy
. - CURRENT_WATERMARK - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
CurrentWatermarkTypeStrategy
. - currentProcessingTime() - Method in interface org.apache.flink.table.connector.source.lookup.cache.trigger.CacheReloadTrigger.Context
-
Returns the current processing time.
- currentWatermark() - Method in interface org.apache.flink.table.connector.source.lookup.cache.trigger.CacheReloadTrigger.Context
-
Returns the current event-time watermark.
D
- data - Variable in class org.apache.flink.table.data.columnar.vector.BytesColumnVector.Bytes
- DATA_TYPE - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- DatabaseAlreadyExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to create a database that already exists.
- DatabaseAlreadyExistException(String, String) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseAlreadyExistException
- DatabaseAlreadyExistException(String, String, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseAlreadyExistException
- databaseExists(String) - Method in interface org.apache.flink.table.catalog.Catalog
-
Check if a database exists in this catalog.
- DatabaseNotEmptyException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to drop on a database that is not empty.
- DatabaseNotEmptyException(String, String) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseNotEmptyException
- DatabaseNotEmptyException(String, String, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseNotEmptyException
- DatabaseNotExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to operate on a database that doesn't exist.
- DatabaseNotExistException(String, String) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseNotExistException
- DatabaseNotExistException(String, String, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.DatabaseNotExistException
- dataType - Variable in class org.apache.flink.table.catalog.Column
- dataType() - Method in interface org.apache.flink.table.functions.TableSemantics
-
Data type of the passed table.
- DataType - Class in org.apache.flink.table.types
-
Describes the data type of a value in the table ecosystem.
- DataTypeConversionClassTransformation - Class in org.apache.flink.table.types.inference.transforms
-
This type transformation transforms the specified data types to a new one with the expected conversion class.
- DataTypeConversionClassTransformation(Map<LogicalTypeRoot, Class<?>>) - Constructor for class org.apache.flink.table.types.inference.transforms.DataTypeConversionClassTransformation
- DataTypeDefaultVisitor<R> - Class in org.apache.flink.table.types.utils
-
Implementation of
DataTypeVisitor
that redirects all calls toDataTypeDefaultVisitor.defaultMethod(DataType)
. - DataTypeDefaultVisitor() - Constructor for class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
- DataTypeExtractor - Class in org.apache.flink.table.types.extraction
- DataTypeFactory - Interface in org.apache.flink.table.catalog
-
Factory for creating fully resolved data types that can be used for planning.
- DataTypeHint - Annotation Type in org.apache.flink.table.annotation
-
A hint that influences the reflection-based extraction of a
DataType
. - DataTypeQueryable - Interface in org.apache.flink.table.types
-
Indicates that a
DataType
can be retrieved from a class that implements this interfaces. - DataTypes - Class in org.apache.flink.table.api
-
A
DataType
can be used to declare input and/or output types of operations. - DataTypes.AbstractField - Class in org.apache.flink.table.api
-
Common helper class for resolved and unresolved fields of a row or structured type.
- DataTypes.Field - Class in org.apache.flink.table.api
-
Helper class for defining the field of a row or structured type.
- DataTypes.Resolution - Class in org.apache.flink.table.api
-
Helper class for defining the resolution of an interval.
- DataTypes.UnresolvedField - Class in org.apache.flink.table.api
-
Helper class for defining the unresolved field of a row or structured type.
- DataTypeUtils - Class in org.apache.flink.table.types.utils
-
Utilities for handling
DataType
s. - DataTypeVisitor<R> - Interface in org.apache.flink.table.types
-
The visitor definition of
DataType
. - DataView - Interface in org.apache.flink.table.api.dataview
-
A
DataView
is a collection type that can be used in the accumulator of anImperativeAggregateFunction
. - Date - Class in org.apache.flink.table.catalog.stats
-
Class representing a date value in statistics.
- Date(long) - Constructor for class org.apache.flink.table.catalog.stats.Date
- DATE - org.apache.flink.table.types.logical.LogicalTypeRoot
- DATE() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a date consisting of
year-month-day
with values ranging from0000-01-01
to9999-12-31
. - DATE_FORMAT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- DATETIME - org.apache.flink.table.types.logical.LogicalTypeFamily
- DateTimeUtils - Class in org.apache.flink.table.utils
-
Utility functions for datetime types: date, time, timestamp.
- DateTimeUtils() - Constructor for class org.apache.flink.table.utils.DateTimeUtils
- DateTimeUtils.TimeUnit - Enum in org.apache.flink.table.utils
-
Enumeration of time units used to construct an interval.
- DateTimeUtils.TimeUnitRange - Enum in org.apache.flink.table.utils
-
A range of time units.
- dateToTimestampWithLocalZone(int, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- DateType - Class in org.apache.flink.table.types.logical
-
Logical type of a date consisting of
year-month-day
with values ranging from0000-01-01
to9999-12-31
. - DateType() - Constructor for class org.apache.flink.table.types.logical.DateType
- DateType(boolean) - Constructor for class org.apache.flink.table.types.logical.DateType
- DAY - org.apache.flink.table.catalog.IntervalFreshness.TimeUnit
- DAY - org.apache.flink.table.expressions.TimeIntervalUnit
- DAY - org.apache.flink.table.expressions.TimePointUnit
- DAY - org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
- DAY - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- DAY - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- DAY() - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in days with 2 digits for the number of days by default.
- DAY(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in days.
- DAY_TO_HOUR - org.apache.flink.table.expressions.TimeIntervalUnit
- DAY_TO_HOUR - org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
- DAY_TO_HOUR - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- DAY_TO_MINUTE - org.apache.flink.table.expressions.TimeIntervalUnit
- DAY_TO_MINUTE - org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
- DAY_TO_MINUTE - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- DAY_TO_SECOND - org.apache.flink.table.expressions.TimeIntervalUnit
- DAY_TO_SECOND - org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
- DAY_TO_SECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- DayTimeIntervalType - Class in org.apache.flink.table.types.logical
-
Logical type for a group of day-time interval types.
- DayTimeIntervalType(boolean, DayTimeIntervalType.DayTimeResolution, int, int) - Constructor for class org.apache.flink.table.types.logical.DayTimeIntervalType
- DayTimeIntervalType(DayTimeIntervalType.DayTimeResolution) - Constructor for class org.apache.flink.table.types.logical.DayTimeIntervalType
- DayTimeIntervalType(DayTimeIntervalType.DayTimeResolution, int, int) - Constructor for class org.apache.flink.table.types.logical.DayTimeIntervalType
- DayTimeIntervalType.DayTimeResolution - Enum in org.apache.flink.table.types.logical
-
Supported resolutions of this type.
- DECADE - org.apache.flink.table.expressions.TimeIntervalUnit
- DECADE - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- DECADE - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- DECIMAL - org.apache.flink.table.types.logical.LogicalTypeRoot
- DECIMAL() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API big decimal or SQL DECIMAL type.
- DECIMAL(int, int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a decimal number with fixed precision and scale
DECIMAL(p, s)
wherep
is the number of digits in a number (=precision) ands
is the number of digits to the right of the decimal point in a number (=scale). - DECIMAL_DIVIDE - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
DecimalDivideTypeStrategy
. - DECIMAL_MOD - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
DecimalModTypeStrategy
. - DECIMAL_PLUS - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
DecimalPlusTypeStrategy
. - DECIMAL_SCALE_0 - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
DecimalScale0TypeStrategy
. - DECIMAL_SUM0 - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- DECIMAL_TIMES - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
DecimalTimesTypeStrategy
. - DecimalColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Decimal column vector.
- DecimalData - Class in org.apache.flink.table.data
-
An internal data structure representing data of
DecimalType
. - DecimalType - Class in org.apache.flink.table.types.logical
-
Logical type of a decimal number with fixed precision and scale.
- DecimalType() - Constructor for class org.apache.flink.table.types.logical.DecimalType
- DecimalType(boolean, int, int) - Constructor for class org.apache.flink.table.types.logical.DecimalType
- DecimalType(int) - Constructor for class org.apache.flink.table.types.logical.DecimalType
- DecimalType(int, int) - Constructor for class org.apache.flink.table.types.logical.DecimalType
- DECODE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- decodeBase64ToBytes(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
- decodeBase64ToString(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
- decodeHex(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
-
Converts an array of characters representing hexadecimal values into an array of bytes of those same values.
- decodeStringToObject(String, Class<T>) - Static method in class org.apache.flink.table.utils.EncodingUtils
- decodeStringToObject(String, Class<T>, ClassLoader) - Static method in class org.apache.flink.table.utils.EncodingUtils
- decodeStringToObject(String, ClassLoader) - Static method in class org.apache.flink.table.utils.EncodingUtils
- decodeToBinary(int) - Method in interface org.apache.flink.table.data.columnar.vector.Dictionary
- decodeToDouble(int) - Method in interface org.apache.flink.table.data.columnar.vector.Dictionary
- decodeToFloat(int) - Method in interface org.apache.flink.table.data.columnar.vector.Dictionary
- decodeToInt(int) - Method in interface org.apache.flink.table.data.columnar.vector.Dictionary
- decodeToLong(int) - Method in interface org.apache.flink.table.data.columnar.vector.Dictionary
- decodeToTimestamp(int) - Method in interface org.apache.flink.table.data.columnar.vector.Dictionary
- DecodingFormat<I> - Interface in org.apache.flink.table.connector.format
-
A
Format
for aDynamicTableSource
for reading rows. - DecodingFormatFactory<I> - Interface in org.apache.flink.table.factories
- DEFAULT - org.apache.flink.table.api.JsonValueOnEmptyOrError
-
Use a given default expression.
- DEFAULT_CATALOG_STORE_KIND - Static variable in class org.apache.flink.table.catalog.CommonCatalogOptions
- DEFAULT_DATABASE_KEY - Static variable in class org.apache.flink.table.catalog.CommonCatalogOptions
-
Key used for specifying a default database
ConfigOption
. - DEFAULT_DAY_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
- DEFAULT_FRACTIONAL_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
- DEFAULT_LENGTH - Static variable in class org.apache.flink.table.types.logical.BinaryType
- DEFAULT_LENGTH - Static variable in class org.apache.flink.table.types.logical.CharType
- DEFAULT_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarBinaryType
- DEFAULT_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarCharType
- DEFAULT_MAX_COLUMN_WIDTH - Static variable in interface org.apache.flink.table.utils.print.PrintStyle
-
Default max column width.
- DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.DecimalType
- DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimestampType
- DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimeType
- DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.YearMonthIntervalType
- DEFAULT_PRECISION - Static variable in class org.apache.flink.table.types.logical.ZonedTimestampType
- DEFAULT_SCALE - Static variable in class org.apache.flink.table.types.logical.DecimalType
- DEFAULT_SIZE - Static variable in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
This number is carefully chosen to minimize overhead and typically allows one VectorizedColumnBatch to fit in cache.
- DEFAULT_VERSION - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- DefaultCatalogContext(String, Map<String, String>, ReadableConfig, ClassLoader) - Constructor for class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
- DefaultCatalogMaterializedTable - Class in org.apache.flink.table.catalog
-
Default implementation of a
CatalogMaterializedTable
. - DefaultCatalogMaterializedTable(Schema, String, List<String>, Map<String, String>, Long, String, IntervalFreshness, CatalogMaterializedTable.LogicalRefreshMode, CatalogMaterializedTable.RefreshMode, CatalogMaterializedTable.RefreshStatus, String, byte[]) - Constructor for class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- DefaultCatalogModel - Class in org.apache.flink.table.catalog
-
A catalog model implementation.
- DefaultCatalogModel(Schema, Schema, Map<String, String>, String) - Constructor for class org.apache.flink.table.catalog.DefaultCatalogModel
- DefaultCatalogStoreContext(Map<String, String>, ReadableConfig, ClassLoader) - Constructor for class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogStoreContext
- DefaultCatalogTable - Class in org.apache.flink.table.catalog
-
Default implementation of a
CatalogTable
. - DefaultCatalogTable(Schema, String, List<String>, Map<String, String>) - Constructor for class org.apache.flink.table.catalog.DefaultCatalogTable
- DefaultCatalogTable(Schema, String, List<String>, Map<String, String>, Long, TableDistribution) - Constructor for class org.apache.flink.table.catalog.DefaultCatalogTable
- defaultDecimalPrecision() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
Defines a default precision for all decimal data types that are extracted.
- defaultDecimalScale() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
Defines a default scale for all decimal data types that are extracted.
- DefaultDynamicTableContext(ObjectIdentifier, ResolvedCatalogTable, Map<String, String>, ReadableConfig, ClassLoader, boolean) - Constructor for class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
- DefaultLookupCache - Class in org.apache.flink.table.connector.source.lookup.cache
-
Default implementation of
LookupCache
. - DefaultLookupCache.Builder - Class in org.apache.flink.table.connector.source.lookup.cache
-
Builder for
DefaultLookupCache
. - defaultMethod(Expression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
- defaultMethod(DataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
- defaultMethod(LogicalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- defaultMethod(LogicalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
- DefaultModuleContext(Map<String, String>, ReadableConfig, ClassLoader) - Constructor for class org.apache.flink.table.factories.FactoryUtil.DefaultModuleContext
- DefaultResolvedCatalogModel - Class in org.apache.flink.table.catalog
-
A validated
CatalogModel
that is backed by the original metadata coming from theCatalog
but resolved by the framework. - DefaultResolvedCatalogModel(CatalogModel, ResolvedSchema, ResolvedSchema) - Constructor for class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- defaultSecondPrecision() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
Defines a default fractional second precision for all day-time intervals and timestamps that are extracted.
- DefaultWorkflowSchedulerContext(ReadableConfig, Map<String, String>) - Constructor for class org.apache.flink.table.factories.WorkflowSchedulerFactoryUtil.DefaultWorkflowSchedulerContext
- defaultYearPrecision() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
Defines a default year precision for all year-month intervals that are extracted.
- DefinedFieldMapping - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.This interface will not be supported in the new source design around
DynamicTableSource
. See FLIP-95 for more information. - DefinedProctimeAttribute - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.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 - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.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. - definitionQuery(String) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- DEGREES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- DELETE - org.apache.flink.table.connector.source.abilities.SupportsRowLevelModificationScan.RowLevelModificationType
- DELETED_ROWS - org.apache.flink.table.connector.sink.abilities.SupportsRowLevelDelete.RowLevelDeleteMode
- deleteRefreshWorkflow(DeleteRefreshWorkflow<T>) - Method in interface org.apache.flink.table.workflow.WorkflowScheduler
-
Delete the refresh workflow in scheduler service.
- DeleteRefreshWorkflow<T extends RefreshHandler> - Class in org.apache.flink.table.workflow
-
DeleteRefreshWorkflow
provides the related information to delete refresh workflow ofCatalogMaterializedTable
. - DeleteRefreshWorkflow(T) - Constructor for class org.apache.flink.table.workflow.DeleteRefreshWorkflow
- deprecatedOptionKeys - Variable in class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
- derived() - Static method in class org.apache.flink.table.api.Schema
-
Convenience method for stating explicitly that a schema is empty and should be fully derived by the framework.
- description - Variable in class org.apache.flink.table.api.DataTypes.AbstractField
- description(String) - Method in class org.apache.flink.table.types.logical.DistinctType.Builder
- description(String) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
- Descriptor - Interface in org.apache.flink.table.legacy.descriptors
-
Deprecated.
Descriptor
was primarily used for the legacy connector stack and have been deprecated. UseTableDescriptor
for creating sources and sinks from the Table API. - DescriptorProperties - Class in org.apache.flink.table.descriptors
-
Deprecated.This utility will be dropped soon.
DynamicTableFactory
is based onConfigOption
and catalogs useCatalogPropertiesUtil
. - DescriptorProperties() - Constructor for class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- DescriptorProperties(boolean) - Constructor for class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- DescriptorValidator - Interface in org.apache.flink.table.descriptors
-
Deprecated.See
Descriptor
for details. - DeserializationFormatFactory - Interface in org.apache.flink.table.factories
-
Factory for creating a
DecodingFormat
forDeserializationSchema
. - deserialize(byte[], ClassLoader) - Method in class org.apache.flink.table.refresh.ContinuousRefreshHandlerSerializer
- deserialize(byte[], ClassLoader) - Method in interface org.apache.flink.table.refresh.RefreshHandlerSerializer
-
Deserialize the bytes to a
RefreshHandler
instance. - deserialize(Object, DataInputView) - Method in class org.apache.flink.table.dataview.NullSerializer
- deserialize(Map<K, V>, DataInputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- deserialize(DataInputView) - Method in class org.apache.flink.table.dataview.NullSerializer
- deserialize(ListView<T>, DataInputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- deserialize(MapView<K, V>, DataInputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- deserializeCatalogMaterializedTable(Map<String, String>) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
Deserializes the given map of string properties into an unresolved
CatalogMaterializedTable
. - deserializeCatalogModel(Map<String, String>) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
- deserializeCatalogTable(Map<String, String>) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
Deserializes the given map of string properties into an unresolved
CatalogTable
. - deserializeCatalogTable(Map<String, String>, String) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
Deserializes the given map of string properties into an unresolved
CatalogTable
. - dictionary - Variable in class org.apache.flink.table.data.columnar.vector.writable.AbstractWritableVector
-
The Dictionary for this column.
- Dictionary - Interface in org.apache.flink.table.data.columnar.vector
-
The interface for dictionary in AbstractColumnVector to decode dictionary encoded values.
- dictionaryIds - Variable in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
-
Reusable column for ids of dictionary.
- difference(Projection) - Method in class org.apache.flink.table.connector.Projection
-
Perform a difference of this
Projection
with anotherProjection
. - discoverDecodingFormat(Class<F>, ConfigOption<String>) - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
-
Discovers a
DecodingFormat
of the given type using the given option as factory identifier. - discoverEncodingFormat(Class<F>, ConfigOption<String>) - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
-
Discovers a
EncodingFormat
of the given type using the given option as factory identifier. - discoverFactory(ClassLoader, Class<T>, String) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Discovers a factory using the given factory base class and identifier.
- discoverOptionalDecodingFormat(Class<F>, ConfigOption<String>) - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
-
Discovers a
DecodingFormat
of the given type using the given option (if present) as factory identifier. - discoverOptionalEncodingFormat(Class<F>, ConfigOption<String>) - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
-
Discovers a
EncodingFormat
of the given type using the given option (if present) as factory identifier. - DISTINCT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- DISTINCT - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Function syntax for handling DISTINCT aggregates.
- DISTINCT_TYPE - org.apache.flink.table.types.logical.LogicalTypeRoot
- DistinctType - Class in org.apache.flink.table.types.logical
-
Logical type of a user-defined distinct type.
- DistinctType.Builder - Class in org.apache.flink.table.types.logical
-
A builder for a
DistinctType
. - distribution(TableDistribution) - Method in class org.apache.flink.table.catalog.CatalogTable.Builder
- DIVIDE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- DOUBLE - org.apache.flink.table.types.logical.LogicalTypeRoot
- DOUBLE() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of an 8-byte double precision floating point number.
- DOUBLE() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API integer or SQL DOUBLE type.
- DOUBLE_ARRAY_OFFSET - Static variable in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- DoubleColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Double column vector.
- DoubleType - Class in org.apache.flink.table.types.logical
-
Logical type of an 8-byte double precision floating point number.
- DoubleType() - Constructor for class org.apache.flink.table.types.logical.DoubleType
- DoubleType(boolean) - Constructor for class org.apache.flink.table.types.logical.DoubleType
- DOW - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- DOW - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- DOY - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- DOY - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- dropColumn(String) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to drop column.
- dropConstraint(String) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to drop constraint.
- dropConstraint(TableSchema, String) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
-
Creates a new schema but drop the constraint with given name.
- dropDatabase(String, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Drop a database.
- dropDatabase(String, boolean, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Drop a database.
- dropDistribution() - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to drop a table's distribution.
- DropDistribution() - Constructor for class org.apache.flink.table.catalog.TableChange.DropDistribution
- dropFunction(ObjectPath, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Drop a function.
- dropModel(ObjectPath, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Drop a model.
- dropPartition(ObjectPath, CatalogPartitionSpec, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Drop a partition.
- dropTable(ObjectPath, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Drop a table or view.
- dropWatermark() - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to drop watermark.
- DropWatermark() - Constructor for class org.apache.flink.table.catalog.TableChange.DropWatermark
- duplicate() - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- duplicate() - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- duplicate() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- DynamicFilteringData - Class in org.apache.flink.table.connector.source
-
Data for dynamic filtering.
- DynamicFilteringData(TypeInformation<RowData>, RowType, List<byte[]>, boolean) - Constructor for class org.apache.flink.table.connector.source.DynamicFilteringData
- DynamicFilteringEvent - Class in org.apache.flink.table.connector.source
-
A source event to transport the
DynamicFilteringData
for dynamic filtering purpose. - DynamicFilteringEvent(DynamicFilteringData) - Constructor for class org.apache.flink.table.connector.source.DynamicFilteringEvent
- DynamicTableFactory - Interface in org.apache.flink.table.factories
-
Base interface for configuring a dynamic table connector for an external storage system from catalog and session information.
- DynamicTableFactory.Context - Interface in org.apache.flink.table.factories
-
Provides catalog and session information describing the dynamic table to be accessed.
- DynamicTableSink - Interface in org.apache.flink.table.connector.sink
-
Sink of a dynamic table to an external storage system.
- DynamicTableSink.Context - Interface in org.apache.flink.table.connector.sink
-
Context for creating runtime implementation via a
DynamicTableSink.SinkRuntimeProvider
. - DynamicTableSink.DataStructureConverter - Interface in org.apache.flink.table.connector.sink
-
Converter for mapping between Flink's internal data structures and objects specified by the given
DataType
that can be passed into a runtime implementation. - DynamicTableSink.SinkRuntimeProvider - Interface in org.apache.flink.table.connector.sink
-
Provides actual runtime implementation for writing the data.
- DynamicTableSinkFactory - Interface in org.apache.flink.table.factories
-
Creates a
DynamicTableSink
instance from aCatalogTable
and additional context information. - DynamicTableSource - Interface in org.apache.flink.table.connector.source
-
Source of a dynamic table from an external storage system.
- DynamicTableSource.Context - Interface in org.apache.flink.table.connector.source
-
Base context for creating runtime implementation via a
ScanTableSource.ScanRuntimeProvider
andLookupTableSource.LookupRuntimeProvider
. - DynamicTableSource.DataStructureConverter - Interface in org.apache.flink.table.connector.source
-
Converter for mapping between objects and Flink's internal data structures during runtime.
- DynamicTableSourceFactory - Interface in org.apache.flink.table.factories
-
Creates a
DynamicTableSource
instance from aCatalogTable
and additional context information.
E
- E - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ELT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- emitStrategy(WatermarkEmitStrategy) - Method in class org.apache.flink.table.watermark.WatermarkParams.WatermarkParamsBuilder
- emitValue(Object, Object) - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- empty() - Static method in class org.apache.flink.table.connector.Projection
-
Create an empty
Projection
, that is a projection that projects no fields, returning an emptyDataType
. - EMPTY_ARRAY - org.apache.flink.table.api.JsonQueryOnEmptyOrError
- EMPTY_LITERAL_LENGTH - Static variable in class org.apache.flink.table.types.logical.BinaryType
- EMPTY_LITERAL_LENGTH - Static variable in class org.apache.flink.table.types.logical.CharType
- EMPTY_LITERAL_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarBinaryType
- EMPTY_LITERAL_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarCharType
- EMPTY_OBJECT - org.apache.flink.table.api.JsonQueryOnEmptyOrError
- EMPTY_UTF8 - Static variable in class org.apache.flink.table.data.binary.BinaryStringData
- ENCODE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- encodeBytesToBase64(byte[]) - Static method in class org.apache.flink.table.utils.EncodingUtils
- encodeObjectToString(Serializable) - Static method in class org.apache.flink.table.utils.EncodingUtils
- encodeObjectToString(Object) - Static method in class org.apache.flink.table.utils.EncodingUtils
- encodeStringToBase64(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
- EncodingFormat<I> - Interface in org.apache.flink.table.connector.format
-
A
Format
for aDynamicTableSink
for writing rows. - EncodingFormatFactory<I> - Interface in org.apache.flink.table.factories
-
Base interface for configuring an
EncodingFormat
for aDynamicTableSink
. - EncodingUtils - Class in org.apache.flink.table.utils
-
General utilities for string-encoding.
- ENDS_WITH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- endsWith(BinaryStringData) - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Tests if this BinaryStringData ends with the specified suffix.
- endUnit - Variable in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- ensureMaterialized() - Method in class org.apache.flink.table.data.binary.BinaryStringData
- ensureMaterialized(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
-
Ensure we have materialized binary format.
- entries() - Method in class org.apache.flink.table.api.dataview.MapView
-
Returns all entries of the map view.
- EPOCH - org.apache.flink.table.expressions.TimeIntervalUnit
- EPOCH - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- EPOCH - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- EPOCH_JULIAN - Static variable in class org.apache.flink.table.utils.DateTimeUtils
-
The julian date of the epoch, 1970-01-01.
- equals(Object) - Method in class org.apache.flink.table.api.DataTypes.AbstractField
- equals(Object) - Method in class org.apache.flink.table.api.DataTypes.Field
- equals(Object) - Method in class org.apache.flink.table.api.DataTypes.UnresolvedField
- equals(Object) - Method in class org.apache.flink.table.api.dataview.ListView
- equals(Object) - Method in class org.apache.flink.table.api.dataview.MapView
- equals(Object) - Method in class org.apache.flink.table.api.Schema
- equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
- equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
- equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedConstraint
- equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
- equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
- equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
- equals(Object) - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
- equals(Object) - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
- equals(Object) - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
- equals(Object) - Method in class org.apache.flink.table.catalog.Column
- equals(Object) - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
- equals(Object) - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- equals(Object) - Method in class org.apache.flink.table.catalog.DefaultCatalogModel
- equals(Object) - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- equals(Object) - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- equals(Object) - Method in class org.apache.flink.table.catalog.IntervalFreshness
- equals(Object) - Method in class org.apache.flink.table.catalog.ObjectIdentifier
- equals(Object) - Method in class org.apache.flink.table.catalog.ObjectPath
- equals(Object) - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- equals(Object) - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- equals(Object) - Method in class org.apache.flink.table.catalog.ResolvedSchema
- equals(Object) - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
- equals(Object) - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
- equals(Object) - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
- equals(Object) - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
- equals(Object) - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
- equals(Object) - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
- equals(Object) - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
- equals(Object) - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
- equals(Object) - Method in class org.apache.flink.table.catalog.stats.Date
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.AddColumn
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.AddDistribution
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.AddUniqueConstraint
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.AddWatermark
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.After
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.DropColumn
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.DropConstraint
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumn
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumnComment
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumnName
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumnPosition
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyDefinitionQuery
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyDistribution
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyPhysicalColumnType
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyRefreshHandler
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyRefreshStatus
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyUniqueConstraint
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ModifyWatermark
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.ResetOption
- equals(Object) - Method in class org.apache.flink.table.catalog.TableChange.SetOption
- equals(Object) - Method in class org.apache.flink.table.catalog.TableDistribution
- equals(Object) - Method in class org.apache.flink.table.catalog.UniqueConstraint
- equals(Object) - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
- equals(Object) - Method in class org.apache.flink.table.catalog.WatermarkSpec
- equals(Object) - Method in class org.apache.flink.table.connector.ChangelogMode
- equals(Object) - Method in class org.apache.flink.table.connector.Projection
- equals(Object) - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache
- equals(Object) - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
- equals(Object) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- equals(Object) - Method in class org.apache.flink.table.data.binary.BinarySection
- equals(Object) - Method in class org.apache.flink.table.data.binary.BinaryStringData
- equals(Object) - Method in class org.apache.flink.table.data.binary.NestedRowData
- equals(Object) - Method in class org.apache.flink.table.data.columnar.ColumnarMapData
- equals(Object) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- equals(Object) - Method in class org.apache.flink.table.data.DecimalData
- equals(Object) - Method in class org.apache.flink.table.data.GenericArrayData
- equals(Object) - Method in class org.apache.flink.table.data.GenericMapData
- equals(Object) - Method in class org.apache.flink.table.data.GenericRowData
- equals(Object) - Method in class org.apache.flink.table.data.TimestampData
- equals(Object) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- equals(Object) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- equals(Object) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.expressions.AggregateExpression
- equals(Object) - Method in class org.apache.flink.table.expressions.CallExpression
- equals(Object) - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- equals(Object) - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- equals(Object) - Method in class org.apache.flink.table.expressions.SqlCallExpression
- equals(Object) - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
- equals(Object) - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
- equals(Object) - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.functions.FunctionIdentifier
- equals(Object) - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.legacy.api.constraints.UniqueConstraint
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.legacy.api.TableColumn.ComputedColumn
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.legacy.api.TableColumn.MetadataColumn
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.legacy.api.WatermarkSpec
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.legacy.sources.RowtimeAttributeDescriptor
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.plan.stats.ColumnStats
- equals(Object) - Method in class org.apache.flink.table.plan.stats.TableStats
- equals(Object) - Method in class org.apache.flink.table.resource.ResourceUri
- equals(Object) - Method in class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
- equals(Object) - Method in class org.apache.flink.table.types.CollectionDataType
- equals(Object) - Method in class org.apache.flink.table.types.DataType
- equals(Object) - Method in class org.apache.flink.table.types.FieldsDataType
- equals(Object) - Method in class org.apache.flink.table.types.inference.ConstantArgumentCount
- equals(Object) - Method in class org.apache.flink.table.types.inference.StaticArgument
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.ExplicitTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.MatchFamilyTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.NullableIfArgsTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.RepeatingSequenceInputTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.SymbolArgumentTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.VaryingStringTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
- equals(Object) - Method in class org.apache.flink.table.types.KeyValueDataType
- equals(Object) - Method in class org.apache.flink.table.types.logical.ArrayType
- equals(Object) - Method in class org.apache.flink.table.types.logical.BinaryType
- equals(Object) - Method in class org.apache.flink.table.types.logical.CharType
- equals(Object) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- equals(Object) - Method in class org.apache.flink.table.types.logical.DecimalType
- equals(Object) - Method in class org.apache.flink.table.types.logical.DistinctType
- equals(Object) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- equals(Object) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- equals(Object) - Method in class org.apache.flink.table.types.logical.LogicalType
- equals(Object) - Method in class org.apache.flink.table.types.logical.MapType
- equals(Object) - Method in class org.apache.flink.table.types.logical.MultisetType
- equals(Object) - Method in class org.apache.flink.table.types.logical.RawType
- equals(Object) - Method in class org.apache.flink.table.types.logical.RowType
- equals(Object) - Method in class org.apache.flink.table.types.logical.RowType.RowField
- equals(Object) - Method in class org.apache.flink.table.types.logical.StructuredType
- equals(Object) - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- equals(Object) - Method in class org.apache.flink.table.types.logical.TimestampType
- equals(Object) - Method in class org.apache.flink.table.types.logical.TimeType
- equals(Object) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- equals(Object) - Method in class org.apache.flink.table.types.logical.UserDefinedType
- equals(Object) - Method in class org.apache.flink.table.types.logical.VarBinaryType
- equals(Object) - Method in class org.apache.flink.table.types.logical.VarCharType
- equals(Object) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- equals(Object) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- equals(Object) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- equals(Object) - Method in class org.apache.flink.table.watermark.WatermarkParams
- equals(MemorySegment[], int, MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Equals two memory segments regions.
- EQUALS - org.apache.flink.table.types.logical.StructuredType.StructuredComparison
- EQUALS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ERROR - org.apache.flink.table.api.JsonExistsOnError
- ERROR - org.apache.flink.table.api.JsonQueryOnEmptyOrError
- ERROR - org.apache.flink.table.api.JsonValueOnEmptyOrError
-
Propagate or throw an error.
- escapeBackticks(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
- escapeIdentifier(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
- escapeJava(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
-
Escapes the characters in a
String
using Java String rules. - escapeSingleQuotes(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
- eval(Object...) - Method in class org.apache.flink.table.functions.LookupFunction
-
Invoke
LookupFunction.lookup(org.apache.flink.table.data.RowData)
and handle exceptions. - eval(Object...) - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
- eval(Object...) - Method in class org.apache.flink.table.functions.python.PythonTableFunction
- eval(CompletableFuture<Collection<RowData>>, Object...) - Method in class org.apache.flink.table.functions.AsyncLookupFunction
-
Invokes
AsyncLookupFunction.asyncLookup(org.apache.flink.table.data.RowData)
and chains futures. - EXACT_NUMERIC - org.apache.flink.table.types.logical.LogicalTypeFamily
- executeDeletion() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsDeletePushDown
-
Deletes data during execution phase.
- executeTruncation() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsTruncate
-
Execute truncating table.
- EXP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- expandCompositeTypeToSchema(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Expands a composite
DataType
to a correspondingResolvedSchema
. - expireAfterAccess(Duration) - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache.Builder
-
Specifies the duration after an entry is last accessed that it should be automatically removed.
- expireAfterWrite(Duration) - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache.Builder
-
Specifies the duration after an entry is created that it should be automatically removed.
- explainExtras() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
- explainExtras() - Method in class org.apache.flink.table.catalog.Column
-
Returns an explanation of specific column extras next to name and type.
- explainExtras() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
- explainExtras() - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
- explainExtras() - Method in class org.apache.flink.table.legacy.api.TableColumn.ComputedColumn
-
Deprecated.
- explainExtras() - Method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Returns an explanation of specific column extras next to name and type.
- explainExtras() - Method in class org.apache.flink.table.legacy.api.TableColumn.MetadataColumn
-
Deprecated.
- explainExtras() - Method in class org.apache.flink.table.legacy.api.TableColumn.PhysicalColumn
-
Deprecated.
- explainSource() - Method in interface org.apache.flink.table.legacy.sources.TableSource
-
Deprecated.Describes the table source.
- explicit(DataType) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for an argument that corresponds to an explicitly defined type casting.
- explicit(DataType) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy that returns a fixed
DataType
. - ExplicitArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for an argument that corresponds to an explicitly defined type.
- ExplicitArgumentTypeStrategy(DataType) - Constructor for class org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
- explicitSequence(String[], DataType[]) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a named function signature of explicitly defined types like
f(s STRING, i INT)
. - explicitSequence(DataType...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a function signature of explicitly defined types like
f(STRING, INT)
. - ExplicitTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that returns a fixed
DataType
. - ExplicitTypeStrategy(DataType) - Constructor for class org.apache.flink.table.types.inference.strategies.ExplicitTypeStrategy
- EXPR - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- Expression - Interface in org.apache.flink.table.expressions
-
General interface for all kinds of expressions.
- ExpressionDefaultVisitor<T> - Class in org.apache.flink.table.expressions
-
Implementation of
ExpressionVisitor
that redirects all calls toExpressionDefaultVisitor.defaultMethod(Expression)
. - ExpressionDefaultVisitor() - Constructor for class org.apache.flink.table.expressions.ExpressionDefaultVisitor
- ExpressionParserException - Exception in org.apache.flink.table.api
-
Deprecated.This exception is considered internal and has been erroneously placed in the *.api package. It is replaced by
ExpressionParserException
and should not be used directly anymore. - ExpressionParserException - Exception in org.apache.flink.table.expressions
-
Exception for all errors occurring during expression parsing.
- ExpressionParserException(String) - Constructor for exception org.apache.flink.table.api.ExpressionParserException
-
Deprecated.
- ExpressionParserException(String) - Constructor for exception org.apache.flink.table.expressions.ExpressionParserException
- ExpressionUtils - Class in org.apache.flink.table.expressions
-
Utility methods for working with
Expression
s. - ExpressionVisitor<R> - Interface in org.apache.flink.table.expressions
-
The visitor definition of
Expression
. - EXTENSION - org.apache.flink.table.types.logical.LogicalTypeFamily
- EXTRACT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- EXTRACT - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
See
ExtractInputTypeStrategy
. - extractAssigningConstructor(Class<?>, List<Field>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks whether the given constructor takes all of the given fields with matching (possibly primitive) type and name.
- extractDataType(Class<?>) - Static method in class org.apache.flink.table.types.utils.ClassDataTypeConverter
-
Returns the clearly identifiable data type if possible.
- extractDataType(Object) - Static method in class org.apache.flink.table.types.utils.ValueDataTypeConverter
-
Returns the clearly identifiable data type if possible.
- extractFromDate(DateTimeUtils.TimeUnitRange, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- extractFromDate(DateTimeUtils.TimeUnitRange, long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- extractFromGeneric(DataTypeFactory, Class<?>, int, Type) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
-
Extracts a data type from a type variable at
genericPos
ofbaseClass
using the information of the most specific typecontextType
. - extractFromGenericMethodParameter(DataTypeFactory, Class<?>, Method, int, int) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
-
Extracts a data type from a method parameter by considering surrounding classes and parameter annotation.
- extractFromMethodParameter(DataTypeFactory, Class<?>, Method, int) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
-
Extracts a data type from a method parameter by considering surrounding classes and parameter annotation.
- extractFromMethodReturnType(DataTypeFactory, Class<?>, Method) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
-
Extracts a data type from a method return type by considering surrounding classes and method annotation.
- extractFromMethodReturnType(DataTypeFactory, Class<?>, Method, Type) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
-
Extracts a data type from a method return type with specifying the method's type explicitly by considering surrounding classes and method annotation.
- extractFromTimestamp(DateTimeUtils.TimeUnitRange, TimestampData, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- extractFromType(DataTypeFactory, Type) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
-
Extracts a data type from a type without considering surrounding classes or templates.
- extractFromType(DataTypeFactory, DataTypeTemplate, Type) - Static method in class org.apache.flink.table.types.extraction.DataTypeExtractor
-
Extracts a data type from a type without considering surrounding classes but templates.
- ExtractionUtils - Class in org.apache.flink.table.types.extraction
-
Utilities for performing reflection tasks.
- ExtractionUtils.AssigningConstructor - Class in org.apache.flink.table.types.extraction
-
Result of the extraction in
ExtractionUtils.extractAssigningConstructor(Class, List)
. - ExtractionUtils.Autoboxing - Enum in org.apache.flink.table.types.extraction
-
Checks the relation between primitive and boxed types.
- ExtractionVersion - Enum in org.apache.flink.table.annotation
-
Logical version that describes the expected behavior of the reflection-based data type extraction.
- extractPartitionSpecFromPath(Path) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
-
Make partition spec from path.
- extractPartitionValues(Path) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
-
Make partition values from path.
- extractSimpleGeneric(Class<?>, Class<?>, int) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
A minimal version to extract a generic parameter from a given class.
- extractValue(Expression, Class<V>) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
-
Extracts the value (excluding null) of a given class from an expression assuming it is a
ValueLiteralExpression
.
F
- factory - Variable in class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
- factory(CatalogStoreFactory) - Method in class org.apache.flink.table.catalog.CatalogStoreHolder.Builder
- Factory - Interface in org.apache.flink.table.factories
-
Base interface for all kind of factories that create object instances from a list of key-value pairs in Flink's Table & SQL API.
- FactoryHelper(F, Map<String, String>, ConfigOption<?>...) - Constructor for class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
- factoryIdentifier() - Method in interface org.apache.flink.table.factories.Factory
-
Returns a unique identifier among same factory interfaces.
- factoryIdentifier() - Method in interface org.apache.flink.table.factories.ModuleFactory
- factoryIdentifier() - Method in class org.apache.flink.table.module.CoreModuleFactory
- FactoryUtil - Class in org.apache.flink.table.factories
-
Utility for working with
Factory
s. - FactoryUtil.CatalogFactoryHelper - Class in org.apache.flink.table.factories
-
Helper utility for validating all options for a
CatalogFactory
. - FactoryUtil.CatalogStoreFactoryHelper - Class in org.apache.flink.table.factories
-
Helper utility for validating all options for a
CatalogStoreFactory
. - FactoryUtil.DefaultCatalogContext - Class in org.apache.flink.table.factories
-
Default implementation of
CatalogFactory.Context
. - FactoryUtil.DefaultCatalogStoreContext - Class in org.apache.flink.table.factories
-
Default implementation of
CatalogStoreFactory.Context
. - FactoryUtil.DefaultDynamicTableContext - Class in org.apache.flink.table.factories
-
Default implementation of
DynamicTableFactory.Context
. - FactoryUtil.DefaultModuleContext - Class in org.apache.flink.table.factories
-
Default implementation of
ModuleFactory.Context
. - FactoryUtil.FactoryHelper<F extends Factory> - Class in org.apache.flink.table.factories
-
Base helper utility for validating all options for a
Factory
. - FactoryUtil.ModuleFactoryHelper - Class in org.apache.flink.table.factories
-
Helper utility for validating all options for a
ModuleFactory
. - FactoryUtil.TableFactoryHelper - Class in org.apache.flink.table.factories
-
Helper utility for discovering formats and validating all options for a
DynamicTableFactory
. - fail(boolean, String, Object...) - Method in interface org.apache.flink.table.types.inference.CallContext
-
Helper method for handling failures during the type inference process while considering the
throwOnFailure
flag. - FALSE - org.apache.flink.table.annotation.HintFlag
- FALSE - org.apache.flink.table.api.JsonExistsOnError
- FamilyArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for an argument that corresponds to a given
LogicalTypeFamily
and nullability. - FamilyArgumentTypeStrategy(LogicalTypeFamily, Boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
- field(String, String) - Method in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.Adds a field with the field name and the type string.
- field(String, TypeInformation<?>) - Method in class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.This method will be removed in future versions as it uses the old type system. It is recommended to use
TableSchema.Builder.field(String, DataType)
instead which uses the new type system based onDataTypes
. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information. - field(String, TypeInformation<?>) - Method in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.This method will be removed in future versions as it uses the old type system. Please use
Schema.field(String, DataType)
instead. - field(String, DataType) - Method in class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.Add a field with name and data type.
- field(String, DataType) - Method in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.Adds a field with the field name and the data type.
- field(String, DataType, String) - Method in class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.Add a computed field which is generated by the given expression.
- FIELD(String, AbstractDataType<?>) - Static method in class org.apache.flink.table.api.DataTypes
-
Unresolved field definition with field name and data type.
- FIELD(String, AbstractDataType<?>, String) - Static method in class org.apache.flink.table.api.DataTypes
-
Unresolved field definition with field name, unresolved data type, and a description.
- FIELD(String, DataType) - Static method in class org.apache.flink.table.api.DataTypes
-
Field definition with field name and data type.
- FIELD(String, DataType, String) - Static method in class org.apache.flink.table.api.DataTypes
-
Field definition with field name, data type, and a description.
- FIELD_FORMAT_NO_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.RowType.RowField
- FIELD_FORMAT_NO_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- FIELD_FORMAT_WITH_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.RowType.RowField
- FIELD_FORMAT_WITH_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- FieldComputer<T> - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.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() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
- FieldReferenceExpression - Class in org.apache.flink.table.expressions
-
A reference to a field in an input.
- FieldReferenceExpression(String, DataType, int, int) - Constructor for class org.apache.flink.table.expressions.FieldReferenceExpression
- FieldReferenceExpression(String, DataType, int, int, String) - Constructor for class org.apache.flink.table.expressions.FieldReferenceExpression
- fields(String[], DataType[]) - Method in class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.Add an array of fields with names and data types.
- FieldsDataType - Class in org.apache.flink.table.types
-
A data type that contains field data types (i.e. row and structured type).
- FieldsDataType(LogicalType, Class<?>, List<DataType>) - Constructor for class org.apache.flink.table.types.FieldsDataType
- FieldsDataType(LogicalType, List<DataType>) - Constructor for class org.apache.flink.table.types.FieldsDataType
- FILE - org.apache.flink.table.resource.ResourceType
- FileBasedStatisticsReportableInputFormat - Interface in org.apache.flink.table.connector.format
-
Extension of input format which is able to report estimated statistics for file based connector.
- FileSystemValidator - Class in org.apache.flink.table.descriptors
-
Deprecated.The legacy CSV connector has been replaced by
FileSource
/FileSink
. It is kept only to support tests for the legacy connector stack. - FileSystemValidator() - Constructor for class org.apache.flink.table.descriptors.FileSystemValidator
-
Deprecated.
- fill(boolean) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapBooleanVector
- fill(boolean) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableBooleanVector
-
Fill the column vector with the provided value.
- fill(byte) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapByteVector
- fill(byte) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableByteVector
-
Fill the column vector with the provided value.
- fill(byte[]) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapBytesVector
- fill(byte[]) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableBytesVector
-
Fill the column vector with the provided value.
- fill(double) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapDoubleVector
- fill(double) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableDoubleVector
-
Fill the column vector with the provided value.
- fill(float) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapFloatVector
- fill(float) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableFloatVector
-
Fill the column vector with the provided value.
- fill(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector
- fill(int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableIntVector
-
Fill the column vector with the provided value.
- fill(long) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapLongVector
- fill(long) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableLongVector
-
Fill the column vector with the provided value.
- fill(short) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapShortVector
- fill(short) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableShortVector
-
Fill the column vector with the provided value.
- fill(TimestampData) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapTimestampVector
- fill(TimestampData) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableTimestampVector
-
Fill the column vector with the provided value.
- fillPartitionValueForRecord(String[], DataType[], int[], List<String>, Path, String) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
-
Extract partition value from path and fill to record.
- fillWithNulls() - Method in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- fillWithNulls() - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableColumnVector
-
Fill the column vector with nulls.
- FilterableTableSource<T> - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.This interface will not be supported in the new source design around
DynamicTableSource
. UseSupportsFilterPushDown
instead. See FLIP-95 for more information. - find(Class<T>, Map<String, String>) - Static method in class org.apache.flink.table.factories.TableFactoryService
-
Deprecated.Finds a table factory of the given class and property map.
- find(Class<T>, Map<String, String>, ClassLoader) - Static method in class org.apache.flink.table.factories.TableFactoryService
-
Deprecated.Finds a table factory of the given class, property map, and classloader.
- find(Class<T>, Descriptor) - Static method in class org.apache.flink.table.factories.TableFactoryService
-
Deprecated.Finds a table factory of the given class and descriptor.
- find(Class<T>, Descriptor, ClassLoader) - Static method in class org.apache.flink.table.factories.TableFactoryService
-
Deprecated.Finds a table factory of the given class, descriptor, and classloader.
- find(MemorySegment[], int, int, MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Find equal segments2 in segments1.
- findAdditionDecimalType(int, int, int, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
-
Finds the result type of a decimal addition operation.
- findAll(Class<T>, Map<String, String>) - Static method in class org.apache.flink.table.factories.TableFactoryService
-
Deprecated.Finds all table factories of the given class and property map.
- findAvgAggType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
-
Finds the result type of a decimal average aggregation.
- findCommonType(List<LogicalType>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
-
Returns the most common, more general
LogicalType
for a given set of types. - findDivisionDecimalType(int, int, int, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
-
Finds the result type of a decimal division operation.
- findModuloDecimalType(int, int, int, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
-
Finds the result type of a decimal modulo operation.
- findMultiplicationDecimalType(int, int, int, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
-
Finds the result type of a decimal multiplication operation.
- findRoundDecimalType(int, int, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
-
Finds the result type of a decimal rounding operation.
- findSumAggType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeMerging
-
Finds the result type of a decimal sum aggregation.
- finish() - Method in class org.apache.flink.table.functions.TableFunction
-
This method is called at the end of data processing.
- finish() - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
-
Constructs the given strategy.
- finishWithVarying(InputTypeStrategy) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
-
Defines a common
InputTypeStrategy
for the next arguments. - first() - Static method in interface org.apache.flink.table.catalog.TableChange.ColumnPosition
-
Get the position to place the column at the first.
- first(TypeStrategy...) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy that returns the first type that could be inferred.
- FIRST_VALUE - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- FIRST_VALUE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- FIRST_VALUE_RETRACT - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- FirstTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that returns the first type that could be inferred.
- FirstTypeStrategy(List<? extends TypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
- FIXED_DELAY - org.apache.flink.table.connector.source.lookup.cache.trigger.PeriodicCacheReloadTrigger.ScheduleMode
- FIXED_RATE - org.apache.flink.table.connector.source.lookup.cache.trigger.PeriodicCacheReloadTrigger.ScheduleMode
- FLATTEN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- flattenToDataTypes(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Returns the data types of the flat representation in the first level of the given data type.
- flattenToNames(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Returns the names of the flat representation of the given data type.
- flattenToNames(DataType, List<String>) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
- FLINK_PROPERTY_PREFIX - Static variable in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
Globally reserved prefix for catalog properties.
- FLOAT - org.apache.flink.table.types.logical.LogicalTypeRoot
- FLOAT() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a 4-byte single precision floating point number.
- FLOAT() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API float or SQL FLOAT/REAL type.
- FLOAT_ARRAY_OFFSET - Static variable in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- FLOAT_SUM0 - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- FloatColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Float column vector.
- FloatType - Class in org.apache.flink.table.types.logical
-
Logical type of a 4-byte single precision floating point number.
- FloatType() - Constructor for class org.apache.flink.table.types.logical.FloatType
- FloatType(boolean) - Constructor for class org.apache.flink.table.types.logical.FloatType
- FLOOR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- FLOOR_OR_CEIL - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Special sql syntax for FLOOR and CEIL.
- forAggregateFunction(DataTypeFactory, Class<? extends AggregateFunction<?, ?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
Extracts a type inference from a
AggregateFunction
. - forAsyncScalarFunction(DataTypeFactory, Class<? extends AsyncScalarFunction>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
Extracts a type inference from a
AsyncScalarFunction
. - forAsyncTableFunction(DataTypeFactory, Class<? extends AsyncTableFunction<?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
Extracts a type inference from a
AsyncTableFunction
. - forceNullable(TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy which forces the given {@param initialStrategy} to be nullable.
- ForceNullableTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Forces a given type strategy to be nullable.
- ForceNullableTypeStrategy(TypeStrategy) - Constructor for class org.apache.flink.table.types.inference.strategies.ForceNullableTypeStrategy
- forceRawPattern() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
Defines that a RAW data type must be used for all classes if their class name starts with or is equal to one of the given patterns.
- Format - Interface in org.apache.flink.table.connector.format
-
Base interface for connector formats.
- FORMAT - Static variable in class org.apache.flink.table.factories.FactoryUtil
- FORMAT - Static variable in class org.apache.flink.table.factories.TableFactoryService
-
Deprecated.Prefix for format-related properties.
- FORMAT - Static variable in class org.apache.flink.table.types.logical.ArrayType
- FORMAT - Static variable in class org.apache.flink.table.types.logical.MapType
- FORMAT - Static variable in class org.apache.flink.table.types.logical.MultisetType
- FORMAT - Static variable in class org.apache.flink.table.types.logical.RawType
- FORMAT - Static variable in class org.apache.flink.table.types.logical.RowType
- FORMAT - Static variable in class org.apache.flink.table.types.logical.StructuredType
- FORMAT_DERIVE_SCHEMA - Static variable in class org.apache.flink.table.factories.TableFactoryService
-
Deprecated.Key for deriving the schema of the format from the table's schema.
- FORMAT_PROPERTY_VERSION - Static variable in class org.apache.flink.table.factories.TableFactoryService
-
Deprecated.Key for describing the property version.
- FORMAT_SUFFIX - Static variable in class org.apache.flink.table.factories.FactoryUtil
-
Suffix for keys of
ConfigOption
in case a connector requires multiple formats (e.g. - FORMAT_TYPE - Static variable in class org.apache.flink.table.factories.TableFactoryService
-
Deprecated.Key for describing the type of the format.
- formatDate(int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Helper for CAST({date} AS VARCHAR(n)).
- FormatFactory - Interface in org.apache.flink.table.factories
-
Base interface for
DecodingFormatFactory
andEncodingFormatFactory
. - formatIntervalDayTime(long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatIntervalYearMonth(int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatTimestamp(TimestampData, String) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatTimestamp(TimestampData, String, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatTimestamp(TimestampData, TimeZone, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatTimestampMillis(int, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatTimestampMillis(long, String, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatTimestampString(String, String) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatTimestampString(String, String, String, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatTimestampString(String, String, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatTimestampStringWithOffset(String, String, String, TimeZone, long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- formatUnixTimestamp(long, String, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Convert unix timestamp (seconds since '1970-01-01 00:00:00' UTC) to datetime string in the given format.
- formatUnixTimestamp(long, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Convert unix timestamp (seconds since '1970-01-01 00:00:00' UTC) to datetime string in the "yyyy-MM-dd HH:mm:ss" format.
- forProcedure(DataTypeFactory, Class<? extends Procedure>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
Extracts a type in inference from a
Procedure
. - forProcessTableFunction(DataTypeFactory, Class<? extends ProcessTableFunction<?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
Extracts a type inference from a
ProcessTableFunction
. - forScalarFunction(DataTypeFactory, Class<? extends ScalarFunction>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
Extracts a type inference from a
ScalarFunction
. - forTableAggregateFunction(DataTypeFactory, Class<? extends TableAggregateFunction<?, ?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
Extracts a type inference from a
TableAggregateFunction
. - forTableFunction(DataTypeFactory, Class<? extends TableFunction<?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
Extracts a type inference from a
TableFunction
. - forwardOptions() - Method in interface org.apache.flink.table.factories.DynamicTableFactory
-
Returns a set of
ConfigOption
that are directly forwarded to the runtime implementation but don't affect the final execution topology. - forwardOptions() - Method in interface org.apache.flink.table.factories.FormatFactory
-
Returns a set of
ConfigOption
that are directly forwarded to the runtime implementation but don't affect the final execution topology. - freshness(IntervalFreshness) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- from(int) - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
- from(int[]) - Static method in class org.apache.flink.table.data.utils.ProjectedRowData
-
Create an empty
ProjectedRowData
starting from aprojection
array. - from(int[][]) - Static method in class org.apache.flink.table.data.utils.ProjectedRowData
-
Like
ProjectedRowData.from(int[])
, but throwsIllegalArgumentException
if the providedprojection
array contains nested projections, which are not supported byProjectedRowData
. - from(String) - Method in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.Specifies the origin of the previously defined field.
- from(Projection) - Static method in class org.apache.flink.table.data.utils.ProjectedRowData
-
Create an empty
ProjectedRowData
starting from aProjection
. - FROM_BASE64 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- FROM_UNIXTIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- fromAddress(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
-
Creates a
BinaryStringData
instance from the given address (base and offset) and length. - fromBigDecimal(BigDecimal, int, int) - Static method in class org.apache.flink.table.data.DecimalData
-
Creates an instance of
DecimalData
from aBigDecimal
and the given precision and scale. - fromBytes(byte[]) - Static method in class org.apache.flink.table.data.binary.BinaryRawValueData
-
Creates a
BinaryStringData
instance from the given bytes. - fromBytes(byte[]) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
-
Creates a
BinaryStringData
instance from the given UTF-8 bytes. - fromBytes(byte[]) - Static method in interface org.apache.flink.table.data.RawValueData
-
Creates an instance of
RawValueData
from the given byte array. - fromBytes(byte[]) - Static method in interface org.apache.flink.table.data.StringData
-
Creates an instance of
StringData
from the given UTF-8 byte array. - fromBytes(byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinaryRawValueData
-
Creates a
BinaryStringData
instance from the given bytes with offset and number of bytes. - fromBytes(byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
-
Creates a
BinaryStringData
instance from the given UTF-8 bytes with offset and number of bytes. - fromBytes(byte[], int, int) - Static method in interface org.apache.flink.table.data.StringData
-
Creates an instance of
StringData
from the given UTF-8 byte array with offset and number of bytes. - fromClassToDataType(Class<?>) - Static method in class org.apache.flink.table.types.utils.TypeConversions
- fromColumns(List<Schema.UnresolvedColumn>) - Method in class org.apache.flink.table.api.Schema.Builder
-
Adopts all columns from the given list.
- fromConfig(ReadableConfig) - Static method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache
- fromConfig(ReadableConfig) - Static method in class org.apache.flink.table.connector.source.lookup.cache.trigger.PeriodicCacheReloadTrigger
- fromConfig(ReadableConfig) - Static method in class org.apache.flink.table.connector.source.lookup.cache.trigger.TimedCacheReloadTrigger
- fromDataToLogicalType(DataType) - Static method in class org.apache.flink.table.types.utils.TypeConversions
- fromDataToLogicalType(DataType[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
- fromDataTypeToLegacyInfo(DataType) - Static method in class org.apache.flink.table.types.utils.TypeConversions
-
Deprecated.Please don't use this method anymore. It will be removed soon and we should not make the removal more painful. Sources and sinks should use the method available in context to convert, within the planner you should use either
InternalTypeInfo
orExternalTypeInfo
depending on the use case. - fromDataTypeToLegacyInfo(DataType[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
-
Deprecated.Please don't use this method anymore. It will be removed soon and we should not make the removal more painful. Sources and sinks should use the method available in context to convert, within the planner you should use either
InternalTypeInfo
orExternalTypeInfo
depending on the use case. - fromEpochMillis(long) - Static method in class org.apache.flink.table.data.TimestampData
-
Creates an instance of
TimestampData
from milliseconds. - fromEpochMillis(long, int) - Static method in class org.apache.flink.table.data.TimestampData
-
Creates an instance of
TimestampData
from milliseconds and a nanos-of-millisecond. - fromFieldNames(DataType, List<String>) - Static method in class org.apache.flink.table.connector.Projection
- fromFields(String[], AbstractDataType<?>[]) - Method in class org.apache.flink.table.api.Schema.Builder
-
Adopts the given field names and field data types as physical columns of the schema.
- fromFields(List<String>, List<? extends AbstractDataType<?>>) - Method in class org.apache.flink.table.api.Schema.Builder
-
Adopts the given field names and field data types as physical columns of the schema.
- fromInstant(Instant) - Static method in class org.apache.flink.table.data.TimestampData
-
Creates an instance of
TimestampData
from an instance ofInstant
. - fromLegacyInfoToDataType(TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.TypeConversions
-
Deprecated.Please don't use this method anymore. It will be removed soon and we should not make the removal more painful. Sources and sinks should use the method available in context to convert, within the planner you should use either
InternalTypeInfo
orExternalTypeInfo
depending on the use case. - fromLegacyInfoToDataType(TypeInformation<?>[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
-
Deprecated.Please don't use this method anymore. It will be removed soon and we should not make the removal more painful. Sources and sinks should use the method available in context to convert, within the planner you should use either
InternalTypeInfo
orExternalTypeInfo
depending on the use case. - fromLocalDateTime(LocalDateTime) - Static method in class org.apache.flink.table.data.TimestampData
-
Creates an instance of
TimestampData
from an instance ofLocalDateTime
. - fromLogicalToDataType(LogicalType) - Static method in class org.apache.flink.table.types.utils.TypeConversions
- fromLogicalToDataType(LogicalType[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
- fromObject(T) - Static method in class org.apache.flink.table.data.binary.BinaryRawValueData
-
Creates a
BinaryRawValueData
instance from the given Java object. - fromObject(T) - Static method in interface org.apache.flink.table.data.RawValueData
-
Creates an instance of
RawValueData
from a Java object. - fromPrimitiveArray(boolean[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
- fromPrimitiveArray(byte[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
- fromPrimitiveArray(double[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
- fromPrimitiveArray(float[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
- fromPrimitiveArray(int[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
- fromPrimitiveArray(long[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
- fromPrimitiveArray(short[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
- fromProperties(Map<String, String>) - Static method in interface org.apache.flink.table.catalog.CatalogTable
-
Creates an instance of
CatalogTable
from a map of string properties that were previously created withResolvedCatalogTable.toProperties()
. - fromProperties(Map<String, String>) - Static method in interface org.apache.flink.table.catalog.ResolvedCatalogModel
-
Creates an instance of
CatalogModel
from a map of string properties that were previously created withResolvedCatalogModel.toProperties()
. - fromResolvedSchema(ResolvedSchema) - Method in class org.apache.flink.table.api.Schema.Builder
-
Adopts all members from the given resolved schema.
- fromResolvedSchema(ResolvedSchema) - Static method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Helps to migrate to the new
ResolvedSchema
to old API methods. - fromRowDataType(DataType) - Method in class org.apache.flink.table.api.Schema.Builder
-
Adopts all fields of the given row as physical columns of the schema.
- fromSchema(Schema) - Method in class org.apache.flink.table.api.Schema.Builder
-
Adopts all members from the given unresolved schema.
- fromString(String) - Static method in class org.apache.flink.table.catalog.ObjectPath
- fromString(String) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
-
Creates a
BinaryStringData
instance from the given Java string. - fromString(String) - Static method in interface org.apache.flink.table.data.StringData
-
Creates an instance of
StringData
from the givenString
. - fromTimestamp(long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- fromTimestamp(Timestamp) - Static method in class org.apache.flink.table.data.TimestampData
-
Creates an instance of
TimestampData
from an instance ofTimestamp
. - fromTypeInfo(TypeInformation<?>) - Static method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.This method will be removed soon. Use
DataTypes
to declare types. - fromUnscaledBytes(byte[], int, int) - Static method in class org.apache.flink.table.data.DecimalData
-
Creates an instance of
DecimalData
from an unscaled byte array value and the given precision and scale. - fromUnscaledLong(long, int, int) - Static method in class org.apache.flink.table.data.DecimalData
-
Creates an instance of
DecimalData
from an unscaled long value and the given precision and scale. - FULL - org.apache.flink.table.catalog.CatalogMaterializedTable.LogicalRefreshMode
-
The refresh pipeline will be executed in full mode, corresponding to
CatalogMaterializedTable.RefreshMode.FULL
. - FULL - org.apache.flink.table.catalog.CatalogMaterializedTable.RefreshMode
- FULL - org.apache.flink.table.connector.source.lookup.LookupOptions.LookupCacheType
- FULL - org.apache.flink.table.types.logical.StructuredType.StructuredComparison
- FULL_CACHE_PERIODIC_RELOAD_INTERVAL - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- FULL_CACHE_PERIODIC_RELOAD_SCHEDULE_MODE - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- FULL_CACHE_RELOAD_STRATEGY - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- FULL_CACHE_TIMED_RELOAD_INTERVAL_IN_DAYS - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- FULL_CACHE_TIMED_RELOAD_ISO_TIME - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- FullCachingLookupProvider - Interface in org.apache.flink.table.connector.source.lookup
-
A
LookupFunctionProvider
that never lookup in external system on cache miss and provides a cache for holding all entries in the external system. - FUNCTION - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Function syntax, as in "Foo(x, y)".
- FunctionAlreadyExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to create a function that already exists.
- FunctionAlreadyExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.FunctionAlreadyExistException
- FunctionAlreadyExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.FunctionAlreadyExistException
- FunctionContext - Class in org.apache.flink.table.functions
-
A
FunctionContext
allows to obtain global runtime information about the context in which the user-defined function is executed. - FunctionContext(RuntimeContext) - Constructor for class org.apache.flink.table.functions.FunctionContext
- FunctionContext(RuntimeContext, ClassLoader, OpenContext) - Constructor for class org.apache.flink.table.functions.FunctionContext
- FunctionDefinition - Interface in org.apache.flink.table.functions
-
Definition of a function.
- FunctionDefinitionFactory - Interface in org.apache.flink.table.factories
-
A factory to create
FunctionDefinition
. - FunctionDefinitionFactory.Context - Interface in org.apache.flink.table.factories
-
Context provided when a function definition is created.
- functionExists(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Check whether a function exists or not.
- FunctionHint - Annotation Type in org.apache.flink.table.annotation
-
A hint that influences the reflection-based extraction of arguments, accumulator, and output for constructing the
TypeInference
logic of aUserDefinedFunction
. - FunctionHints - Annotation Type in org.apache.flink.table.annotation
-
Helper annotation for repeatable
FunctionHint
s. - functionIdentifier() - Method in class org.apache.flink.table.functions.UserDefinedFunction
-
Returns a unique, serialized representation for this function.
- FunctionIdentifier - Class in org.apache.flink.table.functions
-
Identifies a system function with function name or a catalog function with a fully qualified identifier.
- FunctionKind - Enum in org.apache.flink.table.functions
-
Categorizes the semantics of a
FunctionDefinition
. - FunctionLanguage - Enum in org.apache.flink.table.catalog
-
Categorizes the language semantics of a
CatalogFunction
. - FunctionNotExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to operate on a function that doesn't exist.
- FunctionNotExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.FunctionNotExistException
- FunctionNotExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.FunctionNotExistException
- FunctionRequirement - Enum in org.apache.flink.table.functions
-
Characteristics that a
FunctionDefinition
requires.
G
- GENERAL - org.apache.flink.table.functions.python.PythonFunctionKind
- generateInlineFunctionName(UserDefinedFunction) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Name for anonymous, inline functions.
- generatePartitionPath(LinkedHashMap<String, String>) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
-
Make partition path from partition spec.
- generateRuntimeName(Class<?>, String[]) - Static method in class org.apache.flink.table.utils.TableConnectorUtils
-
Returns the table connector name used for logging and web UI.
- generateSignature(TypeInference, String, FunctionDefinition) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
-
Generates a signature of the given
FunctionDefinition
. - GenericArrayData - Class in org.apache.flink.table.data
-
An internal data structure representing data of
ArrayType
. - GenericArrayData(boolean[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
- GenericArrayData(byte[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
- GenericArrayData(double[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
- GenericArrayData(float[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
- GenericArrayData(int[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
- GenericArrayData(long[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
- GenericArrayData(short[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
- GenericArrayData(Object[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
-
Creates an instance of
GenericArrayData
using the given Java array. - GenericMapData - Class in org.apache.flink.table.data
-
An internal data structure representing data of
MapType
orMultisetType
. - GenericMapData(Map<?, ?>) - Constructor for class org.apache.flink.table.data.GenericMapData
-
Creates an instance of
GenericMapData
using the given Java map. - GenericRowData - Class in org.apache.flink.table.data
-
An internal data structure representing data of
RowType
and other (possibly nested) structured types such asStructuredType
. - GenericRowData(int) - Constructor for class org.apache.flink.table.data.GenericRowData
-
Creates an instance of
GenericRowData
with given number of fields. - GenericRowData(RowKind, int) - Constructor for class org.apache.flink.table.data.GenericRowData
-
Creates an instance of
GenericRowData
with given kind and number of fields. - get() - Method in class org.apache.flink.table.api.dataview.ListView
-
Returns an iterable of the list view.
- get(Object) - Method in class org.apache.flink.table.data.GenericMapData
-
Returns the value to which the specified key is mapped, or
null
if this map contains no mapping for the key. - get(K) - Method in class org.apache.flink.table.api.dataview.MapView
-
Return the value for the specified key or
null
if the key is not in the map view. - get(K) - Method in class org.apache.flink.table.utils.ThreadLocalCache
- GET - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- GET - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
GetTypeStrategy
. - getAbstractDataType() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
- getAbstractDataType() - Method in class org.apache.flink.table.api.DataTypes.Field
- getAbstractDataType() - Method in class org.apache.flink.table.api.DataTypes.UnresolvedField
- getAcceptedFilters() - Method in class org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown.Result
- getAccessedFields(TimestampExtractor, DataType, Function<String, String>) - Static method in class org.apache.flink.table.sources.tsextractors.TimestampExtractorUtils
-
Retrieves all field accesses needed for the given
TimestampExtractor
. - getAccumulatorDataType() - Method in class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
- getAccumulatorType() - Method in class org.apache.flink.table.functions.ImperativeAggregateFunction
-
Deprecated.This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated
TableEnvironment.registerFunction(...)
method. The new reflective extraction logic (possibly enriched withDataTypeHint
andFunctionHint
) should be powerful enough to cover most use cases. For advanced users, it is possible to overrideUserDefinedFunction.getTypeInference(DataTypeFactory)
. - getAccumulatorType() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- getAccumulatorType() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- getAccumulatorTypeInfo() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- getAccumulatorTypeInfo() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- getAccumulatorTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
- getAccumulatorTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>, TypeInformation<ACC>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
- getAccumulatorTypeStrategy() - Method in class org.apache.flink.table.types.inference.TypeInference
-
Deprecated.Use
TypeInference.getStateTypeStrategies()
instead. - getAggregateFunction() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- getAlias() - Method in enum org.apache.flink.table.watermark.WatermarkEmitStrategy
- getAlignGroupName() - Method in class org.apache.flink.table.watermark.WatermarkParams
- getAlignMaxDrift() - Method in class org.apache.flink.table.watermark.WatermarkParams
- getAlignUpdateInterval() - Method in class org.apache.flink.table.watermark.WatermarkParams
- getArgs() - Method in class org.apache.flink.table.expressions.AggregateExpression
- getArgumentCount() - Method in interface org.apache.flink.table.types.inference.InputTypeStrategy
-
Initial input validation based on the number of arguments.
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.CommonCollectionInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.CommonInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.LeadLagInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.OverTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.ReinterpretCastInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.RepeatingSequenceInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.SubQueryInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
- getArgumentCount() - Method in class org.apache.flink.table.types.inference.strategies.WindowTimeIndictorInputTypeStrategy
- getArgumentDataTypes() - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns a resolved list of the call's argument types.
- getArgumentDataTypes() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- getArgumentDataTypes() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
- getArgumentFields() - Method in interface org.apache.flink.table.legacy.sources.FieldComputer
-
Deprecated.Returns the names of all fields that the expression of the field computer accesses.
- getArguments() - Method in class org.apache.flink.table.types.inference.Signature
- getArgumentValue(int, Class<T>) - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns the literal value of the argument at the given position, given that the argument is a literal, is not null, and can be expressed as an instance of the provided class.
- getArgumentValue(int, Class<T>) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- getArgumentValue(int, Class<T>) - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
- getArity() - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getArity() - Method in class org.apache.flink.table.data.binary.NestedRowData
- getArity() - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getArity() - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getArity() - Method in class org.apache.flink.table.data.GenericRowData
- getArity() - Method in interface org.apache.flink.table.data.RowData
-
Returns the number of fields in this row.
- getArity() - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getArity() - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getArity() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- getArity() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- getArity() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- getArray(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the array value at the given position.
- getArray(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getArray(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getArray(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getArray(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getArray(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getArray(int) - Method in interface org.apache.flink.table.data.columnar.vector.ArrayColumnVector
- getArray(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- getArray(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getArray(int) - Method in class org.apache.flink.table.data.GenericRowData
- getArray(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the array value at the given position.
- getArray(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getArray(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getArray(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getArray(String, Function<String, E>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns all array elements under a given existing key.
- getAsyncLookupFunction(String[]) - Method in interface org.apache.flink.table.legacy.sources.LookupableTableSource
-
Deprecated.Gets the
AsyncTableFunction
which supports async lookup one key at a time. - getAtomicName(List<String>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
-
Returns a unique name for an atomic type.
- getAttributeName() - Method in class org.apache.flink.table.legacy.sources.RowtimeAttributeDescriptor
-
Deprecated.Returns the name of the rowtime attribute.
- getAttributes() - Method in class org.apache.flink.table.types.logical.StructuredType
- getAvgLen() - Method in class org.apache.flink.table.plan.stats.ColumnStats
- getAvgLength() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
- getAvgLength() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
- getBigDecimal(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a big decimal value under the given existing key.
- getBinary(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the binary value at the given position.
- getBinary(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getBinary(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getBinary(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getBinary(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getBinary(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getBinary(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getBinary(int) - Method in class org.apache.flink.table.data.GenericRowData
- getBinary(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the binary value at the given position.
- getBinary(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getBinary(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getBinarySection() - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
- getBoolean(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the boolean value at the given position.
- getBoolean(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getBoolean(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getBoolean(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getBoolean(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getBoolean(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getBoolean(int) - Method in interface org.apache.flink.table.data.columnar.vector.BooleanColumnVector
- getBoolean(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapBooleanVector
- getBoolean(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getBoolean(int) - Method in class org.apache.flink.table.data.GenericRowData
- getBoolean(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the boolean value at the given position.
- getBoolean(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getBoolean(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getBoolean(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getBoolean(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a boolean value under the given existing key.
- getBoolean(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get boolean from segments.
- getBucketCount() - Method in class org.apache.flink.table.catalog.TableDistribution
- getBucketKeys() - Method in class org.apache.flink.table.catalog.TableDistribution
- getBuiltInClassLoader() - Method in interface org.apache.flink.table.functions.SpecializedFunction.SpecializedContext
-
Returns the classloader used to resolve built-in functions.
- getByte(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the byte value at the given position.
- getByte(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getByte(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getByte(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getByte(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getByte(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getByte(int) - Method in interface org.apache.flink.table.data.columnar.vector.ByteColumnVector
- getByte(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapByteVector
- getByte(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getByte(int) - Method in class org.apache.flink.table.data.GenericRowData
- getByte(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the byte value at the given position.
- getByte(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getByte(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getByte(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getByte(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a byte value under the given existing key.
- getByte(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get byte from segments.
- getByteArray(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getBytes() - Method in class org.apache.flink.table.data.columnar.vector.BytesColumnVector.Bytes
- getBytes(int) - Method in interface org.apache.flink.table.data.columnar.vector.BytesColumnVector
- getBytes(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapBytesVector
- getBytes(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Maybe not copied, if want copy, please use copyTo.
- getCache() - Method in interface org.apache.flink.table.connector.source.lookup.PartialCachingAsyncLookupProvider
-
Get a new instance of
LookupCache
. - getCache() - Method in interface org.apache.flink.table.connector.source.lookup.PartialCachingLookupProvider
-
Get a new instance of
LookupCache
. - getCachedFile(String) - Method in class org.apache.flink.table.functions.FunctionContext
-
Gets the local temporary file copy of a distributed cache files.
- getCacheReloadTrigger() - Method in interface org.apache.flink.table.connector.source.lookup.FullCachingLookupProvider
-
Get a
CacheReloadTrigger
for triggering the reload operation. - getCallContext() - Method in interface org.apache.flink.table.functions.SpecializedFunction.SpecializedContext
-
Returns the context of the current call.
- getCallSyntax() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- getCatalog(String) - Method in interface org.apache.flink.table.catalog.CatalogStore
-
Get a catalog by name.
- getCatalogName() - Method in class org.apache.flink.table.catalog.CatalogDescriptor
- getCatalogName() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
- getCatalogName() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
- getCatalogTable() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
-
Returns the resolved table information received from the
Catalog
or persisted plan. - getCatalogTable() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
- getChangelogMode() - Method in interface org.apache.flink.table.connector.format.Format
-
Returns the set of changes that a connector (and transitively the planner) can expect during runtime.
- getChangelogMode() - Method in interface org.apache.flink.table.connector.source.ScanTableSource
-
Returns the set of changes that the planner can expect during runtime.
- getChangelogMode(ChangelogMode) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
-
Returns the set of changes that the sink accepts during runtime.
- getCharacter(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a character value under the given existing key.
- getChild() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- getChildren() - Method in class org.apache.flink.table.expressions.AggregateExpression
- getChildren() - Method in class org.apache.flink.table.expressions.CallExpression
- getChildren() - Method in interface org.apache.flink.table.expressions.Expression
- getChildren() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- getChildren() - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- getChildren() - Method in class org.apache.flink.table.expressions.SqlCallExpression
- getChildren() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
- getChildren() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
- getChildren() - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- getChildren() - Method in class org.apache.flink.table.types.AtomicDataType
- getChildren() - Method in class org.apache.flink.table.types.CollectionDataType
- getChildren() - Method in class org.apache.flink.table.types.DataType
-
Returns the children of this data type, if any.
- getChildren() - Method in class org.apache.flink.table.types.FieldsDataType
- getChildren() - Method in class org.apache.flink.table.types.KeyValueDataType
- getChildren() - Method in class org.apache.flink.table.types.logical.ArrayType
- getChildren() - Method in class org.apache.flink.table.types.logical.BigIntType
- getChildren() - Method in class org.apache.flink.table.types.logical.BinaryType
- getChildren() - Method in class org.apache.flink.table.types.logical.BooleanType
- getChildren() - Method in class org.apache.flink.table.types.logical.CharType
- getChildren() - Method in class org.apache.flink.table.types.logical.DateType
- getChildren() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- getChildren() - Method in class org.apache.flink.table.types.logical.DecimalType
- getChildren() - Method in class org.apache.flink.table.types.logical.DistinctType
- getChildren() - Method in class org.apache.flink.table.types.logical.DoubleType
- getChildren() - Method in class org.apache.flink.table.types.logical.FloatType
- getChildren() - Method in class org.apache.flink.table.types.logical.IntType
- getChildren() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- getChildren() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- getChildren() - Method in class org.apache.flink.table.types.logical.LogicalType
- getChildren() - Method in class org.apache.flink.table.types.logical.MapType
- getChildren() - Method in class org.apache.flink.table.types.logical.MultisetType
- getChildren() - Method in class org.apache.flink.table.types.logical.NullType
- getChildren() - Method in class org.apache.flink.table.types.logical.RawType
- getChildren() - Method in class org.apache.flink.table.types.logical.RowType
- getChildren() - Method in class org.apache.flink.table.types.logical.SmallIntType
- getChildren() - Method in class org.apache.flink.table.types.logical.StructuredType
- getChildren() - Method in class org.apache.flink.table.types.logical.SymbolType
- getChildren() - Method in class org.apache.flink.table.types.logical.TimestampType
- getChildren() - Method in class org.apache.flink.table.types.logical.TimeType
- getChildren() - Method in class org.apache.flink.table.types.logical.TinyIntType
- getChildren() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- getChildren() - Method in class org.apache.flink.table.types.logical.VarBinaryType
- getChildren() - Method in class org.apache.flink.table.types.logical.VarCharType
- getChildren() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- getChildren() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- getClass(String, Class<T>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a class value under the given existing key.
- getClassFromType(Type) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Gets the associated class type from a Type parameter.
- getClassLoader() - Method in interface org.apache.flink.table.connector.RuntimeConverter.Context
-
Runtime classloader for loading user-defined classes.
- getClassLoader() - Method in interface org.apache.flink.table.factories.CatalogFactory.Context
-
Returns the class loader of the current session.
- getClassLoader() - Method in interface org.apache.flink.table.factories.CatalogStoreFactory.Context
-
Returns the class loader of the current session.
- getClassLoader() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
-
Returns the class loader of the current session.
- getClassLoader() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
- getClassLoader() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogStoreContext
- getClassLoader() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
- getClassLoader() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultModuleContext
- getClassLoader() - Method in interface org.apache.flink.table.factories.FunctionDefinitionFactory.Context
-
Returns the class loader of the current session.
- getClassLoader() - Method in interface org.apache.flink.table.factories.ModuleFactory.Context
-
Returns the class loader of the current session.
- getClassName() - Method in interface org.apache.flink.table.catalog.CatalogFunction
-
Get the full name of the class backing the function.
- getClusterId() - Method in class org.apache.flink.table.refresh.ContinuousRefreshHandler
- getColumn() - Method in class org.apache.flink.table.catalog.TableChange.AddColumn
- getColumn(int) - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns the
Column
instance for the given column index. - getColumn(String) - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns the
Column
instance for the given column name. - getColumnCount() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns the number of
Column
s of this schema. - getColumnDataTypes() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns all column data types.
- getColumnName() - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
- getColumnName() - Method in class org.apache.flink.table.catalog.TableChange.DropColumn
-
Returns the column name.
- getColumnNames() - Method in class org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
- getColumnNames() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns all column names.
- getColumns() - Method in class org.apache.flink.table.api.Schema
- getColumns() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns all
Column
s of this schema. - getColumns() - Method in class org.apache.flink.table.catalog.UniqueConstraint
-
List of column names for which the primary key was defined.
- getColumns() - Method in class org.apache.flink.table.legacy.api.constraints.UniqueConstraint
-
Deprecated.List of column names for which the primary key was defined.
- getColumnStatisticsData() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
- getColumnStats() - Method in class org.apache.flink.table.plan.stats.TableStats
- getColumnWidths() - Method in class org.apache.flink.table.utils.print.TableauStyle
-
Returns null if the column widths are not precomputed using the row type.
- getComment() - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
- getComment() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
Get comment of the table or view.
- getComment() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
-
Get comment of the database.
- getComment() - Method in class org.apache.flink.table.catalog.CatalogDescriptor
- getComment() - Method in interface org.apache.flink.table.catalog.CatalogModel
-
Get comment of the model.
- getComment() - Method in interface org.apache.flink.table.catalog.CatalogPartition
-
Get comment of the partition.
- getComment() - Method in class org.apache.flink.table.catalog.Column
-
Returns the comment of this column.
- getComment() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getComment() - Method in class org.apache.flink.table.catalog.DefaultCatalogModel
- getComment() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- getComment() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- getComment() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getComment() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- getComment() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
- getComparison() - Method in class org.apache.flink.table.types.logical.StructuredType
- getConfiguration() - Method in class org.apache.flink.table.catalog.CatalogDescriptor
- getConfiguration() - Method in interface org.apache.flink.table.factories.CatalogFactory.Context
-
Gives read-only access to the configuration of the current session.
- getConfiguration() - Method in interface org.apache.flink.table.factories.CatalogStoreFactory.Context
-
Gives read-only access to the configuration of the current session.
- getConfiguration() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
-
Gives read-only access to the configuration of the current session.
- getConfiguration() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
- getConfiguration() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogStoreContext
- getConfiguration() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
- getConfiguration() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultModuleContext
- getConfiguration() - Method in interface org.apache.flink.table.factories.ModuleFactory.Context
-
Gives read-only access to the configuration of the current session.
- getConfiguration() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- getConfiguration() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
-
Deprecated.
- getConfiguration() - Method in interface org.apache.flink.table.factories.WorkflowSchedulerFactory.Context
-
Gives the config option to create
WorkflowScheduler
. - getConfiguration() - Method in class org.apache.flink.table.factories.WorkflowSchedulerFactoryUtil.DefaultWorkflowSchedulerContext
- getConfiguration() - Method in interface org.apache.flink.table.functions.SpecializedFunction.SpecializedContext
-
Gives read-only access to the configuration of the current session.
- getConfiguration() - Method in interface org.apache.flink.table.legacy.factories.TableSinkFactory.Context
-
Deprecated.
- getConfiguration() - Method in interface org.apache.flink.table.legacy.factories.TableSourceFactory.Context
-
Deprecated.
- getConstraint() - Method in class org.apache.flink.table.catalog.TableChange.AddUniqueConstraint
-
Returns the unique constraint to add.
- getConstraintName() - Method in class org.apache.flink.table.api.Schema.UnresolvedConstraint
- getConstraintName() - Method in class org.apache.flink.table.catalog.TableChange.DropConstraint
-
Returns the constraint name.
- getConsumedDataType() - Method in interface org.apache.flink.table.legacy.sinks.TableSink
-
Deprecated.Returns the data type consumed by this
TableSink
. - getContainedKinds() - Method in class org.apache.flink.table.connector.ChangelogMode
- getConversionClass() - Method in class org.apache.flink.table.types.DataType
-
Returns the corresponding conversion class for representing values.
- getConversionClass() - Method in class org.apache.flink.table.types.inference.StaticArgument
- getCronExpression() - Method in class org.apache.flink.table.workflow.CreatePeriodicRefreshWorkflow
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
Deprecated.
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.dataview.MapViewSerializerSnapshot
-
Deprecated.
- getCurrentOuterSnapshotVersion() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
-
Deprecated.
- getData() - Method in class org.apache.flink.table.connector.source.DynamicFilteringData
- getData() - Method in class org.apache.flink.table.connector.source.DynamicFilteringEvent
- getDatabase(String) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get a database from this catalog.
- getDatabaseName() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
- getDatabaseName() - Method in class org.apache.flink.table.catalog.ObjectPath
- getDatabaseName() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
- getDataType() - Method in class org.apache.flink.table.api.DataTypes.Field
- getDataType() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
- getDataType() - Method in class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
- getDataType() - Method in class org.apache.flink.table.catalog.Column
-
Returns the data type of this column.
- getDataType() - Method in interface org.apache.flink.table.types.DataTypeQueryable
- getDataType() - Method in class org.apache.flink.table.types.inference.StaticArgument
- getDataType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- getDataType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns the DataType under the given existing key.
- getDataTypeFactory() - Method in interface org.apache.flink.table.types.inference.CallContext
-
Enables to lookup types in a catalog and resolve RAW types.
- getDataTypeFactory() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- getDataTypeFactory() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
- getDayPrecision() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- getDayPrecision(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- getDaysSinceEpoch() - Method in class org.apache.flink.table.catalog.stats.Date
- getDecimal(int, int, int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the decimal value at the given position.
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getDecimal(int, int, int) - Method in interface org.apache.flink.table.data.columnar.vector.DecimalColumnVector
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.GenericArrayData
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.GenericRowData
- getDecimal(int, int, int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the decimal value at the given position.
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getDecimal(int, int, int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getDefaultConversion() - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.ArrayType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.BigIntType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.BinaryType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.BooleanType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.CharType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DateType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DecimalType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DistinctType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DoubleType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.FloatType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.IntType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns the default conversion class.
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.MapType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.MultisetType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.NullType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.RawType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.RowType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.SmallIntType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.StructuredType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.SymbolType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TimestampType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TimeType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TinyIntType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.VarBinaryType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.VarCharType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- getDefaultDatabase() - Method in class org.apache.flink.table.catalog.AbstractCatalog
- getDefaultDatabase() - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the name of the default database for this catalog.
- getDefinitionFreshness() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Get the definition freshness of materialized table which is used to determine the physical refresh mode.
- getDefinitionFreshness() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getDefinitionFreshness() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getDefinitionQuery() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
The definition query text of materialized table, text is expanded in contrast to the original SQL.
- getDefinitionQuery() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getDefinitionQuery() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getDefinitionQuery() - Method in class org.apache.flink.table.catalog.TableChange.ModifyDefinitionQuery
- getDefinitions() - Static method in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- getDescription() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
- getDescription() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
Get a brief description of the table or view.
- getDescription() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
-
Get a brief description of the database.
- getDescription() - Method in interface org.apache.flink.table.catalog.CatalogFunction
-
Get a brief description of the function.
- getDescription() - Method in interface org.apache.flink.table.catalog.CatalogPartition
-
Get a brief description of the database.
- getDescription() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getDescription() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- getDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- getDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
- getDescription() - Method in class org.apache.flink.table.types.logical.RowType.RowField
- getDescription() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- getDescription() - Method in class org.apache.flink.table.types.logical.UserDefinedType
- getDescriptionStatement() - Method in class org.apache.flink.table.workflow.CreatePeriodicRefreshWorkflow
- getDetailedDescription() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
Get a detailed description of the table or view.
- getDetailedDescription() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
-
Get a detailed description of the database.
- getDetailedDescription() - Method in interface org.apache.flink.table.catalog.CatalogFunction
-
Get a detailed description of the function.
- getDetailedDescription() - Method in interface org.apache.flink.table.catalog.CatalogPartition
-
Get a detailed description of the database.
- getDetailedDescription() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getDetailedDescription() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- getDetailedDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getDetailedDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- getDetailedDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
- getDictionaryIds() - Method in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
-
Returns the underlying integer column for ids of dictionary.
- getDictionaryIds() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapBooleanVector
- getDictionaryIds() - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableColumnVector
-
Get reserved dictionary ids.
- getDistribution() - Method in interface org.apache.flink.table.catalog.CatalogTable
-
Returns the distribution of the table if the
DISTRIBUTED
clause is defined. - getDistribution() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- getDistribution() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- getDistribution() - Method in class org.apache.flink.table.catalog.TableChange.AddDistribution
-
Returns the unique constraint to add.
- getDistribution() - Method in class org.apache.flink.table.catalog.TableChange.ModifyDistribution
-
Returns the unique constraint to add.
- getDouble(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the double value at the given position.
- getDouble(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getDouble(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getDouble(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getDouble(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getDouble(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getDouble(int) - Method in interface org.apache.flink.table.data.columnar.vector.DoubleColumnVector
- getDouble(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapDoubleVector
- getDouble(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getDouble(int) - Method in class org.apache.flink.table.data.GenericRowData
- getDouble(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the double value at the given position.
- getDouble(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getDouble(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getDouble(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getDouble(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a double value under the given existing key.
- getDouble(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get double from segments.
- getDuration(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a java
Duration
under the given existing key. - getDynamicOptions() - Method in class org.apache.flink.table.workflow.ResumeRefreshWorkflow
- getDynamicTableFactory(Class<T>, Catalog) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Returns the
DynamicTableFactory
viaCatalog
. - getElementDataType() - Method in class org.apache.flink.table.types.CollectionDataType
- getElementOrNull(ArrayData, int) - Method in interface org.apache.flink.table.data.ArrayData.ElementGetter
- getElementType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- getElementType() - Method in class org.apache.flink.table.types.logical.ArrayType
- getElementType() - Method in class org.apache.flink.table.types.logical.MultisetType
- getEmitStrategy() - Method in class org.apache.flink.table.watermark.WatermarkParams
- getEnrichmentOptions() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
-
Returns a map of options that can enrich the options of the original
DynamicTableFactory.Context.getCatalogTable()
during a plan restore. - getEnrichmentOptions() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
- getExecType() - Method in class org.apache.flink.table.functions.python.PythonEnv
- getExecutionConfig() - Method in class org.apache.flink.table.workflow.CreatePeriodicRefreshWorkflow
- getExecutionTarget() - Method in class org.apache.flink.table.refresh.ContinuousRefreshHandler
- getExpandedQuery() - Method in interface org.apache.flink.table.catalog.CatalogView
-
Expanded text of the original view definition This is needed because the context such as current DB is lost after the session, in which view is defined, is gone.
- getExpandedQuery() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
- getExpectedArgument(FunctionDefinition, int) - Method in interface org.apache.flink.table.types.inference.ArgumentTypeStrategy
-
Returns a summary of the function's expected argument at
argumentPos
. - getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.ArrayComparableElementArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.ArrayOfStringArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.CommonArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.CompositeArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.IndexArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.ItemAtIndexArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.JsonQueryOnErrorEmptyArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.PercentageArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.PercentageArrayArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.SymbolArgumentTypeStrategy
- getExpectedArgument(FunctionDefinition, int) - Method in class org.apache.flink.table.types.inference.strategies.TypeLiteralArgumentTypeStrategy
- getExpectedArgumentTypes() - Method in class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
- getExpectedSignatures(FunctionDefinition) - Method in interface org.apache.flink.table.types.inference.InputTypeStrategy
-
Returns a summary of the function's expected signatures.
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.CommonCollectionInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.CommonInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.LeadLagInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.OverTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.ReinterpretCastInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.RepeatingSequenceInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.SubQueryInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
- getExpectedSignatures(FunctionDefinition) - Method in class org.apache.flink.table.types.inference.strategies.WindowTimeIndictorInputTypeStrategy
- getExpression() - Method in class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
- getExpression() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
- getExpression() - Method in class org.apache.flink.table.legacy.api.TableColumn.ComputedColumn
-
Deprecated.
- getExpression(ResolvedFieldReference[]) - Method in interface org.apache.flink.table.legacy.sources.FieldComputer
-
Deprecated.Returns the
Expression
that computes the value of the field. - getExternalResourceInfos(String) - Method in class org.apache.flink.table.functions.FunctionContext
-
Get the external resource information.
- getFactory() - Method in interface org.apache.flink.table.catalog.Catalog
-
Returns a factory for creating instances from catalog objects.
- getFalseCount() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
- getFamilies() - Method in enum org.apache.flink.table.types.logical.LogicalTypeRoot
- getField(int) - Method in class org.apache.flink.table.data.GenericRowData
-
Returns the field value at the given position.
- getField(DataType, int) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Retrieves a nested field from a composite type at given position.
- getField(DataType, String) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Retrieves a nested field from a composite type with given name.
- getFieldCount() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns the number of fields.
- getFieldCount() - Method in class org.apache.flink.table.types.logical.RowType
- getFieldCount(DataType) - Static method in class org.apache.flink.table.types.DataType
-
Returns the count of the first-level fields for the provided
DataType
. - getFieldCount(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns the field count of row and structured types.
- getFieldDataType(int) - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns the specified data type for the given field index.
- getFieldDataType(String) - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns the specified data type for the given field name.
- getFieldDataTypes() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns all field data types as an array.
- getFieldDataTypes(DataType) - Static method in class org.apache.flink.table.types.DataType
-
Returns the first-level field data types for the provided
DataType
. - getFieldIndex() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- getFieldIndex(String) - Method in class org.apache.flink.table.types.logical.RowType
- getFieldIndices() - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- getFieldMapping() - Method in interface org.apache.flink.table.legacy.sources.DefinedFieldMapping
-
Deprecated.Returns the mapping for the fields of the
TableSource
'sTableSchema
to the fields of its producedDataType
. - getFieldName(int) - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns the specified name for the given field index.
- getFieldNames() - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- getFieldNames() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns all field names as an array.
- getFieldNames() - Method in interface org.apache.flink.table.legacy.sinks.TableSink
-
Deprecated.Use the field names of
TableSink.getTableSchema()
instead. - getFieldNames() - Method in class org.apache.flink.table.sinks.TableSinkBase
-
Deprecated.Returns the field names of the table to emit.
- getFieldNames() - Method in class org.apache.flink.table.types.logical.RowType
- getFieldNames(DataType) - Static method in class org.apache.flink.table.types.DataType
-
Returns the first-level field names for the provided
DataType
. - getFieldNames(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns the field names of row and structured types.
- getFieldOrNull(RowData) - Method in interface org.apache.flink.table.data.RowData.FieldGetter
- getFields() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapRowVector
- getFields() - Method in class org.apache.flink.table.types.logical.RowType
- getFields(DataType) - Static method in class org.apache.flink.table.types.DataType
-
Returns an ordered list of fields starting from the provided
DataType
. - getFieldType(int) - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.This method will be removed in future versions as it uses the old type system. It is recommended to use
TableSchema.getFieldDataType(int)
instead which uses the new type system based onDataTypes
. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information. - getFieldType(String) - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.This method will be removed in future versions as it uses the old type system. It is recommended to use
TableSchema.getFieldDataType(String)
instead which uses the new type system based onDataTypes
. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information. - getFieldTypes() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.This method will be removed in future versions as it uses the old type system. It is recommended to use
TableSchema.getFieldDataTypes()
instead which uses the new type system based onDataTypes
. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information. - getFieldTypes() - Method in interface org.apache.flink.table.legacy.sinks.TableSink
-
Deprecated.Use the field types of
TableSink.getTableSchema()
instead. - getFieldTypes() - Method in class org.apache.flink.table.sinks.TableSinkBase
-
Deprecated.Returns the field types of the table to emit.
- getFieldTypes(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns the field types of row and structured types.
- getFileCount() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
- getFilterArg() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunctionInfo
- getFilterExpression() - Method in class org.apache.flink.table.expressions.AggregateExpression
- getFixedIndexedProperties(String, List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns the property keys of fixed indexed properties.
- getFixedLengthPartSize() - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getFloat(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the float value at the given position.
- getFloat(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getFloat(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getFloat(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getFloat(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getFloat(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getFloat(int) - Method in interface org.apache.flink.table.data.columnar.vector.FloatColumnVector
- getFloat(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapFloatVector
- getFloat(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getFloat(int) - Method in class org.apache.flink.table.data.GenericRowData
- getFloat(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the float value at the given position.
- getFloat(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getFloat(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getFloat(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getFloat(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a float value under the given given existing key.
- getFloat(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get float from segments.
- getFormatPrefix(ConfigOption<String>, String) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Returns the required option prefix for options of the given format.
- getFractionalPrecision() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- getFractionalPrecision(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- getFreshness() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Get the
Duration
value of materialized table definition freshness, it is converted fromIntervalFreshness
. - getFullName() - Method in class org.apache.flink.table.catalog.ObjectPath
- getFunction(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the function.
- getFunctionDefinition() - Method in class org.apache.flink.table.expressions.AggregateExpression
- getFunctionDefinition() - Method in class org.apache.flink.table.expressions.CallExpression
- getFunctionDefinition() - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns the function definition that defines the function currently being called.
- getFunctionDefinition() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- getFunctionDefinition() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
- getFunctionDefinition(String) - Method in class org.apache.flink.table.module.CoreModule
- getFunctionDefinition(String) - Method in interface org.apache.flink.table.module.Module
-
Get an optional of
FunctionDefinition
by a given name. - getFunctionDefinitionFactory() - Method in interface org.apache.flink.table.catalog.Catalog
-
Get an optional
FunctionDefinitionFactory
instance that's responsible for instantiating function definitions. - getFunctionIdentifier() - Method in class org.apache.flink.table.expressions.CallExpression
- getFunctionLanguage() - Method in interface org.apache.flink.table.catalog.CatalogFunction
-
Get the language used for the definition of function.
- getFunctionName() - Method in class org.apache.flink.table.expressions.CallExpression
-
Returns a string representation of the call's function for logging or printing to a console.
- getFunctionName() - Method in class org.apache.flink.table.functions.FunctionIdentifier
- getFunctionResources() - Method in interface org.apache.flink.table.catalog.CatalogFunction
-
Get a detailed resource description of the function.
- getIdentifier() - Method in class org.apache.flink.table.functions.FunctionIdentifier
- getIfPresent(RowData) - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache
- getIfPresent(RowData) - Method in interface org.apache.flink.table.connector.source.lookup.cache.LookupCache
-
Returns the value associated with key in this cache, or null if there is no cached value for key.
- getImplementationClass() - Method in class org.apache.flink.table.types.logical.StructuredType
- getIndexedProperty(String, String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns all properties under a given key that contains an index in between.
- getInitConfig() - Method in class org.apache.flink.table.workflow.CreatePeriodicRefreshWorkflow
- getInputIndex() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- getInputs() - Method in class org.apache.flink.table.functions.python.PythonFunctionInfo
- getInputSchema() - Method in interface org.apache.flink.table.catalog.CatalogModel
-
Get the unresolved input schema of the model.
- getInputSchema() - Method in class org.apache.flink.table.catalog.DefaultCatalogModel
- getInputSchema() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- getInputTypeStrategy() - Method in class org.apache.flink.table.types.inference.TypeInference
- getInputTypeStrategy(ImperativeAggregateFunction<?, ?>) - Static method in class org.apache.flink.table.functions.LegacyUserDefinedFunctionInference
-
Deprecated.
- getInputTypeStrategy(ScalarFunction) - Static method in class org.apache.flink.table.functions.LegacyUserDefinedFunctionInference
-
Deprecated.
- getInputTypeStrategy(TableFunction<?>) - Static method in class org.apache.flink.table.functions.LegacyUserDefinedFunctionInference
-
Deprecated.
- getInt(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the integer value at the given position.
- getInt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getInt(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getInt(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getInt(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getInt(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getInt(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector
- getInt(int) - Method in interface org.apache.flink.table.data.columnar.vector.IntColumnVector
- getInt(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getInt(int) - Method in class org.apache.flink.table.data.GenericRowData
- getInt(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the integer value at the given position.
- getInt(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getInt(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getInt(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getInt(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns an integer value under the given existing key.
- getInt(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get int from segments.
- getInterval() - Method in class org.apache.flink.table.catalog.IntervalFreshness
- getJavaObject() - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
- getJobId() - Method in class org.apache.flink.table.refresh.ContinuousRefreshHandler
- getJobParameter(String, String) - Method in class org.apache.flink.table.functions.FunctionContext
-
Gets the global job parameter value associated with the given key as a string.
- getKey() - Method in class org.apache.flink.table.catalog.TableChange.ResetOption
-
Returns the Option key to reset.
- getKey() - Method in class org.apache.flink.table.catalog.TableChange.SetOption
-
Returns the Option key to set.
- getKeyColumnVector() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector
- getKeyDataType() - Method in class org.apache.flink.table.types.KeyValueDataType
- getKeys() - Method in interface org.apache.flink.table.connector.source.LookupTableSource.LookupContext
-
Returns an array of key index paths that should be used during the lookup.
- getKeySerializer() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- getKeyType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- getKeyType() - Method in class org.apache.flink.table.types.logical.MapType
- getKind() - Method in class org.apache.flink.table.catalog.TableDistribution
- getKind() - Method in class org.apache.flink.table.functions.AggregateFunction
- getKind() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- getKind() - Method in class org.apache.flink.table.functions.AsyncScalarFunction
- getKind() - Method in class org.apache.flink.table.functions.AsyncTableFunction
- getKind() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- getKind() - Method in interface org.apache.flink.table.functions.FunctionDefinition
-
Returns the kind of function this definition describes.
- getKind() - Method in class org.apache.flink.table.functions.ProcessTableFunction
- getKind() - Method in class org.apache.flink.table.functions.ScalarFunction
- getKind() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- getKind() - Method in class org.apache.flink.table.functions.TableAggregateFunction
- getKind() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- getKind() - Method in class org.apache.flink.table.functions.TableFunction
- getKind() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- getKind() - Method in class org.apache.flink.table.procedures.ProcedureDefinition
- getKind() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- getKind() - Method in class org.apache.flink.table.types.logical.TimestampType
- getKind() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- getLen() - Method in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- getLength() - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- getLength() - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- getLength() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- getLength() - Method in class org.apache.flink.table.dataview.NullSerializer
- getLength() - Method in class org.apache.flink.table.types.logical.BinaryType
- getLength() - Method in class org.apache.flink.table.types.logical.CharType
- getLength() - Method in class org.apache.flink.table.types.logical.VarBinaryType
- getLength() - Method in class org.apache.flink.table.types.logical.VarCharType
- getLength(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- getLengths() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- getList() - Method in class org.apache.flink.table.api.dataview.ListView
-
Returns the entire view's content as an instance of
List
. - getListSerializer() - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- getLogicalRefreshMode() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Get the logical refresh mode of materialized table.
- getLogicalRefreshMode() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getLogicalRefreshMode() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getLogicalType() - Method in class org.apache.flink.table.types.DataType
-
Returns the corresponding logical type.
- getLong(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the long value at the given position.
- getLong(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getLong(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getLong(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getLong(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getLong(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getLong(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapLongVector
- getLong(int) - Method in interface org.apache.flink.table.data.columnar.vector.LongColumnVector
- getLong(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getLong(int) - Method in class org.apache.flink.table.data.GenericRowData
- getLong(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the long value at the given position.
- getLong(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getLong(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getLong(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getLong(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a long value under the given existing key.
- getLong(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get long from segments.
- getLookupFunction(String[]) - Method in interface org.apache.flink.table.legacy.sources.LookupableTableSource
-
Deprecated.Gets the
TableFunction
which supports lookup one key at a time. - getLookupRuntimeProvider(LookupTableSource.LookupContext) - Method in interface org.apache.flink.table.connector.source.LookupTableSource
-
Returns a provider of runtime implementation for reading the data.
- getMap() - Method in class org.apache.flink.table.api.dataview.MapView
-
Returns the entire view's content as an instance of
Map
. - getMap(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the map value at the given position.
- getMap(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getMap(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getMap(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getMap(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getMap(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getMap(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector
- getMap(int) - Method in interface org.apache.flink.table.data.columnar.vector.MapColumnVector
- getMap(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getMap(int) - Method in class org.apache.flink.table.data.GenericRowData
- getMap(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the map value at the given position.
- getMap(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getMap(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getMap(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getMapSerializer() - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- getMaterializedTableIdentifier() - Method in class org.apache.flink.table.workflow.CreatePeriodicRefreshWorkflow
- getMax() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
- getMax() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
- getMax() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
- getMax() - Method in class org.apache.flink.table.plan.stats.ColumnStats
- getMaxCount() - Method in interface org.apache.flink.table.types.inference.ArgumentCount
-
Returns the maximum number of argument (inclusive) that a function can take.
- getMaxCount() - Method in class org.apache.flink.table.types.inference.ConstantArgumentCount
- getMaxLen() - Method in class org.apache.flink.table.plan.stats.ColumnStats
- getMaxLength() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
- getMaxLength() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
- getMemorySize(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a Flink
MemorySize
under the given existing key. - getMessage() - Method in exception org.apache.flink.table.api.AmbiguousTableFactoryException
-
Deprecated.
- getMessage() - Method in exception org.apache.flink.table.api.NoMatchingTableFactoryException
-
Deprecated.
- getMetadataAlias() - Method in class org.apache.flink.table.legacy.api.TableColumn.MetadataColumn
-
Deprecated.
- getMetadataKey() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
- getMetadataKey() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
- getMetricGroup() - Method in class org.apache.flink.table.functions.FunctionContext
-
Returns the metric group for this parallel subtask.
- getMillisecond() - Method in class org.apache.flink.table.data.TimestampData
-
Returns the number of milliseconds since
1970-01-01 00:00:00
. - getMin() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
- getMin() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
- getMin() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
- getMin() - Method in class org.apache.flink.table.plan.stats.ColumnStats
- getMinCount() - Method in interface org.apache.flink.table.types.inference.ArgumentCount
-
Returns the minimum number of argument (inclusive) that a function can take.
- getMinCount() - Method in class org.apache.flink.table.types.inference.ConstantArgumentCount
- getModel(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Returns a
CatalogModel
identified by the givenObjectPath
. - getName() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
- getName() - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
- getName() - Method in class org.apache.flink.table.catalog.AbstractCatalog
- getName() - Method in class org.apache.flink.table.catalog.Column
-
Returns the name of this column.
- getName() - Method in interface org.apache.flink.table.catalog.Constraint
- getName() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- getName() - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- getName() - Method in interface org.apache.flink.table.factories.CatalogFactory.Context
-
Returns the name with which the catalog is created.
- getName() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
- getName() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- getName() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- getName() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- getName() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- getName() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- getName() - Method in interface org.apache.flink.table.legacy.api.constraints.Constraint
-
Deprecated.
- getName() - Method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Returns the name of this column.
- getName() - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns the function's name usually referencing the function in a catalog.
- getName() - Method in class org.apache.flink.table.types.inference.Signature.Argument
- getName() - Method in class org.apache.flink.table.types.inference.StaticArgument
- getName() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- getName() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
- getName() - Method in class org.apache.flink.table.types.logical.RowType.RowField
- getName() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- getNamedArguments() - Method in class org.apache.flink.table.types.inference.TypeInference
-
Deprecated.Use
TypeInference.getStaticArguments()
instead. - getNanoOfMillisecond() - Method in class org.apache.flink.table.data.TimestampData
-
Returns the number of nanoseconds (the nanoseconds within the milliseconds).
- getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
- getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
- getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
- getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
- getNdv() - Method in class org.apache.flink.table.plan.stats.ColumnStats
- getNestedSerializers(ListViewSerializer<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
Deprecated.
- getNestedSerializers(MapViewSerializer<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializerSnapshot
-
Deprecated.
- getNestedSerializers(NullAwareMapSerializer<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
-
Deprecated.
- getNewColumn() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumn
-
Returns the modified
Column
instance. - getNewColumnName() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumnName
-
Returns the new column name after renaming the column name.
- getNewComment() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumnComment
-
Get the new comment for the column.
- getNewConstraint() - Method in class org.apache.flink.table.catalog.TableChange.ModifyUniqueConstraint
-
Returns the modified unique constraint.
- getNewInstance(K) - Method in class org.apache.flink.table.utils.ThreadLocalCache
- getNewPosition() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumn
-
Returns the position of the modified
Column
instance. - getNewType() - Method in class org.apache.flink.table.catalog.TableChange.ModifyPhysicalColumnType
-
Get the column type for the new column.
- getNewWatermark() - Method in class org.apache.flink.table.catalog.TableChange.ModifyWatermark
-
Returns the modified watermark.
- getNullCount() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
- getNullCount() - Method in class org.apache.flink.table.plan.stats.ColumnStats
- getNumRows() - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getObjectIdentifier() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
-
Returns the identifier of the table in the
Catalog
. - getObjectIdentifier() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
- getObjectIdentifier() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- getObjectIdentifier() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
-
Deprecated.
- getObjectIdentifier() - Method in interface org.apache.flink.table.legacy.factories.TableSinkFactory.Context
-
Deprecated.
- getObjectIdentifier() - Method in interface org.apache.flink.table.legacy.factories.TableSourceFactory.Context
-
Deprecated.
- getObjectIdentifier() - Method in class org.apache.flink.table.types.logical.UserDefinedType
- getObjectName() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
- getObjectName() - Method in class org.apache.flink.table.catalog.ObjectPath
- getObjectName() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
- getOffset() - Method in interface org.apache.flink.table.data.binary.BinaryFormat
-
Gets the start offset of this binary data in the
MemorySegment
s. - getOffset() - Method in class org.apache.flink.table.data.binary.BinarySection
- getOffset() - Method in class org.apache.flink.table.data.binary.BinaryStringData
- getOffset() - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
- getOffsets() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- getOldColumn() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumn
-
Returns the original
Column
instance. - getOldColumnName() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumnName
-
Returns the origin column name.
- getOptionalArguments() - Method in class org.apache.flink.table.types.inference.TypeInference
-
Deprecated.Use
TypeInference.getStaticArguments()
instead. - getOptionalArray(String, Function<String, E>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns all array elements under a given key if it exists.
- getOptionalBigDecimal(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a big decimal value under the given key if it exists.
- getOptionalBoolean(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a boolean value under the given key if it exists.
- getOptionalByte(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a byte value under the given key if it exists.
- getOptionalCharacter(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a character value under the given key if it exists.
- getOptionalClass(String, Class<T>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a class value under the given key if it exists.
- getOptionalDataType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns the DataType under the given key if it exists.
- getOptionalDouble(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a double value under the given key if it exists.
- getOptionalDuration(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a Java
Duration
under the given key if it exists. - getOptionalFloat(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a float value under the given key if it exists.
- getOptionalInt(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns an integer value under the given key if it exists.
- getOptionalLong(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a long value under the given key if it exists.
- getOptionalMemorySize(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a Flink
MemorySize
under the given key if it exists. - getOptionalShort(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a short value under the given key if it exists.
- getOptionalString(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a string value under the given key if it exists.
- getOptionalTableSchema(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a table schema under the given key if it exists.
- getOptionalType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns the type information under the given key if it exists.
- getOptions() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
Returns a map of string-based options.
- getOptions() - Method in interface org.apache.flink.table.catalog.CatalogModel
-
Returns a map of string-based model options.
- getOptions() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getOptions() - Method in class org.apache.flink.table.catalog.DefaultCatalogModel
- getOptions() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- getOptions() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- getOptions() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getOptions() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- getOptions() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
- getOptions() - Method in interface org.apache.flink.table.factories.CatalogFactory.Context
-
Returns the options with which the catalog is created.
- getOptions() - Method in interface org.apache.flink.table.factories.CatalogStoreFactory.Context
-
Returns the options with which the catalog store is created.
- getOptions() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogContext
- getOptions() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultCatalogStoreContext
- getOptions() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultModuleContext
- getOptions() - Method in class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
-
Returns all options currently being consumed by the factory.
- getOptions() - Method in class org.apache.flink.table.factories.FactoryUtil.TableFactoryHelper
-
Returns all options currently being consumed by the factory.
- getOptions() - Method in interface org.apache.flink.table.factories.ModuleFactory.Context
-
Returns the options with which the module is created.
- getOrigin() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- getOrigin() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogBaseTable
-
Returns the original, unresolved metadata object from the
Catalog
. - getOrigin() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getOrigin() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogModel
-
Returns the original, unresolved metadata object from the
Catalog
. - getOrigin() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- getOrigin() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
- getOriginalQuery() - Method in interface org.apache.flink.table.catalog.CatalogView
-
Original text of the view definition that also preserves the original formatting.
- getOriginalQuery() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
- getOriginatingClass() - Method in class org.apache.flink.table.types.logical.RawType
- getOutputDataType() - Method in class org.apache.flink.table.expressions.AggregateExpression
- getOutputDataType() - Method in class org.apache.flink.table.expressions.CallExpression
- getOutputDataType() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- getOutputDataType() - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- getOutputDataType() - Method in interface org.apache.flink.table.expressions.ResolvedExpression
-
Returns the data type of the computation result.
- getOutputDataType() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
- getOutputDataType() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
- getOutputDataType() - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns the inferred output data type of the function call.
- getOutputDataType() - Method in class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
- getOutputDataType() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- getOutputDataType() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
- getOutputSchema() - Method in interface org.apache.flink.table.catalog.CatalogModel
-
Get the unresolved output schema of the model.
- getOutputSchema() - Method in class org.apache.flink.table.catalog.DefaultCatalogModel
- getOutputSchema() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- getOutputType() - Method in interface org.apache.flink.table.legacy.sinks.TableSink
-
Deprecated.This method will be removed in future versions as it uses the old type system. It is recommended to use
TableSink.getConsumedDataType()
instead which uses the new type system based onDataTypes
. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information. - getOutputTypeStrategy() - Method in class org.apache.flink.table.types.inference.TypeInference
- getOutputTypeStrategy(ScalarFunction) - Static method in class org.apache.flink.table.functions.LegacyUserDefinedFunctionInference
-
Deprecated.
- getParallelism() - Method in interface org.apache.flink.table.connector.ParallelismProvider
-
Returns the parallelism for this instance.
- getParameterTypes(Class[]) - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
- getParameterTypes(Class[]) - Method in class org.apache.flink.table.functions.python.PythonTableFunction
- getParameterTypes(Class<?>[]) - Method in class org.apache.flink.table.functions.ScalarFunction
-
Deprecated.This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated
TableEnvironment.registerFunction(...)
method. The new reflective extraction logic (possibly enriched withDataTypeHint
andFunctionHint
) should be powerful enough to cover most use cases. For advanced users, it is possible to overrideUserDefinedFunction.getTypeInference(DataTypeFactory)
. - getParameterTypes(Class<?>[]) - Method in class org.apache.flink.table.functions.TableFunction
-
Deprecated.This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated
TableEnvironment.registerFunction(...)
method. The new reflective extraction logic (possibly enriched withDataTypeHint
andFunctionHint
) should be powerful enough to cover most use cases. For advanced users, it is possible to overrideUserDefinedFunction.getTypeInference(DataTypeFactory)
. - getPartition(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get a partition of the given table.
- getPartitionColumnStatistics(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the column statistics of a partition.
- getPartitioner() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsLookupCustomShuffle
-
This method is used to retrieve a custom partitioner that will be applied to the input stream of lookup-join node.
- getPartitionKeys() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Get the partition keys of the table.
- getPartitionKeys() - Method in interface org.apache.flink.table.catalog.CatalogTable
-
Get the partition keys of the table.
- getPartitionKeys() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getPartitionKeys() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- getPartitionKeys() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getPartitionKeys() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- getPartitionKeys() - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns partition keys.
- getPartitions() - Method in interface org.apache.flink.table.legacy.sources.PartitionableTableSource
-
Deprecated.Returns all the partitions of this
PartitionableTableSource
. - getPartitionSpec() - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
-
Get the partition spec as key-value map.
- getPartitionStatistics(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the statistics of a partition.
- getPersistedSchema(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
-
Return
TableSchema
which consists of all persisted columns. - getPhysicalRowDataType() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
-
Returns the physical schema to use for encoding and decoding records.
- getPhysicalSchema(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
-
Return
TableSchema
which consists of all physical columns. - getPosition() - Method in class org.apache.flink.table.catalog.TableChange.AddColumn
- getPrecision() - Method in class org.apache.flink.table.types.logical.DecimalType
- getPrecision() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- getPrecision() - Method in class org.apache.flink.table.types.logical.TimestampType
- getPrecision() - Method in class org.apache.flink.table.types.logical.TimeType
- getPrecision() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- getPrecision(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns the precision of all types that define a precision implicitly or explicitly.
- getPrimaryKey() - Method in class org.apache.flink.table.api.Schema
- getPrimaryKey() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns the primary key if it has been defined.
- getPrimaryKey() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.
- getPrimaryKeyIndexes() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns the primary key indexes, if any, otherwise returns an empty array.
- getPrimaryKeyIndexes() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
-
Returns the primary key indexes, if any, otherwise returns an empty array.
- getPrimaryKeyIndices(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
-
Returns the field indices of primary key in the physical columns of this schema (not include computed columns or metadata columns).
- getProcedure(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the procedure.
- getProctimeAttribute() - Method in interface org.apache.flink.table.legacy.sources.DefinedProctimeAttribute
-
Deprecated.Returns the name of a processing time attribute or null if no processing time attribute is present.
- getProducedDataType() - Method in interface org.apache.flink.table.legacy.sources.TableSource
-
Deprecated.Returns the
DataType
for the produced data of theTableSource
. - getProperties() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
-
Get a map of properties associated with the database.
- getProperties() - Method in interface org.apache.flink.table.catalog.CatalogPartition
-
Get a map of properties associated with the partition.
- getProperties() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
- getProperties() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
- getProperties() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
- getPropertiesWithPrefix(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a map of properties whose key starts with the given prefix, and the prefix is removed upon return.
- getPythonEnv() - Method in enum org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- getPythonEnv() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- getPythonEnv() - Method in interface org.apache.flink.table.functions.python.PythonFunction
-
Returns the Python execution environment.
- getPythonEnv() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
- getPythonEnv() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- getPythonEnv() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
- getPythonFunction() - Method in class org.apache.flink.table.functions.python.PythonFunctionInfo
- getPythonFunction(String, ReadableConfig, ClassLoader) - Static method in enum org.apache.flink.table.functions.python.utils.PythonFunctionUtils
- getPythonFunctionKind() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- getPythonFunctionKind() - Method in interface org.apache.flink.table.functions.python.PythonFunction
-
Returns the kind of the user-defined python function.
- getPythonFunctionKind() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
- getPythonFunctionKind() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- getPythonFunctionKind() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
- getQualifiedName() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- getRawDataSize() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
- getRawValue(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the raw value at the given position.
- getRawValue(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getRawValue(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getRawValue(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getRawValue(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getRawValue(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getRawValue(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getRawValue(int) - Method in class org.apache.flink.table.data.GenericRowData
- getRawValue(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the raw value at the given position.
- getRawValue(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getRawValue(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getRefreshHandler() - Method in class org.apache.flink.table.workflow.DeleteRefreshWorkflow
-
Return
RefreshHandler
from correspondingWorkflowScheduler
which provides meta info to points to the refresh workflow in scheduler service. - getRefreshHandler() - Method in interface org.apache.flink.table.workflow.ModifyRefreshWorkflow
-
Return
RefreshHandler
from correspondingWorkflowScheduler
which provides meta info to points to the refresh workflow in scheduler service. - getRefreshHandler() - Method in class org.apache.flink.table.workflow.ResumeRefreshWorkflow
- getRefreshHandler() - Method in class org.apache.flink.table.workflow.SuspendRefreshWorkflow
- getRefreshHandlerBytes() - Method in class org.apache.flink.table.catalog.TableChange.ModifyRefreshHandler
- getRefreshHandlerDesc() - Method in class org.apache.flink.table.catalog.TableChange.ModifyRefreshHandler
- getRefreshHandlerDescription() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Return summary description of refresh handler.
- getRefreshHandlerDescription() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getRefreshHandlerDescription() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getRefreshHandlerSerializer() - Method in interface org.apache.flink.table.workflow.WorkflowScheduler
-
Return a
RefreshHandlerSerializer
instance to serialize and deserializeRefreshHandler
created by specific workflow scheduler service. - getRefreshMode() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Get the physical refresh mode of materialized table.
- getRefreshMode() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getRefreshMode() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getRefreshStatus() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Get the refresh status of materialized table.
- getRefreshStatus() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getRefreshStatus() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getRefreshStatus() - Method in class org.apache.flink.table.catalog.TableChange.ModifyRefreshStatus
- getRemainingFilters() - Method in class org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown.Result
- getRequirements() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- getRequirements() - Method in interface org.apache.flink.table.functions.FunctionDefinition
-
Returns the set of requirements this definition demands.
- getRequirements() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- getRequirements() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- getRequirements() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- getRequirements() - Method in enum org.apache.flink.table.types.inference.StaticArgumentTrait
- getResolution() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- getResolution() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- getResolvedChildren() - Method in class org.apache.flink.table.expressions.AggregateExpression
- getResolvedChildren() - Method in class org.apache.flink.table.expressions.CallExpression
- getResolvedChildren() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- getResolvedChildren() - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- getResolvedChildren() - Method in interface org.apache.flink.table.expressions.ResolvedExpression
- getResolvedChildren() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
- getResolvedChildren() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
- getResolvedInputSchema() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- getResolvedInputSchema() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogModel
-
Returns a fully resolved and validated
ResolvedSchema
inputSchema. - getResolvedOutputSchema() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- getResolvedOutputSchema() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogModel
-
Returns a fully resolved and validated
ResolvedSchema
outputSchema. - getResolvedSchema() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogBaseTable
-
Returns a fully resolved and validated
ResolvedSchema
. - getResolvedSchema() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getResolvedSchema() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- getResolvedSchema() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
- getResourceType() - Method in class org.apache.flink.table.resource.ResourceUri
-
Get resource type info.
- getRestEndpointUrl() - Method in class org.apache.flink.table.workflow.CreatePeriodicRefreshWorkflow
- getRestorePath() - Method in class org.apache.flink.table.refresh.ContinuousRefreshHandler
- getResultType() - Method in class org.apache.flink.table.functions.ImperativeAggregateFunction
-
Deprecated.This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated
TableEnvironment.registerFunction(...)
method. The new reflective extraction logic (possibly enriched withDataTypeHint
andFunctionHint
) should be powerful enough to cover most use cases. For advanced users, it is possible to overrideUserDefinedFunction.getTypeInference(DataTypeFactory)
. - getResultType() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- getResultType() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- getResultType() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
- getResultType() - Method in class org.apache.flink.table.functions.TableFunction
-
Deprecated.This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated
TableEnvironment.registerFunction(...)
method. The new reflective extraction logic (possibly enriched withDataTypeHint
andFunctionHint
) should be powerful enough to cover most use cases. For advanced users, it is possible to overrideUserDefinedFunction.getTypeInference(DataTypeFactory)
. - getResultType() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- getResultType(Class[]) - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
- getResultType(Class<?>[]) - Method in class org.apache.flink.table.functions.ScalarFunction
-
Deprecated.This method uses the old type system and is based on the old reflective extraction logic. The method will be removed in future versions and is only called when using the deprecated
TableEnvironment.registerFunction(...)
method. The new reflective extraction logic (possibly enriched withDataTypeHint
andFunctionHint
) should be powerful enough to cover most use cases. For advanced users, it is possible to overrideUserDefinedFunction.getTypeInference(DataTypeFactory)
. - getResultTypeInfo() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- getResultTypeInfo() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- getReturnType() - Method in interface org.apache.flink.table.legacy.sources.FieldComputer
-
Deprecated.Returns the result type of the expression.
- getReturnType() - Method in interface org.apache.flink.table.legacy.sources.TableSource
-
Deprecated.This method will be removed in future versions as it uses the old type system. It is recommended to use
TableSource.getProducedDataType()
instead which uses the new type system based onDataTypes
. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information. - getReturnType() - Method in class org.apache.flink.table.legacy.sources.tsextractors.TimestampExtractor
-
Deprecated.
- getReturnTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
- getReturnTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>, TypeInformation<T>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
- getReturnTypeOfTableFunction(TableFunction<T>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
- getReturnTypeOfTableFunction(TableFunction<T>, TypeInformation<T>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
- getRow(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapRowVector
- getRow(int) - Method in interface org.apache.flink.table.data.columnar.vector.RowColumnVector
- getRow(int, int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the row value at the given position.
- getRow(int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getRow(int, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getRow(int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getRow(int, int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getRow(int, int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getRow(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getRow(int, int) - Method in class org.apache.flink.table.data.GenericArrayData
- getRow(int, int) - Method in class org.apache.flink.table.data.GenericRowData
- getRow(int, int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the row value at the given position.
- getRow(int, int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getRow(int, int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getRowCount() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
The number of rows.
- getRowCount() - Method in class org.apache.flink.table.plan.stats.TableStats
- getRowKind() - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getRowKind() - Method in class org.apache.flink.table.data.binary.NestedRowData
- getRowKind() - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getRowKind() - Method in class org.apache.flink.table.data.GenericRowData
- getRowKind() - Method in interface org.apache.flink.table.data.RowData
-
Returns the kind of change that this row describes in a changelog.
- getRowKind() - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getRowKind() - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getRowLevelDeleteMode() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsRowLevelDelete.RowLevelDeleteInfo
-
Planner will rewrite delete statement to query base on the
SupportsRowLevelDelete.RowLevelDeleteInfo
, keeping the query of delete unchanged by default(in `DELETE_ROWS` mode), or changing the query to the complementary set in REMAINING_ROWS mode. - getRowLevelUpdateMode() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsRowLevelUpdate.RowLevelUpdateInfo
-
Planner will rewrite the update statement to query base on the
SupportsRowLevelUpdate.RowLevelUpdateMode
, keeping the query of update unchanged by default(in `UPDATED_ROWS` mode), or changing the query to union the updated rows and the other rows (in `ALL_ROWS` mode). - getRowtimeAttribute() - Method in class org.apache.flink.table.catalog.WatermarkSpec
-
Returns the name of a rowtime attribute.
- getRowtimeAttribute() - Method in class org.apache.flink.table.legacy.api.WatermarkSpec
-
Deprecated.Returns the name of rowtime attribute, it can be a nested field using dot separator.
- getRowtimeAttributeDescriptors() - Method in interface org.apache.flink.table.legacy.sources.DefinedRowtimeAttributes
-
Deprecated.Returns a list of
RowtimeAttributeDescriptor
for all rowtime attributes of the table. - getRowType() - Method in class org.apache.flink.table.connector.source.DynamicFilteringData
- getRuntimeClass() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- getScalarFunction() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- getScale() - Method in class org.apache.flink.table.types.logical.DecimalType
- getScale(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns the scale of all types that define a scale implicitly or explicitly.
- getScanRuntimeProvider() - Method in interface org.apache.flink.table.connector.source.lookup.FullCachingLookupProvider
-
Get a
ScanTableSource.ScanRuntimeProvider
for scanning all entries from the external lookup table and load into the cache. - getScanRuntimeProvider(ScanTableSource.ScanContext) - Method in interface org.apache.flink.table.connector.source.ScanTableSource
-
Returns a provider of runtime implementation for reading the data.
- getSchema() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
Deprecated.This method returns the deprecated
TableSchema
class. The old class was a hybrid of resolved and unresolved schema information. It has been replaced by the newSchema
which is always unresolved and will be resolved by the framework later. - getSchema() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogBaseTable
-
Deprecated.This method returns the deprecated
TableSchema
class. The old class was a hybrid of resolved and unresolved schema information. It has been replaced by the newResolvedSchema
which is resolved by the framework and accessible viaResolvedCatalogBaseTable.getResolvedSchema()
. - getSegments() - Method in interface org.apache.flink.table.data.binary.BinaryFormat
-
Gets the underlying
MemorySegment
s this binary format spans. - getSegments() - Method in class org.apache.flink.table.data.binary.BinarySection
- getSegments() - Method in class org.apache.flink.table.data.binary.BinaryStringData
- getSegments() - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
- getSerializedPythonFunction() - Method in enum org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- getSerializedPythonFunction() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- getSerializedPythonFunction() - Method in interface org.apache.flink.table.functions.python.PythonFunction
-
Returns the serialized representation of the user-defined python function.
- getSerializedPythonFunction() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
- getSerializedPythonFunction() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- getSerializedPythonFunction() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
- getSerializedRefreshHandler() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Return the serialized refresh handler of materialized table.
- getSerializedRefreshHandler() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getSerializedRefreshHandler() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getSerializerString() - Method in class org.apache.flink.table.types.logical.RawType
-
Returns the serialized
TypeSerializerSnapshot
in Base64 encoding of this raw type. - getShort(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the short value at the given position.
- getShort(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getShort(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getShort(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getShort(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getShort(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getShort(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapShortVector
- getShort(int) - Method in interface org.apache.flink.table.data.columnar.vector.ShortColumnVector
- getShort(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getShort(int) - Method in class org.apache.flink.table.data.GenericRowData
- getShort(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the short value at the given position.
- getShort(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getShort(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getShort(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getShort(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a short value under the given existing key.
- getShort(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get short from segments.
- getSimpleName() - Method in class org.apache.flink.table.functions.FunctionIdentifier
- getSinkRuntimeProvider(DynamicTableSink.Context) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
-
Returns a provider of runtime implementation for writing the data.
- getSize() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- getSize() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector
- getSizeInBytes() - Method in interface org.apache.flink.table.data.binary.BinaryFormat
-
Gets the size in bytes of this binary data.
- getSizeInBytes() - Method in class org.apache.flink.table.data.binary.BinarySection
- getSizeInBytes() - Method in class org.apache.flink.table.data.binary.BinaryStringData
- getSizeInBytes() - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
- getSnapshot() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Return the snapshot specified for the table.
- getSnapshot() - Method in interface org.apache.flink.table.catalog.CatalogTable
-
Return the snapshot specified for the table.
- getSnapshot() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getSnapshot() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- getSnapshot() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- getSnapshot() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- getSourceIdleTimeout() - Method in class org.apache.flink.table.watermark.WatermarkParams
- getSourceType() - Method in class org.apache.flink.table.types.logical.DistinctType
- getSqlExpression() - Method in class org.apache.flink.table.expressions.SqlCallExpression
- getSqlName() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- getStagingPurpose() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsStaging.StagingContext
- getStagingPurpose() - Method in class org.apache.flink.table.connector.sink.SinkStagingContext
- getStateTypeStrategies() - Method in class org.apache.flink.table.types.inference.TypeInference
- getStaticArguments() - Method in class org.apache.flink.table.types.inference.TypeInference
- getString(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the string value at the given position.
- getString(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getString(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getString(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getString(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getString(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getString(int) - Method in class org.apache.flink.table.data.GenericArrayData
- getString(int) - Method in class org.apache.flink.table.data.GenericRowData
- getString(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the string value at the given position.
- getString(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getString(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getString(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getString(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a string value under the given existing key.
- getStructuredField(Class<?>, String) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Returns the field of a structured type.
- getStructuredFieldGetter(Class<?>, Field) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks for a field getter of a structured type.
- getStructuredFieldSetter(Class<?>, Field) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks for a field setters of a structured type.
- getSuperType() - Method in class org.apache.flink.table.types.logical.StructuredType
- getTable() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- getTable() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
-
Deprecated.
- getTable() - Method in interface org.apache.flink.table.legacy.factories.TableSinkFactory.Context
-
Deprecated.
- getTable() - Method in interface org.apache.flink.table.legacy.factories.TableSourceFactory.Context
-
Deprecated.
- getTable(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
- getTable(ObjectPath, long) - Method in interface org.apache.flink.table.catalog.Catalog
- getTableAggregateFunction() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- getTableColumn(int) - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns the
TableColumn
instance for the given field index. - getTableColumn(String) - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns the
TableColumn
instance for the given field name. - getTableColumns() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns all the
TableColumn
s for this table schema. - getTableColumnStatistics(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the column statistics of a table.
- getTableFunction() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- getTableKind() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
The kind of table this
CatalogBaseTable
describes. - getTableKind() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
- getTableKind() - Method in interface org.apache.flink.table.catalog.CatalogTable
- getTableKind() - Method in interface org.apache.flink.table.catalog.CatalogView
- getTableSchema() - Method in interface org.apache.flink.table.legacy.sinks.TableSink
-
Deprecated.Returns the schema of the consumed table.
- getTableSchema() - Method in interface org.apache.flink.table.legacy.sources.TableSource
-
Deprecated.Table schema is a logical description of a table and should not be part of the physical TableSource. Define schema when registering a Table either in DDL or in
TableEnvironment#connect(...)
. - getTableSchema(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a table schema under the given existing key.
- getTableSemantics(int) - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns information about the table that has been passed to a table argument.
- getTableSemantics(int) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- getTableSinkFactory() - Method in interface org.apache.flink.table.module.Module
-
Returns a
DynamicTableSinkFactory
for creating sink tables. - getTableSourceFactory() - Method in interface org.apache.flink.table.module.Module
-
Returns a
DynamicTableSourceFactory
for creating source tables. - getTableStatistics(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the statistics of a table.
- getTargetColumns() - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
-
Returns an
Optional
array of column index paths related to user specified target column list orOptional.empty()
when not specified. - getTaskInfo() - Method in class org.apache.flink.table.functions.FunctionContext
-
Get the
TaskInfo
for this parallel subtask. - getTimestamp(int, int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the timestamp value at the given position.
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapTimestampVector
- getTimestamp(int, int) - Method in interface org.apache.flink.table.data.columnar.vector.TimestampColumnVector
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.GenericArrayData
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.GenericRowData
- getTimestamp(int, int) - Method in interface org.apache.flink.table.data.RowData
-
Returns the timestamp value at the given position.
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- getTimestamp(int, int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- getTimestamp(int, int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- getTimestampExtractor() - Method in class org.apache.flink.table.legacy.sources.RowtimeAttributeDescriptor
-
Deprecated.Returns the [[TimestampExtractor]] for the attribute.
- getTimeUnit() - Method in class org.apache.flink.table.catalog.IntervalFreshness
- getTotalFields() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- getTotalFields() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- getTotalFields() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- getTotalSize() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
- getTraits() - Method in class org.apache.flink.table.types.inference.StaticArgument
- getTrueCount() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
- getType() - Method in interface org.apache.flink.table.catalog.Constraint
-
Tells what kind of constraint it is, e.g.
- getType() - Method in class org.apache.flink.table.catalog.UniqueConstraint
- getType() - Method in interface org.apache.flink.table.legacy.api.constraints.Constraint
-
Deprecated.Tells what kind of constraint it is, e.g.
- getType() - Method in class org.apache.flink.table.legacy.api.constraints.UniqueConstraint
-
Deprecated.
- getType() - Method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Returns the data type of this column.
- getType() - Method in class org.apache.flink.table.types.inference.Signature.Argument
- getType() - Method in class org.apache.flink.table.types.logical.RowType.RowField
- getType() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- getType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns the type information under the given existing key.
- getTypeAt(int) - Method in class org.apache.flink.table.types.logical.RowType
- getTypeClass() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- getTypeClass() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- getTypeClass() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- getTypedArguments() - Method in class org.apache.flink.table.types.inference.TypeInference
-
Deprecated.Use
TypeInference.getStaticArguments()
instead. - getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.AggregateFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.AsyncScalarFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.AsyncTableFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- getTypeInference(DataTypeFactory) - Method in interface org.apache.flink.table.functions.FunctionDefinition
-
Returns the logic for performing type inference of a call to this function definition.
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.ProcessTableFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.python.PythonTableFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.ScalarFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.TableAggregateFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.TableFunction
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.UserDefinedFunction
-
Returns the logic for performing type inference of a call to this function definition.
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.procedures.ProcedureDefinition
- getTypeInformation() - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- getTypeInformation() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- getTypeRoot() - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns the root of this type.
- getTypeSerializer() - Method in class org.apache.flink.table.types.logical.RawType
- getUnresolvedIdentifier() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- getUnresolvedSchema() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
Returns the schema of the table or view.
- getUnresolvedSchema() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- getUnresolvedSchema() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- getUnresolvedSchema() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- getUnresolvedSchema() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
- getUri() - Method in class org.apache.flink.table.resource.ResourceUri
-
Get resource unique path info.
- getUserCodeClassLoader() - Method in class org.apache.flink.table.functions.FunctionContext
-
Gets the
ClassLoader
to load classes that are not in system's classpath, but are part of the JAR file of a user job. - getValue() - Method in class org.apache.flink.table.catalog.TableChange.SetOption
-
Returns the Option value to set.
- getValue(int) - Static method in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnit
-
Returns the TimeUnit associated with an ordinal.
- getValue(ACC) - Method in class org.apache.flink.table.functions.AggregateFunction
-
Called every time when an aggregation result should be materialized.
- getValue(Object) - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- getValueAs(Class<T>) - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
-
Returns the value (excluding null) as an instance of the given class.
- getValueColumnVector() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector
- getValueDataType() - Method in class org.apache.flink.table.types.KeyValueDataType
- getValueSerializer() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- getValueType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- getValueType() - Method in class org.apache.flink.table.types.logical.MapType
- getVariableIndexedProperties(String, List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns the property keys of variable indexed properties.
- getVersion() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- getWatermark() - Method in class org.apache.flink.table.catalog.TableChange.AddWatermark
-
Returns the watermark to add.
- getWatermarkExpr() - Method in class org.apache.flink.table.legacy.api.WatermarkSpec
-
Deprecated.Returns the string representation of watermark generation expression.
- getWatermarkExpression() - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
- getWatermarkExpression() - Method in class org.apache.flink.table.catalog.WatermarkSpec
-
Returns the
ResolvedExpression
for watermark generation. - getWatermarkExprOutputType() - Method in class org.apache.flink.table.legacy.api.WatermarkSpec
-
Deprecated.Returns the data type of the computation result of watermark generation expression.
- getWatermarkSpecs() - Method in class org.apache.flink.table.api.Schema
- getWatermarkSpecs() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns a list of watermark specifications each consisting of a rowtime attribute and watermark strategy expression.
- getWatermarkSpecs() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Returns a list of the watermark specification which contains rowtime attribute and watermark strategy expression.
- getWatermarkStrategy() - Method in class org.apache.flink.table.legacy.sources.RowtimeAttributeDescriptor
-
Deprecated.Returns the [[WatermarkStrategy]] for the attribute.
- getWorkflowSchedulerOptions() - Method in interface org.apache.flink.table.factories.WorkflowSchedulerFactory.Context
-
Returns the options with which the workflow scheduler is created.
- getWorkflowSchedulerOptions() - Method in class org.apache.flink.table.factories.WorkflowSchedulerFactoryUtil.DefaultWorkflowSchedulerContext
- getYearPrecision() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- getYearPrecision(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- GREATER_THAN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- GREATER_THAN_OR_EQUAL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- GREATEST - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
H
- hasDayPrecision(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- hasDictionary() - Method in class org.apache.flink.table.data.columnar.vector.writable.AbstractWritableVector
-
Returns true if this column has a dictionary.
- hasDictionary() - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableColumnVector
-
Check if there's a dictionary.
- hasFractionalPrecision(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- hash(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
hash segments to int.
- HASH - org.apache.flink.table.catalog.TableDistribution.Kind
- hashByWords(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
hash segments to int, numBytes must be aligned to 4 bytes.
- hashCode() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
- hashCode() - Method in class org.apache.flink.table.api.DataTypes.Field
- hashCode() - Method in class org.apache.flink.table.api.DataTypes.UnresolvedField
- hashCode() - Method in class org.apache.flink.table.api.dataview.ListView
- hashCode() - Method in class org.apache.flink.table.api.dataview.MapView
- hashCode() - Method in class org.apache.flink.table.api.Schema
- hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
- hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
- hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedConstraint
- hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
- hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
- hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
- hashCode() - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
- hashCode() - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
- hashCode() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
- hashCode() - Method in class org.apache.flink.table.catalog.Column
- hashCode() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
- hashCode() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- hashCode() - Method in class org.apache.flink.table.catalog.DefaultCatalogModel
- hashCode() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- hashCode() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- hashCode() - Method in class org.apache.flink.table.catalog.IntervalFreshness
- hashCode() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
- hashCode() - Method in class org.apache.flink.table.catalog.ObjectPath
- hashCode() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- hashCode() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- hashCode() - Method in class org.apache.flink.table.catalog.ResolvedSchema
- hashCode() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
- hashCode() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
- hashCode() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
- hashCode() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
- hashCode() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
- hashCode() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
- hashCode() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
- hashCode() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
- hashCode() - Method in class org.apache.flink.table.catalog.stats.Date
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.AddColumn
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.AddDistribution
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.AddUniqueConstraint
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.AddWatermark
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.After
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.DropColumn
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.DropConstraint
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumn
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.ModifyDefinitionQuery
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.ModifyDistribution
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.ModifyRefreshHandler
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.ModifyRefreshStatus
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.ModifyUniqueConstraint
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.ModifyWatermark
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.ResetOption
- hashCode() - Method in class org.apache.flink.table.catalog.TableChange.SetOption
- hashCode() - Method in class org.apache.flink.table.catalog.TableDistribution
- hashCode() - Method in class org.apache.flink.table.catalog.UniqueConstraint
- hashCode() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
- hashCode() - Method in class org.apache.flink.table.catalog.WatermarkSpec
- hashCode() - Method in class org.apache.flink.table.connector.ChangelogMode
- hashCode() - Method in class org.apache.flink.table.connector.Projection
- hashCode() - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache
- hashCode() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- hashCode() - Method in class org.apache.flink.table.data.binary.BinaryMapData
- hashCode() - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
- hashCode() - Method in class org.apache.flink.table.data.binary.BinaryRowData
- hashCode() - Method in class org.apache.flink.table.data.binary.BinarySection
- hashCode() - Method in class org.apache.flink.table.data.binary.BinaryStringData
- hashCode() - Method in class org.apache.flink.table.data.binary.NestedRowData
- hashCode() - Method in class org.apache.flink.table.data.columnar.ColumnarMapData
- hashCode() - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- hashCode() - Method in class org.apache.flink.table.data.DecimalData
- hashCode() - Method in class org.apache.flink.table.data.GenericArrayData
- hashCode() - Method in class org.apache.flink.table.data.GenericMapData
- hashCode() - Method in class org.apache.flink.table.data.GenericRowData
- hashCode() - Method in class org.apache.flink.table.data.TimestampData
- hashCode() - Method in class org.apache.flink.table.data.utils.JoinedRowData
- hashCode() - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- hashCode() - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.expressions.AggregateExpression
- hashCode() - Method in class org.apache.flink.table.expressions.CallExpression
- hashCode() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- hashCode() - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- hashCode() - Method in class org.apache.flink.table.expressions.SqlCallExpression
- hashCode() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
- hashCode() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
- hashCode() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.functions.FunctionIdentifier
- hashCode() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.legacy.api.constraints.UniqueConstraint
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.legacy.api.TableColumn.ComputedColumn
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.legacy.api.TableColumn.MetadataColumn
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.legacy.api.WatermarkSpec
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.legacy.sources.RowtimeAttributeDescriptor
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.plan.stats.ColumnStats
- hashCode() - Method in class org.apache.flink.table.plan.stats.TableStats
- hashCode() - Method in class org.apache.flink.table.resource.ResourceUri
- hashCode() - Method in class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
- hashCode() - Method in class org.apache.flink.table.types.CollectionDataType
- hashCode() - Method in class org.apache.flink.table.types.DataType
- hashCode() - Method in class org.apache.flink.table.types.FieldsDataType
- hashCode() - Method in class org.apache.flink.table.types.inference.ConstantArgumentCount
- hashCode() - Method in class org.apache.flink.table.types.inference.StaticArgument
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.ExplicitTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.MatchFamilyTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.NullableIfArgsTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.RepeatingSequenceInputTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.SymbolArgumentTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.VaryingStringTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
- hashCode() - Method in class org.apache.flink.table.types.KeyValueDataType
- hashCode() - Method in class org.apache.flink.table.types.logical.ArrayType
- hashCode() - Method in class org.apache.flink.table.types.logical.BinaryType
- hashCode() - Method in class org.apache.flink.table.types.logical.CharType
- hashCode() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- hashCode() - Method in class org.apache.flink.table.types.logical.DecimalType
- hashCode() - Method in class org.apache.flink.table.types.logical.DistinctType
- hashCode() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- hashCode() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- hashCode() - Method in class org.apache.flink.table.types.logical.LogicalType
- hashCode() - Method in class org.apache.flink.table.types.logical.MapType
- hashCode() - Method in class org.apache.flink.table.types.logical.MultisetType
- hashCode() - Method in class org.apache.flink.table.types.logical.RawType
- hashCode() - Method in class org.apache.flink.table.types.logical.RowType
- hashCode() - Method in class org.apache.flink.table.types.logical.RowType.RowField
- hashCode() - Method in class org.apache.flink.table.types.logical.StructuredType
- hashCode() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- hashCode() - Method in class org.apache.flink.table.types.logical.TimestampType
- hashCode() - Method in class org.apache.flink.table.types.logical.TimeType
- hashCode() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- hashCode() - Method in class org.apache.flink.table.types.logical.UserDefinedType
- hashCode() - Method in class org.apache.flink.table.types.logical.VarBinaryType
- hashCode() - Method in class org.apache.flink.table.types.logical.VarCharType
- hashCode() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- hashCode() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- hashCode() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- hashCode() - Method in class org.apache.flink.table.watermark.WatermarkParams
- hasInvokableConstructor(Class<?>, Class<?>...) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks for an invokable constructor matching the given arguments.
- hasLegacyTypes(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Checks whether a (possibly nested) logical type contains
LegacyTypeInformationType
orTypeInformationRawType
. - hasLength(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- hasNested(LogicalType, Predicate<LogicalType>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Checks whether a (possibly nested) logical type fulfills the given predicate.
- hasPrecision(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Checks the precision of a type that defines a precision implicitly or explicitly.
- hasPrefix(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns if a given prefix exists in the properties.
- hasProctimeAttribute(TableSource<?>) - Static method in class org.apache.flink.table.sources.TableSourceValidation
-
Checks if the given
TableSource
defines a proctime attribute. - hasRowtimeAttribute(TableSource<?>) - Static method in class org.apache.flink.table.sources.TableSourceValidation
-
Checks if the given
TableSource
defines a rowtime attribute. - hasRuntimeImplementation() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- hasScale(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Checks the scale of all types that define a scale implicitly or explicitly.
- hasWellDefinedString(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Checks whether the given
LogicalType
has a well-defined string representation when callingObject.toString()
on the internal data structure. - hasYearPrecision(LogicalType, int) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- HEADER_SIZE_IN_BITS - Static variable in class org.apache.flink.table.data.binary.BinaryRowData
- HeapArrayVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable heap array column vector.
- HeapArrayVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- HeapArrayVector(int, ColumnVector) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- HeapBooleanVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable heap boolean column vector.
- HeapBooleanVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapBooleanVector
- HeapBytesVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class supports string and binary data by value reference -- i.e. each field is explicitly present, as opposed to provided by a dictionary reference.
- HeapBytesVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapBytesVector
-
Don't call this constructor except for testing purposes.
- HeapByteVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable byte column vector.
- HeapByteVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapByteVector
-
Don't use this except for testing purposes.
- HeapDoubleVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable double precision floating point column vector.
- HeapDoubleVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapDoubleVector
-
Don't use this except for testing purposes.
- HeapFloatVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable double precision floating point column vector.
- HeapFloatVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapFloatVector
-
Don't use this except for testing purposes.
- HeapIntVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable int column vector.
- HeapIntVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector
-
Don't use this except for testing purposes.
- HeapLongVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable long column vector.
- HeapLongVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapLongVector
-
Don't use this except for testing purposes.
- HeapMapVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable heap map column vector.
- HeapMapVector(int, ColumnVector, ColumnVector) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector
- HeapRowVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable heap row column vector.
- HeapRowVector(int, WritableColumnVector...) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapRowVector
- HeapShortVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable short column vector.
- HeapShortVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapShortVector
-
Don't use this except for testing purposes.
- HeapTimestampVector - Class in org.apache.flink.table.data.columnar.vector.heap
-
This class represents a nullable byte column vector.
- HeapTimestampVector(int) - Constructor for class org.apache.flink.table.data.columnar.vector.heap.HeapTimestampVector
- hex(byte[]) - Static method in class org.apache.flink.table.utils.EncodingUtils
- hex(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
- HEX - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- HIGHEST_FIRST_BIT - Static variable in interface org.apache.flink.table.data.binary.BinaryFormat
-
To get the mark in highest bit of long.
- HIGHEST_SECOND_TO_EIGHTH_BIT - Static variable in interface org.apache.flink.table.data.binary.BinaryFormat
-
To get the 7 bits length in second bit to eighth bit out of a long.
- HintFlag - Enum in org.apache.flink.table.annotation
-
Three-valued flag for representing
TRUE
,FALSE
, andUNKNOWN
. - HIVE_AGG_DECIMAL_PLUS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
Special "+" operator used internally for implementing native hive SUM/AVG aggregations on a Decimal type.
- HIVE_AGG_DECIMAL_PLUS - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
- HiveAggDecimalPlusTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that returns the result type of a decimal addition, used internally for implementing native SUM/AVG aggregations on a Decimal type.
- HiveAggDecimalPlusTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.HiveAggDecimalPlusTypeStrategy
- HOUR - org.apache.flink.table.catalog.IntervalFreshness.TimeUnit
- HOUR - org.apache.flink.table.expressions.TimeIntervalUnit
- HOUR - org.apache.flink.table.expressions.TimePointUnit
- HOUR - org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
- HOUR - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- HOUR - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- HOUR() - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in hours.
- HOUR_TO_MINUTE - org.apache.flink.table.expressions.TimeIntervalUnit
- HOUR_TO_MINUTE - org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
- HOUR_TO_MINUTE - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- HOUR_TO_SECOND - org.apache.flink.table.expressions.TimeIntervalUnit
- HOUR_TO_SECOND - org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
- HOUR_TO_SECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
I
- IDENTIFIER - Static variable in class org.apache.flink.table.module.CoreModuleFactory
- IF - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- IF_NULL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- IF_NULL - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
IfNullTypeStrategy
. - ImperativeAggregateFunction<T,ACC> - Class in org.apache.flink.table.functions
-
Base class for user-defined
AggregateFunction
andTableAggregateFunction
. - ImperativeAggregateFunction() - Constructor for class org.apache.flink.table.functions.ImperativeAggregateFunction
- IN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- IN - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Call syntax for
BuiltInFunctionDefinitions.IN
. - IN - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
Type strategy specific for
BuiltInFunctionDefinitions.IN
. - INDEX - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
Argument type strategy that expects a
LogicalTypeFamily.INTEGER_NUMERIC
starting from 0. - IndexArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
ArgumentTypeStrategy
that expects aLogicalTypeFamily.INTEGER_NUMERIC
starting from 0. - IndexArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.IndexArgumentTypeStrategy
- indexOf(BinaryStringData, int) - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Returns the index within this string of the first occurrence of the specified substring, starting at the specified index.
- inferArgumentType(CallContext, int, boolean) - Method in interface org.apache.flink.table.types.inference.ArgumentTypeStrategy
-
Main logic for inferring and validating an argument.
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.AndArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.ArrayComparableElementArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.ArrayOfStringArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.CommonArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.CompositeArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.ExplicitArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.IndexArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.ItemAtIndexArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.JsonQueryOnErrorEmptyArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.PercentageArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.PercentageArrayArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.SymbolArgumentTypeStrategy
- inferArgumentType(CallContext, int, boolean) - Method in class org.apache.flink.table.types.inference.strategies.TypeLiteralArgumentTypeStrategy
- inferColumnWidth(List<String[]>) - Method in class org.apache.flink.table.utils.print.TableauStyle
- inferInputTypes(CallContext, boolean) - Method in interface org.apache.flink.table.types.inference.InputTypeStrategy
-
Main logic for inferring and validating the input arguments.
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.CommonCollectionInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.CommonInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.ComparableTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.LeadLagInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.OverTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.ReinterpretCastInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.RepeatingSequenceInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.SubQueryInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
- inferInputTypes(CallContext, boolean) - Method in class org.apache.flink.table.types.inference.strategies.WindowTimeIndictorInputTypeStrategy
- inferOutputType(DataTypeFactory) - Method in interface org.apache.flink.table.types.inference.TypeInferenceUtil.SurroundingInfo
- inferOutputType(CallContext, TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
-
Infers an output type using the given
TypeStrategy
. - inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.ArgumentMappingTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.ArrayAppendPrependTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.ArrayElementTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.CollectTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.ExplicitTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.ForceNullableTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.HiveAggDecimalPlusTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.ItemAtTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.MatchFamilyTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.NullableIfArgsTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.RowtimeTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.ToTimestampLtzTypeStrategy
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.VaryingStringTypeStrategy
- inferType(CallContext) - Method in interface org.apache.flink.table.types.inference.TypeStrategy
-
Infers a type from the given function call.
- INIT_CAP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- INITIALIZING - org.apache.flink.table.catalog.CatalogMaterializedTable.RefreshStatus
- input() - Method in annotation type org.apache.flink.table.annotation.FunctionHint
-
Explicitly lists the argument types that a function takes as input.
- input() - Method in annotation type org.apache.flink.table.annotation.ProcedureHint
-
Explicitly lists the argument types that a procedure takes as input.
- InputFormatProvider - Interface in org.apache.flink.table.connector.source
-
Provider of an
InputFormat
instance as a runtime implementation forScanTableSource
. - inputGroup() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
This hint parameter influences the extraction of a
TypeInference
in functions. - InputGroup - Enum in org.apache.flink.table.annotation
-
A list of commonly used pre-defined groups of similar types for accepting more than just one data type as an input argument in
DataTypeHint
s. - InputTypeStrategies - Class in org.apache.flink.table.types.inference
-
Strategies for inferring and validating input arguments in a function call.
- inputTypeStrategy(InputTypeStrategy) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
- inputTypeStrategy(InputTypeStrategy) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets the strategy for inferring and validating input arguments in a function call.
- InputTypeStrategy - Interface in org.apache.flink.table.types.inference
-
Strategy for inferring and validating input arguments in a function call.
- insertOnly() - Static method in class org.apache.flink.table.connector.ChangelogMode
-
Shortcut for a simple
RowKind.INSERT
-only changelog. - INSTANCE - Static variable in class org.apache.flink.table.dataview.NullSerializer
- INSTANCE - Static variable in class org.apache.flink.table.module.CoreModule
- INSTANCE - Static variable in class org.apache.flink.table.refresh.ContinuousRefreshHandlerSerializer
- INSTANCE - Static variable in class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
- INSTANCE - Static variable in class org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
- INSTANCE - Static variable in class org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
- instantiateFunction(Class<?>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Instantiates a
UserDefinedFunction
assuming a JVM function with default constructor. - instantiateFunction(ClassLoader, ReadableConfig, String, CatalogFunction) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Instantiates a
UserDefinedFunction
from aCatalogFunction
. - INSTR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- INT() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a 4-byte signed integer with values from -2,147,483,648 to 2,147,483,647.
- INT() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API integer or SQL INT/INTEGER type.
- INT_ARRAY_OFFSET - Static variable in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- INT_SUM0 - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- IntColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Int column vector.
- INTEGER - org.apache.flink.table.types.logical.LogicalTypeRoot
- INTEGER_NUMERIC - org.apache.flink.table.types.logical.LogicalTypeFamily
- internal() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Specifies that this
BuiltInFunctionDefinition
is meant for internal purposes only and should not be exposed when listing functions. - INTERNAL_HASHCODE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- INTERNAL_REPLICATE_ROWS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- INTERNAL_REPLICATE_ROWS - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
InternalReplicateRowsTypeStrategy
. - INTERNAL_UNNEST_ROWS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- INTERVAL - org.apache.flink.table.types.logical.LogicalTypeFamily
- INTERVAL(DataTypes.Resolution) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a temporal interval.
- INTERVAL(DataTypes.Resolution, DataTypes.Resolution) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a temporal interval.
- INTERVAL_DAY_TIME - org.apache.flink.table.types.logical.LogicalTypeRoot
- INTERVAL_MILLIS - Static variable in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- INTERVAL_MILLIS() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API interval of milliseconds.
- INTERVAL_MONTHS - Static variable in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- INTERVAL_MONTHS() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API interval of months.
- INTERVAL_YEAR_MONTH - org.apache.flink.table.types.logical.LogicalTypeRoot
- IntervalFreshness - Class in org.apache.flink.table.catalog
-
The
IntervalFreshness
represents freshness definition ofCatalogMaterializedTable
. - IntervalFreshness.TimeUnit - Enum in org.apache.flink.table.catalog
-
An enumeration of time unit representing the unit of interval freshness.
- IntervalFreshnessUtils - Class in org.apache.flink.table.utils
-
Utilities to
IntervalFreshness
. - IntType - Class in org.apache.flink.table.types.logical
-
Logical type of a 4-byte signed integer with values from -2,147,483,648 to 2,147,483,647.
- IntType() - Constructor for class org.apache.flink.table.types.logical.IntType
- IntType(boolean) - Constructor for class org.apache.flink.table.types.logical.IntType
- invalidate(RowData) - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache
- invalidate(RowData) - Method in interface org.apache.flink.table.connector.source.lookup.cache.LookupCache
-
Discards any cached value for the specified key.
- is(StaticArgumentTrait) - Method in class org.apache.flink.table.types.inference.StaticArgument
- is(LogicalTypeFamily) - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns whether the family type of the type equals to the
family
or not. - is(LogicalTypeRoot) - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns whether the root of the type equals to the
typeRoot
or not. - IS_FALSE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- IS_GENERIC - Static variable in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
Flag to distinguish if a meta-object is a generic Flink object or not.
- IS_JSON - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- IS_NOT_FALSE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- IS_NOT_NULL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- IS_NOT_TRUE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- IS_NULL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- IS_TRUE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- isAnyOf(LogicalTypeFamily...) - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns whether the root of the type is part of at least one family of the
typeFamily
or not. - isAnyOf(LogicalTypeRoot...) - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns whether the root of the type equals to at least on of the
typeRoots
or not. - isApproximate() - Method in class org.apache.flink.table.expressions.AggregateExpression
- isArgumentLiteral(int) - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns whether the argument at the given position is a value literal.
- isArgumentLiteral(int) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- isArgumentLiteral(int) - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
- isArgumentNull(int) - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns
true
if the argument at the given position is a literal andnull
,false
otherwise. - isArgumentNull(int) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- isArgumentNull(int) - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
- isAssignable(Class<?>, Class<?>, ExtractionUtils.Autoboxing) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks if one
Class
can be assigned to a variable of anotherClass
. - isAsyncEnabled() - Method in interface org.apache.flink.table.legacy.sources.LookupableTableSource
-
Deprecated.Returns true if async lookup is enabled.
- isBasicType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- isBasicType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- isBasicType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- isBounded() - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
-
Returns whether a runtime implementation can expect a finite number of rows.
- isBounded() - Method in interface org.apache.flink.table.connector.source.ScanTableSource.ScanRuntimeProvider
-
Returns whether the data is bounded or not.
- isBounded() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- isBounded() - Method in interface org.apache.flink.table.legacy.factories.TableSinkFactory.Context
-
Deprecated.It depends on whether the
TableEnvironment
execution mode is batch. - isClassNameSerializable(UserDefinedFunction) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Returns whether a
UserDefinedFunction
can be easily serialized and identified by only a fully qualified class name. - isCompact() - Method in class org.apache.flink.table.data.DecimalData
-
Returns whether the decimal value is small enough to be stored in a long.
- isCompact(int) - Static method in class org.apache.flink.table.data.DecimalData
-
Returns whether the decimal value is small enough to be stored in a long.
- isCompact(int) - Static method in class org.apache.flink.table.data.TimestampData
-
Returns whether the timestamp data is small enough to be stored in a long of milliseconds.
- isComparison() - Method in enum org.apache.flink.table.types.logical.StructuredType.StructuredComparison
- isCompositeType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Checks if the given type is a composite type.
- isDeterministic() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsLookupCustomShuffle.InputDataPartitioner
-
Returns information about the determinism of this partitioner.
- isDeterministic() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- isDeterministic() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- isDeterministic() - Method in interface org.apache.flink.table.functions.FunctionDefinition
-
Returns information about the determinism of the function's results.
- isDeterministic() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- isDeterministic() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
- isDeterministic() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- isDeterministic() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
- isDeterministic() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- isDeterministic() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- isDeterministic() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- isDistinct() - Method in class org.apache.flink.table.expressions.AggregateExpression
- isDistinct() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunctionInfo
- isEmpty() - Method in class org.apache.flink.table.api.dataview.MapView
-
Returns true if the map view contains no key-value mappings, otherwise false.
- isEnforced() - Method in interface org.apache.flink.table.catalog.Constraint
-
Constraints can either be enforced or non-enforced.
- isEnforced() - Method in interface org.apache.flink.table.legacy.api.constraints.Constraint
-
Deprecated.Constraints can either be enforced or non-enforced.
- isEqual(DynamicFilteringData, DynamicFilteringData) - Static method in class org.apache.flink.table.connector.source.DynamicFilteringData
- isEquality() - Method in enum org.apache.flink.table.types.logical.StructuredType.StructuredComparison
- isEventTime() - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- isFiltering() - Method in class org.apache.flink.table.connector.source.DynamicFilteringData
- isFilterPushedDown() - Method in interface org.apache.flink.table.legacy.sources.FilterableTableSource
-
Deprecated.Return the flag to indicate whether filter push down has been tried.
- isFinal() - Method in class org.apache.flink.table.types.logical.UserDefinedType
- isGroupedAggregation() - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns whether the function call happens as part of an aggregation that defines grouping columns.
- isGroupedAggregation() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- isGroupedAggregation() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
- isIgnoreNulls() - Method in class org.apache.flink.table.expressions.AggregateExpression
- isImmutableType() - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- isImmutableType() - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- isImmutableType() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- isImmutableType() - Method in class org.apache.flink.table.dataview.NullSerializer
- isInFixedLengthPart(LogicalType) - Static method in class org.apache.flink.table.data.binary.BinaryRowData
-
If it is a fixed-length field, we can call this BinaryRowData's setXX method for in-place updates.
- isInstantiable() - Method in class org.apache.flink.table.types.logical.StructuredType
- isInternal() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- isInternal(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Checks whether a given data type is an internal data structure.
- isInternal(DataType, boolean) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Checks whether a given data type is an internal data structure.
- isInvokable(ExtractionUtils.Autoboxing, Executable, Class<?>...) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks whether a method/constructor can be called with the given argument classes.
- isKeyType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- isKeyType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- isKeyType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- isLimitPushedDown() - Method in interface org.apache.flink.table.legacy.sources.LimitableTableSource
-
Deprecated.Return the flag to indicate whether limit push down has been tried.
- isMutable(LogicalType) - Static method in class org.apache.flink.table.data.binary.BinaryRowData
- isNested() - Method in class org.apache.flink.table.connector.Projection
- isNull - Variable in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- isNull() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
- isNullable() - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns whether a value of this type can be
null
. - isNullAt(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns true if the element is null at the given position.
- isNullAt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- isNullAt(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- isNullAt(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- isNullAt(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- isNullAt(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- isNullAt(int) - Method in interface org.apache.flink.table.data.columnar.vector.ColumnVector
- isNullAt(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- isNullAt(int) - Method in class org.apache.flink.table.data.GenericArrayData
- isNullAt(int) - Method in class org.apache.flink.table.data.GenericRowData
- isNullAt(int) - Method in interface org.apache.flink.table.data.RowData
-
Returns true if the field is null at the given position.
- isNullAt(int) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- isNullAt(int) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- isNullAt(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- isNullAware() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- isNullSerializer() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- isNullSerializer() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- ISODOW - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- ISODOW - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- isOnEvent() - Method in enum org.apache.flink.table.watermark.WatermarkEmitStrategy
- isOnPeriodic() - Method in enum org.apache.flink.table.watermark.WatermarkEmitStrategy
- isOpen - Variable in class org.apache.flink.table.catalog.AbstractCatalogStore
-
Catalog store state.
- isOptional() - Method in annotation type org.apache.flink.table.annotation.ArgumentHint
-
Specifies whether the argument is optional or required.
- isOptional() - Method in class org.apache.flink.table.types.inference.StaticArgument
- ISOYEAR - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- ISOYEAR - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- isPartitioned() - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Check if the table is partitioned or not.
- isPartitioned() - Method in interface org.apache.flink.table.catalog.CatalogTable
-
Check if the table is partitioned or not.
- isPartitioned() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- isPartitioned() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- isPartitioned() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- isPartitioned() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- isPersisted() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
- isPersisted() - Method in class org.apache.flink.table.catalog.Column
-
Returns whether the given column is persisted in a sink operation.
- isPersisted() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
- isPersisted() - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
- isPersisted() - Method in class org.apache.flink.table.legacy.api.TableColumn.ComputedColumn
-
Deprecated.
- isPersisted() - Method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Returns whether the given column is persisted in a sink operation.
- isPersisted() - Method in class org.apache.flink.table.legacy.api.TableColumn.MetadataColumn
-
Deprecated.
- isPersisted() - Method in class org.apache.flink.table.legacy.api.TableColumn.PhysicalColumn
-
Deprecated.
- isPhysical() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
- isPhysical() - Method in class org.apache.flink.table.catalog.Column
-
Returns whether the given column is a physical column of a table; neither computed nor metadata.
- isPhysical() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
- isPhysical() - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
- isPhysical() - Method in class org.apache.flink.table.legacy.api.TableColumn.ComputedColumn
-
Deprecated.
- isPhysical() - Method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Returns whether the given column is a physical column of a table; neither computed nor metadata.
- isPhysical() - Method in class org.apache.flink.table.legacy.api.TableColumn.MetadataColumn
-
Deprecated.
- isPhysical() - Method in class org.apache.flink.table.legacy.api.TableColumn.PhysicalColumn
-
Deprecated.
- isPrimitiveArray() - Method in class org.apache.flink.table.data.GenericArrayData
-
Returns true if this is a primitive array.
- isProctimeAttribute(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- isRoot() - Method in enum org.apache.flink.table.annotation.ArgumentTrait
- isRowtimeAttribute(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- isSingleFieldInterval(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- isStructuredFieldDirectlyReadable(Field) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks whether a field is directly readable without a getter.
- isStructuredFieldDirectlyWritable(Field) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks whether a field is directly writable without a setter or constructor.
- isTemporary() - Method in class org.apache.flink.table.expressions.CallExpression
- isTemporary() - Method in interface org.apache.flink.table.factories.DynamicTableFactory.Context
-
Whether the table is temporary.
- isTemporary() - Method in class org.apache.flink.table.factories.FactoryUtil.DefaultDynamicTableContext
- isTemporary() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- isTemporary() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
-
Deprecated.
- isTemporary() - Method in interface org.apache.flink.table.legacy.factories.TableSinkFactory.Context
-
Deprecated.Whether the table is temporary.
- isTemporary() - Method in interface org.apache.flink.table.legacy.factories.TableSourceFactory.Context
-
Deprecated.Whether the table is temporary.
- isTimeAttribute(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
- isTupleType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- isTupleType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- isTupleType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- isValidCount(int) - Method in interface org.apache.flink.table.types.inference.ArgumentCount
-
Enables custom validation of argument counts after
ArgumentCount.getMinCount()
andArgumentCount.getMaxCount()
have been validated. - isValidCount(int) - Method in class org.apache.flink.table.types.inference.ConstantArgumentCount
- isValidValue(BigDecimal) - Method in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnit
-
Returns whether a given value is valid for a field of this time unit.
- isValue(String, String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns if a value under key is exactly equal to the given value.
- isVarArgs() - Method in annotation type org.apache.flink.table.annotation.FunctionHint
-
Defines that the last argument type defined in
FunctionHint.input()
should be treated as a variable-length argument. - isVarArgs() - Method in annotation type org.apache.flink.table.annotation.ProcedureHint
-
Defines that the last argument type defined in
ProcedureHint.input()
should be treated as a variable-length argument. - isVirtual() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
- isVirtual() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
- isVirtual() - Method in class org.apache.flink.table.legacy.api.TableColumn.MetadataColumn
-
Deprecated.
- ITEM_AT - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
- ITEM_AT_INDEX - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
- ItemAtIndexArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
ArgumentTypeStrategy
that expects: - ItemAtIndexArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.ItemAtIndexArgumentTypeStrategy
- ItemAtTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An output type strategy for
BuiltInFunctionDefinitions.AT
. - ItemAtTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.ItemAtTypeStrategy
- iterator() - Method in class org.apache.flink.table.api.dataview.MapView
-
Returns an iterator over all entries of the map view.
J
- JAR - org.apache.flink.table.resource.ResourceType
- JAVA - org.apache.flink.table.catalog.FunctionLanguage
- JoinedRowData - Class in org.apache.flink.table.data.utils
- JoinedRowData() - Constructor for class org.apache.flink.table.data.utils.JoinedRowData
-
Creates a new
JoinedRowData
of kindRowKind.INSERT
, but without backing rows. - JoinedRowData(RowData, RowData) - Constructor for class org.apache.flink.table.data.utils.JoinedRowData
-
Creates a new
JoinedRowData
of kindRowKind.INSERT
backed by {@param row1} and {@param row2}. - JoinedRowData(RowKind, RowData, RowData) - Constructor for class org.apache.flink.table.data.utils.JoinedRowData
-
Creates a new
JoinedRowData
of kind {@param rowKind} backed by {@param row1} and {@param row2}. - JSON_ARGUMENT - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
Argument type representing all types supported in a JSON context.
- JSON_ARRAY - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_ARRAYAGG_ABSENT_ON_NULL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_ARRAYAGG_NULL_ON_NULL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_EXISTS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_OBJECT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_OBJECT - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
Input strategy for
BuiltInFunctionDefinitions.JSON_OBJECT
. - JSON_OBJECTAGG_ABSENT_ON_NULL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_OBJECTAGG_NULL_ON_NULL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_QUERY - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_QUERY_ON_EMPTY_ERROR_BEHAVIOUR - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
- JSON_QUOTE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_STRING - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_UNQUOTE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JSON_VALUE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- JsonExistsOnError - Enum in org.apache.flink.table.api
-
Behavior in case of errors for
BuiltInFunctionDefinitions.JSON_EXISTS
. - JsonOnNull - Enum in org.apache.flink.table.api
-
Behavior for entries with a null value for
BuiltInFunctionDefinitions.JSON_OBJECT
andBuiltInFunctionDefinitions.JSON_ARRAY
. - JsonQueryOnEmptyOrError - Enum in org.apache.flink.table.api
-
Behavior of
BuiltInFunctionDefinitions.JSON_QUERY
in case a path expression is empty or raises an error. - JsonQueryOnErrorEmptyArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Argument strategy for
BuiltInFunctionDefinitions.JSON_QUERY
to check the `ON EMPTY` and/or `ON ERROR` behaviour in combination with the return type. - JsonQueryOnErrorEmptyArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.JsonQueryOnErrorEmptyArgumentTypeStrategy
- JsonQueryWrapper - Enum in org.apache.flink.table.api
-
Defines whether and when to wrap the result of
BuiltInFunctionDefinitions.JSON_QUERY
into an array. - JsonType - Enum in org.apache.flink.table.api
-
Supported JSON types for
BuiltInFunctionDefinitions.IS_JSON
. - JsonValueOnEmptyOrError - Enum in org.apache.flink.table.api
-
Behavior for
BuiltInFunctionDefinitions.JSON_VALUE
. - JVM - org.apache.flink.table.types.extraction.ExtractionUtils.Autoboxing
-
int.class can be passed into f(Integer.class).
K
- keyArray() - Method in class org.apache.flink.table.data.binary.BinaryMapData
- keyArray() - Method in class org.apache.flink.table.data.columnar.ColumnarMapData
- keyArray() - Method in class org.apache.flink.table.data.GenericMapData
- keyArray() - Method in interface org.apache.flink.table.data.MapData
-
Returns an array view of the keys contained in this map.
- keys() - Method in class org.apache.flink.table.api.dataview.MapView
-
Returns all the keys in the map view.
- KeyValueDataType - Class in org.apache.flink.table.types
-
A data type that contains a key and value data type (e.g.
- KeyValueDataType(LogicalType, Class<?>, DataType, DataType) - Constructor for class org.apache.flink.table.types.KeyValueDataType
- KeyValueDataType(LogicalType, DataType, DataType) - Constructor for class org.apache.flink.table.types.KeyValueDataType
- kind(FunctionKind) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
L
- LAG - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LAST_VALUE - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- LAST_VALUE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LAST_VALUE_RETRACT - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- LazyBinaryFormat<T> - Class in org.apache.flink.table.data.binary
-
An abstract implementation fo
BinaryFormat
which is lazily serialized into binary or lazily deserialized into Java object. - LazyBinaryFormat() - Constructor for class org.apache.flink.table.data.binary.LazyBinaryFormat
- LazyBinaryFormat(MemorySegment[], int, int) - Constructor for class org.apache.flink.table.data.binary.LazyBinaryFormat
- LazyBinaryFormat(MemorySegment[], int, int, T) - Constructor for class org.apache.flink.table.data.binary.LazyBinaryFormat
- LazyBinaryFormat(T) - Constructor for class org.apache.flink.table.data.binary.LazyBinaryFormat
- LazyBinaryFormat(T, BinarySection) - Constructor for class org.apache.flink.table.data.binary.LazyBinaryFormat
- LEAD - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LEAD_LAG - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
Type strategy for
BuiltInFunctionDefinitions.LAG
and { @link BuiltInFunctionDefinitions#LEAD}. - LEAD_LAG - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
Strategy for
BuiltInFunctionDefinitions.LAG
andBuiltInFunctionDefinitions.LEAD
. - LeadLagInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy for
BuiltInFunctionDefinitions.LAG
and { @link BuiltInFunctionDefinitions#LEAD}. - LeadLagInputTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.LeadLagInputTypeStrategy
- LEAST - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LEFT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- legacyRawToTypeInfoRaw() - Static method in class org.apache.flink.table.types.inference.TypeTransformations
-
Returns a type transformation that transforms LEGACY('RAW', ...) type to the RAW(..., ?)
- LegacyRawTypeTransformation - Class in org.apache.flink.table.types.inference.transforms
-
This type transformation transforms the LEGACY('RAW', ...) type to the RAW(..., ?)
- LegacyRawTypeTransformation() - Constructor for class org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
- legacyToNonLegacy() - Static method in class org.apache.flink.table.types.inference.TypeTransformations
-
Returns a type transformation that transforms LEGACY(...) type to a non-legacy type.
- LegacyToNonLegacyTransformation - Class in org.apache.flink.table.types.inference.transforms
-
Transformation that applies
TypeInfoDataTypeConverter
onLegacyTypeInformationType
. - LegacyToNonLegacyTransformation() - Constructor for class org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
- LegacyTypeInfoDataTypeConverter - Class in org.apache.flink.table.types.utils
-
Deprecated.Use
DataTypeFactory.createDataType(TypeInformation)
instead. Note that this method will not create legacy types anymore. It fully uses the new type system available only in the planner. - LegacyTypeInformationType<T> - Class in org.apache.flink.table.types.logical
-
This type is a temporary solution to fully support the old type system stack through the new stack.
- LegacyTypeInformationType(LogicalTypeRoot, TypeInformation<T>) - Constructor for class org.apache.flink.table.types.logical.LegacyTypeInformationType
- LegacyUserDefinedFunctionInference - Class in org.apache.flink.table.functions
-
Deprecated.
- len - Variable in class org.apache.flink.table.data.columnar.vector.BytesColumnVector.Bytes
- length - Variable in class org.apache.flink.table.data.columnar.vector.heap.HeapBytesVector
-
The length of each field.
- LESS_THAN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LESS_THAN_OR_EQUAL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LIKE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LIKE - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Special sql syntax for LIKE.
- LimitableTableSource<T> - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.This interface will not be supported in the new source design around
DynamicTableSource
. UseSupportsLimitPushDown
instead. See FLIP-95 for more information. - LIST_AGG - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- LIST_AGG_RETRACT - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- LIST_AGG_WS_RETRACT - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- listAcceptedFilterFields() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsDynamicFiltering
-
Return the filter fields this partition table source supported.
- LISTAGG - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- listAlgorithms() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsBucketing
-
Returns the set of supported bucketing algorithms.
- listCatalogs() - Method in interface org.apache.flink.table.catalog.CatalogStore
-
Retrieves the names of all registered catalogs.
- listDatabases() - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the names of all databases in this catalog.
- listFunctions() - Method in class org.apache.flink.table.module.CoreModule
- listFunctions() - Method in interface org.apache.flink.table.module.Module
-
List names of all functions in this module.
- listFunctions(boolean) - Method in class org.apache.flink.table.module.CoreModule
- listFunctions(boolean) - Method in interface org.apache.flink.table.module.Module
-
List names of all functions in this module.
- listFunctions(String) - Method in interface org.apache.flink.table.catalog.Catalog
-
List the names of all functions in the given database.
- listModels(String) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get names of all models under this database.
- listPartitions() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsPartitionPushDown
-
Returns a list of all partitions that a source can read if available.
- listPartitions(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get CatalogPartitionSpec of all partitions of the table.
- listPartitions(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get CatalogPartitionSpec of all partitions that is under the given CatalogPartitionSpec in the table.
- listPartitionsByFilter(ObjectPath, List<Expression>) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get CatalogPartitionSpec of partitions by expression filters in the table.
- listProcedures(String) - Method in interface org.apache.flink.table.catalog.Catalog
-
List the names of all procedures in the given database.
- listReadableMetadata() - Method in interface org.apache.flink.table.connector.format.DecodingFormat
-
Returns the map of metadata keys and their corresponding data types that can be produced by this format for reading.
- listReadableMetadata() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsReadingMetadata
-
Returns the map of metadata keys and their corresponding data types that can be produced by this table source for reading.
- listStatusWithoutHidden(FileSystem, Path) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
-
List file status without hidden files.
- listTables(String) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get names of all tables and views under this database.
- ListView<T> - Class in org.apache.flink.table.api.dataview
-
A
DataView
that providesList
-like functionality in the accumulator of anAggregateFunction
orTableAggregateFunction
when large amounts of data are expected. - ListView() - Constructor for class org.apache.flink.table.api.dataview.ListView
-
Creates a list view.
- listViews(String) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get names of all views under this database.
- ListViewSerializer<T> - Class in org.apache.flink.table.dataview
-
Deprecated.
- ListViewSerializer(TypeSerializer<List<T>>) - Constructor for class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- ListViewSerializerSnapshot<T> - Class in org.apache.flink.table.dataview
-
Deprecated.
- ListViewSerializerSnapshot() - Constructor for class org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
Deprecated.Constructor for read instantiation.
- ListViewSerializerSnapshot(ListViewSerializer<T>) - Constructor for class org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
Deprecated.Constructor to create the snapshot for writing.
- ListViewTypeInfo<T> - Class in org.apache.flink.table.dataview
-
Deprecated.
- ListViewTypeInfo(TypeInformation<T>) - Constructor for class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- ListViewTypeInfo(TypeInformation<T>, boolean) - Constructor for class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- listWritableMetadata() - Method in interface org.apache.flink.table.connector.format.EncodingFormat
-
Returns the map of metadata keys and their corresponding data types that can be consumed by this format for writing.
- listWritableMetadata() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsWritingMetadata
-
Returns the map of metadata keys and their corresponding data types that can be consumed by this table sink for writing.
- LITERAL - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that checks if an argument is a literal.
- LITERAL_OR_NULL - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that checks if an argument is a literal or NULL.
- LiteralArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy that checks if an argument is a literal.
- LiteralArgumentTypeStrategy(boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.LiteralArgumentTypeStrategy
- LITTLE_ENDIAN - Static variable in class org.apache.flink.table.data.binary.BinaryRowData
- LITTLE_ENDIAN - Static variable in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Constant that flags the byte order.
- LITTLE_ENDIAN - Static variable in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- LN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- loadClass(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
-
Deprecated.Use
EncodingUtils.loadClass(String, ClassLoader)
instead, in order to explicitly provide the correct classloader. - loadClass(String, ClassLoader) - Static method in class org.apache.flink.table.utils.EncodingUtils
- LOCAL_DATE() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API LocalDate type.
- LOCAL_DATE_TIME() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API LocalDateTime type.
- LOCAL_TIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LOCAL_TIME() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API LocalTime type.
- LOCAL_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LOCAL_TZ - Static variable in class org.apache.flink.table.utils.DateTimeUtils
-
The local time zone.
- LocalZonedTimestampType - Class in org.apache.flink.table.types.logical
-
Logical type of a timestamp WITH LOCAL time zone consisting of
year-month-day hour:minute:second[.fractional] zone
with up to nanosecond precision and values ranging from0000-01-01 00:00:00.000000000 +14:59
to9999-12-31 23:59:59.999999999 -14:59
. - LocalZonedTimestampType() - Constructor for class org.apache.flink.table.types.logical.LocalZonedTimestampType
- LocalZonedTimestampType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.LocalZonedTimestampType
- LocalZonedTimestampType(boolean, TimestampKind, int) - Constructor for class org.apache.flink.table.types.logical.LocalZonedTimestampType
-
Internal constructor that allows attaching additional metadata about time attribute properties.
- LocalZonedTimestampType(int) - Constructor for class org.apache.flink.table.types.logical.LocalZonedTimestampType
- LOCATE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LOG - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LOG10 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LOG2 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- logical(LogicalTypeFamily) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for an argument that corresponds to a given
LogicalTypeFamily
. - logical(LogicalTypeFamily, boolean) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for an argument that corresponds to a given
LogicalTypeFamily
and nullability. - logical(LogicalTypeRoot) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for an argument that corresponds to a given
LogicalTypeRoot
. - logical(LogicalTypeRoot, boolean) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for an argument that corresponds to a given
LogicalTypeRoot
and nullability. - logicalRefreshMode(CatalogMaterializedTable.LogicalRefreshMode) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- logicalType - Variable in class org.apache.flink.table.types.DataType
- LogicalType - Class in org.apache.flink.table.types.logical
-
A logical type that describes the data type of a value.
- LogicalType(boolean, LogicalTypeRoot) - Constructor for class org.apache.flink.table.types.logical.LogicalType
- LogicalTypeCasts - Class in org.apache.flink.table.types.logical.utils
-
Utilities for casting
LogicalType
. - LogicalTypeChecks - Class in org.apache.flink.table.types.logical.utils
-
Utilities for checking
LogicalType
and avoiding a lot of type casting and repetitive work. - LogicalTypeDataTypeConverter - Class in org.apache.flink.table.types.utils
-
A converter between
LogicalType
andDataType
. - LogicalTypeDefaultVisitor<R> - Class in org.apache.flink.table.types.logical.utils
-
Implementation of
LogicalTypeVisitor
that redirects all calls toLogicalTypeDefaultVisitor.defaultMethod(LogicalType)
. - LogicalTypeDefaultVisitor() - Constructor for class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- LogicalTypeDuplicator - Class in org.apache.flink.table.types.logical.utils
-
Returns a deep copy of a
LogicalType
. - LogicalTypeDuplicator() - Constructor for class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
- LogicalTypeFamily - Enum in org.apache.flink.table.types.logical
-
An enumeration of logical type families for clustering
LogicalTypeRoot
s into categories. - LogicalTypeMerging - Class in org.apache.flink.table.types.logical.utils
-
Utilities for merging multiple
LogicalType
. - LogicalTypeParser - Class in org.apache.flink.table.types.logical.utils
-
Parser for creating instances of
LogicalType
from a serialized string created withLogicalType.asSerializableString()
. - LogicalTypeParser() - Constructor for class org.apache.flink.table.types.logical.utils.LogicalTypeParser
- LogicalTypeRoot - Enum in org.apache.flink.table.types.logical
-
An enumeration of logical type roots containing static information about logical data types.
- LogicalTypeUtils - Class in org.apache.flink.table.types.logical.utils
-
Utilities for handling
LogicalType
s. - LogicalTypeVisitor<R> - Interface in org.apache.flink.table.types.logical
-
The visitor definition of
LogicalType
. - LONG() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API long or SQL BIGINT type.
- LONG_ARRAY_OFFSET - Static variable in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- LongColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Long column vector.
- lookup(RowData) - Method in class org.apache.flink.table.functions.LookupFunction
-
Synchronously lookup rows matching the lookup keys.
- LookupableTableSource<T> - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.This interface will not be supported in the new source design around
DynamicTableSource
. UseLookupTableSource
instead. See FLIP-95 for more information. - LookupCache - Interface in org.apache.flink.table.connector.source.lookup.cache
-
A semi-persistent mapping from keys to values for storing entries of lookup table.
- LookupFunction - Class in org.apache.flink.table.functions
-
A wrapper class of
TableFunction
for synchronously lookup rows matching the lookup keys from external system. - LookupFunction() - Constructor for class org.apache.flink.table.functions.LookupFunction
- LookupFunctionProvider - Interface in org.apache.flink.table.connector.source.lookup
-
A provider for creating
LookupFunction
. - LookupOptions - Class in org.apache.flink.table.connector.source.lookup
-
Predefined options for lookup table.
- LookupOptions() - Constructor for class org.apache.flink.table.connector.source.lookup.LookupOptions
- LookupOptions.LookupCacheType - Enum in org.apache.flink.table.connector.source.lookup
-
Types of the lookup cache.
- LookupOptions.ReloadStrategy - Enum in org.apache.flink.table.connector.source.lookup
-
Defines which
CacheReloadTrigger
to use. - LookupTableSource - Interface in org.apache.flink.table.connector.source
-
A
DynamicTableSource
that looks up rows of an external storage system by one or more keys during runtime. - LookupTableSource.LookupContext - Interface in org.apache.flink.table.connector.source
-
Context for creating runtime implementation via a
LookupTableSource.LookupRuntimeProvider
. - LookupTableSource.LookupRuntimeProvider - Interface in org.apache.flink.table.connector.source
-
Provides actual runtime implementation for reading the data.
- LOWER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LOWERCASE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LPAD - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- LTRIM - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
M
- MAP - org.apache.flink.table.types.logical.LogicalTypeRoot
- MAP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- MAP - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
See
MapInputTypeStrategy
. - MAP - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
MapTypeStrategy
. - MAP(TypeInformation<K>, TypeInformation<V>) - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Generates type information for a Java HashMap.
- MAP(AbstractDataType<?>, AbstractDataType<?>) - Static method in class org.apache.flink.table.api.DataTypes
-
Unresolved data type of an associative array that maps keys (including
NULL
) to values (includingNULL
). - MAP(DataType, DataType) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of an associative array that maps keys (including
NULL
) to values (includingNULL
). - MAP_ENTRIES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- MAP_ENTRIES - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
Type strategy specific for
BuiltInFunctionDefinitions.MAP_ENTRIES
. - MAP_FROM_ARRAYS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- MAP_FROM_ARRAYS - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
Type strategy specific for
BuiltInFunctionDefinitions.MAP_FROM_ARRAYS
. - MAP_KEYS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- MAP_KEYS - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
Type strategy specific for
BuiltInFunctionDefinitions.MAP_KEYS
. - MAP_UNION - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- MAP_VALUES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- MAP_VALUES - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
Type strategy specific for
BuiltInFunctionDefinitions.MAP_VALUES
. - MapColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Map column vector.
- MapData - Interface in org.apache.flink.table.data
-
Base interface of an internal data structure representing data of
MapType
orMultisetType
. - mapping(Map<InputTypeStrategy, TypeStrategy>) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy that maps an
InputTypeStrategy
to aTypeStrategy
if the input strategy infers identical types. - MappingTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that maps an
InputTypeStrategy
to aTypeStrategy
if the input strategy infers compatible types. - MappingTypeStrategy(Map<InputTypeStrategy, TypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.MappingTypeStrategy
- MapType - Class in org.apache.flink.table.types.logical
-
Logical type of an associative array that maps keys (including
NULL
) to values (includingNULL
). - MapType(boolean, LogicalType, LogicalType) - Constructor for class org.apache.flink.table.types.logical.MapType
- MapType(LogicalType, LogicalType) - Constructor for class org.apache.flink.table.types.logical.MapType
- MapView<K,V> - Class in org.apache.flink.table.api.dataview
-
A
DataView
that providesMap
-like functionality in the accumulator of anAggregateFunction
orTableAggregateFunction
when large amounts of data are expected. - MapView() - Constructor for class org.apache.flink.table.api.dataview.MapView
-
Creates a map view.
- MapViewSerializer<K,V> - Class in org.apache.flink.table.dataview
-
Deprecated.
- MapViewSerializer(TypeSerializer<Map<K, V>>) - Constructor for class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- MapViewSerializerSnapshot<K,V> - Class in org.apache.flink.table.dataview
-
Deprecated.
- MapViewSerializerSnapshot() - Constructor for class org.apache.flink.table.dataview.MapViewSerializerSnapshot
-
Deprecated.Constructor for read instantiation.
- MapViewSerializerSnapshot(MapViewSerializer<K, V>) - Constructor for class org.apache.flink.table.dataview.MapViewSerializerSnapshot
-
Deprecated.Constructor to create the snapshot for writing.
- MapViewTypeInfo<K,V> - Class in org.apache.flink.table.dataview
-
Deprecated.
- MapViewTypeInfo(TypeInformation<K>, TypeInformation<V>) - Constructor for class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- MapViewTypeInfo(TypeInformation<K>, TypeInformation<V>, boolean, boolean) - Constructor for class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- matchFamily(int, LogicalTypeFamily) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy that returns the given argument if it is of the same logical type family.
- MatchFamilyTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that returns the given argument if it is of the same logical type family.
- MatchFamilyTypeStrategy(int, LogicalTypeFamily) - Constructor for class org.apache.flink.table.types.inference.strategies.MatchFamilyTypeStrategy
- materialize(TypeSerializer<String>) - Method in class org.apache.flink.table.data.binary.BinaryStringData
- materialize(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
- materialize(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
-
Materialize java object to binary format.
- MATERIALIZED_TABLE - org.apache.flink.table.catalog.CatalogBaseTable.TableKind
- MAX - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- MAX - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- MAX_DAY_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
- MAX_FIX_PART_DATA_SIZE - Static variable in interface org.apache.flink.table.data.binary.BinaryFormat
-
It decides whether to put data in FixLenPart or VarLenPart.
- MAX_FRACTIONAL_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
- MAX_LENGTH - Static variable in class org.apache.flink.table.types.logical.BinaryType
- MAX_LENGTH - Static variable in class org.apache.flink.table.types.logical.CharType
- MAX_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarBinaryType
- MAX_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarCharType
- MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.DecimalType
- MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimestampType
- MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimeType
- MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.YearMonthIntervalType
- MAX_PRECISION - Static variable in class org.apache.flink.table.types.logical.ZonedTimestampType
- MAX_RETRACT - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- MAX_RETRIES - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- maximumSize(long) - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache.Builder
-
Specifies the maximum number of entries of the cache.
- md5(String) - Static method in class org.apache.flink.table.utils.EncodingUtils
- MD5 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- merge(ColumnStats, boolean) - Method in class org.apache.flink.table.plan.stats.ColumnStats
-
Merges two column stats.
- merge(TableStats, Set<String>) - Method in class org.apache.flink.table.plan.stats.TableStats
-
Merges two table stats.
- metadata(String, DataType) - Static method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Creates a metadata column from metadata of the given column name.
- metadata(String, DataType, boolean) - Static method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Creates a metadata column from metadata of the given column name.
- metadata(String, DataType, String) - Static method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Creates a metadata column from metadata of the given alias.
- metadata(String, DataType, String, boolean) - Static method in class org.apache.flink.table.catalog.Column
-
Creates a metadata column from metadata of the given column name or from metadata of the given key (if not null).
- metadata(String, DataType, String, boolean) - Static method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Creates a metadata column from metadata of the given column name or from metadata of the given alias (if not null).
- METADATA - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- MICROSECOND - org.apache.flink.table.expressions.TimeIntervalUnit
- MICROSECOND - org.apache.flink.table.expressions.TimePointUnit
- MICROSECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- MICROSECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- MILLENNIUM - org.apache.flink.table.expressions.TimeIntervalUnit
- MILLENNIUM - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- MILLENNIUM - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- MILLIS_PER_DAY - Static variable in class org.apache.flink.table.utils.DateTimeUtils
-
The number of milliseconds in a day.
- MILLISECOND - org.apache.flink.table.expressions.TimeIntervalUnit
- MILLISECOND - org.apache.flink.table.expressions.TimePointUnit
- MILLISECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- MILLISECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- MIN - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- MIN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- MIN_DAY_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
- MIN_FRACTIONAL_PRECISION - Static variable in class org.apache.flink.table.types.logical.DayTimeIntervalType
- MIN_LENGTH - Static variable in class org.apache.flink.table.types.logical.BinaryType
- MIN_LENGTH - Static variable in class org.apache.flink.table.types.logical.CharType
- MIN_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarBinaryType
- MIN_LENGTH - Static variable in class org.apache.flink.table.types.logical.VarCharType
- MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.DecimalType
- MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimestampType
- MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.TimeType
- MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.YearMonthIntervalType
- MIN_PRECISION - Static variable in class org.apache.flink.table.types.logical.ZonedTimestampType
- MIN_RETRACT - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- MIN_SCALE - Static variable in class org.apache.flink.table.types.logical.DecimalType
- MINUS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
Combines numeric subtraction and "datetime - interval" arithmetic.
- MINUS_PREFIX - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- MINUTE - org.apache.flink.table.catalog.IntervalFreshness.TimeUnit
- MINUTE - org.apache.flink.table.expressions.TimeIntervalUnit
- MINUTE - org.apache.flink.table.expressions.TimePointUnit
- MINUTE - org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
- MINUTE - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- MINUTE - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- MINUTE() - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in minutes.
- MINUTE_TO_SECOND - org.apache.flink.table.expressions.TimeIntervalUnit
- MINUTE_TO_SECOND - org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
- MINUTE_TO_SECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- MISSING - Static variable in class org.apache.flink.table.types.inference.TypeStrategies
-
Placeholder for a missing type strategy.
- MissingTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Placeholder for a missing type strategy.
- MissingTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.MissingTypeStrategy
- MOD - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- MODEL - org.apache.flink.table.types.inference.StaticArgumentTrait
- ModelAlreadyExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to create a model that already exists.
- ModelAlreadyExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.ModelAlreadyExistException
- ModelAlreadyExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.ModelAlreadyExistException
- modelExists(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Check if a model exists in this catalog.
- ModelNotExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to operate on a model that doesn't exist.
- ModelNotExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.ModelNotExistException
- ModelNotExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.ModelNotExistException
- modify(Column, Column, TableChange.ColumnPosition) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to modify a column.
- modify(TableDistribution) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to modify a distribution.
- modify(UniqueConstraint) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to modify a unique constraint.
- modify(WatermarkSpec) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to modify a watermark.
- ModifyColumn(Column, Column, TableChange.ColumnPosition) - Constructor for class org.apache.flink.table.catalog.TableChange.ModifyColumn
- modifyColumnComment(Column, String) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to modify the column comment.
- modifyColumnName(Column, String) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to modify the column name.
- modifyColumnPosition(Column, TableChange.ColumnPosition) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to modify the column position.
- ModifyColumnPosition(Column, TableChange.ColumnPosition) - Constructor for class org.apache.flink.table.catalog.TableChange.ModifyColumnPosition
- modifyDefinitionQuery(String) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to modify materialized table definition query.
- ModifyDefinitionQuery(String) - Constructor for class org.apache.flink.table.catalog.TableChange.ModifyDefinitionQuery
- modifyPhysicalColumnType(Column, DataType) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change that modify the physical column data type.
- modifyRefreshHandler(String, byte[]) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to modify materialized table refresh handler.
- ModifyRefreshHandler(String, byte[]) - Constructor for class org.apache.flink.table.catalog.TableChange.ModifyRefreshHandler
- modifyRefreshStatus(CatalogMaterializedTable.RefreshStatus) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to modify materialized table refresh status.
- ModifyRefreshStatus(CatalogMaterializedTable.RefreshStatus) - Constructor for class org.apache.flink.table.catalog.TableChange.ModifyRefreshStatus
- modifyRefreshWorkflow(ModifyRefreshWorkflow<T>) - Method in interface org.apache.flink.table.workflow.WorkflowScheduler
-
Modify the refresh workflow status in scheduler service.
- ModifyRefreshWorkflow<T extends RefreshHandler> - Interface in org.apache.flink.table.workflow
-
ModifyRefreshWorkflow
provides the related information to modify refresh workflow ofCatalogMaterializedTable
. - ModifyUniqueConstraint(UniqueConstraint) - Constructor for class org.apache.flink.table.catalog.TableChange.ModifyUniqueConstraint
- ModifyWatermark(WatermarkSpec) - Constructor for class org.apache.flink.table.catalog.TableChange.ModifyWatermark
- Module - Interface in org.apache.flink.table.module
-
Modules define a set of metadata, including functions, user defined types, operators, rules, etc.
- MODULE_TYPE - Static variable in class org.apache.flink.table.module.CommonModuleOptions
-
Deprecated.This is only required for the legacy factory stack
- ModuleException - Exception in org.apache.flink.table.module
-
Exception related to modules.
- ModuleException(String) - Constructor for exception org.apache.flink.table.module.ModuleException
-
Creates a new
ModuleException
. - ModuleException(String, Throwable) - Constructor for exception org.apache.flink.table.module.ModuleException
-
Creates a new
ModuleException
. - ModuleFactory - Interface in org.apache.flink.table.factories
-
A factory to create configured module instances based on string-based properties.
- ModuleFactory.Context - Interface in org.apache.flink.table.factories
-
Context provided when a module is created.
- ModuleFactoryHelper(ModuleFactory, ModuleFactory.Context) - Constructor for class org.apache.flink.table.factories.FactoryUtil.ModuleFactoryHelper
- MONTH - org.apache.flink.table.expressions.TimeIntervalUnit
- MONTH - org.apache.flink.table.expressions.TimePointUnit
- MONTH - org.apache.flink.table.types.logical.YearMonthIntervalType.YearMonthResolution
- MONTH - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- MONTH - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- MONTH() - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in months.
- monthly() - Method in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
-
Whether this is in the YEAR-TO-MONTH family of intervals.
- MULTIPLE_BINARY_OP - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Binary operator syntax that in Table API can accept multiple operands, as in "x AND y AND t AND w".
- multiplier - Variable in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- MULTISET - org.apache.flink.table.types.logical.LogicalTypeRoot
- MULTISET(TypeInformation<E>) - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Generates type information for a Multiset.
- MULTISET(AbstractDataType<?>) - Static method in class org.apache.flink.table.api.DataTypes
-
Unresolved data type of a multiset (=bag).
- MULTISET(DataType) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a multiset (=bag).
- MultisetType - Class in org.apache.flink.table.types.logical
-
Logical type of a multiset (=bag).
- MultisetType(boolean, LogicalType) - Constructor for class org.apache.flink.table.types.logical.MultisetType
- MultisetType(LogicalType) - Constructor for class org.apache.flink.table.types.logical.MultisetType
N
- name - Variable in class org.apache.flink.table.api.DataTypes.AbstractField
- name - Variable in class org.apache.flink.table.catalog.Column
- name() - Method in annotation type org.apache.flink.table.annotation.ArgumentHint
-
The name of the argument.
- name() - Method in annotation type org.apache.flink.table.annotation.StateHint
-
The name of the state entry.
- name() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
- name(String) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Specifies a name that uniquely identifies a built-in function.
- NAME - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- namedArguments(String...) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Deprecated.
- namedArguments(String...) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Deprecated.
- namedArguments(List<String>) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Deprecated.Use
TypeInference.Builder.staticArguments(List)
instead. - NANOSECOND - org.apache.flink.table.expressions.TimeIntervalUnit
- NANOSECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- NANOSECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- NestedFieldReferenceExpression - Class in org.apache.flink.table.expressions
-
A reference to a nested field in an input.
- NestedFieldReferenceExpression(String[], int[], DataType) - Constructor for class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- NestedFieldsProjectableTableSource<T> - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.This interface will not be supported in the new source design around
DynamicTableSource
. UseSupportsProjectionPushDown
instead. See FLIP-95 for more information. - NestedRowData - Class in org.apache.flink.table.data.binary
-
Its memory storage structure is exactly the same with
BinaryRowData
. - NestedRowData(int) - Constructor for class org.apache.flink.table.data.binary.NestedRowData
- newBuilder() - Static method in class org.apache.flink.table.api.Schema
-
Builder for configuring and creating instances of
Schema
. - newBuilder() - Static method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Builder for configuring and creating instances of
CatalogMaterializedTable
. - newBuilder() - Static method in class org.apache.flink.table.catalog.CatalogStoreHolder
- newBuilder() - Static method in interface org.apache.flink.table.catalog.CatalogTable
-
Builder for configuring and creating instances of
CatalogTable
. - newBuilder() - Static method in class org.apache.flink.table.connector.ChangelogMode
-
Builder for configuring and creating instances of
ChangelogMode
. - newBuilder() - Static method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache
-
Creates a builder for the cache.
- newBuilder() - Static method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
-
Builder for configuring and creating instances of
BuiltInFunctionDefinition
. - newBuilder() - Static method in class org.apache.flink.table.types.inference.TypeInference
-
Builder for configuring and creating instances of
TypeInference
. - newBuilder(Class<?>) - Static method in class org.apache.flink.table.types.logical.StructuredType
-
Creates a builder for a
StructuredType
that is not stored in a catalog and is identified by an implementationClass
. - newBuilder(ObjectIdentifier) - Static method in class org.apache.flink.table.types.logical.StructuredType
-
Creates a builder for a
StructuredType
that has been stored in a catalog and is identified by anObjectIdentifier
. - newBuilder(ObjectIdentifier, Class<?>) - Static method in class org.apache.flink.table.types.logical.StructuredType
-
Creates a builder for a
StructuredType
that has been stored in a catalog and is identified by anObjectIdentifier
. - newBuilder(ObjectIdentifier, LogicalType) - Static method in class org.apache.flink.table.types.logical.DistinctType
-
Creates a builder for a
DistinctType
. - newColumn - Variable in class org.apache.flink.table.catalog.TableChange.ModifyColumn
- newListViewDataType(DataType) - Static method in class org.apache.flink.table.api.dataview.ListView
- newMapViewDataType(DataType, DataType) - Static method in class org.apache.flink.table.api.dataview.MapView
- newPosition - Variable in class org.apache.flink.table.catalog.TableChange.ModifyColumn
- newValidationError(String, Object...) - Method in interface org.apache.flink.table.types.inference.CallContext
-
Creates a validation exception for exiting the type inference process with a meaningful exception.
- NO_ARGS - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that does not expect any arguments.
- NO_PARENTHESIS - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Function syntax for functions without parenthesis (e.g., CURRENT_DATE, LOCALTIMESTAMP, LOCALTIME, CURRENT_TIMESTAMP, CURRENT_TIME).
- NoMatchingTableFactoryException - Exception in org.apache.flink.table.api
-
Deprecated.This exception is considered internal and has been erroneously placed in the *.api package. It is replaced by
NoMatchingTableFactoryException
and should not be used directly anymore. - NoMatchingTableFactoryException - Exception in org.apache.flink.table.factories
-
Exception for not finding a
TableFactory
for the given properties. - NoMatchingTableFactoryException(String, Class<?>, List<TableFactory>, Map<String, String>) - Constructor for exception org.apache.flink.table.api.NoMatchingTableFactoryException
-
Deprecated.
- NoMatchingTableFactoryException(String, Class<?>, List<TableFactory>, Map<String, String>) - Constructor for exception org.apache.flink.table.factories.NoMatchingTableFactoryException
- NoMatchingTableFactoryException(String, String, Class<?>, List<TableFactory>, Map<String, String>) - Constructor for exception org.apache.flink.table.api.NoMatchingTableFactoryException
-
Deprecated.
- NoMatchingTableFactoryException(String, String, Class<?>, List<TableFactory>, Map<String, String>) - Constructor for exception org.apache.flink.table.factories.NoMatchingTableFactoryException
- NoMatchingTableFactoryException(String, String, Class<?>, List<TableFactory>, Map<String, String>, Throwable) - Constructor for exception org.apache.flink.table.api.NoMatchingTableFactoryException
-
Deprecated.
- NoMatchingTableFactoryException(String, String, Class<?>, List<TableFactory>, Map<String, String>, Throwable) - Constructor for exception org.apache.flink.table.factories.NoMatchingTableFactoryException
- NONE - org.apache.flink.table.connector.source.lookup.LookupOptions.LookupCacheType
- NONE - org.apache.flink.table.types.extraction.ExtractionUtils.Autoboxing
-
int.class cannot be passed into f(Integer.class).
- NONE - org.apache.flink.table.types.logical.StructuredType.StructuredComparison
- noNulls - Variable in class org.apache.flink.table.data.columnar.vector.writable.AbstractWritableVector
- normalizeName(String) - Static method in class org.apache.flink.table.functions.FunctionIdentifier
-
Normalize a function name.
- normalizeObjectIdentifier(ObjectIdentifier) - Static method in class org.apache.flink.table.functions.FunctionIdentifier
-
Normalize an object identifier by only normalizing the function name.
- NOT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- NOT_BETWEEN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- NOT_EQUALS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- notDeterministic() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
- notNull() - Method in interface org.apache.flink.table.types.AbstractDataType
-
Adds a hint that null values are not expected in the data for this type.
- notNull() - Method in class org.apache.flink.table.types.AtomicDataType
- notNull() - Method in class org.apache.flink.table.types.CollectionDataType
- notNull() - Method in class org.apache.flink.table.types.FieldsDataType
- notNull() - Method in class org.apache.flink.table.types.KeyValueDataType
- notNull() - Method in class org.apache.flink.table.types.UnresolvedDataType
- noValidation() - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns an empty validation logic.
- NOW - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- NULL - org.apache.flink.table.api.JsonOnNull
-
Use a JSON
null
value. - NULL - org.apache.flink.table.api.JsonQueryOnEmptyOrError
- NULL - org.apache.flink.table.api.JsonValueOnEmptyOrError
-
Return
NULL
. - NULL - org.apache.flink.table.types.logical.LogicalTypeRoot
- NULL() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type for representing untyped
NULL
values. - NULL_VALUE - Static variable in interface org.apache.flink.table.utils.print.PrintStyle
-
Value used to print
null
. - nullable() - Method in interface org.apache.flink.table.types.AbstractDataType
-
Adds a hint that null values are expected in the data for this type (default behavior).
- nullable() - Method in class org.apache.flink.table.types.AtomicDataType
- nullable() - Method in class org.apache.flink.table.types.CollectionDataType
- nullable() - Method in class org.apache.flink.table.types.FieldsDataType
- nullable() - Method in class org.apache.flink.table.types.KeyValueDataType
- nullable() - Method in class org.apache.flink.table.types.UnresolvedDataType
- nullableIfAllArgs(ConstantArgumentCount, TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
A type strategy that can be used to make a result type nullable if all the selected input arguments are nullable.
- nullableIfAllArgs(TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
A type strategy that can be used to make a result type nullable if all the input arguments is nullable.
- nullableIfArgs(ConstantArgumentCount, TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
A type strategy that can be used to make a result type nullable if any of the selected input arguments is nullable.
- nullableIfArgs(TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
A type strategy that can be used to make a result type nullable if any of the input arguments is nullable.
- NullableIfArgsTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
A type strategy that can be used to make a result type nullable if any or all of the selected input arguments are nullable.
- NullableIfArgsTypeStrategy(ConstantArgumentCount, TypeStrategy, boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.NullableIfArgsTypeStrategy
- NullAwareGetters - Interface in org.apache.flink.table.data.binary
-
Provides null related getters.
- NullAwareMapSerializer<K,V> - Class in org.apache.flink.table.dataview
-
Deprecated.
- NullAwareMapSerializer(TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- NullAwareMapSerializerSnapshot<K,V> - Class in org.apache.flink.table.dataview
-
Deprecated.
- NullAwareMapSerializerSnapshot() - Constructor for class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
-
Deprecated.Constructor for read instantiation.
- NullAwareMapSerializerSnapshot(NullAwareMapSerializer<K, V>) - Constructor for class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
-
Deprecated.Constructor to create the snapshot for writing.
- NullSerializer - Class in org.apache.flink.table.dataview
-
A serializer for null.
- NullSerializer.NullSerializerSnapshot - Class in org.apache.flink.table.dataview
-
Serializer configuration snapshot for compatibility and format evolution.
- NullSerializerSnapshot() - Constructor for class org.apache.flink.table.dataview.NullSerializer.NullSerializerSnapshot
- NullType - Class in org.apache.flink.table.types.logical
-
Logical type for representing untyped
NULL
values. - NullType() - Constructor for class org.apache.flink.table.types.logical.NullType
- number(StringBuilder, int, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- numChars() - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Returns the number of UTF-8 code points in the string.
- NUMERIC - org.apache.flink.table.types.logical.LogicalTypeFamily
O
- OBJECT - org.apache.flink.table.api.JsonType
- OBJECT_ARRAY(TypeInformation<E>) - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Generates type information for an array consisting of Java object elements.
- ObjectIdentifier - Class in org.apache.flink.table.catalog
-
Identifies an object in a catalog.
- ObjectPath - Class in org.apache.flink.table.catalog
-
A database name and object (table/view/function) name combo in a catalog.
- ObjectPath(String, String) - Constructor for class org.apache.flink.table.catalog.ObjectPath
- of(boolean, LogicalType...) - Static method in class org.apache.flink.table.types.logical.RowType
- of(boolean, LogicalType[], String[]) - Static method in class org.apache.flink.table.types.logical.RowType
- of(int) - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
- of(int[]) - Static method in class org.apache.flink.table.connector.Projection
-
Create a
Projection
of the providedindexes
. - of(int[][]) - Static method in class org.apache.flink.table.connector.Projection
-
Create a
Projection
of the providedindexes
. - of(Class<?>) - Static method in class org.apache.flink.table.api.DataTypes
-
Creates an unresolved type that will be resolved to a
DataType
by analyzing the given class later. - of(Object...) - Static method in class org.apache.flink.table.data.GenericRowData
-
Creates an instance of
GenericRowData
with given field values. - of(String) - Static method in class org.apache.flink.table.api.DataTypes
-
Creates an unresolved type that will be resolved to a
DataType
by using a fully or partially defined name. - of(String) - Static method in class org.apache.flink.table.functions.FunctionIdentifier
- of(String) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- of(String...) - Static method in class org.apache.flink.table.catalog.UnresolvedIdentifier
-
Constructs an
UnresolvedIdentifier
from an array of identifier segments. - of(String, String) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- of(String, String, String) - Static method in class org.apache.flink.table.catalog.ObjectIdentifier
- of(String, Configuration) - Static method in class org.apache.flink.table.catalog.CatalogDescriptor
- of(String, Configuration, String) - Static method in class org.apache.flink.table.catalog.CatalogDescriptor
-
Creates an instance of this interface.
- of(String, IntervalFreshness.TimeUnit) - Static method in class org.apache.flink.table.catalog.IntervalFreshness
- of(String, ResolvedExpression) - Static method in class org.apache.flink.table.catalog.WatermarkSpec
- of(String, FunctionDefinition, TypeInference, int, int, boolean) - Static method in interface org.apache.flink.table.types.inference.TypeInferenceUtil.SurroundingInfo
- of(String, DataType) - Static method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Use
TableColumn.physical(String, DataType)
instead. - of(String, DataType, String) - Static method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Use
TableColumn.computed(String, DataType, String)
instead. - of(String, LogicalType) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- of(Function<K, V>) - Static method in class org.apache.flink.table.utils.ThreadLocalCache
- of(List<String>) - Static method in class org.apache.flink.table.catalog.UnresolvedIdentifier
-
Constructs an
UnresolvedIdentifier
from a list of identifier segments. - of(List<Column>) - Static method in class org.apache.flink.table.catalog.ResolvedSchema
-
Shortcut for a resolved schema of only columns.
- of(List<ResolvedExpression>, List<ResolvedExpression>) - Static method in class org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown.Result
-
Constructs a filter push-down result.
- of(List<Signature.Argument>) - Static method in class org.apache.flink.table.types.inference.Signature
-
Creates an immutable instance of
Signature
. - of(InputFormat<RowData, ?>) - Static method in interface org.apache.flink.table.connector.source.InputFormatProvider
-
Helper method for creating a static provider.
- of(InputFormat<RowData, ?>, Integer) - Static method in interface org.apache.flink.table.connector.source.InputFormatProvider
-
Helper method for creating a static provider with a provided source parallelism.
- of(OutputFormat<RowData>) - Static method in interface org.apache.flink.table.connector.sink.OutputFormatProvider
-
Helper method for creating a static provider.
- of(OutputFormat<RowData>, Integer) - Static method in interface org.apache.flink.table.connector.sink.OutputFormatProvider
-
Helper method for creating a static provider with a provided sink parallelism.
- of(TypeInformation<?>) - Static method in class org.apache.flink.table.api.DataTypes
-
Creates an unresolved type that will be resolved to a
DataType
by converting the givenTypeInformation
later. - of(Sink<RowData>) - Static method in interface org.apache.flink.table.connector.sink.SinkV2Provider
-
Helper method for creating a static provider.
- of(Sink<RowData>, Integer) - Static method in interface org.apache.flink.table.connector.sink.SinkV2Provider
-
Helper method for creating a Sink provider with a provided sink parallelism.
- of(Source<RowData, ?, ?>) - Static method in interface org.apache.flink.table.connector.source.SourceProvider
-
Helper method for creating a static provider.
- of(Source<RowData, ?, ?>, Integer) - Static method in interface org.apache.flink.table.connector.source.SourceProvider
-
Helper method for creating a Source provider with a provided source parallelism.
- of(Schema, String, String, String, Map<String, String>) - Static method in interface org.apache.flink.table.catalog.CatalogView
-
Creates a basic implementation of this interface.
- of(Schema, Schema, Map<String, String>, String) - Static method in interface org.apache.flink.table.catalog.CatalogModel
-
Creates a basic implementation of this interface.
- of(CatalogModel, ResolvedSchema, ResolvedSchema) - Static method in interface org.apache.flink.table.catalog.ResolvedCatalogModel
-
Creates a basic implementation of this interface.
- of(Column...) - Static method in class org.apache.flink.table.catalog.ResolvedSchema
-
Shortcut for a resolved schema of only columns.
- of(ObjectIdentifier) - Static method in class org.apache.flink.table.catalog.UnresolvedIdentifier
-
Constructs an
UnresolvedIdentifier
from anObjectIdentifier
. - of(ObjectIdentifier) - Static method in class org.apache.flink.table.functions.FunctionIdentifier
- of(TableDistribution.Kind, Integer, List<String>) - Static method in class org.apache.flink.table.catalog.TableDistribution
-
Distribution of the given kind over the given keys with a declared number of buckets.
- of(ScanTableSource.ScanRuntimeProvider, CacheReloadTrigger) - Static method in interface org.apache.flink.table.connector.source.lookup.FullCachingLookupProvider
-
Build a
FullCachingLookupProvider
from the specifiedScanTableSource.ScanRuntimeProvider
andCacheReloadTrigger
. - of(AsyncLookupFunction) - Static method in interface org.apache.flink.table.connector.source.lookup.AsyncLookupFunctionProvider
-
Helper function for creating a static provider.
- of(AsyncLookupFunction, LookupCache) - Static method in interface org.apache.flink.table.connector.source.lookup.PartialCachingAsyncLookupProvider
- of(AsyncTableFunction<T>) - Static method in interface org.apache.flink.table.legacy.connector.source.AsyncTableFunctionProvider
-
Deprecated.Helper method for creating a static provider.
- of(FunctionKind, TypeInference) - Static method in class org.apache.flink.table.types.inference.SystemTypeInference
- of(LookupFunction) - Static method in interface org.apache.flink.table.connector.source.lookup.LookupFunctionProvider
-
Helper function for creating a static provider.
- of(LookupFunction, LookupCache) - Static method in interface org.apache.flink.table.connector.source.lookup.PartialCachingLookupProvider
- of(TableFunction<T>) - Static method in interface org.apache.flink.table.legacy.connector.source.TableFunctionProvider
-
Deprecated.Helper method for creating a static provider.
- of(DataType) - Static method in interface org.apache.flink.table.types.inference.TypeInferenceUtil.SurroundingInfo
- of(Signature.Argument...) - Static method in class org.apache.flink.table.types.inference.Signature
-
Creates an immutable instance of
Signature
. - of(TypeStrategy) - Static method in interface org.apache.flink.table.types.inference.StateTypeStrategy
- of(LogicalType) - Static method in class org.apache.flink.table.api.DataTypes
-
Creates a
DataType
from aLogicalType
with default conversion class. - of(LogicalType) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- of(LogicalType...) - Static method in class org.apache.flink.table.types.logical.RowType
- of(LogicalType[], String[]) - Static method in class org.apache.flink.table.types.logical.RowType
- of(DateTimeUtils.TimeUnit, DateTimeUtils.TimeUnit) - Static method in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
-
Returns a
TimeUnitRange
with a given start and end unit. - ofDay(String) - Static method in class org.apache.flink.table.catalog.IntervalFreshness
- ofEmptyLiteral() - Static method in class org.apache.flink.table.types.logical.BinaryType
-
The SQL standard defines that character string literals are allowed to be zero-length strings (i.e., to contain no characters) even though it is not permitted to declare a type that is zero.
- ofEmptyLiteral() - Static method in class org.apache.flink.table.types.logical.CharType
-
The SQL standard defines that character string literals are allowed to be zero-length strings (i.e., to contain no characters) even though it is not permitted to declare a type that is zero.
- ofEmptyLiteral() - Static method in class org.apache.flink.table.types.logical.VarBinaryType
-
The SQL standard defines that character string literals are allowed to be zero-length strings (i.e., to contain no characters) even though it is not permitted to declare a type that is zero.
- ofEmptyLiteral() - Static method in class org.apache.flink.table.types.logical.VarCharType
-
The SQL standard defines that character string literals are allowed to be zero-length strings (i.e., to contain no characters) even though it is not permitted to declare a type that is zero.
- offset - Variable in class org.apache.flink.table.data.binary.BinarySection
- offset - Variable in class org.apache.flink.table.data.columnar.vector.BytesColumnVector.Bytes
- ofGroup(Class<? extends Enum<? extends TableSymbol>>) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofGroup(String) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofGroup(String, Class<? extends Enum<? extends TableSymbol>>) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofGroup(String, String) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofGroup(String, LogicalTypeFamily) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofGroup(String, LogicalTypeRoot) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofGroup(LogicalTypeFamily) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofGroup(LogicalTypeRoot) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofGroupVarying(String) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofGroupVarying(String, String) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofHash(List<String>, Integer) - Static method in class org.apache.flink.table.catalog.TableDistribution
-
Hash distribution over the given keys among the declared number of buckets.
- ofHour(String) - Static method in class org.apache.flink.table.catalog.IntervalFreshness
- ofKind(RowKind, Object...) - Static method in class org.apache.flink.table.data.GenericRowData
-
Creates an instance of
GenericRowData
with given kind and field values. - ofMinute(String) - Static method in class org.apache.flink.table.catalog.IntervalFreshness
- ofRange(List<String>, Integer) - Static method in class org.apache.flink.table.catalog.TableDistribution
-
Range distribution over the given keys among the declared number of buckets.
- ofSecond(String) - Static method in class org.apache.flink.table.catalog.IntervalFreshness
- ofUnknown(int) - Static method in class org.apache.flink.table.catalog.TableDistribution
-
Connector-dependent distribution with a declared number of buckets.
- ofUnknown(List<String>, Integer) - Static method in class org.apache.flink.table.catalog.TableDistribution
-
Connector-dependent distribution with a declared number of buckets.
- ofVarying(String) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- ofVarying(String, String) - Static method in class org.apache.flink.table.types.inference.Signature.Argument
- oldColumn - Variable in class org.apache.flink.table.catalog.TableChange.ModifyColumn
- ON_EVENT - org.apache.flink.table.watermark.WatermarkEmitStrategy
-
Emit watermark for every event.
- ON_PERIODIC - org.apache.flink.table.watermark.WatermarkEmitStrategy
-
Emit watermark periodically. the period is configured by
PipelineOptions.AUTO_WATERMARK_INTERVAL
- onCreateTemporaryFunction(ObjectPath, CatalogFunction) - Method in interface org.apache.flink.table.catalog.TemporaryOperationListener
-
This method is called when a temporary function is to be created in this catalog.
- onCreateTemporaryModel(ObjectPath, CatalogModel) - Method in interface org.apache.flink.table.catalog.TemporaryOperationListener
-
This method is called when a temporary model is to be created in this catalog.
- onCreateTemporaryTable(ObjectPath, CatalogBaseTable) - Method in interface org.apache.flink.table.catalog.TemporaryOperationListener
-
This method is called when a temporary table or view is to be created in this catalog.
- onDropTemporaryFunction(ObjectPath) - Method in interface org.apache.flink.table.catalog.TemporaryOperationListener
-
This method is called when a temporary function in this catalog is to be dropped.
- onDropTemporaryModel(ObjectPath) - Method in interface org.apache.flink.table.catalog.TemporaryOperationListener
-
This method is called when a temporary model in this catalog is to be dropped.
- onDropTemporaryTable(ObjectPath) - Method in interface org.apache.flink.table.catalog.TemporaryOperationListener
-
This method is called when a temporary table or view in this catalog is to be dropped.
- open() - Method in class org.apache.flink.table.catalog.AbstractCatalogStore
-
Opens the catalog store.
- open() - Method in interface org.apache.flink.table.catalog.Catalog
-
Open the catalog.
- open() - Method in interface org.apache.flink.table.catalog.CatalogStore
-
Open the catalog store.
- open() - Method in class org.apache.flink.table.catalog.CatalogStoreHolder
- open() - Method in interface org.apache.flink.table.workflow.WorkflowScheduler
-
Open this workflow scheduler instance.
- open(CacheMetricGroup) - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache
- open(CacheMetricGroup) - Method in interface org.apache.flink.table.connector.source.lookup.cache.LookupCache
-
Initialize the cache.
- open(RuntimeConverter.Context) - Method in interface org.apache.flink.table.connector.RuntimeConverter
-
Initializes the converter during runtime.
- open(CacheReloadTrigger.Context) - Method in interface org.apache.flink.table.connector.source.lookup.cache.trigger.CacheReloadTrigger
-
Open the trigger.
- open(CacheReloadTrigger.Context) - Method in class org.apache.flink.table.connector.source.lookup.cache.trigger.PeriodicCacheReloadTrigger
- open(CacheReloadTrigger.Context) - Method in class org.apache.flink.table.connector.source.lookup.cache.trigger.TimedCacheReloadTrigger
- open(CatalogStoreFactory.Context) - Method in interface org.apache.flink.table.factories.CatalogStoreFactory
-
Initialize the CatalogStoreFactory.
- open(FunctionContext) - Method in interface org.apache.flink.table.functions.SpecializedFunction.ExpressionEvaluator
-
Creates and initializes runtime implementation for expression evaluation.
- open(FunctionContext) - Method in class org.apache.flink.table.functions.UserDefinedFunction
-
Setup method for user-defined function.
- OPTIONAL_PARTITION_BY - org.apache.flink.table.annotation.ArgumentTrait
-
Defines that a PARTITION BY clause is optional for
ArgumentTrait.TABLE_AS_SET
. - OPTIONAL_PARTITION_BY - org.apache.flink.table.types.inference.StaticArgumentTrait
- optionalArguments(List<Boolean>) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Deprecated.Use
TypeInference.Builder.staticArguments(List)
instead. - optionalOptions() - Method in interface org.apache.flink.table.factories.Factory
-
Returns a set of
ConfigOption
that an implementation of this factory consumes in addition toFactory.requiredOptions()
. - optionalOptions() - Method in interface org.apache.flink.table.factories.ModuleFactory
- optionalOptions() - Method in class org.apache.flink.table.module.CoreModuleFactory
- options(Map<String, String>) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- options(Map<String, String>) - Method in class org.apache.flink.table.catalog.CatalogTable.Builder
- or(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a disjunction of multiple
ArgumentTypeStrategy
s into one likef(NUMERIC || STRING)
. - or(InputTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a disjunction of multiple
InputTypeStrategy
s into one likef(NUMERIC) || f(STRING)
. - OR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- OrArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for inferring and validating an argument using a disjunction of multiple
ArgumentTypeStrategy
s into one likef(NUMERIC || STRING)
. - OrArgumentTypeStrategy(List<? extends ArgumentTypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.OrArgumentTypeStrategy
- ORDER_ASC - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ORDER_DESC - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- orderByColumns() - Method in interface org.apache.flink.table.functions.TableSemantics
-
Returns information about how the passed table is ordered.
- ORDERING - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- org.apache.flink.table.annotation - package org.apache.flink.table.annotation
- org.apache.flink.table.api - package org.apache.flink.table.api
- org.apache.flink.table.api.dataview - package org.apache.flink.table.api.dataview
- org.apache.flink.table.catalog - package org.apache.flink.table.catalog
- org.apache.flink.table.catalog.exceptions - package org.apache.flink.table.catalog.exceptions
- org.apache.flink.table.catalog.stats - package org.apache.flink.table.catalog.stats
- org.apache.flink.table.connector - package org.apache.flink.table.connector
- org.apache.flink.table.connector.format - package org.apache.flink.table.connector.format
- org.apache.flink.table.connector.sink - package org.apache.flink.table.connector.sink
- org.apache.flink.table.connector.sink.abilities - package org.apache.flink.table.connector.sink.abilities
- org.apache.flink.table.connector.source - package org.apache.flink.table.connector.source
- org.apache.flink.table.connector.source.abilities - package org.apache.flink.table.connector.source.abilities
- org.apache.flink.table.connector.source.lookup - package org.apache.flink.table.connector.source.lookup
- org.apache.flink.table.connector.source.lookup.cache - package org.apache.flink.table.connector.source.lookup.cache
- org.apache.flink.table.connector.source.lookup.cache.trigger - package org.apache.flink.table.connector.source.lookup.cache.trigger
- org.apache.flink.table.data - package org.apache.flink.table.data
- org.apache.flink.table.data.binary - package org.apache.flink.table.data.binary
- org.apache.flink.table.data.columnar - package org.apache.flink.table.data.columnar
- org.apache.flink.table.data.columnar.vector - package org.apache.flink.table.data.columnar.vector
- org.apache.flink.table.data.columnar.vector.heap - package org.apache.flink.table.data.columnar.vector.heap
- org.apache.flink.table.data.columnar.vector.writable - package org.apache.flink.table.data.columnar.vector.writable
- org.apache.flink.table.data.utils - package org.apache.flink.table.data.utils
- org.apache.flink.table.dataview - package org.apache.flink.table.dataview
- org.apache.flink.table.descriptors - package org.apache.flink.table.descriptors
- org.apache.flink.table.expressions - package org.apache.flink.table.expressions
- org.apache.flink.table.factories - package org.apache.flink.table.factories
- org.apache.flink.table.functions - package org.apache.flink.table.functions
- org.apache.flink.table.functions.python - package org.apache.flink.table.functions.python
- org.apache.flink.table.functions.python.utils - package org.apache.flink.table.functions.python.utils
- org.apache.flink.table.legacy.api - package org.apache.flink.table.legacy.api
- org.apache.flink.table.legacy.api.constraints - package org.apache.flink.table.legacy.api.constraints
- org.apache.flink.table.legacy.connector.source - package org.apache.flink.table.legacy.connector.source
- org.apache.flink.table.legacy.descriptors - package org.apache.flink.table.legacy.descriptors
- org.apache.flink.table.legacy.factories - package org.apache.flink.table.legacy.factories
- org.apache.flink.table.legacy.sinks - package org.apache.flink.table.legacy.sinks
- org.apache.flink.table.legacy.sources - package org.apache.flink.table.legacy.sources
- org.apache.flink.table.legacy.sources.tsextractors - package org.apache.flink.table.legacy.sources.tsextractors
- org.apache.flink.table.legacy.types.logical - package org.apache.flink.table.legacy.types.logical
- org.apache.flink.table.legacy.utils - package org.apache.flink.table.legacy.utils
- org.apache.flink.table.module - package org.apache.flink.table.module
- org.apache.flink.table.plan.stats - package org.apache.flink.table.plan.stats
- org.apache.flink.table.procedures - package org.apache.flink.table.procedures
- org.apache.flink.table.refresh - package org.apache.flink.table.refresh
- org.apache.flink.table.resource - package org.apache.flink.table.resource
- org.apache.flink.table.sinks - package org.apache.flink.table.sinks
- org.apache.flink.table.sources - package org.apache.flink.table.sources
- org.apache.flink.table.sources.tsextractors - package org.apache.flink.table.sources.tsextractors
- org.apache.flink.table.sources.wmstrategies - package org.apache.flink.table.sources.wmstrategies
- org.apache.flink.table.types - package org.apache.flink.table.types
- org.apache.flink.table.types.extraction - package org.apache.flink.table.types.extraction
- org.apache.flink.table.types.inference - package org.apache.flink.table.types.inference
- org.apache.flink.table.types.inference.strategies - package org.apache.flink.table.types.inference.strategies
- org.apache.flink.table.types.inference.transforms - package org.apache.flink.table.types.inference.transforms
- org.apache.flink.table.types.inference.utils - package org.apache.flink.table.types.inference.utils
- org.apache.flink.table.types.logical - package org.apache.flink.table.types.logical
- org.apache.flink.table.types.logical.utils - package org.apache.flink.table.types.logical.utils
- org.apache.flink.table.types.utils - package org.apache.flink.table.types.utils
- org.apache.flink.table.typeutils - package org.apache.flink.table.typeutils
- org.apache.flink.table.utils - package org.apache.flink.table.utils
- org.apache.flink.table.utils.print - package org.apache.flink.table.utils.print
- org.apache.flink.table.watermark - package org.apache.flink.table.watermark
- org.apache.flink.table.workflow - package org.apache.flink.table.workflow
- OrInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for inferring and validating the input using a disjunction of multiple
InputTypeStrategy
s into one likef(NUMERIC) || f(STRING)
. - OrInputTypeStrategy(List<? extends InputTypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.OrInputTypeStrategy
- OTHER - org.apache.flink.table.functions.FunctionKind
- output() - Method in annotation type org.apache.flink.table.annotation.FunctionHint
-
Explicitly defines the result type that a function uses as output.
- output() - Method in annotation type org.apache.flink.table.annotation.ProcedureHint
-
Explicitly defines the result type that a procedure uses as output.
- OUTPUT_IF_NULL - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for inferring an unknown argument type from the function's output
DataType
if available. - OutputArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for inferring an unknown argument type from the function's output
DataType
if available. - OutputArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.OutputArgumentTypeStrategy
- OutputFormatProvider - Interface in org.apache.flink.table.connector.sink
-
Provider of an
OutputFormat
instance as a runtime implementation forDynamicTableSink
. - outputTypeStrategy(TypeStrategy) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
- outputTypeStrategy(TypeStrategy) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets the strategy for inferring the final output data type of a function call.
- OVER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- OVER - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
- OVER - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
See
OverTypeStrategy
. - OVER_WINDOW_ONLY - org.apache.flink.table.functions.FunctionRequirement
-
Requirement that an aggregate function can only be applied in an OVER window.
- OVERLAY - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- OVERLAY - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Special sql syntax for OVERLAY.
- OverTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Specific
InputTypeStrategy
forBuiltInFunctionDefinitions.OVER
. - OverTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.OverTypeStrategy
- OverWindowRange - Enum in org.apache.flink.table.api
-
Range specification for
BuiltInFunctionDefinitions.OVER
window. - OverwritableTableSink - Interface in org.apache.flink.table.legacy.sinks
-
Deprecated.This interface will not be supported in the new sink design around
DynamicTableSink
. UseSupportsOverwrite
instead. See FLIP-95 for more information.
P
- PANDAS - org.apache.flink.table.functions.python.PythonFunctionKind
- ParallelismProvider - Interface in org.apache.flink.table.connector
-
Parallelism provider for other connector providers.
- parameterNames - Variable in class org.apache.flink.table.types.extraction.ExtractionUtils.AssigningConstructor
- parse(String, ClassLoader) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeParser
-
Parses a type string.
- PARSE_URL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- parseDate(String) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- parseDate(String, String) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Returns the epoch days since 1970-01-01.
- parseTime(String) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- parseTimestampData(String) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- parseTimestampData(String, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- parseTimestampData(String, int, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- parseTimestampData(String, String) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- PARTIAL - org.apache.flink.table.connector.source.lookup.LookupOptions.LookupCacheType
- PARTIAL_CACHE_CACHE_MISSING_KEY - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- PARTIAL_CACHE_EXPIRE_AFTER_ACCESS - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- PARTIAL_CACHE_EXPIRE_AFTER_WRITE - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- PARTIAL_CACHE_MAX_ROWS - Static variable in class org.apache.flink.table.connector.source.lookup.LookupOptions
- PartialCachingAsyncLookupProvider - Interface in org.apache.flink.table.connector.source.lookup
-
Provider for creating
AsyncLookupFunction
andLookupCache
for storing lookup entries. - PartialCachingLookupProvider - Interface in org.apache.flink.table.connector.source.lookup
-
Provider for creating
LookupFunction
andLookupCache
for storing lookup entries. - partition(RowData, int) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsLookupCustomShuffle.InputDataPartitioner
-
Determining the partition id for each input data.
- PARTITION_KEYS - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- PartitionableTableSink - Interface in org.apache.flink.table.legacy.sinks
-
Deprecated.This interface will not be supported in the new sink design around
DynamicTableSink
. UseSupportsPartitioning
instead. See FLIP-95 for more information. - PartitionableTableSource - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.This interface will not be supported in the new source design around
DynamicTableSource
. UseSupportsPartitionPushDown
instead. See FLIP-95 for more information. - PartitionAlreadyExistsException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to create a partition that already exists.
- PartitionAlreadyExistsException(String, ObjectPath, CatalogPartitionSpec) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionAlreadyExistsException
- PartitionAlreadyExistsException(String, ObjectPath, CatalogPartitionSpec, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionAlreadyExistsException
- partitionByColumns() - Method in interface org.apache.flink.table.functions.TableSemantics
-
Returns information about how the passed table is partitioned.
- partitionExists(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
-
Check whether a partition exists or not.
- partitionKeys(List<String>) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- partitionKeys(List<String>) - Method in class org.apache.flink.table.catalog.CatalogTable.Builder
- PartitionNotExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for operation on a partition that doesn't exist.
- PartitionNotExistException(String, ObjectPath, CatalogPartitionSpec) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionNotExistException
- PartitionNotExistException(String, ObjectPath, CatalogPartitionSpec, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionNotExistException
- PartitionPathUtils - Class in org.apache.flink.table.utils
-
Utils for file system.
- PartitionPathUtils() - Constructor for class org.apache.flink.table.utils.PartitionPathUtils
- PartitionSpecInvalidException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for invalid PartitionSpec compared with partition key list of a partitioned Table.
- PartitionSpecInvalidException(String, List<String>, ObjectPath, CatalogPartitionSpec) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionSpecInvalidException
- PartitionSpecInvalidException(String, List<String>, ObjectPath, CatalogPartitionSpec, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionSpecInvalidException
- PASS_COLUMNS_THROUGH - org.apache.flink.table.annotation.ArgumentTrait
-
Defines that all columns of a table argument (i.e.
- PASS_COLUMNS_THROUGH - org.apache.flink.table.types.inference.StaticArgumentTrait
- percentage(boolean) - Static method in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
An
ArgumentTypeStrategy
that expects a percentage value between [0.0, 1.0]. - PercentageArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
ArgumentTypeStrategy
that expects a percentage value between [0.0, 1.0]. - PercentageArgumentTypeStrategy(boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.PercentageArgumentTypeStrategy
- percentageArray(boolean) - Static method in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
An
ArgumentTypeStrategy
that expects an array of percentages with each element between [0.0, 1.0]. - PercentageArrayArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
ArgumentTypeStrategy
that expects an array of percentages with each element between [0.0, 1.0]. - PercentageArrayArgumentTypeStrategy(boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.PercentageArrayArgumentTypeStrategy
- PERCENTILE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- PERCENTILE - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
Type strategy specific for
BuiltInFunctionDefinitions.PERCENTILE
. - PERIODIC - org.apache.flink.table.connector.source.lookup.LookupOptions.ReloadStrategy
- PeriodicCacheReloadTrigger - Class in org.apache.flink.table.connector.source.lookup.cache.trigger
-
A trigger that reloads cache entries periodically with specified interval and
PeriodicCacheReloadTrigger.ScheduleMode
. - PeriodicCacheReloadTrigger(Duration, PeriodicCacheReloadTrigger.ScheduleMode) - Constructor for class org.apache.flink.table.connector.source.lookup.cache.trigger.PeriodicCacheReloadTrigger
- PeriodicCacheReloadTrigger.ScheduleMode - Enum in org.apache.flink.table.connector.source.lookup.cache.trigger
-
Defines the mode how to schedule cache reloads.
- permanent(BuiltInFunctionDefinition, List<ResolvedExpression>, DataType) - Static method in class org.apache.flink.table.expressions.CallExpression
-
Creates a
CallExpression
to a resolved built-in function. - permanent(FunctionIdentifier, FunctionDefinition, List<ResolvedExpression>, DataType) - Static method in class org.apache.flink.table.expressions.CallExpression
- physical(String[], DataType[]) - Static method in class org.apache.flink.table.catalog.ResolvedSchema
-
Shortcut for a resolved schema of only physical columns.
- physical(String, DataType) - Static method in class org.apache.flink.table.catalog.Column
-
Creates a regular table column that represents physical data.
- physical(String, DataType) - Static method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.Creates a regular table column that represents physical data.
- physical(List<String>, List<DataType>) - Static method in class org.apache.flink.table.catalog.ResolvedSchema
-
Shortcut for a resolved schema of only physical columns.
- PI - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- PLACEHOLDER_SYMBOL - Static variable in class org.apache.flink.table.factories.FactoryUtil
-
The placeholder symbol to be used for keys of options which can be templated.
- PLUS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
Combines numeric addition, "datetime + interval"/"interval + interval" arithmetic, and string concatenation.
- PLUS_OP - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Syntax for unparsing '+', Special handling for a plus on string arguments.
- pointTo(MemorySegment[], int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- pointTo(MemorySegment[], int, int) - Method in class org.apache.flink.table.data.binary.BinaryMapData
- pointTo(MemorySegment[], int, int) - Method in class org.apache.flink.table.data.binary.BinarySection
- pointTo(MemorySegment, int, int) - Method in class org.apache.flink.table.data.binary.BinarySection
- POSITION - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- POWER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- precision() - Method in class org.apache.flink.table.data.DecimalData
-
Returns the precision of this
DecimalData
. - PRECISION - Static variable in class org.apache.flink.table.types.logical.BigIntType
- PRECISION - Static variable in class org.apache.flink.table.types.logical.DoubleType
- PRECISION - Static variable in class org.apache.flink.table.types.logical.FloatType
- PRECISION - Static variable in class org.apache.flink.table.types.logical.IntType
- PRECISION - Static variable in class org.apache.flink.table.types.logical.SmallIntType
- PRECISION - Static variable in class org.apache.flink.table.types.logical.TinyIntType
- PREDEFINED - org.apache.flink.table.types.logical.LogicalTypeFamily
- preferCustomShuffle() - Method in interface org.apache.flink.table.connector.source.LookupTableSource.LookupContext
-
Whether the distribution of the input stream data matches the partitioner provided by the
LookupTableSource
. - prepareInstance(ReadableConfig, UserDefinedFunction) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Prepares a
UserDefinedFunction
instance for usage in the API. - PreserveWatermarks - Class in org.apache.flink.table.sources.wmstrategies
-
A strategy which indicates the watermarks should be preserved from the underlying datastream.
- PreserveWatermarks() - Constructor for class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
- PRIMARY_KEY - org.apache.flink.table.catalog.Constraint.ConstraintType
- PRIMARY_KEY - org.apache.flink.table.legacy.api.constraints.Constraint.ConstraintType
-
Deprecated.
- PRIMARY_KEY_COLUMNS - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- PRIMARY_KEY_NAME - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- primaryKey(String...) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a primary key constraint for a set of given columns.
- primaryKey(String...) - Method in class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.Creates a primary key constraint for a set of given columns.
- primaryKey(String, String[]) - Method in class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.Creates a primary key constraint for a set of given columns.
- primaryKey(String, List<String>) - Static method in class org.apache.flink.table.catalog.UniqueConstraint
-
Creates a non enforced
Constraint.ConstraintType.PRIMARY_KEY
constraint. - primaryKey(String, List<String>) - Static method in class org.apache.flink.table.legacy.api.constraints.UniqueConstraint
-
Deprecated.Creates a non enforced
Constraint.ConstraintType.PRIMARY_KEY
constraint. - primaryKey(List<String>) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a primary key constraint for a set of given columns.
- primaryKeyNamed(String, String...) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a primary key constraint for a set of given columns.
- primaryKeyNamed(String, List<String>) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a primary key constraint for a set of given columns.
- PRIMITIVE_ARRAY(TypeInformation<?>) - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Generates type information for an array consisting of Java primitive elements.
- primitiveToWrapper(Class<?>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Converts the specified primitive Class object to its corresponding wrapper Class object.
- print(Iterator<RowData>, PrintWriter) - Method in interface org.apache.flink.table.utils.print.PrintStyle
-
Displays the result.
- print(Iterator<RowData>, PrintWriter) - Method in class org.apache.flink.table.utils.print.RawContentStyle
- print(Iterator<RowData>, PrintWriter) - Method in class org.apache.flink.table.utils.print.TableauStyle
- printBorderLine(PrintWriter) - Method in class org.apache.flink.table.utils.print.TableauStyle
- printColumnNamesTableauRow(PrintWriter) - Method in class org.apache.flink.table.utils.print.TableauStyle
- printEmptyResult(Iterator<RowData>, PrintWriter) - Method in class org.apache.flink.table.utils.print.TableauStyle
- PRINTF - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- printFooter(PrintWriter, long) - Method in class org.apache.flink.table.utils.print.TableauStyle
- PrintStyle - Interface in org.apache.flink.table.utils.print
-
A
PrintStyle
defines style and formatting to print a collection ofRowData
. - printTable(Iterator<RowData>, PrintWriter) - Method in class org.apache.flink.table.utils.print.TableauStyle
-
Print table with column names and borders.
- printTableauRow(String[], PrintWriter) - Method in class org.apache.flink.table.utils.print.TableauStyle
- Procedure - Interface in org.apache.flink.table.procedures
-
Base interface representing a stored procedure that can be executed by Flink.
- PROCEDURE_CALL - Static variable in class org.apache.flink.table.procedures.ProcedureDefinition
-
the name for the methods to be involved in the procedure.
- ProcedureDefinition - Class in org.apache.flink.table.procedures
-
Definition of a procedure.
- ProcedureDefinition(Procedure) - Constructor for class org.apache.flink.table.procedures.ProcedureDefinition
- ProcedureHint - Annotation Type in org.apache.flink.table.annotation
-
A hint that influences the reflection-based extraction of arguments and output for constructing the
TypeInference
logic of aProcedure
. - ProcedureHints - Annotation Type in org.apache.flink.table.annotation
-
Helper annotation for repeatable
ProcedureHint
s. - ProcedureNotExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to operate on a procedure that doesn't exist.
- ProcedureNotExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.ProcedureNotExistException
- ProcedureNotExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.ProcedureNotExistException
- PROCESS - org.apache.flink.table.functions.python.PythonEnv.ExecType
- PROCESS_TABLE - org.apache.flink.table.functions.FunctionKind
- PROCESS_TABLE_EVAL - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- ProcessTableFunction<T> - Class in org.apache.flink.table.functions
-
Base class for a user-defined process table function.
- ProcessTableFunction() - Constructor for class org.apache.flink.table.functions.ProcessTableFunction
- ProcessTableFunction.Context - Interface in org.apache.flink.table.functions
-
Context that can be added as a first argument to the eval() method for additional information about the input tables and other services provided by the framework.
- proctime() - Method in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.Specifies the previously defined field as a processing-time attribute.
- PROCTIME - org.apache.flink.table.types.logical.TimestampKind
- PROCTIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- PROCTIME_BATCH_MARKER - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- PROCTIME_INDICATOR - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- PROCTIME_STREAM_MARKER - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- project(DataType) - Method in class org.apache.flink.table.connector.Projection
-
Projects a (possibly nested) row data type by returning a new data type that only includes fields of the given index paths.
- project(LogicalType) - Method in class org.apache.flink.table.connector.Projection
-
Same as
Projection.project(DataType)
, but accepting and returningLogicalType
. - ProjectableDecodingFormat<I> - Interface in org.apache.flink.table.connector.format
-
Extension of
DecodingFormat
which is able to produce projected rows. - ProjectableTableSource<T> - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.This interface will not be supported in the new source design around
DynamicTableSource
. UseSupportsProjectionPushDown
instead. See FLIP-95 for more information. - ProjectedRowData - Class in org.apache.flink.table.data.utils
- projectFields(int[]) - Method in interface org.apache.flink.table.legacy.sources.ProjectableTableSource
-
Deprecated.Creates a copy of the
TableSource
that projects its output to the given field indexes. - Projection - Class in org.apache.flink.table.connector
-
Projection
represents a list of (possibly nested) indexes that can be used to project data types. - projectNestedFields(int[], String[][]) - Method in interface org.apache.flink.table.legacy.sources.NestedFieldsProjectableTableSource
-
Deprecated.Creates a copy of the
TableSource
that projects its output to the given field indexes. - projectRow(DataType, int[]) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Deprecated.Use the
Projection
type - projectRow(DataType, int[][]) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Deprecated.Use the
Projection
type - PROPERTY_VERSION - Static variable in class org.apache.flink.table.factories.FactoryUtil
-
Describes the property version.
- put(K, V) - Method in class org.apache.flink.table.api.dataview.MapView
-
Inserts a value for the given key into the map view.
- put(RowData, Collection<RowData>) - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache
- put(RowData, Collection<RowData>) - Method in interface org.apache.flink.table.connector.source.lookup.cache.LookupCache
-
Associates the specified value rows with the specified key row in the cache.
- putAll(Map<K, V>) - Method in class org.apache.flink.table.api.dataview.MapView
-
Inserts all mappings from the specified map to this map view.
- putBoolean(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds a boolean under the given key.
- putCharacter(String, char) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds a character under the given key.
- putClass(String, Class<?>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds a class under the given key.
- putIndexedFixedProperties(String, List<String>, List<List<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds an indexed sequence of properties (with sub-properties) under a common key.
- putIndexedOptionalProperties(String, List<String>, List<List<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds an indexed sequence of properties (with sub-properties) under a common key.
- putIndexedVariableProperties(String, List<Map<String, String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds an indexed mapping of properties under a common key.
- putInt(String, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds an integer under the given key.
- putLong(String, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds a long under the given key.
- putMemorySize(String, MemorySize) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds a Flink
MemorySize
under the given key. - putPartitionKeys(List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds table partition keys.
- putProperties(Map<String, String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds a set of properties.
- putProperties(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds a set of descriptor properties.
- putPropertiesWithPrefix(String, Map<String, String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds a properties map by appending the given prefix to element keys with a dot.
- putString(String, String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds a string under the given key.
- putTableSchema(String, TableSchema) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Adds a table schema under the given key.
- PYTHON - org.apache.flink.table.catalog.FunctionLanguage
- PythonAggregateFunction - Class in org.apache.flink.table.functions.python
-
The wrapper of user defined python aggregate function.
- PythonAggregateFunction(String, byte[], String[], String, String, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonAggregateFunction
- PythonAggregateFunction(String, byte[], PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonAggregateFunction
- PythonAggregateFunction(String, byte[], DataType[], DataType, DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonAggregateFunction
- PythonAggregateFunctionInfo - Class in org.apache.flink.table.functions.python
-
PythonAggregateFunctionInfo contains the execution information of a Python aggregate function, such as: the actual Python aggregation function, the input arguments, the filter arg, the distinct flag, etc.
- PythonAggregateFunctionInfo(PythonFunction, Object[], int, boolean) - Constructor for class org.apache.flink.table.functions.python.PythonAggregateFunctionInfo
- PythonEnv - Class in org.apache.flink.table.functions.python
-
Python execution environments.
- PythonEnv(PythonEnv.ExecType) - Constructor for class org.apache.flink.table.functions.python.PythonEnv
- PythonEnv.ExecType - Enum in org.apache.flink.table.functions.python
-
The Execution type specifies how to execute the Python function.
- PythonFunction - Interface in org.apache.flink.table.functions.python
-
The base interface of a wrapper of a Python function.
- PythonFunctionInfo - Class in org.apache.flink.table.functions.python
-
PythonFunctionInfo contains the execution information of a Python function, such as: the actual Python function, the input arguments, etc.
- PythonFunctionInfo(PythonFunction, Object[]) - Constructor for class org.apache.flink.table.functions.python.PythonFunctionInfo
- PythonFunctionKind - Enum in org.apache.flink.table.functions.python
-
Categorizes the Python functions.
- PythonFunctionUtils - Enum in org.apache.flink.table.functions.python.utils
-
Utilities for creating PythonFunction from the fully qualified name of a Python function.
- PythonScalarFunction - Class in org.apache.flink.table.functions.python
-
The wrapper of user defined python scalar function.
- PythonScalarFunction(String, byte[], String[], String, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonScalarFunction
- PythonScalarFunction(String, byte[], PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonScalarFunction
- PythonScalarFunction(String, byte[], DataType[], DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonScalarFunction
- PythonTableAggregateFunction - Class in org.apache.flink.table.functions.python
-
The wrapper of user defined python table aggregate function.
- PythonTableAggregateFunction(String, byte[], String[], String, String, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- PythonTableAggregateFunction(String, byte[], PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- PythonTableAggregateFunction(String, byte[], DataType[], DataType, DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- PythonTableFunction - Class in org.apache.flink.table.functions.python
-
The wrapper of user defined python table function.
- PythonTableFunction(String, byte[], String[], String, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonTableFunction
- PythonTableFunction(String, byte[], PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonTableFunction
- PythonTableFunction(String, byte[], DataType[], DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonTableFunction
Q
- qualifyFunctionName(String, int) - Static method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- QUARTER - org.apache.flink.table.expressions.TimeIntervalUnit
- QUARTER - org.apache.flink.table.expressions.TimePointUnit
- QUARTER - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- QUARTER - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
R
- RADIANS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- RAND - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- RAND_INTEGER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- range(int, int) - Static method in class org.apache.flink.table.connector.Projection
-
Create a
Projection
of a field range. - RANGE - org.apache.flink.table.catalog.TableDistribution.Kind
- RANGE_TO - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- RAW - org.apache.flink.table.types.logical.LogicalTypeRoot
- RAW(Class<T>) - Static method in class org.apache.flink.table.api.DataTypes
-
Unresolved data type of an arbitrary serialized type.
- RAW(Class<T>, TypeSerializer<T>) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of an arbitrary serialized type.
- RAW(TypeInformation<T>) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of an arbitrary serialized type backed by
TypeInformation
. - rawContent(RowDataToStringConverter) - Static method in interface org.apache.flink.table.utils.print.PrintStyle
-
Create a raw content print style, which only print the result content as raw form. column delimiter is ",", row delimiter is "\n".
- RawContentStyle - Class in org.apache.flink.table.utils.print
-
Print only the result content as raw form. column delimiter is ",", row delimiter is "\n".
- rawSerializer() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
Adds a hint that defines a custom serializer that should be used for serializing and deserializing opaque RAW types.
- RawType<T> - Class in org.apache.flink.table.types.logical
-
Logical type of an arbitrary serialized type.
- RawType(boolean, Class<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.table.types.logical.RawType
- RawType(Class<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.table.types.logical.RawType
- RawValueData<T> - Interface in org.apache.flink.table.data
-
An internal data structure representing data of
RawType
. - readArrayData(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Gets an instance of
ArrayData
from underlyingMemorySegment
. - readBinary(MemorySegment[], int, int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Get binary, if len less than 8, will be include in variablePartOffsetAndLen.
- readDecimalData(MemorySegment[], int, long, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Gets an instance of
DecimalData
from underlyingMemorySegment
. - readMapData(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Gets an instance of
MapData
from underlyingMemorySegment
. - readRawValueData(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Gets an instance of
RawValueData
from underlyingMemorySegment
. - readRowData(MemorySegment[], int, int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Gets an instance of
RowData
from underlyingMemorySegment
. - readStringData(MemorySegment[], int, int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Get binary string, if len less than 8, will be include in variablePartOffsetAndLen.
- readTimestampData(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Gets an instance of
TimestampData
from underlyingMemorySegment
. - readTypeInfo(String) - Static method in class org.apache.flink.table.legacy.utils.TypeStringUtils
-
Deprecated.
- RefreshHandler - Interface in org.apache.flink.table.refresh
-
This interface represents the meta information of current materialized table background refresh pipeline.
- refreshHandlerDescription(String) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- RefreshHandlerSerializer<T extends RefreshHandler> - Interface in org.apache.flink.table.refresh
-
This interface is used to serialize and deserialize the
RefreshHandler
. - refreshMode(CatalogMaterializedTable.RefreshMode) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- refreshStatus(CatalogMaterializedTable.RefreshStatus) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- RefreshWorkflow - Interface in org.apache.flink.table.workflow
-
RefreshWorkflow
is the basic interface that provide the related information to operate the refresh workflow ofCatalogMaterializedTable
, the operation of refresh workflow include create, modify, drop, etc. - REGEXP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- REGEXP_COUNT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- REGEXP_EXTRACT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- REGEXP_EXTRACT_ALL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- REGEXP_INSTR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- REGEXP_REPLACE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- REGEXP_SUBSTR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- REGULAR - org.apache.flink.table.types.logical.TimestampKind
- REINTERPRET_CAST - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- REINTERPRET_CAST - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
- ReinterpretCastInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
InputTypeStrategy
specific forBuiltInFunctionDefinitions.REINTERPRET_CAST
. - ReinterpretCastInputTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.ReinterpretCastInputTypeStrategy
- REMAINING_ROWS - org.apache.flink.table.connector.sink.abilities.SupportsRowLevelDelete.RowLevelDeleteMode
- remove(K) - Method in class org.apache.flink.table.api.dataview.MapView
-
Deletes the value for the given key.
- remove(T) - Method in class org.apache.flink.table.api.dataview.ListView
-
Removes the given value from the list.
- removeCatalog(String, boolean) - Method in interface org.apache.flink.table.catalog.CatalogStore
-
Remove a catalog with the given catalog name.
- removeTimeAttribute(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Removes time attributes from the
DataType
. - removeTimeAttributeFromResolvedSchema(ResolvedSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
-
Removes time attributes from the
ResolvedSchema
. - removeTimeAttributes(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
- rename(String) - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
- rename(String) - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
- rename(String) - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
- rename(String) - Method in class org.apache.flink.table.catalog.Column
-
Returns a copy of the column with a replaced name.
- renameModel(ObjectPath, String, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Rename an existing model.
- renameRowFields(RowType, List<String>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
-
Renames the fields of the given
RowType
. - renameTable(ObjectPath, String, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Rename an existing table or view.
- repeat(char, int) - Static method in class org.apache.flink.table.utils.EncodingUtils
-
Returns padding using the specified delimiter repeated to a given length.
- repeat(String, int) - Static method in class org.apache.flink.table.utils.EncodingUtils
-
Repeat a String
repeat
times to form a new String. - REPEAT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- repeatingSequence(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Arbitrarily often repeating sequence of argument type strategies.
- RepeatingSequenceInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
InputTypeStrategy
composed of an arbitrarily often repeating list ofArgumentTypeStrategy
s. - RepeatingSequenceInputTypeStrategy(List<ArgumentTypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.RepeatingSequenceInputTypeStrategy
- replace(RowData, RowData) - Method in class org.apache.flink.table.data.utils.JoinedRowData
-
Replaces the
RowData
backing thisJoinedRowData
. - REPLACE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- REPLACE_TABLE_AS - org.apache.flink.table.connector.sink.abilities.SupportsStaging.StagingPurpose
- replaceArgs(List<ResolvedExpression>, DataType) - Method in class org.apache.flink.table.expressions.CallExpression
- replaceLogicalType(DataType, LogicalType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Replaces the
LogicalType
of aDataType
, i.e., it keeps the bridging class. - replaceRow(RowData) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
-
Replaces the underlying
RowData
backing thisProjectedRowData
. - reportStatistics() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsStatisticReport
-
Returns the estimated statistics of this
DynamicTableSource
, elseTableStats.UNKNOWN
if some situations are not supported or cannot be handled. - reportStatistics(List<Path>, DataType) - Method in interface org.apache.flink.table.connector.format.FileBasedStatisticsReportableInputFormat
-
Returns the estimated statistics of this input format.
- requiredColumns() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsRowLevelDelete.RowLevelDeleteInfo
-
The required columns by the sink to perform row-level delete.
- requiredColumns() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsRowLevelUpdate.RowLevelUpdateInfo
-
The required columns by the sink to perform row-level update.
- requiredContext() - Method in interface org.apache.flink.table.legacy.factories.TableFactory
-
Deprecated.Specifies the context that this factory has been implemented for.
- requiredOptions() - Method in interface org.apache.flink.table.factories.Factory
-
Returns a set of
ConfigOption
that an implementation of this factory requires in addition toFactory.optionalOptions()
. - requiredOptions() - Method in interface org.apache.flink.table.factories.ModuleFactory
- requiredOptions() - Method in class org.apache.flink.table.module.CoreModuleFactory
- requiresBucketCount() - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsBucketing
-
Returns whether the
DynamicTableSink
requires a bucket count. - requiresPartitionGrouping(boolean) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsPartitioning
-
Returns whether data needs to be grouped by partition before it is consumed by the sink.
- reserveDictionaryIds(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- reserveDictionaryIds(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapBooleanVector
- reserveDictionaryIds(int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableColumnVector
-
Reserve a integer column for ids of dictionary.
- reset() - Method in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
-
Resets the column to default state. - fills the isNull array with false. - sets noNulls to true.
- reset() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapBytesVector
- reset() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapRowVector
- reset() - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableColumnVector
-
Resets the column to default state.
- reset(String) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to reset the table option.
- ResetOption(String) - Constructor for class org.apache.flink.table.catalog.TableChange.ResetOption
- resolve(ExecutionConfig) - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- resolve(Schema) - Method in interface org.apache.flink.table.catalog.SchemaResolver
- resolve(SchemaResolver) - Method in class org.apache.flink.table.api.Schema
-
Resolves the given
Schema
to a validatedResolvedSchema
. - ResolvedCatalogBaseTable<T extends CatalogBaseTable> - Interface in org.apache.flink.table.catalog
-
A common parent that describes the resolved metadata of a table or view in a catalog.
- ResolvedCatalogMaterializedTable - Class in org.apache.flink.table.catalog
-
A validated
CatalogMaterializedTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework. - ResolvedCatalogMaterializedTable(CatalogMaterializedTable, ResolvedSchema) - Constructor for class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- ResolvedCatalogModel - Interface in org.apache.flink.table.catalog
-
A validated
CatalogModel
that is backed by the original metadata coming from theCatalog
but resolved by the framework. - ResolvedCatalogTable - Class in org.apache.flink.table.catalog
-
A validated
CatalogTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework. - ResolvedCatalogTable(CatalogTable, ResolvedSchema) - Constructor for class org.apache.flink.table.catalog.ResolvedCatalogTable
- ResolvedCatalogView - Class in org.apache.flink.table.catalog
-
A validated
CatalogView
that is backed by the original metadata coming from theCatalog
but resolved by the framework. - ResolvedCatalogView(CatalogView, ResolvedSchema) - Constructor for class org.apache.flink.table.catalog.ResolvedCatalogView
- ResolvedExpression - Interface in org.apache.flink.table.expressions
-
Expression that has been fully resolved and validated.
- ResolvedFieldReference - Class in org.apache.flink.table.expressions
-
A reference to a field in an input which has been resolved.
- ResolvedFieldReference(String, TypeInformation<?>, int) - Constructor for class org.apache.flink.table.expressions.ResolvedFieldReference
- ResolvedSchema - Class in org.apache.flink.table.catalog
-
Schema of a table or view consisting of columns, constraints, and watermark specifications.
- ResolvedSchema(List<Column>, List<WatermarkSpec>, UniqueConstraint) - Constructor for class org.apache.flink.table.catalog.ResolvedSchema
- resolveVariableWithClassContext(Type, Type) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Resolves a variable type while accepting a context for resolution.
- ResourceType - Enum in org.apache.flink.table.resource
-
An enum that represents the type of resource.
- ResourceUri - Class in org.apache.flink.table.resource
-
Description of resource information.
- ResourceUri(ResourceType, String) - Constructor for class org.apache.flink.table.resource.ResourceUri
- restore(ClassLoader, String, String) - Static method in class org.apache.flink.table.types.logical.RawType
-
Restores a raw type from the components of a serialized string representation.
- Result(List<DataType>, DataType, DataType) - Constructor for class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
- resultType() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
- ResumeRefreshWorkflow<T extends RefreshHandler> - Class in org.apache.flink.table.workflow
-
ModifyRefreshWorkflow
provides the related information to resume refresh workflow ofCatalogMaterializedTable
. - ResumeRefreshWorkflow(T, Map<String, String>) - Constructor for class org.apache.flink.table.workflow.ResumeRefreshWorkflow
- retract(T) - Method in interface org.apache.flink.table.functions.TableAggregateFunction.RetractableCollector
-
Retract a record.
- REVERSE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- RIGHT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- RootArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for an argument that corresponds to a given
LogicalTypeRoot
and nullability. - RootArgumentTypeStrategy(LogicalTypeRoot, Boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.RootArgumentTypeStrategy
- ROUND - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ROUND - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
RoundTypeStrategy
. - ROW - org.apache.flink.table.types.logical.LogicalTypeRoot
- ROW - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ROW - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
RowTypeStrategy
. - ROW() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a row type with no fields.
- ROW(String[], TypeInformation<?>[]) - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for
Row
with fields of the given types and with given names. - ROW(List<DataTypes.Field>) - Static method in class org.apache.flink.table.api.DataTypes
- ROW(TypeInformation<?>...) - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for
Row
with fields of the given types. - ROW(DataTypes.AbstractField...) - Static method in class org.apache.flink.table.api.DataTypes
-
Unresolved data type of a sequence of fields.
- ROW(DataTypes.Field...) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a sequence of fields.
- ROW(AbstractDataType<?>...) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a sequence of fields.
- ROW(DataType...) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a sequence of fields.
- RowColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Row column vector.
- RowData - Interface in org.apache.flink.table.data
-
Base interface for an internal data structure representing data of
RowType
and other (possibly nested) structured types such asStructuredType
in the table ecosystem. - RowData.FieldGetter - Interface in org.apache.flink.table.data
-
Accessor for getting the field of a row during runtime.
- RowDataToStringConverter - Interface in org.apache.flink.table.utils.print
- RowField(String, LogicalType) - Constructor for class org.apache.flink.table.types.logical.RowType.RowField
- RowField(String, LogicalType, String) - Constructor for class org.apache.flink.table.types.logical.RowType.RowField
- rowFieldsToString(RowData) - Method in class org.apache.flink.table.utils.print.TableauStyle
- RowLevelModificationScanContext - Interface in org.apache.flink.table.connector
-
The context is intended to provide the relevant table scan information needed by the sink to perform row-level update/delete.
- rowtime(Rowtime) - Method in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.Specifies the previously defined field as an event-time attribute.
- Rowtime - Class in org.apache.flink.table.legacy.descriptors
-
Deprecated.This class was used for legacy connectors using
Descriptor
. - Rowtime() - Constructor for class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME - org.apache.flink.table.types.logical.TimestampKind
- ROWTIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- ROWTIME - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
RowtimeTypeStrategy
. - ROWTIME_BATCH_MARKER - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- ROWTIME_INDICATOR - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- ROWTIME_STREAM_MARKER - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- ROWTIME_TIMESTAMPS_CLASS - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_TIMESTAMPS_FROM - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_TIMESTAMPS_SERIALIZED - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_TIMESTAMPS_TYPE - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_TIMESTAMPS_TYPE_VALUE_CUSTOM - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_TIMESTAMPS_TYPE_VALUE_FROM_FIELD - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_TIMESTAMPS_TYPE_VALUE_FROM_SOURCE - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_WATERMARKS_CLASS - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_WATERMARKS_DELAY - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_WATERMARKS_SERIALIZED - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_WATERMARKS_TYPE - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_WATERMARKS_TYPE_VALUE_CUSTOM - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_WATERMARKS_TYPE_VALUE_FROM_SOURCE - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_WATERMARKS_TYPE_VALUE_PERIODIC_ASCENDING - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- ROWTIME_WATERMARKS_TYPE_VALUE_PERIODIC_BOUNDED - Static variable in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.
- RowtimeAttributeDescriptor - Class in org.apache.flink.table.legacy.sources
-
Deprecated.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) - Constructor for class org.apache.flink.table.legacy.sources.RowtimeAttributeDescriptor
-
Deprecated.
- RowtimeTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy for
BuiltInFunctionDefinitions.ROWTIME
which mirrors the type of the passed rowtime column, but returnsLogicalTypeRoot.TIMESTAMP_WITHOUT_TIME_ZONE
for aBATCH
mode. - RowtimeTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.RowtimeTypeStrategy
- RowType - Class in org.apache.flink.table.types.logical
-
Logical type of a sequence of fields.
- RowType(boolean, List<RowType.RowField>) - Constructor for class org.apache.flink.table.types.logical.RowType
- RowType(List<RowType.RowField>) - Constructor for class org.apache.flink.table.types.logical.RowType
- RowType.RowField - Class in org.apache.flink.table.types.logical
-
Describes a field of a
RowType
. - RPAD - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- RTRIM - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- runtimeClass(String) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Specifies the runtime class implementing this
BuiltInFunctionDefinition
. - RuntimeConverter - Interface in org.apache.flink.table.connector
-
Base interface for converting data during runtime.
- RuntimeConverter.Context - Interface in org.apache.flink.table.connector
-
Context for conversions during runtime.
- runtimeDeferred() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Specifies that this
BuiltInFunctionDefinition
will be mapped to a Calcite function. - runtimeProvided() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Specifies that this
BuiltInFunctionDefinition
is implemented during code generation. - runTypeInference(TypeInference, CallContext, TypeInferenceUtil.SurroundingInfo) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
-
Runs the entire type inference process.
S
- SCALA - org.apache.flink.table.catalog.FunctionLanguage
- scalar(String, DataType, boolean) - Static method in class org.apache.flink.table.types.inference.StaticArgument
-
Declares a scalar argument such as
f(12)
orf(otherColumn)
. - SCALAR - org.apache.flink.table.annotation.ArgumentTrait
-
An argument that accepts a scalar value.
- SCALAR - org.apache.flink.table.api.JsonType
- SCALAR - org.apache.flink.table.functions.FunctionKind
- SCALAR - org.apache.flink.table.types.inference.StaticArgumentTrait
- SCALAR_EVAL - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- ScalarFunction - Class in org.apache.flink.table.functions
-
Base class for a user-defined scalar function.
- ScalarFunction() - Constructor for class org.apache.flink.table.functions.ScalarFunction
- ScalarFunctionDefinition - Class in org.apache.flink.table.functions
-
Deprecated.Non-legacy functions can simply omit this wrapper for declarations.
- ScalarFunctionDefinition(String, ScalarFunction) - Constructor for class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- scale() - Method in class org.apache.flink.table.data.DecimalData
-
Returns the scale of this
DecimalData
. - ScanTableSource - Interface in org.apache.flink.table.connector.source
-
A
DynamicTableSource
that scans all rows from an external storage system during runtime. - ScanTableSource.ScanContext - Interface in org.apache.flink.table.connector.source
-
Context for creating runtime implementation via a
ScanTableSource.ScanRuntimeProvider
. - ScanTableSource.ScanRuntimeProvider - Interface in org.apache.flink.table.connector.source
-
Provides actual runtime implementation for reading the data.
- schema(Schema) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- schema(Schema) - Method in class org.apache.flink.table.catalog.CatalogTable.Builder
- schema(TableSchema) - Method in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.Sets the schema with field names and the types.
- Schema - Class in org.apache.flink.table.api
-
Schema of a table or view.
- Schema - Class in org.apache.flink.table.legacy.descriptors
-
Deprecated.This class was used for legacy connectors using
Descriptor
. - Schema() - Constructor for class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.
- SCHEMA - Static variable in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.
- SCHEMA_DATA_TYPE - Static variable in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.
- SCHEMA_FROM - Static variable in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.
- SCHEMA_NAME - Static variable in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.
- SCHEMA_PROCTIME - Static variable in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.
- SCHEMA_TYPE - Static variable in class org.apache.flink.table.legacy.descriptors.Schema
- Schema.Builder - Class in org.apache.flink.table.api
-
A builder for constructing an immutable but still unresolved
Schema
. - Schema.UnresolvedColumn - Class in org.apache.flink.table.api
-
Super class for all kinds of columns in an unresolved schema.
- Schema.UnresolvedComputedColumn - Class in org.apache.flink.table.api
-
Declaration of a computed column that will be resolved to
Column.ComputedColumn
during schema resolution. - Schema.UnresolvedConstraint - Class in org.apache.flink.table.api
-
Super class for all kinds of constraints in an unresolved schema.
- Schema.UnresolvedMetadataColumn - Class in org.apache.flink.table.api
-
Declaration of a metadata column that will be resolved to
Column.MetadataColumn
during schema resolution. - Schema.UnresolvedPhysicalColumn - Class in org.apache.flink.table.api
-
Declaration of a physical column that will be resolved to
Column.PhysicalColumn
during schema resolution. - Schema.UnresolvedPrimaryKey - Class in org.apache.flink.table.api
-
Declaration of a primary key that will be resolved to
UniqueConstraint
during schema resolution. - Schema.UnresolvedWatermarkSpec - Class in org.apache.flink.table.api
-
Declaration of a watermark strategy that will be resolved to
WatermarkSpec
during schema resolution. - SchemaResolver - Interface in org.apache.flink.table.catalog
-
Resolves a
Schema
to a validatedResolvedSchema
. - searchPartSpecAndPaths(FileSystem, Path, int) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
-
Search all partitions in this path.
- SECOND - org.apache.flink.table.catalog.IntervalFreshness.TimeUnit
- SECOND - org.apache.flink.table.expressions.TimeIntervalUnit
- SECOND - org.apache.flink.table.expressions.TimePointUnit
- SECOND - org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
- SECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- SECOND - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- SECOND() - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in seconds with 6 digits for fractional seconds by default.
- SECOND(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in seconds and (possibly) fractional seconds.
- segments - Variable in class org.apache.flink.table.data.binary.BinarySection
- separator - Variable in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- sequence(String[], ArgumentTypeStrategy[]) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a named function signature like
f(s STRING, n NUMERIC)
using a sequence ofArgumentTypeStrategy
s. - sequence(List<String>, List<ArgumentTypeStrategy>) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a named function signature like
f(s STRING, n NUMERIC)
using a sequence ofArgumentTypeStrategy
s. - sequence(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a function signature like
f(STRING, NUMERIC)
using a sequence ofArgumentTypeStrategy
s. - SequenceInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for inferring and validating a function signature like
f(STRING, NUMERIC)
orf(s STRING, n NUMERIC)
using a sequence ofArgumentTypeStrategy
s. - SequenceInputTypeStrategy(List<? extends ArgumentTypeStrategy>, List<String>) - Constructor for class org.apache.flink.table.types.inference.strategies.SequenceInputTypeStrategy
- SerializationFormatFactory - Interface in org.apache.flink.table.factories
-
Factory for creating a
EncodingFormat
forSerializationSchema
. - serialize(Object, DataOutputView) - Method in class org.apache.flink.table.dataview.NullSerializer
- serialize(Map<K, V>, DataOutputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- serialize(ListView<T>, DataOutputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- serialize(MapView<K, V>, DataOutputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- serialize(ContinuousRefreshHandler) - Method in class org.apache.flink.table.refresh.ContinuousRefreshHandlerSerializer
- serialize(T) - Method in interface org.apache.flink.table.refresh.RefreshHandlerSerializer
-
Serialize the
RefreshHandler
instance to bytes. - serializeCatalogMaterializedTable(ResolvedCatalogMaterializedTable) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
Serializes the given
ResolvedCatalogMaterializedTable
into a map of string properties. - serializeCatalogTable(ResolvedCatalogTable) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
Serializes the given
ResolvedCatalogTable
into a map of string properties. - serializeCatalogView(ResolvedCatalogView) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
Serializes the given
ResolvedCatalogView
into a map of string properties. - serializedRefreshHandler(byte[]) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- serializeResolvedCatalogModel(ResolvedCatalogModel) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
Serializes the given
ResolvedCatalogModel
into a map of string properties. - set(String, String) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to set the table option.
- setAlignGroupName(String) - Method in class org.apache.flink.table.watermark.WatermarkParams
- setAlignMaxDrift(Duration) - Method in class org.apache.flink.table.watermark.WatermarkParams
- setAlignUpdateInterval(Duration) - Method in class org.apache.flink.table.watermark.WatermarkParams
- setAvgLen(Double) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
- setBoolean(int, boolean) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setBoolean(int, boolean) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setBoolean(int, boolean) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setBoolean(int, boolean) - Method in interface org.apache.flink.table.data.binary.TypedSetters
- setBoolean(int, boolean) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- setBoolean(int, boolean) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setBoolean(int, boolean) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapBooleanVector
- setBoolean(int, boolean) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableBooleanVector
-
Set boolean at rowId with the provided value.
- setBoolean(MemorySegment[], int, boolean) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set boolean from segments.
- setByte(int, byte) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setByte(int, byte) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setByte(int, byte) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setByte(int, byte) - Method in interface org.apache.flink.table.data.binary.TypedSetters
- setByte(int, byte) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- setByte(int, byte) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setByte(int, byte) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapByteVector
- setByte(int, byte) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableByteVector
-
Set byte at rowId with the provided value.
- setByte(MemorySegment[], int, byte) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set byte from segments.
- setChild(ColumnVector) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- setCollector(Collector<T>) - Method in class org.apache.flink.table.functions.ProcessTableFunction
-
Internal use.
- setCollector(Collector<T>) - Method in class org.apache.flink.table.functions.TableFunction
-
Internal use.
- setComment(String) - Method in class org.apache.flink.table.catalog.CatalogDescriptor
- setDecimal(int, DecimalData, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setDecimal(int, DecimalData, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setDecimal(int, DecimalData, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setDecimal(int, DecimalData, int) - Method in interface org.apache.flink.table.data.binary.TypedSetters
-
Set the decimal column value.
- setDecimal(int, DecimalData, int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- setDecimal(int, DecimalData, int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setDictionary(Dictionary) - Method in class org.apache.flink.table.data.columnar.vector.writable.AbstractWritableVector
-
Update the dictionary.
- setDictionary(Dictionary) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableColumnVector
-
Set the dictionary, it should work with dictionary ids.
- setDouble(int, double) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setDouble(int, double) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setDouble(int, double) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setDouble(int, double) - Method in interface org.apache.flink.table.data.binary.TypedSetters
- setDouble(int, double) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- setDouble(int, double) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setDouble(int, double) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapDoubleVector
- setDouble(int, double) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableDoubleVector
-
Set double at rowId with the provided value.
- setDouble(MemorySegment[], int, double) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set double from segments.
- setDoublesFromBinary(int, int, byte[], int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapDoubleVector
- setDoublesFromBinary(int, int, byte[], int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableDoubleVector
-
Set doubles from binary, need use UNSAFE to copy.
- setEmitStrategy(WatermarkEmitStrategy) - Method in class org.apache.flink.table.watermark.WatermarkParams
- setExpectedArguments(List<DataType>) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
- setField(int, Object) - Method in class org.apache.flink.table.data.GenericRowData
-
Sets the field value at the given position.
- setFields(WritableColumnVector[]) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapRowVector
- setFinal(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
- setFloat(int, float) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setFloat(int, float) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setFloat(int, float) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setFloat(int, float) - Method in interface org.apache.flink.table.data.binary.TypedSetters
- setFloat(int, float) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- setFloat(int, float) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setFloat(int, float) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapFloatVector
- setFloat(int, float) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableFloatVector
-
Set float at rowId with the provided value.
- setFloat(MemorySegment[], int, float) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set float from segments.
- setFloatsFromBinary(int, int, byte[], int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapFloatVector
- setFloatsFromBinary(int, int, byte[], int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableFloatVector
-
Set floats from binary, need use UNSAFE to copy.
- setInputs(Object[]) - Method in class org.apache.flink.table.functions.python.PythonFunctionInfo
- setInstantiable(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
- setInt(int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setInt(int, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setInt(int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setInt(int, int) - Method in interface org.apache.flink.table.data.binary.TypedSetters
- setInt(int, int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- setInt(int, int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setInt(int, int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector
- setInt(int, int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableIntVector
-
Set int at rowId with the provided value.
- setInt(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set int from segments.
- setInts(int, int, int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector
- setInts(int, int, int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableIntVector
-
Sets value to [rowId, rowId + count) by the value, this is data that repeats continuously.
- setInts(int, int, int[], int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector
- setInts(int, int, int[], int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableIntVector
-
Sets values from [src[srcIndex], src[srcIndex + count]) to [rowId, rowId + count).
- setIntsFromBinary(int, int, byte[], int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector
- setIntsFromBinary(int, int, byte[], int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableIntVector
-
Set ints from binary, need use UNSAFE to copy.
- setJavaObject(T) - Method in class org.apache.flink.table.data.binary.LazyBinaryFormat
-
Must be public as it is used during code generation.
- setKeys(ColumnVector) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector
- setLengths(long[]) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- setLengths(long[]) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector
- setList(List<T>) - Method in class org.apache.flink.table.api.dataview.ListView
-
Replaces the entire view's content with the content of the given
List
. - setLong(int, long) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setLong(int, long) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setLong(int, long) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setLong(int, long) - Method in interface org.apache.flink.table.data.binary.TypedSetters
- setLong(int, long) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- setLong(int, long) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setLong(int, long) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapLongVector
- setLong(int, long) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableLongVector
-
Set long at rowId with the provided value.
- setLong(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set long from segments.
- setLongsFromBinary(int, int, byte[], int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapLongVector
- setLongsFromBinary(int, int, byte[], int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableLongVector
-
Set longs from binary, need use UNSAFE to copy.
- setMap(Map<K, V>) - Method in class org.apache.flink.table.api.dataview.MapView
-
Replaces the entire view's content with the content of the given
Map
. - setMax(Comparable<?>) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
- setMaxLen(Integer) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
- setMin(Comparable<?>) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
- setNdv(Long) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
- setNotNullAt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setNullable(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
- setNullAt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setNullAt(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setNullAt(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setNullAt(int) - Method in interface org.apache.flink.table.data.binary.TypedSetters
- setNullAt(int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- setNullAt(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setNullAt(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- setNullAt(int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableColumnVector
-
Set null at rowId.
- setNullBoolean(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setNullByte(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setNullCount(Long) - Method in class org.apache.flink.table.plan.stats.ColumnStats.Builder
- setNullDouble(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setNullFloat(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setNullInt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setNullLong(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setNulls(int, int) - Method in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- setNulls(int, int) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableColumnVector
-
Set nulls from rowId to rowId + count (exclude).
- setNullSerializer(boolean) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- setNullSerializer(boolean) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- setNullShort(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setNumRows(int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- setOffsets(long[]) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- setOffsets(long[]) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector
- setOverwrite(boolean) - Method in interface org.apache.flink.table.legacy.sinks.OverwritableTableSink
-
Deprecated.Configures whether the insert should overwrite existing data or not.
- setRowId(int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setRowKind(RowKind) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setRowKind(RowKind) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setRowKind(RowKind) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setRowKind(RowKind) - Method in class org.apache.flink.table.data.GenericRowData
- setRowKind(RowKind) - Method in interface org.apache.flink.table.data.RowData
-
Sets the kind of change that this row describes in a changelog.
- setRowKind(RowKind) - Method in class org.apache.flink.table.data.utils.JoinedRowData
- setRowKind(RowKind) - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- setShort(int, short) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setShort(int, short) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setShort(int, short) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setShort(int, short) - Method in interface org.apache.flink.table.data.binary.TypedSetters
- setShort(int, short) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- setShort(int, short) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setShort(int, short) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapShortVector
- setShort(int, short) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableShortVector
-
Set short at rowId with the provided value.
- setShort(MemorySegment[], int, short) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set short from segments.
- setSize(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector
- setSize(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector
- setSourceIdleTimeout(long) - Method in class org.apache.flink.table.watermark.WatermarkParams
- setStaticPartition(Map<String, String>) - Method in interface org.apache.flink.table.legacy.sinks.PartitionableTableSink
-
Deprecated.Sets the static partition into the
TableSink
. - setTimestamp(int, TimestampData) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapTimestampVector
- setTimestamp(int, TimestampData) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableTimestampVector
-
Set
TimestampData
at rowId with the provided value. - setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
- setTimestamp(int, TimestampData, int) - Method in interface org.apache.flink.table.data.binary.TypedSetters
-
Set Timestamp value.
- setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- setTotalSize(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
- setValues(ColumnVector) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector
- setVectorizedColumnBatch(VectorizedColumnBatch) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
- SHA1 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SHA2 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SHA224 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SHA256 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SHA384 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SHA512 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SHORT() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API short or SQL SMALLINT type.
- ShortColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Short column vector.
- SIGN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- Signature - Class in org.apache.flink.table.types.inference
-
Describes the signature of a function.
- Signature.Argument - Class in org.apache.flink.table.types.inference
-
Representation of a single argument in a signature.
- SIMILAR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SIN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SINH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SINK_PARALLELISM - Static variable in class org.apache.flink.table.factories.FactoryUtil
- SinkStagingContext - Class in org.apache.flink.table.connector.sink
-
Implementation of
SupportsStaging.StagingContext
. - SinkStagingContext(SupportsStaging.StagingPurpose) - Constructor for class org.apache.flink.table.connector.sink.SinkStagingContext
- SinkV2Provider - Interface in org.apache.flink.table.connector.sink
-
Provider of a
Sink
instance as a runtime implementation forDynamicTableSink
. - size() - Method in class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache
- size() - Method in interface org.apache.flink.table.connector.source.lookup.cache.LookupCache
-
Returns the number of key-value mappings in the cache.
- size() - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the number of elements in this array.
- size() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- size() - Method in class org.apache.flink.table.data.binary.BinaryMapData
- size() - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- size() - Method in class org.apache.flink.table.data.columnar.ColumnarMapData
- size() - Method in class org.apache.flink.table.data.GenericArrayData
- size() - Method in class org.apache.flink.table.data.GenericMapData
- size() - Method in interface org.apache.flink.table.data.MapData
-
Returns the number of key-value mappings in this map.
- sizeInBytes - Variable in class org.apache.flink.table.data.binary.BinarySection
- SMALLINT - org.apache.flink.table.types.logical.LogicalTypeRoot
- SMALLINT() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a 2-byte signed integer with values from -32,768 to 32,767.
- SmallIntType - Class in org.apache.flink.table.types.logical
-
Logical type of a 2-byte signed integer with values from -32,768 to 32,767.
- SmallIntType() - Constructor for class org.apache.flink.table.types.logical.SmallIntType
- SmallIntType(boolean) - Constructor for class org.apache.flink.table.types.logical.SmallIntType
- snapshot(Long) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
- snapshot(Long) - Method in class org.apache.flink.table.catalog.CatalogTable.Builder
- snapshotConfiguration() - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- snapshotConfiguration() - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- snapshotConfiguration() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- snapshotConfiguration() - Method in class org.apache.flink.table.dataview.NullSerializer
- SOURCE_IDLE_TIMEOUT - Static variable in class org.apache.flink.table.factories.FactoryUtil
- SOURCE_PARALLELISM - Static variable in class org.apache.flink.table.factories.FactoryUtil
- SOURCE_WATERMARK - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SOURCE_WATERMARK - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
SourceWatermarkTypeStrategy
. - sourceIdleTimeout(long) - Method in class org.apache.flink.table.watermark.WatermarkParams.WatermarkParamsBuilder
- SourceProvider - Interface in org.apache.flink.table.connector.source
-
Provider of a
Source
instance as a runtime implementation forScanTableSource
. - specialize(SpecializedFunction.SpecializedContext) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- specialize(SpecializedFunction.SpecializedContext) - Method in interface org.apache.flink.table.functions.SpecializedFunction
-
Provides a runtime implementation that is specialized for the given call and session.
- SpecializedFunction - Interface in org.apache.flink.table.functions
-
A
FunctionDefinition
that can provide a runtime implementation (i.e. the function's body) that is specialized for the given call and session. - SpecializedFunction.ExpressionEvaluator - Interface in org.apache.flink.table.functions
-
Serializable factory that can be passed into a
UserDefinedFunction
for evaluating previously defined expression during runtime. - SpecializedFunction.ExpressionEvaluatorFactory - Interface in org.apache.flink.table.functions
-
Helper interface for creating
SpecializedFunction.ExpressionEvaluator
s. - SpecializedFunction.SpecializedContext - Interface in org.apache.flink.table.functions
-
Provides call and session information for the specialized function.
- SpecificInputTypeStrategies - Class in org.apache.flink.table.types.inference.strategies
-
Entry point for specific input type strategies not covered in
InputTypeStrategies
. - SpecificTypeStrategies - Class in org.apache.flink.table.types.inference.strategies
-
Entry point for specific type strategies not covered in
TypeStrategies
. - SPLIT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SPLIT_INDEX - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SQL_DATE() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API SQL date or SQL DATE type.
- SQL_GATEWAY_ENDPOINT_TYPE - Static variable in class org.apache.flink.table.factories.FactoryUtil
- SQL_TIME() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API SQL time or SQL TIME type.
- SQL_TIMESTAMP() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API SQL timestamp or SQL TIMESTAMP type.
- SqlCallExpression - Class in org.apache.flink.table.expressions
-
A call to a SQL expression.
- SqlCallExpression(String) - Constructor for class org.apache.flink.table.expressions.SqlCallExpression
- SqlCallSyntax - Interface in org.apache.flink.table.functions
-
Provides a format for unparsing
BuiltInFunctionDefinitions
into a SQL string. - sqlName(String) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Overwrites the name that is used for unparsing a function into a SQL string.
- SQRT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- StagedTable - Interface in org.apache.flink.table.catalog
-
The
StagedTable
is designed to implement Flink's atomic semantic for CTAS(CREATE TABLE AS SELECT) and RTAS([CREATE OR] REPLACE TABLE AS SELECT) statement using a two-phase commit protocol. - start - Variable in class org.apache.flink.table.data.columnar.vector.heap.HeapBytesVector
-
start offset of each field.
- STARTS_WITH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- startsWith(BinaryStringData) - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Tests if this BinaryStringData starts with the specified prefix.
- startUnit - Variable in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- state() - Method in annotation type org.apache.flink.table.annotation.FunctionHint
-
Explicitly lists the intermediate results (i.e. state entries) of a function that is managed by the framework (i.e.
- StateHint - Annotation Type in org.apache.flink.table.annotation
-
A hint that declares an intermediate result (i.e. state entry) that is managed by the framework (i.e.
- stateTypeStrategies(LinkedHashMap<String, StateTypeStrategy>) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets a map of state names to
StateTypeStrategy
s for inferring a function call's intermediate result data types (i.e. state entries). - StateTypeStrategy - Interface in org.apache.flink.table.types.inference
-
Strategy for inferring a function call's intermediate result data type (i.e. state entry).
- StaticArgument - Class in org.apache.flink.table.types.inference
-
Describes an argument in a static signature that is not overloaded and does not support varargs.
- staticArguments(List<StaticArgument>) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets a list of arguments in a static signature that is not overloaded and does not support varargs.
- staticArguments(StaticArgument...) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
- staticArguments(StaticArgument...) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets a list of arguments in a static signature that is not overloaded and does not support varargs.
- StaticArgumentTrait - Enum in org.apache.flink.table.types.inference
-
Declares traits for
StaticArgument
. - STDDEV_POP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- STDDEV_SAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- storeCatalog(String, CatalogDescriptor) - Method in interface org.apache.flink.table.catalog.CatalogStore
-
Stores a catalog under the given catalog name.
- STR_TO_MAP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- STREAM_RECORD_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- STRICT - org.apache.flink.table.types.extraction.ExtractionUtils.Autoboxing
-
int.class can be passed into f(Integer.class).
- STRING() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a variable-length character string with defined maximum length.
- STRING() - Static method in class org.apache.flink.table.legacy.api.Types
-
Deprecated.Returns type information for a Table API string or SQL VARCHAR type.
- STRING_CONCAT - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
StringConcatTypeStrategy
. - STRING_TYPE - Static variable in class org.apache.flink.table.types.logical.VarCharType
- StringData - Interface in org.apache.flink.table.data
-
An internal data structure representing data of
CharType
andVarCharType
. - stringifyOption(String, String) - Static method in class org.apache.flink.table.factories.FactoryUtil
- stripRowPrefix(DataType, String) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Removes a string prefix from the fields of the given row data type.
- STRUCTURED(Class<T>, DataTypes.Field...) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a user-defined object structured type.
- STRUCTURED_TYPE - org.apache.flink.table.types.logical.LogicalTypeRoot
- StructuredAttribute(String, LogicalType) - Constructor for class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- StructuredAttribute(String, LogicalType, String) - Constructor for class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
- StructuredType - Class in org.apache.flink.table.types.logical
-
Logical type of a user-defined object structured type.
- StructuredType.Builder - Class in org.apache.flink.table.types.logical
-
A builder for a
StructuredType
. - StructuredType.StructuredAttribute - Class in org.apache.flink.table.types.logical
-
Defines an attribute of a
StructuredType
. - StructuredType.StructuredComparison - Enum in org.apache.flink.table.types.logical
-
Defines equality properties for scalar evaluation.
- SubQueryInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
- SubQueryInputTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.SubQueryInputTypeStrategy
- subsequence(InputTypeStrategy) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
-
Defines a common
InputTypeStrategy
for the next arguments. - SubsequenceInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
InputTypeStrategy
that lets you apply other strategies for subsequences of the actual arguments. - SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder - Class in org.apache.flink.table.types.inference.strategies
-
A Builder for
SubsequenceInputTypeStrategy
. - SubsequenceStrategyBuilder() - Constructor for class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
- SUBSTR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- substring(int, int) - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Returns a binary string that is a substring of this binary string.
- SUBSTRING - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SUBSTRING - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Special sql syntax for SUBSTRING operators (SUBSTRING, SUBSTR).
- subtractMonths(int, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Finds the number of months between two dates, each represented as the number of days since the epoch.
- subtractMonths(long, long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- SUM - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- SUM - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- SUM_RETRACT - org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
- SUM0 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- superType(StructuredType) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
- supportedProperties() - Method in interface org.apache.flink.table.legacy.factories.TableFactory
-
Deprecated.List of property keys that this factory can handle.
- SupportsAggregatePushDown - Interface in org.apache.flink.table.connector.source.abilities
-
Enables to push down the local aggregates into a
ScanTableSource
. - supportsAvoidingCast(List<LogicalType>, List<LogicalType>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
- supportsAvoidingCast(LogicalType, LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
-
Returns whether the source type can be safely interpreted as the target type.
- SupportsBucketing - Interface in org.apache.flink.table.connector.sink.abilities
-
Enables to write bucketed data into a
DynamicTableSink
. - supportsConstantFolding() - Method in interface org.apache.flink.table.functions.FunctionDefinition
-
If the constant-folding should be run during planning time on calls to this function.
- SupportsDeletePushDown - Interface in org.apache.flink.table.connector.sink.abilities
-
Enables to push down filters decomposed from the
WHERE
clause in delete statement toDynamicTableSink
. - SupportsDynamicFiltering - Interface in org.apache.flink.table.connector.source.abilities
-
Pushes dynamic filter into
ScanTableSource
, the table source can filter the partitions even the input data in runtime to reduce scan I/O. - supportsExplicitCast(LogicalType, LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
-
Returns whether the source type can be casted to the target type.
- SupportsFilterPushDown - Interface in org.apache.flink.table.connector.source.abilities
-
Enables to push down filters into a
ScanTableSource
. - SupportsFilterPushDown.Result - Class in org.apache.flink.table.connector.source.abilities
-
Result of a filter push down.
- supportsImplicitCast(LogicalType, LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
-
Returns whether the source type can be safely casted to the target type without loosing information.
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ArrayType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BigIntType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BinaryType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BooleanType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.CharType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DateType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DecimalType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DistinctType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DoubleType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.FloatType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.IntType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns whether an instance of the given class can be represented as a value of this logical type when entering the table ecosystem.
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MapType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MultisetType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.NullType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RawType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RowType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SmallIntType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.StructuredType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SymbolType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimestampType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimeType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TinyIntType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarBinaryType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarCharType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- SupportsLimitPushDown - Interface in org.apache.flink.table.connector.source.abilities
-
Enables to push down a limit (the expected maximum number of produced records) into a
ScanTableSource
. - SupportsLookupCustomShuffle - Interface in org.apache.flink.table.connector.source.abilities
-
This interface is designed to allow connectors to provide a custom partitioning strategy for the data that is fed into the
LookupTableSource
. - SupportsLookupCustomShuffle.InputDataPartitioner - Interface in org.apache.flink.table.connector.source.abilities
-
This interface is responsible for providing custom partitioning logic for the RowData records.
- supportsMetadataProjection() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsReadingMetadata
-
Defines whether projections can be applied to metadata columns.
- supportsNestedProjection() - Method in interface org.apache.flink.table.connector.format.ProjectableDecodingFormat
-
Returns whether this format supports nested projection.
- supportsNestedProjection() - Method in interface org.apache.flink.table.connector.source.abilities.SupportsProjectionPushDown
-
Returns whether this source supports nested projection.
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ArrayType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BigIntType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BinaryType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BooleanType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.CharType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DateType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DecimalType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DistinctType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DoubleType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.FloatType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.IntType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns whether a value of this logical type can be represented as an instance of the given class when leaving the table ecosystem.
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MapType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MultisetType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.NullType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RawType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RowType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SmallIntType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.StructuredType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SymbolType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimestampType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimeType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TinyIntType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarBinaryType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarCharType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
- SupportsOverwrite - Interface in org.apache.flink.table.connector.sink.abilities
-
Enables to overwrite existing data in a
DynamicTableSink
. - SupportsPartitioning - Interface in org.apache.flink.table.connector.sink.abilities
-
Enables to write partitioned data in a
DynamicTableSink
. - SupportsPartitionPushDown - Interface in org.apache.flink.table.connector.source.abilities
-
Enables to pass available partitions to the planner and push down partitions into a
ScanTableSource
. - SupportsProjectionPushDown - Interface in org.apache.flink.table.connector.source.abilities
-
Enables to push down a (possibly nested) projection into a
ScanTableSource
. - SupportsReadingMetadata - Interface in org.apache.flink.table.connector.source.abilities
-
Interface for
ScanTableSource
s that support reading metadata columns. - supportsReinterpretCast(LogicalType, LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
-
Returns whether the source type can be reinterpreted as the target type.
- SupportsRowLevelDelete - Interface in org.apache.flink.table.connector.sink.abilities
-
Interface for
DynamicTableSink
s that support delete existing data according to row-level changes. - SupportsRowLevelDelete.RowLevelDeleteInfo - Interface in org.apache.flink.table.connector.sink.abilities
-
The information that guides the planner on how to rewrite the delete statement.
- SupportsRowLevelDelete.RowLevelDeleteMode - Enum in org.apache.flink.table.connector.sink.abilities
-
Type of delete modes that the sink expects for delete purpose.
- SupportsRowLevelModificationScan - Interface in org.apache.flink.table.connector.source.abilities
-
Interface for
ScanTableSource
s that support the row-level modification. - SupportsRowLevelModificationScan.RowLevelModificationType - Enum in org.apache.flink.table.connector.source.abilities
-
Type of the row-level modification for table.
- SupportsRowLevelUpdate - Interface in org.apache.flink.table.connector.sink.abilities
-
Interface for
DynamicTableSink
s that support update existing data according to row-level changes. - SupportsRowLevelUpdate.RowLevelUpdateInfo - Interface in org.apache.flink.table.connector.sink.abilities
-
The information that guides the planner on how to rewrite the update statement.
- SupportsRowLevelUpdate.RowLevelUpdateMode - Enum in org.apache.flink.table.connector.sink.abilities
-
Type of update modes that the sink expects for update purpose.
- SupportsSourceWatermark - Interface in org.apache.flink.table.connector.source.abilities
-
Enables to fully rely on the watermark strategy provided by the
ScanTableSource
itself. - SupportsStaging - Interface in org.apache.flink.table.connector.sink.abilities
-
Interface for
DynamicTableSink
s that support atomic semantic for CTAS(CREATE TABLE AS SELECT) or RTAS([CREATE OR] REPLACE TABLE AS SELECT) statement using a two-phase commit protocol. - SupportsStaging.StagingContext - Interface in org.apache.flink.table.connector.sink.abilities
-
The context is intended to tell DynamicTableSink the type of this operation.
- SupportsStaging.StagingPurpose - Enum in org.apache.flink.table.connector.sink.abilities
-
The type of operation the staging sink is for.
- SupportsStatisticReport - Interface in org.apache.flink.table.connector.source.abilities
-
Enables to report the estimated statistics provided by the
DynamicTableSource
. - SupportsTruncate - Interface in org.apache.flink.table.connector.sink.abilities
-
Enables to delete all existing data in a
DynamicTableSink
table usingTRUNCATE TABLE
statement. - SupportsWatermarkPushDown - Interface in org.apache.flink.table.connector.source.abilities
-
Enables to push down a watermark strategy into a
ScanTableSource
. - SupportsWritingMetadata - Interface in org.apache.flink.table.connector.sink.abilities
-
Interface for
DynamicTableSink
s that support writing metadata columns. - SUSPENDED - org.apache.flink.table.catalog.CatalogMaterializedTable.RefreshStatus
- SuspendRefreshWorkflow<T extends RefreshHandler> - Class in org.apache.flink.table.workflow
-
ModifyRefreshWorkflow
provides the related information to suspend refresh workflow ofCatalogMaterializedTable
. - SuspendRefreshWorkflow(T) - Constructor for class org.apache.flink.table.workflow.SuspendRefreshWorkflow
- symbol(Class<? extends Enum<? extends TableSymbol>>) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a symbol argument of a specific
TableSymbol
enum. - symbol(T, T...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a symbol argument of a specific
TableSymbol
enum, with value being one of the provided variants. - SYMBOL - org.apache.flink.table.types.logical.LogicalTypeRoot
- SymbolArgumentTypeStrategy<T extends Enum<? extends TableSymbol>> - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for a symbol argument of a specific
TableSymbol
enum. - SymbolArgumentTypeStrategy(Class<T>) - Constructor for class org.apache.flink.table.types.inference.strategies.SymbolArgumentTypeStrategy
- SymbolArgumentTypeStrategy(Class<T>, Set<T>) - Constructor for class org.apache.flink.table.types.inference.strategies.SymbolArgumentTypeStrategy
- SymbolType<T extends TableSymbol> - Class in org.apache.flink.table.types.logical
-
Logical type for representing symbol values.
- SymbolType() - Constructor for class org.apache.flink.table.types.logical.SymbolType
- SymbolType(boolean) - Constructor for class org.apache.flink.table.types.logical.SymbolType
- SystemTypeInference - Class in org.apache.flink.table.types.inference
-
Extends the
TypeInference
function-aware by additional system columns and validation. - SystemTypeInference() - Constructor for class org.apache.flink.table.types.inference.SystemTypeInference
T
- table(String, Class<?>, boolean, EnumSet<StaticArgumentTrait>) - Static method in class org.apache.flink.table.types.inference.StaticArgument
-
Declares a table argument such as
f(t => myTable)
orf(t => TABLE myTable))
. - table(String, DataType, boolean, EnumSet<StaticArgumentTrait>) - Static method in class org.apache.flink.table.types.inference.StaticArgument
-
Declares a table argument such as
f(t => myTable)
orf(t => TABLE myTable))
. - TABLE - org.apache.flink.table.catalog.CatalogBaseTable.TableKind
- TABLE - org.apache.flink.table.functions.FunctionKind
- TABLE - org.apache.flink.table.types.inference.StaticArgumentTrait
- TABLE_AGGREGATE - org.apache.flink.table.functions.FunctionKind
- TABLE_AGGREGATE_ACCUMULATE - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- TABLE_AGGREGATE_EMIT - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- TABLE_AGGREGATE_EMIT_RETRACT - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- TABLE_AGGREGATE_MERGE - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- TABLE_AGGREGATE_RETRACT - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- TABLE_AS_ROW - org.apache.flink.table.annotation.ArgumentTrait
-
An argument that accepts a table "as row" (i.e. with row semantics).
- TABLE_AS_ROW - org.apache.flink.table.types.inference.StaticArgumentTrait
- TABLE_AS_SET - org.apache.flink.table.annotation.ArgumentTrait
-
An argument that accepts a table "as set" (i.e. with set semantics).
- TABLE_AS_SET - org.apache.flink.table.types.inference.StaticArgumentTrait
- TABLE_CATALOG_STORE_KIND - Static variable in class org.apache.flink.table.catalog.CommonCatalogOptions
- TABLE_CATALOG_STORE_OPTION_PREFIX - Static variable in class org.apache.flink.table.catalog.CommonCatalogOptions
-
Used to filter the specific options for catalog store.
- TABLE_EVAL - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
- TableAggregateFunction<T,ACC> - Class in org.apache.flink.table.functions
-
Base class for a user-defined table aggregate function.
- TableAggregateFunction() - Constructor for class org.apache.flink.table.functions.TableAggregateFunction
- TableAggregateFunction.RetractableCollector<T> - Interface in org.apache.flink.table.functions
-
Collects a record and forwards it.
- TableAggregateFunctionDefinition - Class in org.apache.flink.table.functions
-
Deprecated.Non-legacy functions can simply omit this wrapper for declarations.
- TableAggregateFunctionDefinition(String, TableAggregateFunction<?, ?>, TypeInformation<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- TableAlreadyExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to create a table (or view) that already exists.
- TableAlreadyExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableAlreadyExistException
- TableAlreadyExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableAlreadyExistException
- TableauStyle - Class in org.apache.flink.table.utils.print
-
Print the result and content as tableau form.
- tableauWithDataInferredColumnWidths(ResolvedSchema, RowDataToStringConverter) - Static method in interface org.apache.flink.table.utils.print.PrintStyle
-
Like
PrintStyle.tableauWithDataInferredColumnWidths(ResolvedSchema, RowDataToStringConverter, int, boolean, boolean)
, but using default values. - tableauWithDataInferredColumnWidths(ResolvedSchema, RowDataToStringConverter, int, boolean, boolean) - Static method in interface org.apache.flink.table.utils.print.PrintStyle
-
Like
PrintStyle.tableauWithTypeInferredColumnWidths(ResolvedSchema, RowDataToStringConverter, int, boolean, boolean)
, but uses the data to infer the column size. - tableauWithTypeInferredColumnWidths(ResolvedSchema, RowDataToStringConverter, int, boolean, boolean) - Static method in interface org.apache.flink.table.utils.print.PrintStyle
-
Create a new
TableauStyle
using column widths computed from the type. - TableChange - Interface in org.apache.flink.table.catalog
-
TableChange
represents the modification of theCatalogBaseTable
. - TableChange.AddColumn - Class in org.apache.flink.table.catalog
-
A table change to add a column.
- TableChange.AddDistribution - Class in org.apache.flink.table.catalog
-
A table change to add a distribution.
- TableChange.AddUniqueConstraint - Class in org.apache.flink.table.catalog
-
A table change to add a unique constraint.
- TableChange.AddWatermark - Class in org.apache.flink.table.catalog
-
A table change to add a watermark.
- TableChange.After - Class in org.apache.flink.table.catalog
-
Column position AFTER means the specified column should be put after the given `column`.
- TableChange.CatalogTableChange - Interface in org.apache.flink.table.catalog
-
TableChange.CatalogTableChange
represents the modification of the CatalogTable. - TableChange.ColumnPosition - Interface in org.apache.flink.table.catalog
-
The position of the modified or added column.
- TableChange.DropColumn - Class in org.apache.flink.table.catalog
-
A table change to drop the column.
- TableChange.DropConstraint - Class in org.apache.flink.table.catalog
-
A table change to drop the constraints.
- TableChange.DropDistribution - Class in org.apache.flink.table.catalog
-
A table change to drop a table's distribution.
- TableChange.DropWatermark - Class in org.apache.flink.table.catalog
-
A table change to drop the watermark.
- TableChange.First - Class in org.apache.flink.table.catalog
-
Column position FIRST means the specified column should be the first column.
- TableChange.MaterializedTableChange - Interface in org.apache.flink.table.catalog
-
TableChange.MaterializedTableChange
represents the modification of the materialized table. - TableChange.ModifyColumn - Class in org.apache.flink.table.catalog
-
A base schema change to modify a column.
- TableChange.ModifyColumnComment - Class in org.apache.flink.table.catalog
-
A table change to modify the column comment.
- TableChange.ModifyColumnName - Class in org.apache.flink.table.catalog
-
A table change to modify the column name.
- TableChange.ModifyColumnPosition - Class in org.apache.flink.table.catalog
-
A table change to modify the column position.
- TableChange.ModifyDefinitionQuery - Class in org.apache.flink.table.catalog
-
A table change to modify the definition query.
- TableChange.ModifyDistribution - Class in org.apache.flink.table.catalog
-
A table change to modify a distribution.
- TableChange.ModifyPhysicalColumnType - Class in org.apache.flink.table.catalog
-
A table change that modify the physical column data type.
- TableChange.ModifyRefreshHandler - Class in org.apache.flink.table.catalog
-
A table change to modify materialized table refresh handler.
- TableChange.ModifyRefreshStatus - Class in org.apache.flink.table.catalog
-
A table change to modify materialized table refresh status.
- TableChange.ModifyUniqueConstraint - Class in org.apache.flink.table.catalog
-
A table change to modify a unique constraint.
- TableChange.ModifyWatermark - Class in org.apache.flink.table.catalog
-
A table change to modify the watermark.
- TableChange.ResetOption - Class in org.apache.flink.table.catalog
-
A table change to reset the table option.
- TableChange.SetOption - Class in org.apache.flink.table.catalog
-
A table change to set the table option.
- TableColumn - Class in org.apache.flink.table.legacy.api
-
Deprecated.See
ResolvedSchema
andColumn
. - TableColumn.ComputedColumn - Class in org.apache.flink.table.legacy.api
-
Deprecated.Representation of a computed column.
- TableColumn.MetadataColumn - Class in org.apache.flink.table.legacy.api
-
Deprecated.Representation of a metadata column.
- TableColumn.PhysicalColumn - Class in org.apache.flink.table.legacy.api
-
Deprecated.Representation of a physical column.
- TableConnectorUtils - Class in org.apache.flink.table.utils
-
Utilities for table sources and sinks.
- TableDistribution - Class in org.apache.flink.table.catalog
-
Defines whether the given table is distributed across buckets using a specified algorithm and given columns.
- TableDistribution.Kind - Enum in org.apache.flink.table.catalog
-
Distribution kind.
- TableException - Exception in org.apache.flink.table.api
-
General Exception for all errors during table handling.
- TableException(String) - Constructor for exception org.apache.flink.table.api.TableException
- TableException(String, Throwable) - Constructor for exception org.apache.flink.table.api.TableException
- tableExists(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Check if a table or view exists in this catalog.
- TableFactory - Interface in org.apache.flink.table.legacy.factories
-
Deprecated.This interface has been replaced by
Factory
. - TableFactoryService - Class in org.apache.flink.table.factories
-
Deprecated.
- TableFactoryService() - Constructor for class org.apache.flink.table.factories.TableFactoryService
-
Deprecated.
- TableFunction<T> - Class in org.apache.flink.table.functions
-
Base class for a user-defined table function.
- TableFunction() - Constructor for class org.apache.flink.table.functions.TableFunction
- TableFunctionDefinition - Class in org.apache.flink.table.functions
-
Deprecated.Non-legacy functions can simply omit this wrapper for declarations.
- TableFunctionDefinition(String, TableFunction<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- TableFunctionProvider<T> - Interface in org.apache.flink.table.legacy.connector.source
-
Deprecated.Please use
LookupFunctionProvider
to implement synchronous lookup table. - TableNotExistException - Exception in org.apache.flink.table.api
-
Exception for an operation on a nonexistent table.
- TableNotExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to operate on a table (or view) that doesn't exist.
- TableNotExistException(String, String) - Constructor for exception org.apache.flink.table.api.TableNotExistException
- TableNotExistException(String, String, Throwable) - Constructor for exception org.apache.flink.table.api.TableNotExistException
- TableNotExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotExistException
- TableNotExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotExistException
- TableNotPartitionedException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to operate partition on a non-partitioned table.
- TableNotPartitionedException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotPartitionedException
- TableNotPartitionedException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotPartitionedException
- TablePartitionedException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to operate non-partitioned on a partitioned table.
- TablePartitionedException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TablePartitionedException
- TablePartitionedException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TablePartitionedException
- TableRuntimeException - Exception in org.apache.flink.table.api
-
Exception for errors occurring in the runtime.
- TableRuntimeException(String) - Constructor for exception org.apache.flink.table.api.TableRuntimeException
- TableRuntimeException(String, Throwable) - Constructor for exception org.apache.flink.table.api.TableRuntimeException
- TableSchema - Class in org.apache.flink.table.legacy.api
-
Deprecated.This class has been deprecated as part of FLIP-164. It has been replaced by two more dedicated classes
Schema
andResolvedSchema
. UseSchema
for declaration in APIs.ResolvedSchema
is offered by the framework after resolution and validation. - TableSchema(String[], TypeInformation<?>[]) - Constructor for class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Use the
TableSchema.Builder
instead. - TableSchema.Builder - Class in org.apache.flink.table.legacy.api
-
Deprecated.Builder for creating a
TableSchema
. - TableSchemaUtils - Class in org.apache.flink.table.utils
-
Utilities to
TableSchema
. - TableSchemaUtils() - Constructor for class org.apache.flink.table.utils.TableSchemaUtils
- TableSemantics - Interface in org.apache.flink.table.functions
-
Provides call information about the table that has been passed to a table argument.
- tableSemanticsFor(String) - Method in interface org.apache.flink.table.functions.ProcessTableFunction.Context
-
Returns additional information about the semantics of a table argument.
- TableSink<T> - Interface in org.apache.flink.table.legacy.sinks
-
Deprecated.This interface has been replaced by
DynamicTableSink
. The new interface consumes internal data structures. See FLIP-95 for more information. - TableSinkBase<T> - Class in org.apache.flink.table.sinks
-
Deprecated.This class is implementing the deprecated
TableSink
interface. ImplementDynamicTableSink
directly instead. - TableSinkBase() - Constructor for class org.apache.flink.table.sinks.TableSinkBase
-
Deprecated.
- TableSinkFactory<T> - Interface in org.apache.flink.table.legacy.factories
-
Deprecated.This interface has been replaced by
DynamicTableSinkFactory
. The new interface consumes internal data structures. See FLIP-95 for more information. - TableSinkFactory.Context - Interface in org.apache.flink.table.legacy.factories
-
Deprecated.Context of table sink creation.
- TableSinkFactoryContextImpl - Class in org.apache.flink.table.factories
-
Deprecated.
- TableSinkFactoryContextImpl(ObjectIdentifier, CatalogTable, ReadableConfig, boolean, boolean) - Constructor for class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- TableSource<T> - Interface in org.apache.flink.table.legacy.sources
-
Deprecated.This interface has been replaced by
DynamicTableSource
. The new interface produces internal data structures. See FLIP-95 for more information. - TableSourceFactory<T> - Interface in org.apache.flink.table.legacy.factories
-
Deprecated.This interface has been replaced by
DynamicTableSourceFactory
. The new interface produces internal data structures. See FLIP-95 for more information. - TableSourceFactory.Context - Interface in org.apache.flink.table.legacy.factories
-
Deprecated.Context of table source creation.
- TableSourceFactoryContextImpl - Class in org.apache.flink.table.factories
-
Deprecated.
- TableSourceFactoryContextImpl(ObjectIdentifier, CatalogTable, ReadableConfig, boolean) - Constructor for class org.apache.flink.table.factories.TableSourceFactoryContextImpl
-
Deprecated.
- TableSourceValidation - Class in org.apache.flink.table.sources
-
Logic to validate
TableSource
types. - TableStats - Class in org.apache.flink.table.plan.stats
-
Table statistics.
- TableStats(long) - Constructor for class org.apache.flink.table.plan.stats.TableStats
- TableStats(long, Map<String, ColumnStats>) - Constructor for class org.apache.flink.table.plan.stats.TableStats
- TableSymbol - Interface in org.apache.flink.table.expressions
-
The base interface for all table symbols.
- takesRowAsInput() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- takesRowAsInput() - Method in interface org.apache.flink.table.functions.python.PythonFunction
-
Returns Whether the Python function takes row as input instead of each columns of a row.
- takesRowAsInput() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
- takesRowAsInput() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- takesRowAsInput() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
- TAN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TANH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TEMPORAL_OVERLAPS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TEMPORAL_OVERLAPS - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
See
TemporalOverlapsInputTypeStrategy
. - TemporalTableFunction - Class in org.apache.flink.table.functions
-
Class representing temporal table function over some history table.
- TemporalTableFunction() - Constructor for class org.apache.flink.table.functions.TemporalTableFunction
- temporary(FunctionIdentifier, FunctionDefinition, List<ResolvedExpression>, DataType) - Static method in class org.apache.flink.table.expressions.CallExpression
-
Creates a
CallExpression
to a temporary function (potentially shadowing aCatalog
function or providing a system function). - TemporaryOperationListener - Interface in org.apache.flink.table.catalog
-
This interface is for a
Catalog
to listen on temporary object operations. - ThreadLocalCache<K,V> - Class in org.apache.flink.table.utils
-
Provides a thread local cache with a maximum cache size per thread.
- ThreadLocalCache() - Constructor for class org.apache.flink.table.utils.ThreadLocalCache
- ThreadLocalCache(int) - Constructor for class org.apache.flink.table.utils.ThreadLocalCache
- TIME - org.apache.flink.table.types.logical.LogicalTypeFamily
- TIME() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a time WITHOUT time zone
TIME
with no fractional seconds by default. - TIME(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a time WITHOUT time zone
TIME(p)
wherep
is the number of digits of fractional seconds (=precision). - TIME_ATTRIBUTES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TIME_WITHOUT_TIME_ZONE - org.apache.flink.table.types.logical.LogicalTypeRoot
- timeColumn() - Method in interface org.apache.flink.table.functions.TableSemantics
-
Returns information about the time attribute of the passed table.
- TIMED - org.apache.flink.table.connector.source.lookup.LookupOptions.ReloadStrategy
- TimedCacheReloadTrigger - Class in org.apache.flink.table.connector.source.lookup.cache.trigger
-
A trigger that reloads at a specific time and repeats for the given interval in days.
- TimedCacheReloadTrigger(LocalTime, int) - Constructor for class org.apache.flink.table.connector.source.lookup.cache.trigger.TimedCacheReloadTrigger
- TimedCacheReloadTrigger(OffsetTime, int) - Constructor for class org.apache.flink.table.connector.source.lookup.cache.trigger.TimedCacheReloadTrigger
- TimeIndicatorTypeInfo - Class in org.apache.flink.table.typeutils
-
Deprecated.This class will be removed in future versions as it is used for the old type system. It is recommended to use
DataTypes
instead. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information. - TimeIndicatorTypeInfo(boolean) - Constructor for class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- TimeIntervalTypeInfo<T> - Class in org.apache.flink.table.typeutils
-
Deprecated.This class will be removed in future versions as it is used for the old type system. It is recommended to use
DataTypes
instead. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information. - TimeIntervalUnit - Enum in org.apache.flink.table.expressions
-
Units for working with time intervals.
- TimePointUnit - Enum in org.apache.flink.table.expressions
-
Units for working with points in time.
- TIMES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TIMESTAMP - org.apache.flink.table.types.logical.LogicalTypeFamily
- TIMESTAMP() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITHOUT time zone
TIMESTAMP
with 6 digits of fractional seconds by default. - TIMESTAMP(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITHOUT time zone
TIMESTAMP(p)
wherep
is the number of digits of fractional seconds (=precision). - TIMESTAMP_DIFF - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TIMESTAMP_LTZ() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH LOCAL time zone.
- TIMESTAMP_LTZ(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH LOCAL time zone.
- TIMESTAMP_WITH_LOCAL_TIME_ZONE - org.apache.flink.table.types.logical.LogicalTypeRoot
- TIMESTAMP_WITH_LOCAL_TIME_ZONE() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH LOCAL time zone
TIMESTAMP WITH LOCAL TIME ZONE
with 6 digits of fractional seconds by default. - TIMESTAMP_WITH_LOCAL_TIME_ZONE(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH LOCAL time zone
TIMESTAMP(p) WITH LOCAL TIME ZONE
wherep
is the number of digits of fractional seconds (=precision). - TIMESTAMP_WITH_TIME_ZONE - org.apache.flink.table.types.logical.LogicalTypeRoot
- TIMESTAMP_WITH_TIME_ZONE() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH time zone
TIMESTAMP WITH TIME ZONE
with 6 digits of fractional seconds by default. - TIMESTAMP_WITH_TIME_ZONE(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH time zone
TIMESTAMP(p) WITH TIME ZONE
wherep
is the number of digits of fractional seconds (=precision). - TIMESTAMP_WITHOUT_TIME_ZONE - org.apache.flink.table.types.logical.LogicalTypeRoot
- timestampCeil(DateTimeUtils.TimeUnitRange, long, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Keep the algorithm consistent with Calcite DateTimeUtils.julianDateFloor, but here we take time zone into account.
- TimestampColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Timestamp column vector.
- TimestampData - Class in org.apache.flink.table.data
-
An internal data structure representing data of
TimestampType
andLocalZonedTimestampType
. - TimestampExtractor - Class in org.apache.flink.table.legacy.sources.tsextractors
-
Deprecated.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() - Constructor for class org.apache.flink.table.legacy.sources.tsextractors.TimestampExtractor
-
Deprecated.
- TimestampExtractorUtils - Class in org.apache.flink.table.sources.tsextractors
-
Utility methods for dealing with
TimestampExtractor
. - timestampFloor(DateTimeUtils.TimeUnitRange, long, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- TimestampKind - Enum in org.apache.flink.table.types.logical
-
Internal timestamp kind for attaching time attribute metadata to timestamps with or without a time zone.
- timestampMillisToDate(long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Get date from a timestamp.
- timestampMillisToTime(long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Get time from a timestamp.
- timestampsFromExtractor(TimestampExtractor) - Method in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.Sets a custom timestamp extractor to be used for the rowtime attribute.
- timestampsFromField(String) - Method in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.Sets a built-in timestamp extractor that converts an existing
Long
orTypes.SQL_TIMESTAMP
field into the rowtime attribute. - timestampsFromSource() - Method in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.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.
- timestampToTimestampWithLocalZone(TimestampData, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- TimestampType - Class in org.apache.flink.table.types.logical
-
Logical type of a timestamp WITHOUT time zone consisting of
year-month-day hour:minute:second[.fractional]
with up to nanosecond precision and values ranging from0000-01-01 00:00:00.000000000
to9999-12-31 23:59:59.999999999
. - TimestampType() - Constructor for class org.apache.flink.table.types.logical.TimestampType
- TimestampType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.TimestampType
- TimestampType(boolean, TimestampKind, int) - Constructor for class org.apache.flink.table.types.logical.TimestampType
-
Internal constructor that allows attaching additional metadata about time attribute properties.
- TimestampType(int) - Constructor for class org.apache.flink.table.types.logical.TimestampType
- timestampWithLocalZoneToDate(TimestampData, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- timestampWithLocalZoneToTime(TimestampData, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- timestampWithLocalZoneToTimestamp(TimestampData, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- timeToSqlTypes() - Static method in class org.apache.flink.table.types.inference.TypeTransformations
- timeToTimestampWithLocalZone(int, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- TimeType - Class in org.apache.flink.table.types.logical
-
Logical type of a time WITHOUT time zone consisting of
hour:minute:second[.fractional]
with up to nanosecond precision and values ranging from00:00:00.000000000
to23:59:59.999999999
. - TimeType() - Constructor for class org.apache.flink.table.types.logical.TimeType
- TimeType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.TimeType
- TimeType(int) - Constructor for class org.apache.flink.table.types.logical.TimeType
- TINYINT - org.apache.flink.table.types.logical.LogicalTypeRoot
- TINYINT() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a 1-byte signed integer with values from -128 to 127.
- TinyIntType - Class in org.apache.flink.table.types.logical
-
Logical type of a 1-byte signed integer with values from -128 to 127.
- TinyIntType() - Constructor for class org.apache.flink.table.types.logical.TinyIntType
- TinyIntType(boolean) - Constructor for class org.apache.flink.table.types.logical.TinyIntType
- to(int) - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
- TO_BASE64 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TO_DATE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TO_INTERNAL_CLASS - Static variable in class org.apache.flink.table.types.inference.TypeTransformations
-
Transformation that uses internal data structures for all conversion classes.
- TO_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TO_TIMESTAMP_LTZ - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TO_TIMESTAMP_LTZ - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
- toBigDecimal() - Method in class org.apache.flink.table.data.DecimalData
-
Converts this
DecimalData
into an instance ofBigDecimal
. - toBooleanArray() - Method in interface org.apache.flink.table.data.ArrayData
- toBooleanArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- toBooleanArray() - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- toBooleanArray() - Method in class org.apache.flink.table.data.GenericArrayData
- toByteArray() - Method in interface org.apache.flink.table.data.ArrayData
- toByteArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- toByteArray() - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- toByteArray() - Method in class org.apache.flink.table.data.GenericArrayData
- toBytes() - Method in class org.apache.flink.table.data.binary.BinaryStringData
- toBytes() - Method in interface org.apache.flink.table.data.StringData
-
Converts this
StringData
object to a UTF-8 byte array. - toBytes(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
- toBytes(TypeSerializer<T>) - Method in interface org.apache.flink.table.data.RawValueData
-
Converts this
RawValueData
into a byte array. - toDataType(TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
-
Deprecated.
- toDataType(DataTypeFactory) - Method in class org.apache.flink.table.types.UnresolvedDataType
-
Converts this instance to a resolved
DataType
possibly enriched with additional nullability and conversion class information. - toDataType(DataTypeFactory, TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
-
Converts the given
TypeInformation
intoDataType
. - toDataType(DataTypeFactory, TypeInformation<?>, boolean) - Static method in class org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
-
Converts the given
TypeInformation
intoDataType
but allows to make all fields nullable independent of the nullability in the serialization stack. - toDataType(LogicalType) - Static method in class org.apache.flink.table.types.utils.LogicalTypeDataTypeConverter
-
Returns the data type of a logical type without explicit conversions.
- toDoubleArray() - Method in interface org.apache.flink.table.data.ArrayData
- toDoubleArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- toDoubleArray() - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- toDoubleArray() - Method in class org.apache.flink.table.data.GenericArrayData
- toExternal(Object) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.DataStructureConverter
-
Converts the given internal structure into an external object.
- toFloatArray() - Method in interface org.apache.flink.table.data.ArrayData
- toFloatArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- toFloatArray() - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- toFloatArray() - Method in class org.apache.flink.table.data.GenericArrayData
- toInstant() - Method in class org.apache.flink.table.data.TimestampData
-
Converts this
TimestampData
object to aInstant
. - toIntArray() - Method in interface org.apache.flink.table.data.ArrayData
- toIntArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- toIntArray() - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- toIntArray() - Method in class org.apache.flink.table.data.GenericArrayData
- toInternal() - Method in class org.apache.flink.table.types.DataType
-
Creates a copy of this
DataType
instance with the internal data type conversion classes. - toInternal(Object) - Method in interface org.apache.flink.table.connector.source.DynamicTableSource.DataStructureConverter
-
Converts the given object into an internal data structure.
- toInternal(Date) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Converts the Java type used for UDF parameters of SQL DATE type (
Date
) to internal representation (int). - toInternal(Time) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Converts the Java type used for UDF parameters of SQL TIME type (
Time
) to internal representation (int). - toInternal(Timestamp) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Converts the Java type used for UDF parameters of SQL TIMESTAMP type (
Timestamp
) to internal representation (long). - toInternal(LocalDate) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- toInternal(LocalTime) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- toInternalConversionClass(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
-
Returns the conversion class for the given
LogicalType
that is used by the table runtime as internal data structure. - toInternalDataType(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
- toInternalDataType(LogicalType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Creates a
DataType
from the givenLogicalType
with internal data structures. - toJavaMap(LogicalType, LogicalType) - Method in class org.apache.flink.table.data.binary.BinaryMapData
- toLegacyTypeInfo(DataType) - Static method in class org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
-
Deprecated.
- toList() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
-
List of the component names of this object identifier.
- toList() - Method in class org.apache.flink.table.functions.FunctionIdentifier
-
List of the component names of this function identifier.
- toLocalDate(int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- toLocalDateTime() - Method in class org.apache.flink.table.data.TimestampData
-
Converts this
TimestampData
object to aLocalDateTime
. - toLocalDateTime(long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- toLocalTime(int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- toLogicalType(DataType) - Static method in class org.apache.flink.table.types.utils.LogicalTypeDataTypeConverter
-
Returns the logical type of a data type.
- toLongArray() - Method in interface org.apache.flink.table.data.ArrayData
- toLongArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- toLongArray() - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- toLongArray() - Method in class org.apache.flink.table.data.GenericArrayData
- toLowerCase() - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Converts all of the characters in this
BinaryStringData
to lower case. - toNestedIndexes() - Method in class org.apache.flink.table.connector.Projection
-
Convert this instance to a nested projection index paths.
- toNullable() - Static method in class org.apache.flink.table.types.inference.TypeTransformations
-
Returns a type transformation that transforms data type to nullable data type but keeps other information unchanged.
- toObject(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
- toObject(TypeSerializer<T>) - Method in interface org.apache.flink.table.data.RawValueData
-
Converts this
RawValueData
into a Java object. - toObjectArray() - Method in class org.apache.flink.table.data.GenericArrayData
-
Converts this
GenericArrayData
into an array of JavaObject
. - toObjectArray(LogicalType) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- toObjectPath() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
-
Convert this
ObjectIdentifier
toObjectPath
. - toPersistedRowDataType() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Converts all persisted columns of this schema into a (possibly nested) row data type.
- toPhysicalRowDataType() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Converts all physical columns of this schema into a (possibly nested) row data type.
- toPhysicalRowDataType() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Converts all physical columns of this schema into a (possibly nested) row data type.
- toProperties() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- toProperties() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogModel
-
Serializes this instance into a map of string-based properties.
- toProperties() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
-
Convenience method for
Catalog
implementations for serializing instances of this class into a map of string properties. - toProperties() - Method in interface org.apache.flink.table.legacy.descriptors.Descriptor
-
Deprecated.Converts this descriptor into a set of properties.
- toProperties() - Method in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.Converts this descriptor into a set of properties.
- toProperties() - Method in class org.apache.flink.table.legacy.descriptors.Schema
-
Deprecated.Converts this descriptor into a set of properties.
- toProperties() - Method in class org.apache.flink.table.legacy.sources.tsextractors.TimestampExtractor
-
Deprecated.This method is a default implementation that uses java serialization and it is discouraged.
- toProperties() - Method in class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
- toProperties() - Method in class org.apache.flink.table.sources.wmstrategies.WatermarkStrategy
-
This method is a default implementation that uses java serialization and it is discouraged.
- toResolvedCatalogTable() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
-
Convert this object to a
ResolvedCatalogTable
object for planner optimize query. - toRowDataType() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Converts all columns of this schema into a (possibly nested) row data type.
- toRowType() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Use
TableSchema.toRowDataType()
instead. - toRowType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
-
Converts any logical type to a row type.
- toSchema() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Helps to migrate to the new
Schema
class. - toSchema(Map<String, String>) - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.Helps to migrate to the new
Schema
class, retain comments when needed. - toShortArray() - Method in interface org.apache.flink.table.data.ArrayData
- toShortArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
- toShortArray() - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
- toShortArray() - Method in class org.apache.flink.table.data.GenericArrayData
- toSinkRowDataType() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Converts all persisted columns of this schema into a (possibly nested) row data type.
- toSourceRowDataType() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Converts all columns of this schema into a (possibly nested) row data type.
- toSQLDate(int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Converts the internal representation of a SQL DATE (int) to the Java type used for UDF parameters (
Date
). - toSQLTime(int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Converts the internal representation of a SQL TIME (int) to the Java type used for UDF parameters (
Time
). - toSQLTimestamp(long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Converts the internal representation of a SQL TIMESTAMP (long) to the Java type used for UDF parameters (
Timestamp
). - toStaticTrait() - Method in enum org.apache.flink.table.annotation.ArgumentTrait
- toString() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
- toString() - Method in class org.apache.flink.table.api.DataTypes.Resolution
- toString() - Method in class org.apache.flink.table.api.Schema
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedConstraint
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
- toString() - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
- toString() - Method in class org.apache.flink.table.catalog.Column
- toString() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
- toString() - Method in class org.apache.flink.table.catalog.DefaultCatalogModel
- toString() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
- toString() - Method in class org.apache.flink.table.catalog.DefaultResolvedCatalogModel
- toString() - Method in class org.apache.flink.table.catalog.IntervalFreshness
- toString() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
- toString() - Method in class org.apache.flink.table.catalog.ObjectPath
- toString() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
- toString() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
- toString() - Method in class org.apache.flink.table.catalog.ResolvedSchema
- toString() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
- toString() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
- toString() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
- toString() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
- toString() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
- toString() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
- toString() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
- toString() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
- toString() - Method in class org.apache.flink.table.catalog.stats.Date
- toString() - Method in class org.apache.flink.table.catalog.TableChange.AddColumn
- toString() - Method in class org.apache.flink.table.catalog.TableChange.AddDistribution
- toString() - Method in class org.apache.flink.table.catalog.TableChange.AddUniqueConstraint
- toString() - Method in class org.apache.flink.table.catalog.TableChange.AddWatermark
- toString() - Method in class org.apache.flink.table.catalog.TableChange.After
- toString() - Method in class org.apache.flink.table.catalog.TableChange.DropColumn
- toString() - Method in class org.apache.flink.table.catalog.TableChange.DropConstraint
- toString() - Method in class org.apache.flink.table.catalog.TableChange.DropDistribution
- toString() - Method in class org.apache.flink.table.catalog.TableChange.DropWatermark
- toString() - Method in class org.apache.flink.table.catalog.TableChange.First
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumn
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumnComment
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumnName
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyColumnPosition
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyDefinitionQuery
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyDistribution
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyPhysicalColumnType
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyRefreshHandler
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyRefreshStatus
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyUniqueConstraint
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ModifyWatermark
- toString() - Method in class org.apache.flink.table.catalog.TableChange.ResetOption
- toString() - Method in class org.apache.flink.table.catalog.TableChange.SetOption
- toString() - Method in class org.apache.flink.table.catalog.TableDistribution
- toString() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
- toString() - Method in class org.apache.flink.table.catalog.WatermarkSpec
- toString() - Method in class org.apache.flink.table.connector.ChangelogMode
- toString() - Method in class org.apache.flink.table.connector.Projection
- toString() - Method in class org.apache.flink.table.connector.source.DynamicFilteringData
- toString() - Method in class org.apache.flink.table.connector.source.DynamicFilteringEvent
- toString() - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
- toString() - Method in class org.apache.flink.table.data.binary.BinaryStringData
- toString() - Method in class org.apache.flink.table.data.DecimalData
- toString() - Method in class org.apache.flink.table.data.GenericRowData
- toString() - Method in interface org.apache.flink.table.data.StringData
-
Converts this
StringData
object to aString
. - toString() - Method in class org.apache.flink.table.data.TimestampData
- toString() - Method in class org.apache.flink.table.data.utils.JoinedRowData
- toString() - Method in class org.apache.flink.table.data.utils.ProjectedRowData
- toString() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- toString() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- toString() - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- toString() - Method in class org.apache.flink.table.expressions.AggregateExpression
- toString() - Method in class org.apache.flink.table.expressions.CallExpression
- toString() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
- toString() - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
- toString() - Method in class org.apache.flink.table.expressions.SqlCallExpression
- toString() - Method in class org.apache.flink.table.expressions.TypeLiteralExpression
- toString() - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
- toString() - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
Deprecated.
- toString() - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- toString() - Method in class org.apache.flink.table.functions.FunctionIdentifier
- toString() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
- toString() - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
- toString() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
- toString() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
- toString() - Method in class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- toString() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- toString() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- toString() - Method in class org.apache.flink.table.functions.UserDefinedFunction
-
Returns the name of the UDF that is used for plan explanation and logging.
- toString() - Method in class org.apache.flink.table.legacy.api.TableColumn
-
Deprecated.
- toString() - Method in class org.apache.flink.table.legacy.api.TableSchema
-
Deprecated.
- toString() - Method in class org.apache.flink.table.legacy.api.WatermarkSpec
-
Deprecated.
- toString() - Method in class org.apache.flink.table.plan.stats.ColumnStats
- toString() - Method in class org.apache.flink.table.plan.stats.TableStats
- toString() - Method in class org.apache.flink.table.resource.ResourceUri
- toString() - Method in class org.apache.flink.table.types.DataType
- toString() - Method in class org.apache.flink.table.types.inference.StaticArgument
- toString() - Method in class org.apache.flink.table.types.logical.LogicalType
- toString() - Method in class org.apache.flink.table.types.UnresolvedDataType
- toString() - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- toString() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- toString() - Method in enum org.apache.flink.table.watermark.WatermarkEmitStrategy
- toString() - Method in class org.apache.flink.table.watermark.WatermarkParams
- toString(String) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- toString(String, String) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- toString(Map<String, String>) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- toTimestamp() - Method in class org.apache.flink.table.data.TimestampData
-
Converts this
TimestampData
object to aTimestamp
. - toTimestampData(double, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- toTimestampData(long, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- toTimestampData(DecimalData, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- ToTimestampLtzTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy of
TO_TIMESTAMP_LTZ
. - ToTimestampLtzTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.ToTimestampLtzTypeStrategy
- toTimestampMillis(LocalDateTime) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- toTopLevelIndexes() - Method in class org.apache.flink.table.connector.Projection
-
Convert this instance to a projection of top level indexes.
- toUnscaledBytes() - Method in class org.apache.flink.table.data.DecimalData
-
Returns a byte array describing the unscaled value of this
DecimalData
. - toUnscaledLong() - Method in class org.apache.flink.table.data.DecimalData
-
Returns a long describing the unscaled value of this
DecimalData
. - toUpperCase() - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Converts all of the characters in this
BinaryStringData
to upper case. - transform(DataTypeFactory, DataType) - Method in class org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
- transform(DataTypeFactory, DataType) - Method in interface org.apache.flink.table.types.inference.TypeTransformation
-
Transforms the given data type to a different data type.
- transform(DataTypeFactory, DataType, TypeTransformation...) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Transforms the given data type to a different data type using the given transformations.
- transform(DataType) - Method in class org.apache.flink.table.types.inference.transforms.DataTypeConversionClassTransformation
- transform(DataType) - Method in class org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
- transform(DataType) - Method in class org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
- transform(DataType) - Method in interface org.apache.flink.table.types.inference.TypeTransformation
-
Transforms the given data type to a different data type.
- transform(DataType, TypeTransformation...) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Transforms the given data type to a different data type using the given transformations.
- transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.We need to override this as a
LegacySerializerSnapshotTransformer
because in Flink 1.6.x and below, this serializer was incorrectly returning directly the snapshot of the nested list serializer as its own snapshot. - transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.We need to override this as a
LegacySerializerSnapshotTransformer
because in Flink 1.6.x and below, this serializer was incorrectly returning directly the snapshot of the nested map serializer as its own snapshot. - TRANSLATE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- triggerReload() - Method in interface org.apache.flink.table.connector.source.lookup.cache.trigger.CacheReloadTrigger.Context
-
Trigger a reload operation on the cache.
- trim() - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Returns a string whose value is this string, with any leading and trailing whitespace removed.
- TRIM - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TRIM - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Special sql syntax for TRIM.
- TRUE - org.apache.flink.table.annotation.HintFlag
- TRUE - org.apache.flink.table.api.JsonExistsOnError
- truncate(TimestampData, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- TRUNCATE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TRY_CAST - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TWO_EQUALS_COMPARABLE - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
Strategy that checks all types are equals comparable with each other.
- TWO_FULLY_COMPARABLE - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
Strategy that checks all types are fully comparable with each other.
- type() - Method in annotation type org.apache.flink.table.annotation.ArgumentHint
-
The data type hint for the argument.
- type() - Method in annotation type org.apache.flink.table.annotation.StateHint
-
The data type hint for the state entry.
- TYPE - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- TYPE_LITERAL - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that checks if an argument is a type literal.
- TYPE_OF - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- TypeConversions - Class in org.apache.flink.table.types.utils
- typedArguments(List<DataType>) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Deprecated.Use
TypeInference.Builder.staticArguments(List)
instead. - typedArguments(DataType...) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Deprecated.
- typedArguments(DataType...) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Deprecated.
- TypedSetters - Interface in org.apache.flink.table.data.binary
-
Provide type specialized setters to reduce if/else and eliminate box and unbox.
- TypeInference - Class in org.apache.flink.table.types.inference
-
Provides logic for the type inference of function calls.
- TypeInference.Builder - Class in org.apache.flink.table.types.inference
-
Builder for configuring and creating instances of
TypeInference
. - TypeInferenceExtractor - Class in org.apache.flink.table.types.extraction
-
Reflection-based utility for extracting a
TypeInference
from a supported subclass ofUserDefinedFunction
. - TypeInferenceExtractor() - Constructor for class org.apache.flink.table.types.extraction.TypeInferenceExtractor
- TypeInferenceUtil - Class in org.apache.flink.table.types.inference
-
Utility for performing type inference.
- TypeInferenceUtil.Result - Class in org.apache.flink.table.types.inference
-
The result of a type inference run.
- TypeInferenceUtil.SurroundingInfo - Interface in org.apache.flink.table.types.inference
-
Information what the outer world (i.e. an outer wrapping call) expects from the current function call.
- TypeInfoDataTypeConverter - Class in org.apache.flink.table.types.utils
-
Converter from
TypeInformation
toDataType
. - TypeInfoDataTypeConverter() - Constructor for class org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
- TypeInformationRawType<T> - Class in org.apache.flink.table.legacy.types.logical
-
Deprecated.Use
RawType
instead. - TypeInformationRawType() - Constructor for class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- TypeInformationRawType(boolean, TypeInformation<T>) - Constructor for class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- TypeInformationRawType(TypeInformation<T>) - Constructor for class org.apache.flink.table.legacy.types.logical.TypeInformationRawType
-
Deprecated.
- TypeLiteralArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy that checks if an argument is a type literal.
- TypeLiteralArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.TypeLiteralArgumentTypeStrategy
- TypeLiteralExpression - Class in org.apache.flink.table.expressions
-
Expression that wraps
DataType
as a literal. - TypeLiteralExpression(DataType) - Constructor for class org.apache.flink.table.expressions.TypeLiteralExpression
- TypeMappingUtils - Class in org.apache.flink.table.utils
-
Utility methods for dealing with field types in
TableSource
andTableSink
. - Types - Class in org.apache.flink.table.legacy.api
-
Deprecated.This class will be removed in future versions as it uses the old type system. It is recommended to use
DataTypes
instead which uses the new type system based on instances ofDataType
. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information. - TypeStrategies - Class in org.apache.flink.table.types.inference
-
Strategies for inferring an output or accumulator data type of a function call.
- TypeStrategy - Interface in org.apache.flink.table.types.inference
-
Strategy for inferring a function call's result data type.
- TypeStringUtils - Class in org.apache.flink.table.legacy.utils
-
Deprecated.This utility is based on
TypeInformation
. However, the Table & SQL API is currently updated to useDataType
s based onLogicalType
s. UseLogicalTypeParser
instead. - TypeStringUtils() - Constructor for class org.apache.flink.table.legacy.utils.TypeStringUtils
-
Deprecated.
- TypeTransformation - Interface in org.apache.flink.table.types.inference
-
Transforms one data type to another.
- TypeTransformations - Class in org.apache.flink.table.types.inference
-
Transformations for transforming one data type to another.
U
- UNARY_PREFIX_OP - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Prefix unary operator syntax, as in "- x".
- UNARY_SUFFIX_OP - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
-
Postfix unary operator syntax, as in "x ++".
- UNBOUNDED_RANGE - org.apache.flink.table.api.OverWindowRange
- UNBOUNDED_ROW - org.apache.flink.table.api.OverWindowRange
- UNCONDITIONAL_ARRAY - org.apache.flink.table.api.JsonQueryWrapper
- unescapePathName(String) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
- unhex(byte[]) - Static method in class org.apache.flink.table.utils.EncodingUtils
-
Converts an array of characters representing hexadecimal values into an array of bytes of those same values.
- UNHEX - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- UNIQUE_KEY - org.apache.flink.table.catalog.Constraint.ConstraintType
- UNIQUE_KEY - org.apache.flink.table.legacy.api.constraints.Constraint.ConstraintType
-
Deprecated.
- UniqueConstraint - Class in org.apache.flink.table.catalog
-
A unique key constraint.
- UniqueConstraint - Class in org.apache.flink.table.legacy.api.constraints
-
Deprecated.See
ResolvedSchema
andUniqueConstraint
. - UNIX_TIMESTAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- unixDateCeil(DateTimeUtils.TimeUnitRange, long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- unixDateFloor(DateTimeUtils.TimeUnitRange, long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- unixTimestamp() - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Returns a Unix timestamp in seconds since '1970-01-01 00:00:00' UTC as an unsigned integer.
- unixTimestamp(long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Returns the value of the timestamp to seconds since '1970-01-01 00:00:00' UTC.
- unixTimestamp(String, String, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Returns the value of the argument as an unsigned integer in seconds since '1970-01-01 00:00:00' UTC.
- unixTimestamp(String, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Returns the value of the argument as an unsigned integer in seconds since '1970-01-01 00:00:00' UTC.
- unixTimestampCeil(DateTimeUtils.TimeUnitRange, long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- unixTimestampFloor(DateTimeUtils.TimeUnitRange, long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
- UNKNOWN - org.apache.flink.table.annotation.ExtractionVersion
-
Default if no version is specified.
- UNKNOWN - org.apache.flink.table.annotation.HintFlag
- UNKNOWN - org.apache.flink.table.annotation.InputGroup
-
Default if no group is specified.
- UNKNOWN - org.apache.flink.table.api.JsonExistsOnError
- UNKNOWN - org.apache.flink.table.catalog.TableDistribution.Kind
- UNKNOWN - Static variable in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
- UNKNOWN - Static variable in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
- UNKNOWN - Static variable in class org.apache.flink.table.plan.stats.ColumnStats
-
Unknown definition for column stats.
- UNKNOWN - Static variable in class org.apache.flink.table.plan.stats.TableStats
-
Unknown definition for table stats: Unknown
TableStats.rowCount
is -1. - UnknownCallContext - Class in org.apache.flink.table.types.inference.utils
-
A
CallContext
with unknown data types. - UnknownCallContext(DataTypeFactory, String, FunctionDefinition, int, boolean) - Constructor for class org.apache.flink.table.types.inference.utils.UnknownCallContext
- unparse(String, List<ResolvedExpression>) - Method in interface org.apache.flink.table.functions.SqlCallSyntax
- unparseDistinct(String, List<ResolvedExpression>) - Method in interface org.apache.flink.table.functions.SqlCallSyntax
-
Special case for aggregate functions, which can have a DISTINCT function applied.
- UNRESOLVED - org.apache.flink.table.types.logical.LogicalTypeRoot
- UnresolvedComputedColumn(String, Expression) - Constructor for class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
- UnresolvedComputedColumn(String, Expression, String) - Constructor for class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
- UnresolvedDataType - Class in org.apache.flink.table.types
-
Partially resolved data type that requires a lookup in a catalog or configuration before creating the corresponding
LogicalType
. - UnresolvedDataType(Supplier<String>, Function<DataTypeFactory, DataType>) - Constructor for class org.apache.flink.table.types.UnresolvedDataType
- UnresolvedIdentifier - Class in org.apache.flink.table.catalog
-
Identifier of an object, such as table, view, function or type in a catalog.
- UnresolvedMetadataColumn(String, AbstractDataType<?>, String, boolean) - Constructor for class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
- UnresolvedMetadataColumn(String, AbstractDataType<?>, String, boolean, String) - Constructor for class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
- UnresolvedPhysicalColumn(String, AbstractDataType<?>) - Constructor for class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
- UnresolvedPhysicalColumn(String, AbstractDataType<?>, String) - Constructor for class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
- UnresolvedPrimaryKey(String, List<String>) - Constructor for class org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
- UnresolvedUserDefinedType - Class in org.apache.flink.table.types.logical
-
Placeholder type of an unresolved user-defined type that is identified by an
UnresolvedIdentifier
. - UnresolvedUserDefinedType(boolean, UnresolvedIdentifier) - Constructor for class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- UnresolvedUserDefinedType(UnresolvedIdentifier) - Constructor for class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
- UnresolvedWatermarkSpec(String, Expression) - Constructor for class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
- UNSAFE - Static variable in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
- UNUSED - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See
UnusedTypeStrategy
. - UPDATE - org.apache.flink.table.connector.source.abilities.SupportsRowLevelModificationScan.RowLevelModificationType
- UPDATED_ROWS - org.apache.flink.table.connector.sink.abilities.SupportsRowLevelUpdate.RowLevelUpdateMode
- UPPER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- UPPERCASE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- upsert() - Static method in class org.apache.flink.table.connector.ChangelogMode
-
Shortcut for an upsert changelog that describes idempotent updates on a key and thus does not contain
RowKind.UPDATE_BEFORE
rows. - URL_DECODE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- URL_ENCODE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- USER_DEFINED - org.apache.flink.table.types.logical.LogicalTypeFamily
- UserDefinedFunction - Class in org.apache.flink.table.functions
-
Base class for all user-defined functions.
- UserDefinedFunction() - Constructor for class org.apache.flink.table.functions.UserDefinedFunction
- UserDefinedFunctionHelper - Class in org.apache.flink.table.functions
-
Utility for dealing with subclasses of
UserDefinedFunction
. - UserDefinedType - Class in org.apache.flink.table.types.logical
-
Logical type of a user-defined representation for one or more built-in types.
- UTC_ZONE - Static variable in class org.apache.flink.table.utils.DateTimeUtils
-
The UTC time zone.
- UUID - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
V
- V1 - org.apache.flink.table.annotation.ExtractionVersion
-
Initial reflection-based extraction logic according to FLIP-65.
- validate() - Method in class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
-
Validates the options of the factory.
- validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.ConnectorDescriptorValidator
-
Deprecated.
- validate(DescriptorProperties) - Method in interface org.apache.flink.table.descriptors.DescriptorValidator
-
Deprecated.Performs basic validation such as completeness tests.
- validate(DescriptorProperties) - Method in class org.apache.flink.table.descriptors.FileSystemValidator
-
Deprecated.
- validateArgumentCount(ArgumentCount, int, boolean) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
-
Validates argument counts.
- validateArgumentFields(TypeInformation<?>[]) - Method in interface org.apache.flink.table.legacy.sources.FieldComputer
-
Deprecated.Validates that the fields that the expression references have the correct types.
- validateArray(String, Consumer<String>, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates an array of values.
- validateArray(String, Consumer<String>, int, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates an array of values.
- validateBigDecimal(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a big decimal property.
- validateBigDecimal(String, boolean, BigDecimal, BigDecimal) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a big decimal property.
- validateBoolean(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates that a boolean value is present under the given key.
- validateByte(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a byte property.
- validateByte(String, boolean, byte) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a byte property.
- validateByte(String, boolean, byte, byte) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a byte property.
- validateClass(Class<? extends UserDefinedFunction>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Validates a
UserDefinedFunction
class for usage in the API. - validateClassForRuntime(Class<? extends UserDefinedFunction>, String, Class<?>[], Class<?>, String) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Validates a
UserDefinedFunction
class for usage in the runtime. - validateDataType(String, String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a data type property.
- validateDouble(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a double property.
- validateDouble(String, boolean, double) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a double property.
- validateDouble(String, boolean, double, double) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a double property.
- validateDuration(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a Java
Duration
. - validateDuration(String, boolean, int, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a Java
Duration
. - validateDuration(String, boolean, int, long, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a Java
Duration
. - validateEnum(String, boolean, Map<String, Consumer<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates an enum property with a set of validation logic for each enum value.
- validateEnumValues(String, boolean, List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates an enum property with a set of enum values.
- validateExcept(String...) - Method in class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
-
Validates the options of the factory.
- validateExclusion(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates that the given key is not included in these properties.
- validateFactoryOptions(Set<ConfigOption<?>>, Set<ConfigOption<?>>, ReadableConfig) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Validates the required options and optional options.
- validateFactoryOptions(Factory, ReadableConfig) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Validates the required and optional
ConfigOption
s of a factory. - validateFixedIndexedProperties(String, boolean, Map<String, Consumer<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validation for fixed indexed properties.
- validateFloat(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a float property.
- validateFloat(String, boolean, float) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a float property.
- validateFloat(String, boolean, float, float) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a float property.
- validateFunction(String, Integer, boolean) - Static method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
- validateInputDataType(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
The
DataType
class can only partially verify the conversion class. - validateInt(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates an integer property.
- validateInt(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates an integer property.
- validateInt(String, boolean, int, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates an integer property.
- validateLong(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates an long property.
- validateLong(String, boolean, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates an long property.
- validateLong(String, boolean, long, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates an long property.
- validateMemorySize(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a Flink
MemorySize
. - validateMemorySize(String, boolean, int, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a Flink
MemorySize
. - validateMemorySize(String, boolean, int, long, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a Flink
MemorySize
. - validateOutputDataType(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
The
DataType
class can only partially verify the conversion class. - validatePrefixExclusion(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates that the given prefix is not included in these properties.
- validateShort(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a short property.
- validateShort(String, boolean, short) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a short property.
- validateShort(String, boolean, short, short) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a short property.
- validateString(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a string property.
- validateString(String, boolean, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a string property.
- validateString(String, boolean, int, int) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a string property.
- validateStructuredClass(Class<?>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Validates the characteristics of a class for a
StructuredType
such as accessibility. - validateTableSchema(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a table schema property.
- validateTableSource(TableSource<?>, TableSchema) - Static method in class org.apache.flink.table.sources.TableSourceValidation
-
Validates a TableSource.
- validateType(String, boolean, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates a type property.
- validateUnconsumedKeys(String, Set<String>, Set<String>) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Validates unconsumed option keys.
- validateUnconsumedKeys(String, Set<String>, Set<String>, Set<String>) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Validates unconsumed option keys.
- validateValue(String, String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Validates that a certain value is present under the given key.
- validateWatermarkOptions(String, ReadableConfig) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Validate watermark options from table options.
- ValidationException - Exception in org.apache.flink.table.api
-
Exception for all errors occurring during validation phase.
- ValidationException(String) - Constructor for exception org.apache.flink.table.api.ValidationException
- ValidationException(String, Throwable) - Constructor for exception org.apache.flink.table.api.ValidationException
- value() - Method in annotation type org.apache.flink.table.annotation.ArgumentHint
-
The kind of the argument.
- value() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
The explicit string representation of a data type.
- value() - Method in annotation type org.apache.flink.table.annotation.FunctionHints
- value() - Method in annotation type org.apache.flink.table.annotation.ProcedureHints
- VALUE - org.apache.flink.table.api.JsonType
-
Represents any JSON structure, i.e. it's the union of
JsonType.SCALAR
,JsonType.ARRAY
, andJsonType.OBJECT
. - valueArray() - Method in class org.apache.flink.table.data.binary.BinaryMapData
- valueArray() - Method in class org.apache.flink.table.data.columnar.ColumnarMapData
- valueArray() - Method in class org.apache.flink.table.data.GenericMapData
- valueArray() - Method in interface org.apache.flink.table.data.MapData
-
Returns an array view of the values contained in this map.
- ValueDataTypeConverter - Class in org.apache.flink.table.types.utils
-
Value-based data type extractor that supports extraction of clearly identifiable data types for input conversion.
- ValueLiteralExpression - Class in org.apache.flink.table.expressions
-
Expression for constant literal values.
- ValueLiteralExpression(Object) - Constructor for class org.apache.flink.table.expressions.ValueLiteralExpression
- ValueLiteralExpression(Object, DataType) - Constructor for class org.apache.flink.table.expressions.ValueLiteralExpression
- valueOf(String) - Static method in enum org.apache.flink.table.annotation.ArgumentTrait
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.annotation.ExtractionVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.annotation.HintFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.annotation.InputGroup
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.api.JsonExistsOnError
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.api.JsonOnNull
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.api.JsonQueryOnEmptyOrError
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.api.JsonQueryWrapper
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.api.JsonType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.api.JsonValueOnEmptyOrError
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.api.OverWindowRange
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.catalog.CatalogBaseTable.TableKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.catalog.CatalogMaterializedTable.LogicalRefreshMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.catalog.CatalogMaterializedTable.RefreshMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.catalog.CatalogMaterializedTable.RefreshStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.catalog.Constraint.ConstraintType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.catalog.FunctionLanguage
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.catalog.IntervalFreshness.TimeUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.catalog.TableDistribution.Kind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.connector.sink.abilities.SupportsRowLevelDelete.RowLevelDeleteMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.connector.sink.abilities.SupportsRowLevelUpdate.RowLevelUpdateMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.connector.sink.abilities.SupportsStaging.StagingPurpose
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.connector.source.abilities.SupportsRowLevelModificationScan.RowLevelModificationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.connector.source.lookup.cache.trigger.PeriodicCacheReloadTrigger.ScheduleMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.connector.source.lookup.LookupOptions.LookupCacheType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.connector.source.lookup.LookupOptions.ReloadStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.expressions.TimeIntervalUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.expressions.TimePointUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.FunctionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.FunctionRequirement
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.python.PythonEnv.ExecType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.python.PythonFunctionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.python.utils.PythonFunctionUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.legacy.api.constraints.Constraint.ConstraintType
-
Deprecated.Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.resource.ResourceType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.types.extraction.ExtractionUtils.Autoboxing
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.types.inference.StaticArgumentTrait
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.types.logical.LogicalTypeFamily
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.types.logical.LogicalTypeRoot
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.types.logical.StructuredType.StructuredComparison
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.types.logical.TimestampKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.types.logical.YearMonthIntervalType.YearMonthResolution
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.watermark.WatermarkEmitStrategy
-
Returns the enum constant of this type with the specified name.
- valueOf(BinaryArrayData, BinaryArrayData) - Static method in class org.apache.flink.table.data.binary.BinaryMapData
- values() - Static method in enum org.apache.flink.table.annotation.ArgumentTrait
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.annotation.ExtractionVersion
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.annotation.HintFlag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.annotation.InputGroup
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class org.apache.flink.table.api.dataview.MapView
-
Returns all the values in the map view.
- values() - Static method in enum org.apache.flink.table.api.JsonExistsOnError
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.api.JsonOnNull
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.api.JsonQueryOnEmptyOrError
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.api.JsonQueryWrapper
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.api.JsonType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.api.JsonValueOnEmptyOrError
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.api.OverWindowRange
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.catalog.CatalogBaseTable.TableKind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.catalog.CatalogMaterializedTable.LogicalRefreshMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.catalog.CatalogMaterializedTable.RefreshMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.catalog.CatalogMaterializedTable.RefreshStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.catalog.Constraint.ConstraintType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.catalog.FunctionLanguage
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.catalog.IntervalFreshness.TimeUnit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.catalog.TableDistribution.Kind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.connector.sink.abilities.SupportsRowLevelDelete.RowLevelDeleteMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.connector.sink.abilities.SupportsRowLevelUpdate.RowLevelUpdateMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.connector.sink.abilities.SupportsStaging.StagingPurpose
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.connector.source.abilities.SupportsRowLevelModificationScan.RowLevelModificationType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.connector.source.lookup.cache.trigger.PeriodicCacheReloadTrigger.ScheduleMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.connector.source.lookup.LookupOptions.LookupCacheType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.connector.source.lookup.LookupOptions.ReloadStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.expressions.TimeIntervalUnit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.expressions.TimePointUnit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.functions.FunctionKind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.functions.FunctionRequirement
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.functions.python.PythonEnv.ExecType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.functions.python.PythonFunctionKind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.functions.python.utils.PythonFunctionUtils
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.legacy.api.constraints.Constraint.ConstraintType
-
Deprecated.Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.resource.ResourceType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.types.extraction.ExtractionUtils.Autoboxing
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.types.inference.StaticArgumentTrait
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.types.logical.DayTimeIntervalType.DayTimeResolution
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.types.logical.LogicalTypeFamily
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.types.logical.LogicalTypeRoot
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.types.logical.StructuredType.StructuredComparison
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.types.logical.TimestampKind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.types.logical.YearMonthIntervalType.YearMonthResolution
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnit
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum org.apache.flink.table.watermark.WatermarkEmitStrategy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- VAR_POP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- VAR_SAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- VARBINARY - org.apache.flink.table.types.logical.LogicalTypeRoot
- VARBINARY(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a variable-length binary string (=a sequence of bytes)
VARBINARY(n)
wheren
is the maximum number of bytes. - VarBinaryType - Class in org.apache.flink.table.types.logical
-
Logical type of a variable-length binary string (=a sequence of bytes).
- VarBinaryType() - Constructor for class org.apache.flink.table.types.logical.VarBinaryType
- VarBinaryType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.VarBinaryType
- VarBinaryType(int) - Constructor for class org.apache.flink.table.types.logical.VarBinaryType
- VARCHAR - org.apache.flink.table.types.logical.LogicalTypeRoot
- VARCHAR(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a variable-length character string
VARCHAR(n)
wheren
is the maximum number of code points. - VarCharType - Class in org.apache.flink.table.types.logical
-
Logical type of a variable-length character string.
- VarCharType() - Constructor for class org.apache.flink.table.types.logical.VarCharType
- VarCharType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.VarCharType
- VarCharType(int) - Constructor for class org.apache.flink.table.types.logical.VarCharType
- varyingSequence(String[], ArgumentTypeStrategy[]) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a varying named function signature like
f(i INT, str STRING, num NUMERIC...)
using a sequence ofArgumentTypeStrategy
s. - varyingSequence(List<String>, List<ArgumentTypeStrategy>) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a varying named function signature like
f(i INT, str STRING, num NUMERIC...)
using a sequence ofArgumentTypeStrategy
s. - varyingSequence(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a varying function signature like
f(INT, STRING, NUMERIC...)
using a sequence ofArgumentTypeStrategy
s. - VaryingSequenceInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for inferring and validating a varying function signature like
f(INT, STRING, NUMERIC...)
orf(i INT, str STRING, num NUMERIC...)
using a sequence ofArgumentTypeStrategy
s. - VaryingSequenceInputTypeStrategy(List<ArgumentTypeStrategy>, List<String>) - Constructor for class org.apache.flink.table.types.inference.strategies.VaryingSequenceInputTypeStrategy
- varyingString(TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
A type strategy that ensures that the result type is either
LogicalTypeRoot.VARCHAR
orLogicalTypeRoot.VARBINARY
from their corresponding non-varying roots. - VaryingStringTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
A type strategy that ensures that the result type is either
LogicalTypeRoot.VARCHAR
orLogicalTypeRoot.VARBINARY
from their corresponding non-varying roots. - VaryingStringTypeStrategy(TypeStrategy) - Constructor for class org.apache.flink.table.types.inference.strategies.VaryingStringTypeStrategy
- vector - Variable in class org.apache.flink.table.data.columnar.vector.heap.HeapBooleanVector
- vector - Variable in class org.apache.flink.table.data.columnar.vector.heap.HeapByteVector
- vector - Variable in class org.apache.flink.table.data.columnar.vector.heap.HeapDoubleVector
- vector - Variable in class org.apache.flink.table.data.columnar.vector.heap.HeapFloatVector
- vector - Variable in class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector
- vector - Variable in class org.apache.flink.table.data.columnar.vector.heap.HeapLongVector
- vector - Variable in class org.apache.flink.table.data.columnar.vector.heap.HeapShortVector
- VectorizedColumnBatch - Class in org.apache.flink.table.data.columnar.vector
-
A VectorizedColumnBatch is a set of rows, organized with each column as a vector.
- VectorizedColumnBatch(ColumnVector[]) - Constructor for class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
- version() - Method in annotation type org.apache.flink.table.annotation.DataTypeHint
-
Version that describes the expected behavior of the reflection-based data type extraction.
- version(int) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Specifies a version that will be persisted in the plan together with the function's name.
- VIEW - org.apache.flink.table.catalog.CatalogBaseTable.TableKind
- VIRTUAL - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- visit(CallExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
- visit(CallExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
- visit(Expression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
- visit(Expression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
- visit(FieldReferenceExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
- visit(FieldReferenceExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
- visit(NestedFieldReferenceExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
- visit(NestedFieldReferenceExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
- visit(TypeLiteralExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
- visit(TypeLiteralExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
- visit(ValueLiteralExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
- visit(ValueLiteralExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
- visit(AtomicDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
- visit(AtomicDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
- visit(CollectionDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
- visit(CollectionDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
- visit(FieldsDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
- visit(FieldsDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
- visit(KeyValueDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
- visit(KeyValueDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
- visit(ArrayType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(ArrayType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(ArrayType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
- visit(BigIntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(BigIntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(BinaryType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(BinaryType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(BooleanType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(BooleanType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(CharType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(CharType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(DateType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(DateType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(DayTimeIntervalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(DayTimeIntervalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(DecimalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(DecimalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(DistinctType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(DistinctType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(DistinctType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
- visit(DoubleType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(DoubleType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(FloatType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(FloatType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(IntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(IntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(LocalZonedTimestampType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(LocalZonedTimestampType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(LogicalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(LogicalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(MapType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(MapType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(MapType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
- visit(MultisetType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(MultisetType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(MultisetType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
- visit(NullType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(NullType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(RawType<?>) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(RawType<?>) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(RowType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(RowType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(RowType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
- visit(SmallIntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(SmallIntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(StructuredType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(StructuredType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(StructuredType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
- visit(SymbolType<?>) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(SymbolType<?>) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(TimestampType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(TimestampType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(TimeType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(TimeType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(TinyIntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(TinyIntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(VarBinaryType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(VarBinaryType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(VarCharType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(VarCharType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(YearMonthIntervalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(YearMonthIntervalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
- visit(ZonedTimestampType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
- visit(ZonedTimestampType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
W
- watermark(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares that the given column should serve as an event-time (i.e. rowtime) attribute and specifies a corresponding watermark strategy as an expression.
- watermark(String, String, DataType) - Method in class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.Specifies the previously defined field as an event-time attribute and specifies the watermark strategy.
- watermark(String, Expression) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares that the given column should serve as an event-time (i.e. rowtime) attribute and specifies a corresponding watermark strategy as an expression.
- watermark(WatermarkSpec) - Method in class org.apache.flink.table.legacy.api.TableSchema.Builder
-
Deprecated.Adds the given
WatermarkSpec
to this builder. - WATERMARK - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- WATERMARK_ALIGNMENT_GROUP - Static variable in class org.apache.flink.table.factories.FactoryUtil
- WATERMARK_ALIGNMENT_MAX_DRIFT - Static variable in class org.apache.flink.table.factories.FactoryUtil
- WATERMARK_ALIGNMENT_UPDATE_INTERVAL - Static variable in class org.apache.flink.table.factories.FactoryUtil
- WATERMARK_EMIT_STRATEGY - Static variable in class org.apache.flink.table.factories.FactoryUtil
- WATERMARK_ROWTIME - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- WATERMARK_STRATEGY - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- WATERMARK_STRATEGY_DATA_TYPE - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- WATERMARK_STRATEGY_EXPR - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- WatermarkEmitStrategy - Enum in org.apache.flink.table.watermark
-
The strategy for emitting watermark.
- WatermarkParams - Class in org.apache.flink.table.watermark
-
Pojo class for watermark configs from table options or 'OPTIONS' hint.
- WatermarkParams() - Constructor for class org.apache.flink.table.watermark.WatermarkParams
- WatermarkParams(WatermarkEmitStrategy, String, Duration, Duration, long) - Constructor for class org.apache.flink.table.watermark.WatermarkParams
- WatermarkParams.WatermarkParamsBuilder - Class in org.apache.flink.table.watermark
-
Builder of WatermarkHintParams.
- WatermarkParamsBuilder() - Constructor for class org.apache.flink.table.watermark.WatermarkParams.WatermarkParamsBuilder
- watermarksFromSource() - Method in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.Sets a built-in watermark strategy which indicates the watermarks should be preserved from the underlying DataStream API and thus preserves the assigned watermarks from the source.
- watermarksFromStrategy(WatermarkStrategy) - Method in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.Sets a custom watermark strategy to be used for the rowtime attribute.
- WatermarkSpec - Class in org.apache.flink.table.catalog
-
Representation of a watermark specification in a
ResolvedSchema
. - WatermarkSpec - Class in org.apache.flink.table.legacy.api
-
Deprecated.See
ResolvedSchema
andWatermarkSpec
. - WatermarkSpec(String, String, DataType) - Constructor for class org.apache.flink.table.legacy.api.WatermarkSpec
-
Deprecated.
- watermarksPeriodicAscending() - Method in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.Sets a built-in watermark strategy for ascending rowtime attributes.
- watermarksPeriodicBounded(long) - Method in class org.apache.flink.table.legacy.descriptors.Rowtime
-
Deprecated.Sets a built-in watermark strategy for rowtime attributes which are out-of-order by a bounded time interval.
- WatermarkStrategy - Class in org.apache.flink.table.sources.wmstrategies
-
Provides a strategy to generate watermarks for a rowtime attribute.
- WatermarkStrategy() - Constructor for class org.apache.flink.table.sources.wmstrategies.WatermarkStrategy
- WEEK - org.apache.flink.table.expressions.TimeIntervalUnit
- WEEK - org.apache.flink.table.expressions.TimePointUnit
- WEEK - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- WEEK - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- WILDCARD - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that does not perform any modification or validation of the input.
- WildcardInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy that does not perform any modification or validation of the input.
- WildcardInputTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
- WildcardInputTypeStrategy(ArgumentCount) - Constructor for class org.apache.flink.table.types.inference.strategies.WildcardInputTypeStrategy
- wildcardWithCount(ArgumentCount) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that does not perform any modification or validation of the input.
- WINDOW_END - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- WINDOW_PROPERTIES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- WINDOW_START - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- WINDOW_START_END - Static variable in interface org.apache.flink.table.functions.SqlCallSyntax
- windowTimeIndicator() - Static method in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
- windowTimeIndicator(TimestampKind) - Static method in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
- WindowTimeIndictorInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
- WindowTimeIndictorInputTypeStrategy(TimestampKind) - Constructor for class org.apache.flink.table.types.inference.strategies.WindowTimeIndictorInputTypeStrategy
- WITH_COLUMNS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- withComment(String) - Method in class org.apache.flink.table.api.Schema.Builder
-
Apply comment to the previous column.
- withComment(String) - Method in class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
- withComment(String) - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
- withComment(String) - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
- withComment(String) - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
- withComment(String) - Method in class org.apache.flink.table.catalog.Column
-
Add the comment to the column and return the new object.
- withNullability(String, Object...) - Method in class org.apache.flink.table.types.logical.LogicalType
- WITHOUT_ARRAY - org.apache.flink.table.api.JsonQueryWrapper
- WITHOUT_COLUMNS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
- withoutKeys(List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.Returns a new properties instance with the given keys removed.
- WORKFLOW_SCHEDULER_PREFIX - Static variable in class org.apache.flink.table.factories.WorkflowSchedulerFactoryUtil
- WORKFLOW_SCHEDULER_TYPE - Static variable in class org.apache.flink.table.factories.FactoryUtil
- WorkflowException - Exception in org.apache.flink.table.workflow
-
A workflow-related operation exception to materialized table, including create, suspend, resume, drop workflow operation, etc.
- WorkflowException(String) - Constructor for exception org.apache.flink.table.workflow.WorkflowException
- WorkflowException(String, Throwable) - Constructor for exception org.apache.flink.table.workflow.WorkflowException
- WorkflowScheduler<T extends RefreshHandler> - Interface in org.apache.flink.table.workflow
-
This interface is used to interact with specific workflow scheduler services that support creating, modifying, and deleting refreshed workflow of Materialized Table.
- WorkflowSchedulerFactory - Interface in org.apache.flink.table.factories
-
A factory to create a
WorkflowScheduler
instance. - WorkflowSchedulerFactory.Context - Interface in org.apache.flink.table.factories
-
Context provided when a workflow scheduler is created.
- WorkflowSchedulerFactoryHelper(WorkflowSchedulerFactory, Map<String, String>) - Constructor for class org.apache.flink.table.factories.WorkflowSchedulerFactoryUtil.WorkflowSchedulerFactoryHelper
- WorkflowSchedulerFactoryUtil - Class in org.apache.flink.table.factories
-
Utility for working with
WorkflowScheduler
. - WorkflowSchedulerFactoryUtil.DefaultWorkflowSchedulerContext - Class in org.apache.flink.table.factories
-
Default implementation of
WorkflowSchedulerFactory.Context
. - WorkflowSchedulerFactoryUtil.WorkflowSchedulerFactoryHelper - Class in org.apache.flink.table.factories
-
Helper utility for validating all options for a
WorkflowSchedulerFactory
. - wrapperToPrimitive(Class<?>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Converts the specified wrapper class to its corresponding primitive class.
- WritableBooleanVector - Interface in org.apache.flink.table.data.columnar.vector.writable
-
Writable
BooleanColumnVector
. - WritableBytesVector - Interface in org.apache.flink.table.data.columnar.vector.writable
-
Writable
BytesColumnVector
. - WritableByteVector - Interface in org.apache.flink.table.data.columnar.vector.writable
-
Writable
ByteColumnVector
. - WritableColumnVector - Interface in org.apache.flink.table.data.columnar.vector.writable
-
Writable
ColumnVector
. - WritableDoubleVector - Interface in org.apache.flink.table.data.columnar.vector.writable
-
Writable
DoubleColumnVector
. - WritableFloatVector - Interface in org.apache.flink.table.data.columnar.vector.writable
-
Writable
FloatColumnVector
. - WritableIntVector - Interface in org.apache.flink.table.data.columnar.vector.writable
-
Writable
IntColumnVector
. - WritableLongVector - Interface in org.apache.flink.table.data.columnar.vector.writable
-
Writable
LongColumnVector
. - WritableShortVector - Interface in org.apache.flink.table.data.columnar.vector.writable
-
Writable
ShortColumnVector
. - WritableTimestampVector - Interface in org.apache.flink.table.data.columnar.vector.writable
-
Writable
TimestampColumnVector
. - writeTypeInfo(TypeInformation<?>) - Static method in class org.apache.flink.table.legacy.utils.TypeStringUtils
-
Deprecated.
Y
- YEAR - org.apache.flink.table.expressions.TimeIntervalUnit
- YEAR - org.apache.flink.table.expressions.TimePointUnit
- YEAR - org.apache.flink.table.types.logical.YearMonthIntervalType.YearMonthResolution
- YEAR - org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- YEAR - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- YEAR() - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in years with 2 digits for the number of years by default.
- YEAR(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in years.
- YEAR_TO_MONTH - org.apache.flink.table.expressions.TimeIntervalUnit
- YEAR_TO_MONTH - org.apache.flink.table.types.logical.YearMonthIntervalType.YearMonthResolution
- YEAR_TO_MONTH - org.apache.flink.table.utils.DateTimeUtils.TimeUnitRange
- yearMonth - Variable in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnit
- YearMonthIntervalType - Class in org.apache.flink.table.types.logical
-
Logical type for a group of year-month interval types.
- YearMonthIntervalType(boolean, YearMonthIntervalType.YearMonthResolution, int) - Constructor for class org.apache.flink.table.types.logical.YearMonthIntervalType
- YearMonthIntervalType(YearMonthIntervalType.YearMonthResolution) - Constructor for class org.apache.flink.table.types.logical.YearMonthIntervalType
- YearMonthIntervalType(YearMonthIntervalType.YearMonthResolution, int) - Constructor for class org.apache.flink.table.types.logical.YearMonthIntervalType
- YearMonthIntervalType.YearMonthResolution - Enum in org.apache.flink.table.types.logical
-
Supported resolutions of this type.
Z
- zero(int, int) - Static method in class org.apache.flink.table.data.DecimalData
-
Creates an instance of
DecimalData
for a zero value with the given precision and scale. - ZonedTimestampType - Class in org.apache.flink.table.types.logical
-
Logical type of a timestamp WITH time zone consisting of
year-month-day hour:minute:second[.fractional] zone
with up to nanosecond precision and values ranging from0000-01-01 00:00:00.000000000 +14:59
to9999-12-31 23:59:59.999999999 -14:59
. - ZonedTimestampType() - Constructor for class org.apache.flink.table.types.logical.ZonedTimestampType
- ZonedTimestampType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.ZonedTimestampType
- ZonedTimestampType(boolean, TimestampKind, int) - Constructor for class org.apache.flink.table.types.logical.ZonedTimestampType
-
Internal constructor that allows attaching additional metadata about time attribute properties.
- ZonedTimestampType(int) - Constructor for class org.apache.flink.table.types.logical.ZonedTimestampType
All Classes All Packages