- 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
-
- 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.types.logical.ArrayType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.BigIntType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.BinaryType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.BooleanType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.CharType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DateType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DecimalType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DistinctType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.DoubleType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.FloatType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.IntType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.LogicalType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.MapType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.MultisetType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.NullType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.RawType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.RowType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.SmallIntType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.StructuredType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.SymbolType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TimestampType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TimeType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TinyIntType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
-
Deprecated.
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.VarBinaryType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.VarCharType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
-
- accept(LogicalTypeVisitor<R>) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
-
- accumulate(Object, Object...) - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
-
- accumulate(Object, Object...) - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
-
- accumulatorTypeStrategy(TypeStrategy) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets the strategy for inferring the intermediate accumulator data type of a function
call.
- ACOS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- adaptArguments(TypeInference, CallContext, DataType) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
-
Adapts the call's argument if necessary.
- AdaptedCallContext - Class in org.apache.flink.table.types.inference.utils
-
Helper context that deals with adapted arguments.
- AdaptedCallContext(CallContext, DataType) - Constructor for class org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- add(T) - Method in class org.apache.flink.table.api.dataview.ListView
-
Adds the given value to the list.
- add(TableColumn) - Method in class org.apache.flink.table.api.TableSchema.Builder
-
Deprecated.
- 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(UniqueConstraint) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to add a unique constraint.
- add(TableDistribution) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to add a distribution.
- add(WatermarkSpec) - Static method in interface org.apache.flink.table.catalog.TableChange
-
A table change to add a watermark.
- 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(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.
- 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.
- 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_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
-
- 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 provided
dataType
.
- 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
-
- alterDatabase(String, CatalogDatabase, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Modify an existing database.
- alterFunction(ObjectPath, CatalogFunction, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Modify an existing function.
- alterPartition(ObjectPath, CatalogPartitionSpec, CatalogPartition, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Alter a partition.
- alterPartitionColumnStatistics(ObjectPath, CatalogPartitionSpec, CatalogColumnStatistics, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Update the column statistics of a table partition.
- alterPartitionStatistics(ObjectPath, CatalogPartitionSpec, CatalogTableStatistics, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Update the statistics of a table partition.
- alterTable(ObjectPath, CatalogBaseTable, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Modifies an existing table or view.
- 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
-
- 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>) - Constructor for exception org.apache.flink.table.api.AmbiguousTableFactoryException
-
Deprecated.
- 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>, Throwable) - Constructor for exception org.apache.flink.table.factories.AmbiguousTableFactoryException
-
- AmbiguousTableFactoryException(List<? extends TableFactory>, Class<? extends TableFactory>, List<TableFactory>, Map<String, String>) - Constructor for exception org.apache.flink.table.factories.AmbiguousTableFactoryException
-
- AND - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- and(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
- 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 like
f(NUMERIC && LITERAL)
Some
ArgumentTypeStrategy
s cannot contribute an inferred type that is different from
the input type (e.g.
- AndArgumentTypeStrategy(List<? extends ArgumentTypeStrategy>) - 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
-
- any() - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
-
- ANY - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for an argument that can be of any type.
- AnyArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for an argument that can be of any type.
- AnyArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.AnyArgumentTypeStrategy
-
- anyNull() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- anyNull() - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
The bit is 1 when the field is null.
- anyNull(int[]) - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- anyNull() - Method in interface org.apache.flink.table.data.binary.NullAwareGetters
-
If no field is null, return false.
- anyNull(int[]) - Method in interface org.apache.flink.table.data.binary.NullAwareGetters
-
For the input fields, if no field is null, return false.
- 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.sources.LimitableTableSource
-
Deprecated.
Check and push down the limit to the table source.
- applyOverwrite(boolean) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsOverwrite
-
Provides whether existing data should be overwritten or not.
- applyPartitionPruning(List<Map<String, String>>) - Method in interface org.apache.flink.table.sources.PartitionableTableSource
-
Deprecated.
Applies the remaining partitions to the table source.
- applyPartitions(List<Map<String, String>>) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsPartitionPushDown
-
Provides a list of remaining partitions.
- applyPredicate(List<Expression>) - Method in interface org.apache.flink.table.sources.FilterableTableSource
-
Deprecated.
Check and pick all predicates this table source can support.
- applyProjection(int[][]) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsProjectionPushDown
-
- 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
-
- applyRowLevelModificationScan(SupportsRowLevelModificationScan.RowLevelModificationType, RowLevelModificationScanContext) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsRowLevelModificationScan
-
- applyRowLevelUpdate(List<Column>, RowLevelModificationScanContext) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsRowLevelUpdate
-
- 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
-
- applyStaticPartition(Map<String, String>) - Method in interface org.apache.flink.table.connector.sink.abilities.SupportsPartitioning
-
Provides the static part of a partition.
- applyWatermark(WatermarkStrategy<RowData>) - Method in interface org.apache.flink.table.connector.source.abilities.SupportsWatermarkPushDown
-
Provides a WatermarkStrategy
which defines how to generate Watermark
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.
- areComparable(LogicalType, LogicalType, StructuredType.StructuredComparison) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- argument(ArgumentTypeStrategy) - Method in class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
-
Defines that we expect a single argument at the next position.
- argument(int) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy that returns the n-th input argument.
- 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.
- 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
-
- ArgumentTypeStrategy - Interface in org.apache.flink.table.types.inference
-
Strategy for inferring and validating a single input argument type of a function call.
- ARRAY(DataType) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of an array of elements with same subtype.
- ARRAY(AbstractDataType<?>) - Static method in class org.apache.flink.table.api.DataTypes
-
Unresolved data type of an array of elements with same subtype.
- ARRAY - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- ARRAY - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
- ARRAY - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See ArrayTypeStrategy
.
- 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
returns
DataTypes.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
-
- 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.types.logical.ArrayType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.BigIntType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.BinaryType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.BooleanType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.CharType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.DateType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.DecimalType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.DoubleType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.FloatType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.IntType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns a string that fully serializes this instance.
- asSerializableString() - Method in class org.apache.flink.table.types.logical.MapType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.MultisetType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.NullType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.RawType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.RowType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.RowType.RowField
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.SmallIntType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.SymbolType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.TimestampType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.TimeType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.TinyIntType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
-
Deprecated.
- asSerializableString() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.UserDefinedType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.VarBinaryType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.VarCharType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
-
- asSerializableString() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
-
- asSummaryString() - Method in interface org.apache.flink.table.api.constraints.Constraint
-
Deprecated.
Prints the constraint in a readable way.
- asSummaryString() - Method in class org.apache.flink.table.api.constraints.UniqueConstraint
-
Deprecated.
Returns constraint's summary.
- asSummaryString() - Method in class org.apache.flink.table.api.TableColumn
-
Deprecated.
Returns a string that summarizes this column for printing to a console.
- asSummaryString() - Method in class org.apache.flink.table.api.WatermarkSpec
-
Deprecated.
- asSummaryString() - Method in class org.apache.flink.table.catalog.Column
-
Returns a string that summarizes this column for printing to a console.
- asSummaryString() - Method in interface org.apache.flink.table.catalog.Constraint
-
Prints the constraint in a readable way.
- asSummaryString() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
-
Returns a string that summarizes this instance for printing to a console or log.
- asSummaryString() - Method in class org.apache.flink.table.catalog.UniqueConstraint
-
Returns constraint's summary.
- asSummaryString() - Method in class org.apache.flink.table.catalog.UnresolvedIdentifier
-
Returns a string that summarizes this instance for printing to a console or log.
- asSummaryString() - Method in class org.apache.flink.table.catalog.WatermarkSpec
-
- asSummaryString() - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
-
Returns a string that summarizes this sink for printing to a console or log.
- asSummaryString() - Method in interface org.apache.flink.table.connector.source.DynamicTableSource
-
Returns a string that summarizes this source for printing to a console or log.
- asSummaryString() - Method in class org.apache.flink.table.expressions.AggregateExpression
-
- asSummaryString() - Method in class org.apache.flink.table.expressions.CallExpression
-
- asSummaryString() - Method in interface org.apache.flink.table.expressions.Expression
-
Returns a string that summarizes this expression for printing to a console.
- asSummaryString() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
-
- asSummaryString() - Method in class org.apache.flink.table.expressions.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 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.TypeInformationRawType
-
Deprecated.
- asSummaryString() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- asSummaryString() - Method in class org.apache.flink.table.types.logical.VarBinaryType
-
- asSummaryString() - Method in class org.apache.flink.table.types.logical.VarCharType
-
- asSummaryString() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
-
- ASYNC_SCALAR_EVAL - Static variable in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
- 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
-
- 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.connector.source
-
- AT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- ATAN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- ATAN2 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- AtomicDataType - Class in org.apache.flink.table.types
-
A data type that does not contain further data types (e.g.
- AtomicDataType(LogicalType, Class<?>) - Constructor for class org.apache.flink.table.types.AtomicDataType
-
- AtomicDataType(LogicalType) - Constructor for class org.apache.flink.table.types.AtomicDataType
-
- attributes(List<StructuredType.StructuredAttribute>) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
-
- AVG - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- 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
-
- 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
-
- 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
-
- CallExpression(FunctionIdentifier, FunctionDefinition, List<ResolvedExpression>, DataType) - Constructor for class org.apache.flink.table.expressions.CallExpression
-
- CallExpression(FunctionDefinition, List<ResolvedExpression>, DataType) - Constructor for class org.apache.flink.table.expressions.CallExpression
-
- callSyntax(SqlCallSyntax) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
Overwrites the syntax used for unparsing a function into a SQL string.
- 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.
- 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
-
- 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
-
- CatalogChange - Interface in org.apache.flink.table.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(Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.CatalogException
-
- CatalogException(String, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.CatalogException
-
- CatalogFactory - Interface in org.apache.flink.table.factories
-
A factory to create configured catalog instances based on string-based properties.
- CatalogFactory.Context - Interface in org.apache.flink.table.factories
-
Context provided when a catalog is created.
- CatalogFactoryHelper(CatalogFactory, CatalogFactory.Context) - Constructor for class org.apache.flink.table.factories.FactoryUtil.CatalogFactoryHelper
-
- CatalogFunction - Interface in org.apache.flink.table.catalog
-
Interface for a function in a catalog.
- CatalogLock - Interface in org.apache.flink.table.catalog
-
- CatalogLock.Factory - Interface in org.apache.flink.table.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
-
- 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.
- 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 - Interface in org.apache.flink.table.catalog
-
Represents the storage where persists all
Catalog
s.
- catalogStore(CatalogStore) - Method in class org.apache.flink.table.catalog.CatalogStoreHolder.Builder
-
- catalogStore() - Method in class org.apache.flink.table.catalog.CatalogStoreHolder
-
- 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
-
- CatalogStoreHolder.Builder - Class in org.apache.flink.table.catalog
-
- 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
-
- 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
-
- CHAR(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a fixed-length character string CHAR(n)
where n
is the number of
code points.
- CHAR_LENGTH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- CharType - Class in org.apache.flink.table.types.logical
-
Logical type of a fixed-length character string.
- CharType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.CharType
-
- CharType(int) - Constructor for class org.apache.flink.table.types.logical.CharType
-
- CharType() - Constructor for class org.apache.flink.table.types.logical.CharType
-
- checkOnlyPhysicalColumns(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
-
Throws an exception if the given
TableSchema
contains any non-physical columns.
- 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
-
- 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 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- collect(T) - Method in class org.apache.flink.table.functions.TableFunction
-
Emits an (implicit or explicit) output row.
- COLLECT - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
- 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
-
- CollectTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.CollectTypeStrategy
-
- column(String, AbstractDataType<?>) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a physical column that is appended to this schema.
- column(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a physical column that is appended to this schema.
- Column - Class in org.apache.flink.table.catalog
-
- column() - Method in class org.apache.flink.table.catalog.TableChange.After
-
- 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, Expression) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a computed column that is appended to this schema.
- columnByExpression(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a computed column that is appended to this schema.
- columnByMetadata(String, AbstractDataType<?>) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columnByMetadata(String, String) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columnByMetadata(String, AbstractDataType<?>, boolean) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columnByMetadata(String, AbstractDataType<?>, String) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columnByMetadata(String, AbstractDataType<?>, String, boolean) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- columnByMetadata(String, String, String, boolean) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a metadata column that is appended to this schema.
- 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, Number, Number) - Constructor for class org.apache.flink.table.plan.stats.ColumnStats
-
Deprecated.
- ColumnStats.Builder - Class in org.apache.flink.table.plan.stats
-
ColumnStats builder.
- ColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Nullable column vector.
- 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 - Variable in class org.apache.flink.table.catalog.Column
-
- 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
-
- 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
-
- 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
-
- 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
-
- CommonInputTypeStrategy(ArgumentCount) - Constructor for class org.apache.flink.table.types.inference.strategies.CommonInputTypeStrategy
-
- CommonMapInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
- 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
-
- 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
-
- commonType(int) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
- CommonTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that returns a common, least restrictive type of all arguments.
- CommonTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.CommonTypeStrategy
-
- comparable(ConstantArgumentCount, StructuredType.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(StringData) - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Compares two strings lexicographically.
- compareTo(DecimalData) - Method in class org.apache.flink.table.data.DecimalData
-
- compareTo(TimestampData) - Method in class org.apache.flink.table.data.TimestampData
-
- 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
-
- COMPOSITE - Static variable in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy that checks that the argument has a composite type.
- CompositeArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy that checks that the argument has a composite type.
- CompositeArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.CompositeArgumentTypeStrategy
-
- compositeSequence() - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
An strategy that lets you apply other strategies for subsequences of the actual arguments.
- computed(String, DataType, String) - Static method in class org.apache.flink.table.api.TableColumn
-
Deprecated.
Creates a computed column that is computed from the given SQL expression.
- computed(String, ResolvedExpression) - Static method in class org.apache.flink.table.catalog.Column
-
- 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
-
- config(ReadableConfig) - Method in class org.apache.flink.table.catalog.CatalogStoreHolder.Builder
-
- config() - Method in class org.apache.flink.table.catalog.CatalogStoreHolder
-
- configure(String[], TypeInformation<?>[]) - Method in interface org.apache.flink.table.sinks.TableSink
-
- 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.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
-
- Constraint - Interface in org.apache.flink.table.api.constraints
-
- Constraint - Interface in org.apache.flink.table.catalog
-
Integrity constraints, generally referred to simply as constraints, define the valid states of
SQL-data by constraining the values in the base tables.
- constraint(String, 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.ConstraintType - Enum in org.apache.flink.table.api.constraints
-
Deprecated.
Type of the constraint.
- Constraint.ConstraintType - Enum in org.apache.flink.table.catalog
-
Type of the constraint.
- ConstraintArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for an argument that must fulfill a given constraint.
- ConstraintArgumentTypeStrategy(String, Predicate<List<DataType>>) - Constructor for class org.apache.flink.table.types.inference.strategies.ConstraintArgumentTypeStrategy
-
- constructor - Variable in class org.apache.flink.table.types.extraction.ExtractionUtils.AssigningConstructor
-
- consumedOptionKeys - Variable in class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
-
- 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(String) - Method in interface org.apache.flink.table.catalog.CatalogStore
-
Return whether the catalog exists in the catalog store.
- contains(RowKind) - Method in class org.apache.flink.table.connector.ChangelogMode
-
- contains(RowData) - Method in class org.apache.flink.table.connector.source.DynamicFilteringData
-
Returns true if the dynamic filtering data contains the specific row.
- contains(BinaryStringData) - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Returns true if and only if this BinaryStringData contains the specified sequence of bytes
values.
- containsKey(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns if the given key is contained.
- containsOnly(RowKind) - Method in class org.apache.flink.table.connector.ChangelogMode
-
- containsPhysicalColumnsOnly(TableSchema) - Static method in class org.apache.flink.table.utils.TableSchemaUtils
-
Returns true if there are only physical columns in the given
TableSchema
.
- ContinuousRefreshHandler - Class in org.apache.flink.table.refresh
-
Embedded continuous refresh handler of Flink streaming job for materialized table.
- ContinuousRefreshHandler(String, String) - Constructor for class org.apache.flink.table.refresh.ContinuousRefreshHandler
-
- ContinuousRefreshHandler(String, String, String) - Constructor for class org.apache.flink.table.refresh.ContinuousRefreshHandler
-
- ContinuousRefreshHandlerSerializer - Class in org.apache.flink.table.refresh
-
- 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.
- copy() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Returns a deep copy of the table schema.
- copy() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
Get a deep copy of the CatalogBaseTable instance.
- copy() - Method in interface org.apache.flink.table.catalog.CatalogDatabase
-
Get a deep copy of the CatalogDatabase instance.
- copy(Map<String, String>) - Method in interface org.apache.flink.table.catalog.CatalogDatabase
-
Returns a copy of this CatalogDatabase
with the given properties.
- copy() - Method in interface org.apache.flink.table.catalog.CatalogFunction
-
Create a deep copy of the function.
- copy(Map<String, String>) - Method in interface org.apache.flink.table.catalog.CatalogMaterializedTable
-
Returns a copy of this CatalogMaterializedTable
with given table options options
.
- 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() - Method in interface org.apache.flink.table.catalog.CatalogPartition
-
Get a deep copy of the CatalogPartition instance.
- copy(Map<String, String>) - Method in interface org.apache.flink.table.catalog.CatalogTable
-
Returns a copy of this CatalogTable
with given table options options
.
- copy(DataType) - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
-
- copy(DataType) - Method in class org.apache.flink.table.catalog.Column
-
Returns a copy of the column with a replaced
DataType
.
- copy(DataType) - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
-
- copy(DataType) - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
-
- copy() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
-
- copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
-
- copy(CatalogMaterializedTable.RefreshStatus, String, byte[]) - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
-
- copy() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
-
- copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
-
- copy() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
-
- copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
-
- copy(CatalogMaterializedTable.RefreshStatus, String, byte[]) - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
-
- copy() - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
-
- copy(Map<String, String>) - Method in class org.apache.flink.table.catalog.ResolvedCatalogTable
-
- copy() - Method in class org.apache.flink.table.catalog.ResolvedCatalogView
-
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatistics
-
Create a deep copy of "this" instance.
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBase
-
Create a deep copy of "this" instance.
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
-
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
-
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
-
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
-
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
-
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
-
- copy() - Method in class org.apache.flink.table.catalog.stats.CatalogTableStatistics
-
Create a deep copy of "this" instance.
- copy() - Method in class org.apache.flink.table.catalog.stats.Date
-
- copy() - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
-
Creates a copy of this instance during planning.
- copy() - Method in interface org.apache.flink.table.connector.source.DynamicTableSource
-
Creates a copy of this instance during planning.
- copy() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- copy(BinaryArrayData) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- copy() - Method in class org.apache.flink.table.data.binary.BinaryMapData
-
- copy(BinaryMapData) - Method in class org.apache.flink.table.data.binary.BinaryMapData
-
- copy() - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- copy(BinaryRowData) - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- copy() - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
Copy a new BinaryStringData
.
- copy() - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- copy(RowData) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- copy() - Method in class org.apache.flink.table.data.DecimalData
-
- copy(ListView<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- copy(ListView<T>, ListView<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- copy(MapView<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- copy(MapView<K, V>, MapView<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- copy(Map<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- copy(Map<K, V>, Map<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- copy(Object) - Method in class org.apache.flink.table.dataview.NullSerializer
-
- copy(Object, Object) - Method in class org.apache.flink.table.dataview.NullSerializer
-
- copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.dataview.NullSerializer
-
- copy() - Method in class org.apache.flink.table.plan.stats.ColumnStats
-
Create a deep copy of "this" instance.
- copy() - Method in class org.apache.flink.table.plan.stats.TableStats
-
Create a deep copy of "this" instance.
- copy() - Method in class org.apache.flink.table.sinks.TableSinkBase
-
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() - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns a deep copy of this type.
- copy(boolean) - Method in class org.apache.flink.table.types.logical.MapType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.MultisetType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.NullType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.RawType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.RowType
-
- copy() - Method in class org.apache.flink.table.types.logical.RowType.RowField
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.SmallIntType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType
-
- copy() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.SymbolType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.TimestampType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.TimeType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.TinyIntType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
-
Deprecated.
- copy(boolean) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.VarBinaryType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.VarCharType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
-
- copy(boolean) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
-
- copyFromBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Copy target segments from source byte[].
- copyMultiSegmentsToBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
- copyToBytes(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Copy segments to a new byte[].
- copyToBytes(MemorySegment[], int, byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Copy segments to target byte[].
- copyToUnsafe(MemorySegment[], int, Object, int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Copy segments to target unsafe pointer.
- copyToView(MemorySegment[], int, int, DataOutputView) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Copy bytes of segments to output view.
- CoreModule - Class in org.apache.flink.table.module
-
Module of default core metadata in Flink.
- CoreModuleFactory - Class in org.apache.flink.table.module
-
- CoreModuleFactory() - Constructor for class org.apache.flink.table.module.CoreModuleFactory
-
- COS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- COSH - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- COT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- COUNT - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- create() - Method in interface org.apache.flink.table.catalog.CatalogLock.Factory
-
Deprecated.
- create(ClassLoader) - Static method in interface org.apache.flink.table.connector.RuntimeConverter.Context
-
- createAccumulator() - Method in class org.apache.flink.table.functions.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
-
- createAsyncTableFunction() - Method in interface org.apache.flink.table.connector.source.AsyncTableFunctionProvider
-
Deprecated.
- createCatalog(String, Map<String, String>) - Method in interface org.apache.flink.table.factories.CatalogFactory
-
- createCatalog(CatalogFactory.Context) - Method in interface org.apache.flink.table.factories.CatalogFactory
-
Creates and configures a
Catalog
using the given context.
- createCatalog(String, Map<String, String>, ReadableConfig, ClassLoader) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Attempts to discover an appropriate catalog factory and creates an instance of the catalog.
- createCatalogFactoryHelper(CatalogFactory, CatalogFactory.Context) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
- createCatalogStore() - Method in interface org.apache.flink.table.factories.CatalogStoreFactory
-
- createCatalogStoreFactoryHelper(CatalogStoreFactory, CatalogStoreFactory.Context) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
- createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- createDatabase(String, CatalogDatabase, boolean) - Method in interface org.apache.flink.table.catalog.Catalog
-
Create a database.
- createDataStructureConverter(DataType) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
-
Creates a converter for mapping between Flink's internal data structures and objects
specified by the given
DataType
that can be passed into a runtime implementation.
- createDataStructureConverter(DataType) - Method in interface org.apache.flink.table.connector.source.DynamicTableSource.Context
-
Creates a converter for mapping between objects specified by the given
DataType
and Flink's internal data structures that can be passed into a runtime implementation.
- createDataType(AbstractDataType<?>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
- createDataType(String) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a type by a fully or partially defined name.
- createDataType(UnresolvedIdentifier) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a type by a fully or partially defined identifier.
- createDataType(Class<T>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a type by analyzing the given class.
- createDataType(TypeInformation<T>) - Method in interface org.apache.flink.table.catalog.DataTypeFactory
-
Creates a type for the given TypeInformation
.
- createDecodingFormat(DynamicTableFactory.Context, ReadableConfig) - Method in interface org.apache.flink.table.factories.DecodingFormatFactory
-
Creates a format from the given context and format options.
- createDynamicTableSink(DynamicTableFactory.Context) - Method in interface org.apache.flink.table.factories.DynamicTableSinkFactory
-
- createDynamicTableSink(DynamicTableSinkFactory, ObjectIdentifier, ResolvedCatalogTable, Map<String, String>, ReadableConfig, ClassLoader, boolean) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
- createDynamicTableSink(DynamicTableSinkFactory, ObjectIdentifier, ResolvedCatalogTable, ReadableConfig, ClassLoader, boolean) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
- createDynamicTableSource(DynamicTableFactory.Context) - Method in interface org.apache.flink.table.factories.DynamicTableSourceFactory
-
- createDynamicTableSource(DynamicTableSourceFactory, ObjectIdentifier, ResolvedCatalogTable, Map<String, String>, ReadableConfig, ClassLoader, boolean) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
- createDynamicTableSource(DynamicTableSourceFactory, ObjectIdentifier, ResolvedCatalogTable, ReadableConfig, ClassLoader, boolean) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
- 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(Expression, DataType, DataTypes.Field...) - Method in interface org.apache.flink.table.functions.SpecializedFunction.ExpressionEvaluatorFactory
-
- createEvaluator(String, DataType, DataTypes.Field...) - Method in interface org.apache.flink.table.functions.SpecializedFunction.ExpressionEvaluatorFactory
-
Shorthand for createEvaluator(callSql("..."), ...)
.
- createEvaluator(BuiltInFunctionDefinition, DataType, DataType...) - Method in interface org.apache.flink.table.functions.SpecializedFunction.ExpressionEvaluatorFactory
-
- 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) - Method in interface org.apache.flink.table.factories.FunctionDefinitionFactory
-
- createFunctionDefinition(String, CatalogFunction, FunctionDefinitionFactory.Context) - Method in interface org.apache.flink.table.factories.FunctionDefinitionFactory
-
- 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
-
- createLookupFunction() - Method in interface org.apache.flink.table.connector.source.lookup.LookupFunctionProvider
-
- createMethodSignatureString(String, Class<?>[], Class<?>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Creates a method signature string like int eval(Integer, String)
.
- createModule(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(Map<String, String>) - Method in interface org.apache.flink.table.factories.ModuleFactory
-
- 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
-
- 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 - Interface in org.apache.flink.table.workflow
-
- 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.
- 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, 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)
.
- createRuntimeDecoder(DynamicTableSource.Context, DataType) - Method in interface org.apache.flink.table.connector.format.ProjectableDecodingFormat
-
- 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(ExecutionConfig) - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- createSerializer(SerializerConfig) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- createSink() - Method in interface org.apache.flink.table.connector.sink.SinkProvider
-
Deprecated.
Creates a Sink
instance.
- 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
-
- 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
-
- createTableFunction() - Method in interface org.apache.flink.table.connector.source.TableFunctionProvider
-
Deprecated.
- createTableSink(Catalog, ObjectIdentifier, ResolvedCatalogTable, ReadableConfig, ClassLoader, boolean) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
- createTableSink(Map<String, String>) - Method in interface org.apache.flink.table.factories.TableSinkFactory
-
- createTableSink(ObjectPath, CatalogTable) - Method in interface org.apache.flink.table.factories.TableSinkFactory
-
- createTableSink(TableSinkFactory.Context) - Method in interface org.apache.flink.table.factories.TableSinkFactory
-
Deprecated.
- createTableSource(Catalog, ObjectIdentifier, ResolvedCatalogTable, ReadableConfig, ClassLoader, boolean) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
- createTableSource(Map<String, String>) - Method in interface org.apache.flink.table.factories.TableSourceFactory
-
- createTableSource(ObjectPath, CatalogTable) - Method in interface org.apache.flink.table.factories.TableSourceFactory
-
- createTableSource(TableSourceFactory.Context) - Method in interface org.apache.flink.table.factories.TableSourceFactory
-
Deprecated.
- createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.table.dataview.ListViewTypeInfoFactory
-
Deprecated.
- createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.table.dataview.MapViewTypeInfoFactory
-
Deprecated.
- createTypeInformation(DataType) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
-
Creates type information describing the internal data structures of the given
DataType
.
- createTypeInformation(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(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.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(WorkflowSchedulerFactory.Context) - Method in interface org.apache.flink.table.factories.WorkflowSchedulerFactory
-
Create a workflow scheduler instance which interacts with external scheduler service.
- 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.
- createWorkflowSchedulerFactoryHelper(WorkflowSchedulerFactory, WorkflowSchedulerFactory.Context) - Static method in class org.apache.flink.table.factories.WorkflowSchedulerFactoryUtil
-
- 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_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.
- 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.
- factory - Variable in class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
-
- 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.CatalogFactory
-
- 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.ManagedTableFactory
-
Deprecated.
- 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
-
- FactoryUtil.CatalogFactoryHelper - Class in org.apache.flink.table.factories
-
- FactoryUtil.CatalogStoreFactoryHelper - Class in org.apache.flink.table.factories
-
- FactoryUtil.DefaultCatalogContext - Class in org.apache.flink.table.factories
-
- FactoryUtil.DefaultCatalogStoreContext - Class in org.apache.flink.table.factories
-
- FactoryUtil.DefaultDynamicTableContext - Class in org.apache.flink.table.factories
-
- FactoryUtil.DefaultModuleContext - Class in org.apache.flink.table.factories
-
- 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
-
- FactoryUtil.TableFactoryHelper - Class in org.apache.flink.table.factories
-
- 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.
- FamilyArgumentTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for an argument that corresponds to a given
LogicalTypeFamily
and nullability.
- FamilyArgumentTypeStrategy(LogicalTypeFamily, Boolean) - Constructor for class org.apache.flink.table.types.inference.strategies.FamilyArgumentTypeStrategy
-
- FIELD(String, DataType) - Static method in class org.apache.flink.table.api.DataTypes
-
Field definition with field name and data type.
- FIELD(String, DataType, String) - Static method in class org.apache.flink.table.api.DataTypes
-
Field definition with field name, data type, and a description.
- FIELD(String, AbstractDataType<?>) - Static method in class org.apache.flink.table.api.DataTypes
-
Unresolved field definition with field name and data type.
- FIELD(String, AbstractDataType<?>, String) - Static method in class org.apache.flink.table.api.DataTypes
-
Unresolved field definition with field name, unresolved data type, and a description.
- field(String, DataType) - Method in class org.apache.flink.table.api.TableSchema.Builder
-
Deprecated.
Add a field with name and data type.
- field(String, DataType, String) - Method in class org.apache.flink.table.api.TableSchema.Builder
-
Deprecated.
Add a computed field which is generated by the given expression.
- field(String, TypeInformation<?>) - Method in class org.apache.flink.table.api.TableSchema.Builder
-
- field(String, DataType) - Method in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
Adds a field with the field name and the data type.
- field(String, TypeInformation<?>) - Method in class org.apache.flink.table.descriptors.Schema
-
- field(String, String) - Method in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
Adds a field with the field name and the type string.
- FIELD_FORMAT_NO_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.RowType.RowField
-
- FIELD_FORMAT_NO_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- FIELD_FORMAT_WITH_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.RowType.RowField
-
- FIELD_FORMAT_WITH_DESCRIPTION - Static variable in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- FieldComputer<T> - Interface in org.apache.flink.table.sources
-
- fieldIndex() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
-
- FieldReferenceExpression - Class in org.apache.flink.table.expressions
-
A reference to a field in an input.
- FieldReferenceExpression(String, DataType, int, int) - Constructor for class org.apache.flink.table.expressions.FieldReferenceExpression
-
- fields(String[], DataType[]) - Method in class org.apache.flink.table.api.TableSchema.Builder
-
Deprecated.
Add an array of fields with names and data types.
- FieldsDataType - Class in org.apache.flink.table.types
-
A data type that contains field data types (i.e. 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
-
- 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
-
- 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(byte[]) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapBytesVector
-
- fill(byte) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapByteVector
-
- fill(double) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapDoubleVector
-
- fill(float) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapFloatVector
-
- fill(int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector
-
- fill(long) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapLongVector
-
- fill(short) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapShortVector
-
- fill(TimestampData) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapTimestampVector
-
- 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 interface org.apache.flink.table.data.columnar.vector.writable.WritableBytesVector
-
Fill the column vector with the provided value.
- fill(byte) - Method in interface org.apache.flink.table.data.columnar.vector.writable.WritableByteVector
-
Fill the column vector with the provided value.
- 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 interface org.apache.flink.table.data.columnar.vector.writable.WritableFloatVector
-
Fill the column vector with the provided value.
- 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 interface org.apache.flink.table.data.columnar.vector.writable.WritableLongVector
-
Fill the column vector with the provided value.
- 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 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.sources
-
- find(MemorySegment[], int, int, MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Find equal segments2 in segments1.
- find(Class<T>, Descriptor) - Static method in class org.apache.flink.table.factories.TableFactoryService
-
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(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.
- 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
-
- 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 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- FirstTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Type strategy that returns the first type that could be inferred.
- FirstTypeStrategy(List<? extends TypeStrategy>) - Constructor for class org.apache.flink.table.types.inference.strategies.FirstTypeStrategy
-
- FLATTEN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- flattenToDataTypes(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Returns the data types of the flat representation in the first level of the given data type.
- flattenToNames(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Returns the names of the flat representation 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() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a 4-byte single precision floating point number.
- FLOAT() - Static method in class org.apache.flink.table.api.Types
-
Deprecated.
Returns type information for a Table API float or SQL FLOAT/REAL type.
- FLOAT_ARRAY_OFFSET - Static variable in class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector
-
- 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(boolean) - Constructor for class org.apache.flink.table.types.logical.FloatType
-
- FloatType() - Constructor for class org.apache.flink.table.types.logical.FloatType
-
- FLOOR - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- 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
-
- forAsyncScalarFunction(DataTypeFactory, Class<? extends AsyncScalarFunction>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
- forAsyncTableFunction(DataTypeFactory, Class<? extends AsyncTableFunction<?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
- forceNullable(TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeStrategies
-
Type strategy which forces the given 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
-
- 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
-
- 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(long, String, TimeZone) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
- formatTimestampMillis(int, int) - 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
-
- formatTimestampString(String, String) - 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, 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.
- 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.
- forProcedure(DataTypeFactory, Class<? extends Procedure>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
Extracts a type in inference from a
Procedure
.
- forScalarFunction(DataTypeFactory, Class<? extends ScalarFunction>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
- forTableAggregateFunction(DataTypeFactory, Class<? extends TableAggregateFunction<?, ?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
- forTableFunction(DataTypeFactory, Class<? extends TableFunction<?>>) - Static method in class org.apache.flink.table.types.extraction.TypeInferenceExtractor
-
- 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.data.utils.ProjectedRowData
-
- from(int[]) - Static method in class org.apache.flink.table.data.utils.ProjectedRowData
-
- from(Projection) - Static method in class org.apache.flink.table.data.utils.ProjectedRowData
-
- from(String) - Method in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
Specifies the origin of the previously defined field.
- from(int) - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
-
- FROM_BASE64 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- FROM_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
-
- fromBytes(byte[]) - Static method in class org.apache.flink.table.data.binary.BinaryRawValueData
-
- fromBytes(byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinaryRawValueData
-
Creates a
BinaryStringData
instance from the given bytes with offset and number of
bytes.
- fromBytes(byte[]) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
-
- fromBytes(byte[], int, int) - Static method in class org.apache.flink.table.data.binary.BinaryStringData
-
Creates a
BinaryStringData
instance from the given UTF-8 bytes with offset and number
of bytes.
- fromBytes(byte[]) - Static method in interface org.apache.flink.table.data.RawValueData
-
Creates an instance of
RawValueData
from the given byte array.
- fromBytes(byte[]) - Static method in interface org.apache.flink.table.data.StringData
-
Creates an instance of
StringData
from the given UTF-8 byte array.
- fromBytes(byte[], int, int) - Static method in interface org.apache.flink.table.data.StringData
-
Creates an instance of
StringData
from the given UTF-8 byte array with offset and
number of bytes.
- 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
-
- fromDataTypeToLegacyInfo(DataType[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
-
- fromEpochMillis(long) - Static method in class org.apache.flink.table.data.TimestampData
-
- 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
-
Create a
Projection
of the provided
dataType
using the provided
projectedFields
.
- 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
-
- fromLegacyInfoToDataType(TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.TypeConversions
-
- fromLegacyInfoToDataType(TypeInformation<?>[]) - Static method in class org.apache.flink.table.types.utils.TypeConversions
-
- fromLocalDateTime(LocalDateTime) - Static method in class org.apache.flink.table.data.TimestampData
-
- 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
-
- fromObject(T) - Static method in interface org.apache.flink.table.data.RawValueData
-
- fromPrimitiveArray(boolean[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- fromPrimitiveArray(byte[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- fromPrimitiveArray(short[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- fromPrimitiveArray(int[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- fromPrimitiveArray(long[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- fromPrimitiveArray(float[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- fromPrimitiveArray(double[]) - Static method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- fromProperties(Map<String, String>) - Static method in interface org.apache.flink.table.catalog.CatalogTable
-
- fromResolvedSchema(ResolvedSchema) - Method in class org.apache.flink.table.api.Schema.Builder
-
Adopts all members from the given resolved schema.
- fromResolvedSchema(ResolvedSchema) - Static method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
- 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
-
- fromString(String) - Static method in interface org.apache.flink.table.data.StringData
-
- fromTimestamp(Timestamp) - Static method in class org.apache.flink.table.data.TimestampData
-
- fromTimestamp(long) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
- fromTypeInfo(TypeInformation<?>) - Static method in class org.apache.flink.table.api.TableSchema
-
- 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_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, ClassLoader, Configuration) - Constructor for class org.apache.flink.table.functions.FunctionContext
-
- FunctionContext(RuntimeContext) - 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
-
- 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 input types, accumulator types, and
output types for constructing the
TypeInference
logic of a
UserDefinedFunction
.
- FunctionHints - Annotation Type in org.apache.flink.table.annotation
-
- FunctionIdentifier - Class in org.apache.flink.table.functions
-
Identifies a system function with function name or a catalog function with a fully qualified
identifier.
- functionIdentifier() - Method in class org.apache.flink.table.functions.UserDefinedFunction
-
Returns a unique, serialized representation for this function.
- FunctionKind - Enum in org.apache.flink.table.functions
-
- FunctionLanguage - Enum in org.apache.flink.table.catalog
-
- 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
-
- 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
-
- GenericArrayData - Class in org.apache.flink.table.data
-
An internal data structure representing data of
ArrayType
.
- GenericArrayData(Object[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
-
- GenericArrayData(int[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
-
- GenericArrayData(long[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
-
- GenericArrayData(float[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
-
- GenericArrayData(double[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
-
- GenericArrayData(short[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
-
- GenericArrayData(byte[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
-
- GenericArrayData(boolean[]) - Constructor for class org.apache.flink.table.data.GenericArrayData
-
- GenericMapData - Class in org.apache.flink.table.data
-
- GenericMapData(Map<?, ?>) - Constructor for class org.apache.flink.table.data.GenericMapData
-
- GenericRowData - Class in org.apache.flink.table.data
-
An internal data structure representing data of
RowType
and other (possibly nested)
structured types such as
StructuredType
.
- GenericRowData(RowKind, int) - Constructor for class org.apache.flink.table.data.GenericRowData
-
Creates an instance of
GenericRowData
with given kind and number of fields.
- GenericRowData(int) - Constructor for class org.apache.flink.table.data.GenericRowData
-
- get() - Method in class org.apache.flink.table.api.dataview.ListView
-
Returns an iterable of the list view.
- get(K) - Method in class org.apache.flink.table.api.dataview.MapView
-
Return the value for the specified key or null
if the key is not in the map view.
- get(Object) - Method in class org.apache.flink.table.data.GenericMapData
-
Returns the value to which the specified key is mapped, or null
if this map contains
no mapping for the key.
- GET - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- GET - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificTypeStrategies
-
See GetTypeStrategy
.
- get(K) - Method in class org.apache.flink.table.utils.ThreadLocalCache
-
- getAbstractDataType() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
-
- getAbstractDataType() - Method in class org.apache.flink.table.api.DataTypes.Field
-
- getAbstractDataType() - Method in class org.apache.flink.table.api.DataTypes.UnresolvedField
-
- getAcceptedFilters() - Method in class org.apache.flink.table.connector.source.abilities.SupportsFilterPushDown.Result
-
- getAccessedFields(TimestampExtractor, DataType, Function<String, String>) - Static method in class org.apache.flink.table.sources.tsextractors.TimestampExtractorUtils
-
- getAccumulatorDataType() - Method in class org.apache.flink.table.types.inference.TypeInferenceUtil.Result
-
- getAccumulatorType() - Method in class org.apache.flink.table.functions.ImperativeAggregateFunction
-
- 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
-
- 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.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.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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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(String, Function<String, E>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns all array elements under a given existing key.
- getAsyncLookupFunction(String[]) - Method in interface org.apache.flink.table.sources.LookupableTableSource
-
Deprecated.
- getAtomicName(List<String>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
-
Returns a unique name for an atomic type.
- getAttributeName() - Method in class org.apache.flink.table.sources.RowtimeAttributeDescriptor
-
Deprecated.
Returns the name of the rowtime attribute.
- getAttributes() - Method in class org.apache.flink.table.types.logical.StructuredType
-
- getAvgLen() - Method in class org.apache.flink.table.plan.stats.ColumnStats
-
- getAvgLength() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBinary
-
- getAvgLength() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
-
- getBigDecimal(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a big decimal value under the given existing key.
- getBinary(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the binary value at the given position.
- getBinary(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- getBinary(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- getBinary(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- getBinary(int) - Method in class org.apache.flink.table.data.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(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get boolean from segments.
- getBoolean(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- getBoolean(int) - Method in class org.apache.flink.table.data.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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a boolean value under the given existing key.
- 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(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get byte from segments.
- getByte(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- getByte(int) - Method in class org.apache.flink.table.data.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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a byte value under the given existing key.
- getByteArray(int, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- getBytes(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
Maybe not copied, if want copy, please use copyTo.
- 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
-
- getCache() - Method in interface org.apache.flink.table.connector.source.lookup.PartialCachingAsyncLookupProvider
-
- getCache() - Method in interface org.apache.flink.table.connector.source.lookup.PartialCachingLookupProvider
-
- 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
-
- 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(ChangelogMode) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
-
Returns the set of changes that the sink accepts during runtime.
- getChangelogMode() - Method in interface org.apache.flink.table.connector.source.ScanTableSource
-
Returns the set of changes that the planner can expect during runtime.
- getCharacter(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a character value under the given existing key.
- 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.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.TypeInformationRawType
-
Deprecated.
- getChildren() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- getChildren() - Method in class org.apache.flink.table.types.logical.VarBinaryType
-
- getChildren() - Method in class org.apache.flink.table.types.logical.VarCharType
-
- getChildren() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
-
- getChildren() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
-
- getClass(String, Class<T>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a class value under the given existing key.
- 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.
- 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.
- getColumn() - Method in class org.apache.flink.table.catalog.TableChange.AddColumn
-
- 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.constraints.UniqueConstraint
-
Deprecated.
List of column names for which the primary key was defined.
- getColumns() - Method in class org.apache.flink.table.api.Schema
-
- getColumns() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns all
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.
- 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.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.DefaultCatalogTable
-
- 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 interface org.apache.flink.table.factories.TableSinkFactory.Context
-
Deprecated.
- getConfiguration() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- getConfiguration() - Method in interface org.apache.flink.table.factories.TableSourceFactory.Context
-
Deprecated.
- getConfiguration() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
-
Deprecated.
- getConfiguration() - Method in interface org.apache.flink.table.factories.WorkflowSchedulerFactory.Context
-
- 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.
- 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.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.
- 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(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns the DataType under the given existing key.
- getDataType() - Method in interface org.apache.flink.table.types.DataTypeQueryable
-
- getDataType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- getDataTypeFactory() - Method in interface org.apache.flink.table.types.inference.CallContext
-
Enables to lookup types in a catalog and resolve RAW types.
- getDataTypeFactory() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- getDataTypeFactory() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- getDayPrecision() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
-
- getDayPrecision(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- getDaysSinceEpoch() - Method in class org.apache.flink.table.catalog.stats.Date
-
- getDecimal(int, int, int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the decimal value at the given position.
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- getDecimal(int, int, int) - Method in class org.apache.flink.table.data.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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.ArrayType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.BigIntType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.BinaryType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.BooleanType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.CharType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DateType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DecimalType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DistinctType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.DoubleType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.FloatType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.IntType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns the default conversion class.
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.MapType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.MultisetType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.NullType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.RawType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.RowType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.SmallIntType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.StructuredType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.SymbolType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TimestampType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TimeType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TinyIntType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
-
Deprecated.
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.VarBinaryType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.VarCharType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
-
- getDefaultConversion() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
-
- getDefaultDatabase() - Method in class org.apache.flink.table.catalog.AbstractCatalog
-
- getDefaultDatabase() - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the name of the default database for this catalog.
- 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
-
- 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(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get double from segments.
- getDouble(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- getDouble(int) - Method in class org.apache.flink.table.data.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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a double value under the given existing key.
- getDuration(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a java
Duration
under the given existing key.
- getDynamicOptions() - Method in class org.apache.flink.table.workflow.ResumeRefreshWorkflow
-
- getDynamicTableFactory(Class<T>, Catalog) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
- 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
-
- 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.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.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.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.api.TableColumn.ComputedColumn
-
Deprecated.
- getExpression() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
-
- getExpression(ResolvedFieldReference[]) - Method in interface org.apache.flink.table.sources.FieldComputer
-
Deprecated.
Returns the
Expression
that computes the value of the field.
- getExternalResourceInfos(String) - Method in class org.apache.flink.table.functions.FunctionContext
-
Get the external resource information.
- getFactory() - Method in interface org.apache.flink.table.catalog.Catalog
-
Returns a factory for creating instances from catalog objects.
- getFalseCount() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
-
- getFamilies() - Method in enum org.apache.flink.table.types.logical.LogicalTypeRoot
-
- getField(int) - Method in class org.apache.flink.table.data.GenericRowData
-
Returns the field value at the given position.
- getField(DataType, int) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Retrieves a nested field from a composite type at given position.
- getField(DataType, String) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Retrieves a nested field from a composite type with given name.
- getFieldCount() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Returns the number of fields.
- getFieldCount(DataType) - Static method in class org.apache.flink.table.types.DataType
-
Returns the count of the first-level fields for the provided
DataType
.
- getFieldCount() - Method in class org.apache.flink.table.types.logical.RowType
-
- getFieldCount(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns the field count of row and structured types.
- getFieldDataType(int) - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Returns the specified data type for the given field index.
- getFieldDataType(String) - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Returns the specified data type for the given field name.
- getFieldDataTypes() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Returns all field data types as an array.
- 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.sources.DefinedFieldMapping
-
Deprecated.
- getFieldName(int) - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Returns the specified name for the given field index.
- getFieldNames() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Returns all field names as an array.
- getFieldNames() - Method in class org.apache.flink.table.expressions.NestedFieldReferenceExpression
-
- getFieldNames() - Method in interface org.apache.flink.table.sinks.TableSink
-
- getFieldNames() - Method in class org.apache.flink.table.sinks.TableSinkBase
-
Deprecated.
Returns the field names of the table to emit.
- getFieldNames(DataType) - Static method in class org.apache.flink.table.types.DataType
-
Returns the first-level field names for the provided
DataType
.
- getFieldNames() - Method in class org.apache.flink.table.types.logical.RowType
-
- getFieldNames(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns the field names of row and structured types.
- getFieldOrNull(RowData) - Method in interface org.apache.flink.table.data.RowData.FieldGetter
-
- getFields() - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapRowVector
-
- getFields(DataType) - Static method in class org.apache.flink.table.types.DataType
-
Returns an ordered list of fields starting from the provided
DataType
.
- getFields() - Method in class org.apache.flink.table.types.logical.RowType
-
- getFieldType(int) - Method in class org.apache.flink.table.api.TableSchema
-
- getFieldType(String) - Method in class org.apache.flink.table.api.TableSchema
-
- getFieldTypes() - Method in class org.apache.flink.table.api.TableSchema
-
- getFieldTypes() - Method in interface org.apache.flink.table.sinks.TableSink
-
- 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(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get float from segments.
- getFloat(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- getFloat(int) - Method in class org.apache.flink.table.data.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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a float value under the given given existing key.
- 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
-
- getFullName() - Method in class org.apache.flink.table.catalog.ObjectPath
-
- getFunction(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the function.
- getFunctionDefinition() - Method in class org.apache.flink.table.expressions.AggregateExpression
-
- getFunctionDefinition() - Method in class org.apache.flink.table.expressions.CallExpression
-
- getFunctionDefinition(String) - Method in class org.apache.flink.table.module.CoreModule
-
- getFunctionDefinition(String) - Method in interface org.apache.flink.table.module.Module
-
- getFunctionDefinition() - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns the function definition that defines the function currently being called.
- getFunctionDefinition() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- getFunctionDefinition() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- getFunctionDefinitionFactory() - Method in interface org.apache.flink.table.catalog.Catalog
-
- 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
-
- getInputTypeStrategy(ImperativeAggregateFunction<?, ?>) - Static method in class org.apache.flink.table.functions.LegacyUserDefinedFunctionInference
-
Deprecated.
- getInputTypeStrategy(TableFunction<?>) - 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() - Method in class org.apache.flink.table.types.inference.TypeInference
-
- getInt(int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the integer value at the given position.
- getInt(int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- getInt(int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- getInt(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get int from segments.
- getInt(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- getInt(int) - Method in class org.apache.flink.table.data.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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns an integer value under the given existing key.
- 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.
- 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.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(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- getLength() - Method in class org.apache.flink.table.types.logical.VarBinaryType
-
- getLength() - Method in class org.apache.flink.table.types.logical.VarCharType
-
- 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(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get long from segments.
- getLong(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- getLong(int) - Method in class org.apache.flink.table.data.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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a long value under the given existing key.
- getLookupFunction(String[]) - Method in interface org.apache.flink.table.sources.LookupableTableSource
-
Deprecated.
- 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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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
-
- 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
-
- getMaxValue() - Method in class org.apache.flink.table.plan.stats.ColumnStats
-
Deprecated.
- getMemorySize(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a Flink MemorySize
under the given existing key.
- getMessage() - Method in exception org.apache.flink.table.api.AmbiguousTableFactoryException
-
Deprecated.
- getMessage() - Method in exception org.apache.flink.table.api.NoMatchingTableFactoryException
-
Deprecated.
- getMetadataAlias() - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
-
Deprecated.
- getMetadataKey() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
-
- getMetadataKey() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
-
- getMetricGroup() - Method in class org.apache.flink.table.functions.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
-
- getMinValue() - Method in class org.apache.flink.table.plan.stats.ColumnStats
-
Deprecated.
- getName() - Method in interface org.apache.flink.table.api.constraints.Constraint
-
Deprecated.
- getName() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
-
- getName() - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
-
- getName() - Method in class org.apache.flink.table.api.TableColumn
-
Deprecated.
Returns the name of this column.
- getName() - Method in class org.apache.flink.table.catalog.AbstractCatalog
-
- getName() - Method in class org.apache.flink.table.catalog.Column
-
Returns the name of this column.
- getName() - Method in interface org.apache.flink.table.catalog.Constraint
-
- getName() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
-
- getName() - Method in 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.types.inference.CallContext
-
Returns the function's name usually referencing the function in a catalog.
- getName() - Method in class org.apache.flink.table.types.inference.Signature.Argument
-
- getName() - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- getName() - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- getName() - Method in class org.apache.flink.table.types.logical.RowType.RowField
-
- getName() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- getNamedArguments() - Method in class org.apache.flink.table.types.inference.TypeInference
-
- getNanoOfMillisecond() - Method in class org.apache.flink.table.data.TimestampData
-
Returns the number of nanoseconds (the nanoseconds within the milliseconds).
- getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDate
-
- getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataDouble
-
- getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataLong
-
- getNdv() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataString
-
- getNdv() - Method in class org.apache.flink.table.plan.stats.ColumnStats
-
- getNestedSerializers(ListViewSerializer<T>) - Method in class org.apache.flink.table.dataview.ListViewSerializerSnapshot
-
Deprecated.
- getNestedSerializers(MapViewSerializer<K, V>) - Method in class org.apache.flink.table.dataview.MapViewSerializerSnapshot
-
Deprecated.
- getNestedSerializers(NullAwareMapSerializer<K, V>) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializerSnapshot
-
Deprecated.
- 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 interface org.apache.flink.table.factories.TableSinkFactory.Context
-
Deprecated.
- getObjectIdentifier() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- getObjectIdentifier() - Method in interface org.apache.flink.table.factories.TableSourceFactory.Context
-
Deprecated.
- getObjectIdentifier() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
-
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
-
- getOptionalArray(String, Function<String, E>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns all array elements under a given key if it exists.
- getOptionalBigDecimal(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a big decimal value under the given key if it exists.
- getOptionalBoolean(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a boolean value under the given key if it exists.
- getOptionalByte(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a byte value under the given key if it exists.
- getOptionalCharacter(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a character value under the given key if it exists.
- getOptionalClass(String, Class<T>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a class value under the given key if it exists.
- getOptionalDataType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns the DataType under the given key if it exists.
- getOptionalDouble(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a double value under the given key if it exists.
- getOptionalDuration(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a Java
Duration
under the given key if it exists.
- getOptionalFloat(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a float value under the given key if it exists.
- getOptionalInt(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns an integer value under the given key if it exists.
- getOptionalLong(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a long value under the given key if it exists.
- getOptionalMemorySize(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a Flink MemorySize
under the given key if it exists.
- getOptionalShort(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a short value under the given key if it exists.
- getOptionalString(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a string value under the given key if it exists.
- getOptionalTableSchema(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a table schema under the given key if it exists.
- getOptionalType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns the type information under the given key if it exists.
- getOptions() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
Returns a map of string-based options.
- getOptions() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
-
- getOptions() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
-
- 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 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 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
-
- getOutputType() - Method in interface org.apache.flink.table.sinks.TableSink
-
- getOutputTypeStrategy(ScalarFunction) - Static method in class org.apache.flink.table.functions.LegacyUserDefinedFunctionInference
-
Deprecated.
- getOutputTypeStrategy() - Method in class org.apache.flink.table.types.inference.TypeInference
-
- getParallelism() - Method in interface org.apache.flink.table.connector.ParallelismProvider
-
Returns the parallelism for this instance.
- getParameterTypes(Class[]) - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
-
- getParameterTypes(Class[]) - Method in class org.apache.flink.table.functions.python.PythonTableFunction
-
- getParameterTypes(Class<?>[]) - Method in class org.apache.flink.table.functions.ScalarFunction
-
- getParameterTypes(Class<?>[]) - Method in class org.apache.flink.table.functions.TableFunction
-
- getPartition(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get a partition of the given table.
- getPartitionColumnStatistics(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the column statistics of a partition.
- getPartitionKeys() - Method in interface org.apache.flink.table.catalog.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.sources.PartitionableTableSource
-
Deprecated.
- 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(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
Returns the precision of all types that define a precision implicitly or explicitly.
- getPrecision() - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
-
- getPrimaryKey() - Method in class org.apache.flink.table.api.Schema
-
- getPrimaryKey() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
- getPrimaryKey() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns the primary key if it has been defined.
- 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.sources.DefinedProctimeAttribute
-
Deprecated.
Returns the name of a processing time attribute or null if no processing time attribute is
present.
- getProducedDataType() - Method in interface org.apache.flink.table.sources.TableSource
-
Deprecated.
- 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
-
- getRefreshHandler() - Method in interface org.apache.flink.table.workflow.ModifyRefreshWorkflow
-
- 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
-
- 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.
- 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
-
- getResolvedSchema() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogBaseTable
-
- 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
-
- getResultType() - Method in class org.apache.flink.table.functions.python.PythonAggregateFunction
-
- getResultType(Class[]) - Method in class org.apache.flink.table.functions.python.PythonScalarFunction
-
- getResultType() - Method in class org.apache.flink.table.functions.python.PythonTableAggregateFunction
-
- getResultType() - Method in class org.apache.flink.table.functions.python.PythonTableFunction
-
- getResultType(Class<?>[]) - Method in class org.apache.flink.table.functions.ScalarFunction
-
- getResultType() - Method in class org.apache.flink.table.functions.TableFunction
-
- getResultType() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- 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.sources.FieldComputer
-
Deprecated.
Returns the result type of the expression.
- getReturnType() - Method in interface org.apache.flink.table.sources.TableSource
-
- getReturnType() - Method in class org.apache.flink.table.sources.tsextractors.TimestampExtractor
-
Deprecated.
- getReturnTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
- getReturnTypeOfAggregateFunction(ImperativeAggregateFunction<T, ACC>, TypeInformation<T>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
- getReturnTypeOfTableFunction(TableFunction<T>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
- getReturnTypeOfTableFunction(TableFunction<T>, TypeInformation<T>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
Tries to infer the TypeInformation of an AggregateFunction's accumulator type.
- getRow(int, int) - Method in interface org.apache.flink.table.data.ArrayData
-
Returns the row value at the given position.
- getRow(int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- getRow(int, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- getRow(int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- getRow(int, int) - Method in class org.apache.flink.table.data.columnar.ColumnarArrayData
-
- getRow(int, int) - Method in class org.apache.flink.table.data.columnar.ColumnarRowData
-
- 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 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.api.WatermarkSpec
-
Deprecated.
Returns the name of rowtime attribute, it can be a nested field using dot separator.
- getRowtimeAttribute() - Method in class org.apache.flink.table.catalog.WatermarkSpec
-
Returns the name of a rowtime attribute.
- getRowtimeAttributeDescriptors() - Method in interface org.apache.flink.table.sources.DefinedRowtimeAttributes
-
Deprecated.
- 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
-
- getSchema() - Method in interface org.apache.flink.table.catalog.ResolvedCatalogBaseTable
-
- 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(MemorySegment[], int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
get short from segments.
- getShort(int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- getShort(int) - Method in class org.apache.flink.table.data.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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a short value under the given existing key.
- getSimpleName() - Method in class org.apache.flink.table.functions.FunctionIdentifier
-
- getSinkRuntimeProvider(DynamicTableSink.Context) - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink
-
Returns a provider of runtime implementation for writing the data.
- 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
-
- 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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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(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(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
- getTable(ObjectPath, long) - Method in interface org.apache.flink.table.catalog.Catalog
-
- getTable() - Method in interface org.apache.flink.table.factories.TableSinkFactory.Context
-
Deprecated.
- getTable() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- getTable() - Method in interface org.apache.flink.table.factories.TableSourceFactory.Context
-
Deprecated.
- getTable() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
-
Deprecated.
- getTableAggregateFunction() - Method in class org.apache.flink.table.functions.TableAggregateFunctionDefinition
-
Deprecated.
- getTableColumn(int) - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Returns the
TableColumn
instance for the given field index.
- getTableColumn(String) - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Returns the
TableColumn
instance for the given field name.
- getTableColumns() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
- getTableColumnStatistics(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Get the column statistics of a table.
- getTableFactory() - Method in interface org.apache.flink.table.catalog.Catalog
-
- getTableFunction() - Method in class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- getTableKind() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
- 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(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns a table schema under the given existing key.
- getTableSchema() - Method in interface org.apache.flink.table.sinks.TableSink
-
Deprecated.
Returns the schema of the consumed table.
- getTableSchema() - Method in interface org.apache.flink.table.sources.TableSource
-
- getTableSinkFactory() - Method in interface org.apache.flink.table.module.Module
-
- getTableSourceFactory() - Method in interface org.apache.flink.table.module.Module
-
- 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 or
Optional.empty()
when not specified.
- 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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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
-
- getTimestampExtractor() - Method in class org.apache.flink.table.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
-
- getTrueCount() - Method in class org.apache.flink.table.catalog.stats.CatalogColumnStatisticsDataBoolean
-
- getType() - Method in interface org.apache.flink.table.api.constraints.Constraint
-
Deprecated.
Tells what kind of constraint it is, e.g.
- getType() - Method in class org.apache.flink.table.api.constraints.UniqueConstraint
-
Deprecated.
- getType() - Method in class org.apache.flink.table.api.TableColumn
-
Deprecated.
Returns the data type of this column.
- getType() - Method in interface org.apache.flink.table.catalog.Constraint
-
Tells what kind of constraint it is, e.g.
- getType() - Method in class org.apache.flink.table.catalog.UniqueConstraint
-
- getType(String) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns the type information under the given existing key.
- getType() - Method in class org.apache.flink.table.types.inference.Signature.Argument
-
- getType() - Method in class org.apache.flink.table.types.logical.RowType.RowField
-
- getType() - Method in class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- getTypeAt(int) - Method in class org.apache.flink.table.types.logical.RowType
-
- getTypeClass() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- getTypeClass() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- getTypeClass() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- getTypedArguments() - Method in class org.apache.flink.table.types.inference.TypeInference
-
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.AggregateFunction
-
- getTypeInference(DataTypeFactory) - Method in class org.apache.flink.table.functions.AggregateFunctionDefinition
-
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.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.types.logical.LegacyTypeInformationType
-
- getTypeInformation() - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
-
Deprecated.
- getTypeRoot() - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns the root of this type.
- getTypeSerializer() - Method in class org.apache.flink.table.types.logical.RawType
-
- getUnresolvedIdentifier() - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- getUnresolvedSchema() - Method in interface org.apache.flink.table.catalog.CatalogBaseTable
-
Returns the schema of the table or view.
- getUnresolvedSchema() - Method in class org.apache.flink.table.catalog.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(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
-
- getValue(int) - Static method in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnit
-
Returns the TimeUnit associated with an ordinal.
- getValueAs(Class<T>) - Method in class org.apache.flink.table.expressions.ValueLiteralExpression
-
Returns the value (excluding null) as an instance of the given class.
- getValueDataType() - Method in class org.apache.flink.table.types.KeyValueDataType
-
- getValueSerializer() - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- getValueType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- getValueType() - Method in class org.apache.flink.table.types.logical.MapType
-
- getVariableIndexedProperties(String, List<String>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Returns the property keys of variable indexed properties.
- 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.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
-
- getWatermarkExprOutputType() - Method in class org.apache.flink.table.api.WatermarkSpec
-
Deprecated.
Returns the data type of the computation result of watermark generation expression.
- getWatermarkSpecs() - Method in class org.apache.flink.table.api.Schema
-
- getWatermarkSpecs() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Returns a list of the watermark specification which contains rowtime attribute and watermark
strategy expression.
- getWatermarkSpecs() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Returns a list of watermark specifications each consisting of a rowtime attribute and
watermark strategy expression.
- getWatermarkStrategy() - Method in class org.apache.flink.table.sources.RowtimeAttributeDescriptor
-
Deprecated.
Returns the [[WatermarkStrategy]] for the attribute.
- 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(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- getYearPrecision() - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
-
- GREATER_THAN - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- GREATER_THAN_OR_EQUAL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- GREATEST - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- 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
-
- 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
-
- IN - Static variable in class org.apache.flink.table.types.inference.strategies.SpecificInputTypeStrategies
-
- 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.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.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.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(CallContext, TypeStrategy) - Static method in class org.apache.flink.table.types.inference.TypeInferenceUtil
-
- inferOutputType(DataTypeFactory) - Method in interface org.apache.flink.table.types.inference.TypeInferenceUtil.SurroundingInfo
-
- inferType(CallContext) - Method in class org.apache.flink.table.types.inference.strategies.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
-
- InputFormatProvider - Interface in org.apache.flink.table.connector.source
-
Provider of an
InputFormat
instance as a runtime implementation for
ScanTableSource
.
- InputGroup - Enum in org.apache.flink.table.annotation
-
A list of commonly used pre-defined groups of similar types for accepting more than just one data
type as an input argument in
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 - Interface in org.apache.flink.table.types.inference
-
Strategy for inferring and validating input arguments in a function call.
- inputTypeStrategy(InputTypeStrategy) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets the strategy for inferring and validating input arguments in a function call.
- 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(ClassLoader, ReadableConfig, String, CatalogFunction) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
- instantiateFunction(Class<?>) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
- 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.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
-
- IntColumnVector - Interface in org.apache.flink.table.data.columnar.vector
-
Int column vector.
- 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(DataTypes.Resolution) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a temporal interval.
- INTERVAL(DataTypes.Resolution, DataTypes.Resolution) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a temporal interval.
- INTERVAL_MILLIS() - Static method in class org.apache.flink.table.api.Types
-
Deprecated.
Returns type information for a Table API interval of milliseconds.
- INTERVAL_MILLIS - Static variable in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- INTERVAL_MONTHS() - Static method in class org.apache.flink.table.api.Types
-
Deprecated.
Returns type information for a Table API interval of months.
- INTERVAL_MONTHS - Static variable in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- IntervalFreshness - Class in org.apache.flink.table.catalog
-
- 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
-
- IntType - Class in org.apache.flink.table.types.logical
-
Logical type of a 4-byte signed integer with values from -2,147,483,648 to 2,147,483,647.
- IntType(boolean) - Constructor for class org.apache.flink.table.types.logical.IntType
-
- IntType() - Constructor for class org.apache.flink.table.types.logical.IntType
-
- 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(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(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_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(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.
- 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.
- isApproximate() - Method in class org.apache.flink.table.expressions.AggregateExpression
-
- isArgumentLiteral(int) - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns whether the argument at the given position is a value literal.
- isArgumentLiteral(int) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- isArgumentLiteral(int) - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- isArgumentNull(int) - Method in interface org.apache.flink.table.types.inference.CallContext
-
Returns true
if the argument at the given position is a literal and null
,
false
otherwise.
- isArgumentNull(int) - Method in class org.apache.flink.table.types.inference.utils.AdaptedCallContext
-
- isArgumentNull(int) - Method in class org.apache.flink.table.types.inference.utils.UnknownCallContext
-
- isAssignable(Class<?>, Class<?>, boolean) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks if one Class
can be assigned to a variable of another Class
.
- isAsyncEnabled() - Method in interface org.apache.flink.table.sources.LookupableTableSource
-
Deprecated.
Returns true if async lookup is enabled.
- isBasicType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- isBasicType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- isBasicType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- isBounded() - Method in interface org.apache.flink.table.connector.sink.DynamicTableSink.Context
-
Returns whether a runtime implementation can expect a finite number of rows.
- isBounded() - Method in interface org.apache.flink.table.connector.source.ScanTableSource.ScanRuntimeProvider
-
Returns whether the data is bounded or not.
- isBounded() - Method in interface org.apache.flink.table.factories.TableSinkFactory.Context
-
Deprecated.
It depends on whether the TableEnvironment
execution mode is batch.
- isBounded() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- 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 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.api.constraints.Constraint
-
Deprecated.
Constraints can either be enforced or non-enforced.
- isEnforced() - Method in interface org.apache.flink.table.catalog.Constraint
-
Constraints can either be enforced or non-enforced.
- 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.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
-
- isGeneric() - Method in interface org.apache.flink.table.catalog.CatalogFunction
-
- 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(Executable, Class<?>...) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks whether a method/constructor can be called with the given argument classes.
- isKeyType() - Method in class org.apache.flink.table.dataview.ListViewTypeInfo
-
Deprecated.
- isKeyType() - Method in class org.apache.flink.table.dataview.MapViewTypeInfo
-
Deprecated.
- isKeyType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
-
Deprecated.
- isLimitPushedDown() - Method in interface org.apache.flink.table.sources.LimitableTableSource
-
Deprecated.
Return the flag to indicate whether limit push down has been tried.
- isMutable(LogicalType) - Static method in class org.apache.flink.table.data.binary.BinaryRowData
-
- 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, int) - Method in class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch
-
- 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
-
- 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.
- 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.
- 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.api.TableColumn.ComputedColumn
-
Deprecated.
- isPersisted() - Method in class org.apache.flink.table.api.TableColumn
-
Deprecated.
Returns whether the given column is persisted in a sink operation.
- isPersisted() - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
-
Deprecated.
- isPersisted() - Method in class org.apache.flink.table.api.TableColumn.PhysicalColumn
-
Deprecated.
- isPersisted() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
-
- isPersisted() - Method in class org.apache.flink.table.catalog.Column
-
Returns whether the given column is persisted in a sink operation.
- isPersisted() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
-
- isPersisted() - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
-
- isPhysical() - Method in class org.apache.flink.table.api.TableColumn.ComputedColumn
-
Deprecated.
- isPhysical() - Method in class org.apache.flink.table.api.TableColumn
-
Deprecated.
Returns whether the given column is a physical column of a table; neither computed nor
metadata.
- isPhysical() - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
-
Deprecated.
- isPhysical() - Method in class org.apache.flink.table.api.TableColumn.PhysicalColumn
-
Deprecated.
- isPhysical() - Method in class org.apache.flink.table.catalog.Column.ComputedColumn
-
- isPhysical() - Method in class org.apache.flink.table.catalog.Column
-
Returns whether the given column is a physical column of a table; neither computed nor
metadata.
- isPhysical() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
-
- isPhysical() - Method in class org.apache.flink.table.catalog.Column.PhysicalColumn
-
- isPrimitiveArray() - Method in class org.apache.flink.table.data.GenericArrayData
-
Returns true if this is a primitive array.
- isProctimeAttribute(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- isRowtimeAttribute(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- isSingleFieldInterval(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeChecks
-
- isStructuredFieldDirectlyReadable(Field) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks whether a field is directly readable without a getter.
- isStructuredFieldDirectlyWritable(Field) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Checks whether a field is directly writable without a setter or constructor.
- isTemporary() - Method in 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 interface org.apache.flink.table.factories.TableSinkFactory.Context
-
Deprecated.
Whether the table is temporary.
- isTemporary() - Method in class org.apache.flink.table.factories.TableSinkFactoryContextImpl
-
Deprecated.
- isTemporary() - Method in interface org.apache.flink.table.factories.TableSourceFactory.Context
-
Deprecated.
Whether the table is temporary.
- isTemporary() - Method in class org.apache.flink.table.factories.TableSourceFactoryContextImpl
-
Deprecated.
- 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
-
- 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.
- isVirtual() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
-
- isVirtual() - Method in class org.apache.flink.table.api.TableColumn.MetadataColumn
-
Deprecated.
- isVirtual() - Method in class org.apache.flink.table.catalog.Column.MetadataColumn
-
- 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
-
- ItemAtIndexArgumentTypeStrategy() - Constructor for class org.apache.flink.table.types.inference.strategies.ItemAtIndexArgumentTypeStrategy
-
- ItemAtTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
- 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.
- 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(String) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeParser
-
- PARSE_URL - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- parseDate(String, String) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
Returns the epoch days since 1970-01-01.
- parseDate(String) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
- 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_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
-
- PartialCachingLookupProvider - Interface in org.apache.flink.table.connector.source.lookup
-
- PARTITION_KEYS - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- PartitionableTableSink - Interface in org.apache.flink.table.sinks
-
- PartitionableTableSource - Interface in org.apache.flink.table.sources
-
- PartitionAlreadyExistsException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to create a partition that already exists.
- PartitionAlreadyExistsException(String, ObjectPath, CatalogPartitionSpec) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionAlreadyExistsException
-
- PartitionAlreadyExistsException(String, ObjectPath, CatalogPartitionSpec, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.PartitionAlreadyExistsException
-
- partitionExists(ObjectPath, CatalogPartitionSpec) - Method in interface org.apache.flink.table.catalog.Catalog
-
Check whether a partition exists or not.
- 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
-
- PeriodicCacheReloadTrigger - Class in org.apache.flink.table.connector.source.lookup.cache.trigger
-
- 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(FunctionIdentifier, FunctionDefinition, List<ResolvedExpression>, DataType) - Static method in class org.apache.flink.table.expressions.CallExpression
-
- permanent(BuiltInFunctionDefinition, List<ResolvedExpression>, DataType) - Static method in class org.apache.flink.table.expressions.CallExpression
-
- physical(String, DataType) - Static method in class org.apache.flink.table.api.TableColumn
-
Deprecated.
Creates a regular table column that represents physical data.
- physical(String, DataType) - Static method in class org.apache.flink.table.catalog.Column
-
Creates a regular table column that represents physical data.
- physical(List<String>, List<DataType>) - Static method in class org.apache.flink.table.catalog.ResolvedSchema
-
Shortcut for a resolved schema of only physical columns.
- physical(String[], DataType[]) - Static method in class org.apache.flink.table.catalog.ResolvedSchema
-
Shortcut for a resolved schema of only physical columns.
- PI - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- PLACEHOLDER_SYMBOL - Static variable in class org.apache.flink.table.factories.FactoryUtil
-
The placeholder symbol to be used for keys of options which can be templated.
- PLUS - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
Combines numeric addition, "datetime + interval"/"interval + interval" arithmetic, and string
concatenation.
- pointTo(MemorySegment[], int, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- pointTo(MemorySegment[], int, int) - Method in class org.apache.flink.table.data.binary.BinaryMapData
-
- pointTo(MemorySegment, int, int) - Method in class org.apache.flink.table.data.binary.BinarySection
-
- pointTo(MemorySegment[], int, int) - Method in class org.apache.flink.table.data.binary.BinarySection
-
- POSITION - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- POWER - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- precision() - Method in class org.apache.flink.table.data.DecimalData
-
- PRECISION - Static variable in class org.apache.flink.table.types.logical.BigIntType
-
- PRECISION - Static variable in class org.apache.flink.table.types.logical.DoubleType
-
- PRECISION - Static variable in class org.apache.flink.table.types.logical.FloatType
-
- PRECISION - Static variable in class org.apache.flink.table.types.logical.IntType
-
- PRECISION - Static variable in class org.apache.flink.table.types.logical.SmallIntType
-
- PRECISION - Static variable in class org.apache.flink.table.types.logical.TinyIntType
-
- prepareInstance(ReadableConfig, UserDefinedFunction) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
- PreserveWatermarks - Class in org.apache.flink.table.sources.wmstrategies
-
A strategy which indicates the watermarks should be preserved from the underlying datastream.
- PreserveWatermarks() - Constructor for class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
-
- PRIMARY_KEY_COLUMNS - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- PRIMARY_KEY_NAME - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- primaryKey(String, List<String>) - Static method in class org.apache.flink.table.api.constraints.UniqueConstraint
-
Deprecated.
Creates a non enforced ConstraintType#PRIMARY_KEY
constraint.
- primaryKey(String...) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a primary key constraint for a set of given columns.
- primaryKey(List<String>) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a primary key constraint for a set of given columns.
- primaryKey(String...) - Method in class org.apache.flink.table.api.TableSchema.Builder
-
Deprecated.
Creates a primary key constraint for a set of given columns.
- primaryKey(String, String[]) - Method in class org.apache.flink.table.api.TableSchema.Builder
-
Deprecated.
Creates a primary key constraint for a set of given columns.
- primaryKey(String, List<String>) - Static method in class org.apache.flink.table.catalog.UniqueConstraint
-
Creates a non enforced ConstraintType#PRIMARY_KEY
constraint.
- primaryKeyNamed(String, String...) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a primary key constraint for a set of given columns.
- primaryKeyNamed(String, List<String>) - Method in class org.apache.flink.table.api.Schema.Builder
-
Declares a primary key constraint for a set of given columns.
- PRIMITIVE_ARRAY(TypeInformation<?>) - Static method in class org.apache.flink.table.api.Types
-
Deprecated.
Generates type information for an array consisting of Java primitive elements.
- primitiveToWrapper(Class<?>) - Static method in class org.apache.flink.table.types.extraction.ExtractionUtils
-
Converts the specified primitive Class object to its corresponding wrapper Class object.
- 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
-
- printFooter(PrintWriter, long) - Method in class org.apache.flink.table.utils.print.TableauStyle
-
- PrintStyle - Interface in org.apache.flink.table.utils.print
-
- 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 input types and output types for
constructing the
TypeInference
logic of a
Procedure
.
- ProcedureHints - Annotation Type in org.apache.flink.table.annotation
-
- 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
-
- proctime() - Method in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
Specifies the previously defined field as a processing-time attribute.
- PROCTIME - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- PROCTIME_BATCH_MARKER - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- PROCTIME_INDICATOR - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- PROCTIME_STREAM_MARKER - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- 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
-
- ProjectableDecodingFormat<I> - Interface in org.apache.flink.table.connector.format
-
- ProjectableTableSource<T> - Interface in org.apache.flink.table.sources
-
- ProjectedRowData - Class in org.apache.flink.table.data.utils
-
An implementation of
RowData
which provides a projected view of the underlying
RowData
.
- projectFields(int[]) - Method in interface org.apache.flink.table.sources.ProjectableTableSource
-
Deprecated.
Creates a copy of the
TableSource
that projects its output to the given field
indexes.
- 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.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
-
- projectRow(DataType, int[]) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
- 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.
- PythonAggregateFunction - Class in org.apache.flink.table.functions.python
-
The wrapper of user defined python aggregate function.
- PythonAggregateFunction(String, byte[], DataType[], DataType, DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonAggregateFunction
-
- 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
-
- 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[], DataType[], DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonScalarFunction
-
- 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
-
- PythonTableAggregateFunction - Class in org.apache.flink.table.functions.python
-
The wrapper of user defined python table aggregate function.
- PythonTableAggregateFunction(String, byte[], DataType[], DataType, DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonTableAggregateFunction
-
- 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
-
- PythonTableFunction - Class in org.apache.flink.table.functions.python
-
The wrapper of user defined python table function.
- PythonTableFunction(String, byte[], DataType[], DataType, PythonFunctionKind, boolean, boolean, PythonEnv) - Constructor for class org.apache.flink.table.functions.python.PythonTableFunction
-
- 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
-
- 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
-
- ScalarFunctionDefinition(String, ScalarFunction) - Constructor for class org.apache.flink.table.functions.ScalarFunctionDefinition
-
Deprecated.
- scale() - Method in class org.apache.flink.table.data.DecimalData
-
- ScanTableSource - Interface in org.apache.flink.table.connector.source
-
- ScanTableSource.ScanContext - Interface in org.apache.flink.table.connector.source
-
- ScanTableSource.ScanRuntimeProvider - Interface in org.apache.flink.table.connector.source
-
Provides actual runtime implementation for reading the data.
- Schema - Class in org.apache.flink.table.api
-
Schema of a table or view.
- schema(Schema) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
-
- schema(Schema) - Method in class org.apache.flink.table.catalog.CatalogTable.Builder
-
- Schema - Class in org.apache.flink.table.descriptors
-
- Schema() - Constructor for class org.apache.flink.table.descriptors.Schema
-
Deprecated.
- SCHEMA - Static variable in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
- schema(TableSchema) - Method in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
Sets the schema with field names and the types.
- Schema.Builder - Class in org.apache.flink.table.api
-
A builder for constructing an immutable but still unresolved
Schema
.
- Schema.UnresolvedColumn - Class in org.apache.flink.table.api
-
Super class for all kinds of columns in an unresolved schema.
- Schema.UnresolvedComputedColumn - Class in org.apache.flink.table.api
-
Declaration of a computed column that will be resolved to
Column.ComputedColumn
during
schema resolution.
- Schema.UnresolvedConstraint - Class in org.apache.flink.table.api
-
Super class for all kinds of constraints in an unresolved schema.
- Schema.UnresolvedMetadataColumn - Class in org.apache.flink.table.api
-
Declaration of a metadata column that will be resolved to
Column.MetadataColumn
during
schema resolution.
- Schema.UnresolvedPhysicalColumn - Class in org.apache.flink.table.api
-
Declaration of a physical column that will be resolved to
Column.PhysicalColumn
during
schema resolution.
- Schema.UnresolvedPrimaryKey - Class in org.apache.flink.table.api
-
Declaration of a primary key that will be resolved to
UniqueConstraint
during schema
resolution.
- Schema.UnresolvedWatermarkSpec - Class in org.apache.flink.table.api
-
Declaration of a watermark strategy that will be resolved to
WatermarkSpec
during
schema resolution.
- SCHEMA_DATA_TYPE - Static variable in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
- SCHEMA_FROM - Static variable in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
- SCHEMA_NAME - Static variable in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
- SCHEMA_PROCTIME - Static variable in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
- SCHEMA_TYPE - Static variable in class org.apache.flink.table.descriptors.Schema
-
- SchemaResolver - Interface in org.apache.flink.table.catalog
-
- searchPartSpecAndPaths(FileSystem, Path, int) - Static method in class org.apache.flink.table.utils.PartitionPathUtils
-
Search all partitions in this path.
- SECOND() - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in seconds with 6 digits for fractional seconds by default.
- SECOND(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Resolution in seconds and (possibly) fractional seconds.
- segments - Variable in class org.apache.flink.table.data.binary.BinarySection
-
- separator - Variable in enum org.apache.flink.table.utils.DateTimeUtils.TimeUnit
-
- sequence(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a function signature like
f(STRING, NUMERIC)
using a sequence of
ArgumentTypeStrategy
s.
- sequence(String[], ArgumentTypeStrategy[]) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a named function signature like
f(s STRING, n NUMERIC)
using a sequence
of
ArgumentTypeStrategy
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
of
ArgumentTypeStrategy
s.
- SequenceInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
Strategy for inferring and validating a function signature like
f(STRING, NUMERIC)
or
f(s STRING, n NUMERIC)
using a sequence of
ArgumentTypeStrategy
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
-
- serialize(ListView<T>, DataOutputView) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
- serialize(MapView<K, V>, DataOutputView) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
- serialize(Map<K, V>, DataOutputView) - Method in class org.apache.flink.table.dataview.NullAwareMapSerializer
-
Deprecated.
- serialize(Object, DataOutputView) - Method in class org.apache.flink.table.dataview.NullSerializer
-
- serialize(ContinuousRefreshHandler) - Method in class org.apache.flink.table.refresh.ContinuousRefreshHandlerSerializer
-
- serialize(T) - Method in interface org.apache.flink.table.refresh.RefreshHandlerSerializer
-
- serializeCatalogMaterializedTable(ResolvedCatalogMaterializedTable) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
- serializeCatalogTable(ResolvedCatalogTable) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
- serializeCatalogView(ResolvedCatalogView) - Static method in class org.apache.flink.table.catalog.CatalogPropertiesUtil
-
- serializedRefreshHandler(byte[]) - Method in class org.apache.flink.table.catalog.CatalogMaterializedTable.Builder
-
- 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(MemorySegment[], int, boolean) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set boolean from segments.
- setBoolean(int, boolean) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- setBoolean(int, boolean) - Method in interface org.apache.flink.table.data.binary.TypedSetters
-
- 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.
- setByte(int, byte) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- setByte(int, byte) - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- setByte(MemorySegment[], int, byte) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set byte from segments.
- setByte(int, byte) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- setByte(int, byte) - Method in interface org.apache.flink.table.data.binary.TypedSetters
-
- 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.
- 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.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(MemorySegment[], int, double) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set double from segments.
- setDouble(int, double) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- setDouble(int, double) - Method in interface org.apache.flink.table.data.binary.TypedSetters
-
- 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.
- 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.
- setFinal(boolean) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
-
- setFloat(int, float) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- setFloat(int, float) - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- setFloat(MemorySegment[], int, float) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set float from segments.
- setFloat(int, float) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- setFloat(int, float) - Method in interface org.apache.flink.table.data.binary.TypedSetters
-
- 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.
- 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(MemorySegment[], int, int) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set int from segments.
- setInt(int, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- setInt(int, int) - Method in interface org.apache.flink.table.data.binary.TypedSetters
-
- 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.
- setInts(int, int, int) - Method in class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector
-
- setInts(int, 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 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
.
- setLockFactory(CatalogLock.Factory) - Method in interface org.apache.flink.table.connector.RequireCatalogLock
-
Deprecated.
Set catalog lock factory to the connector.
- setLong(int, long) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- setLong(int, long) - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- setLong(MemorySegment[], int, long) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set long from segments.
- setLong(int, long) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- setLong(int, long) - Method in interface org.apache.flink.table.data.binary.TypedSetters
-
- 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.
- 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.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(MemorySegment[], int, short) - Static method in class org.apache.flink.table.data.binary.BinarySegmentUtils
-
set short from segments.
- setShort(int, short) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- setShort(int, short) - Method in interface org.apache.flink.table.data.binary.TypedSetters
-
- 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.
- 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.sinks.PartitionableTableSink
-
Deprecated.
Sets the static partition into the
TableSink
.
- setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.binary.BinaryRowData
-
- setTimestamp(int, TimestampData, int) - Method in class org.apache.flink.table.data.binary.NestedRowData
-
- setTimestamp(int, TimestampData, int) - Method in interface org.apache.flink.table.data.binary.TypedSetters
-
Set Timestamp value.
- 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
-
- 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
-
- 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.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
-
- SinkProvider - Interface in org.apache.flink.table.connector.sink
-
- 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
-
- 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() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a 2-byte signed integer with values from -32,768 to 32,767.
- SmallIntType - Class in org.apache.flink.table.types.logical
-
Logical type of a 2-byte signed integer with values from -32,768 to 32,767.
- SmallIntType(boolean) - Constructor for class org.apache.flink.table.types.logical.SmallIntType
-
- SmallIntType() - Constructor for class org.apache.flink.table.types.logical.SmallIntType
-
- 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 for
ScanTableSource
.
- specialize(SpecializedFunction.SpecializedContext) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition
-
- specialize(SpecializedFunction.SpecializedContext) - Method in interface org.apache.flink.table.functions.SpecializedFunction
-
Provides a runtime implementation that is specialized for the given call and session.
- SpecializedFunction - Interface in org.apache.flink.table.functions
-
A
FunctionDefinition
that can provide a runtime implementation (i.e. 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
-
- 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
-
- 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.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.api.Types
-
Deprecated.
Returns type information for a Table API SQL time or SQL TIME type.
- SQL_TIMESTAMP() - Static method in class org.apache.flink.table.api.Types
-
Deprecated.
Returns type information for a Table API SQL timestamp or SQL TIMESTAMP type.
- SqlCallExpression - Class in org.apache.flink.table.expressions
-
A call to a SQL expression.
- SqlCallExpression(String) - Constructor for class org.apache.flink.table.expressions.SqlCallExpression
-
- SqlCallSyntax - Interface in org.apache.flink.table.functions
-
- 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.
- 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
-
- 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
-
- STRING() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a variable-length character string with defined maximum length.
- STRING() - Static method in class org.apache.flink.table.api.Types
-
Deprecated.
Returns type information for a Table API string or SQL VARCHAR type.
- STRING_CONCAT - Static variable in class org.apache.flink.table.types.inference.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
-
- 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.
- StructuredAttribute(String, LogicalType, String) - Constructor for class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- StructuredAttribute(String, LogicalType) - Constructor for class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute
-
- StructuredType - Class in org.apache.flink.table.types.logical
-
Logical type of a user-defined object structured type.
- StructuredType.Builder - Class in org.apache.flink.table.types.logical
-
- StructuredType.StructuredAttribute - Class in org.apache.flink.table.types.logical
-
- 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
-
- SubsequenceInputTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
An
InputTypeStrategy
that lets you apply other strategies for subsequences of the actual
arguments.
- SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder - Class in org.apache.flink.table.types.inference.strategies
-
- SubsequenceStrategyBuilder() - Constructor for class org.apache.flink.table.types.inference.strategies.SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder
-
- 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 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- SUM0 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- superType(StructuredType) - Method in class org.apache.flink.table.types.logical.StructuredType.Builder
-
- supportedProperties() - Method in interface org.apache.flink.table.factories.CatalogFactory
-
- supportedProperties() - Method in interface org.apache.flink.table.factories.ModuleFactory
-
- supportedProperties() - Method in interface org.apache.flink.table.factories.TableFactory
-
Deprecated.
List of property keys that this factory can handle.
- SupportsAggregatePushDown - Interface in org.apache.flink.table.connector.source.abilities
-
- supportsAvoidingCast(LogicalType, LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
-
Returns whether the source type can be safely interpreted as the target type.
- supportsAvoidingCast(List<LogicalType>, List<LogicalType>) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
-
- SupportsBucketing - Interface in org.apache.flink.table.connector.sink.abilities
-
- 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 to
DynamicTableSink
.
- 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
-
- SupportsFilterPushDown.Result - Class in org.apache.flink.table.connector.source.abilities
-
Result of a filter push down.
- supportsImplicitCast(LogicalType, LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeCasts
-
Returns whether the source type can be safely casted to the target type without loosing
information.
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ArrayType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BigIntType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BinaryType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BooleanType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.CharType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DateType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DecimalType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DistinctType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DoubleType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.FloatType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.IntType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns whether an instance of the given class can be represented as a value of this logical
type when entering the table ecosystem.
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MapType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MultisetType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.NullType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RawType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RowType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SmallIntType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.StructuredType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SymbolType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimestampType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimeType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TinyIntType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
-
Deprecated.
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarBinaryType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarCharType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
-
- supportsInputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
-
- SupportsLimitPushDown - Interface in org.apache.flink.table.connector.source.abilities
-
Enables to push down a limit (the expected maximum number of produced records) into a
ScanTableSource
.
- supportsManagedTable() - Method in interface org.apache.flink.table.catalog.Catalog
-
- 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.types.logical.ArrayType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BigIntType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BinaryType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.BooleanType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.CharType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DateType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DayTimeIntervalType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DecimalType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DistinctType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.DoubleType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.FloatType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.IntType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LegacyTypeInformationType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LocalZonedTimestampType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.LogicalType
-
Returns whether a value of this logical type can be represented as an instance of the given
class when leaving the table ecosystem.
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MapType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.MultisetType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.NullType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RawType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.RowType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SmallIntType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.StructuredType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.SymbolType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimestampType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TimeType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TinyIntType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.TypeInformationRawType
-
Deprecated.
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.UnresolvedUserDefinedType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarBinaryType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.VarCharType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.YearMonthIntervalType
-
- supportsOutputConversion(Class<?>) - Method in class org.apache.flink.table.types.logical.ZonedTimestampType
-
- SupportsOverwrite - Interface in org.apache.flink.table.connector.sink.abilities
-
- SupportsPartitioning - Interface in org.apache.flink.table.connector.sink.abilities
-
- 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
-
- 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
-
- 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
-
- SupportsTruncate - Interface in org.apache.flink.table.connector.sink.abilities
-
Enables to delete all existing data in a
DynamicTableSink
table using
TRUNCATE
TABLE
statement.
- SupportsWatermarkPushDown - Interface in org.apache.flink.table.connector.source.abilities
-
- SupportsWritingMetadata - Interface in org.apache.flink.table.connector.sink.abilities
-
- SuspendRefreshWorkflow<T extends RefreshHandler> - Class in org.apache.flink.table.workflow
-
- 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.
- 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(boolean, Class<T>) - Constructor for class org.apache.flink.table.types.logical.SymbolType
-
- SymbolType(Class<T>) - Constructor for class org.apache.flink.table.types.logical.SymbolType
-
- SymbolType(boolean) - Constructor for class org.apache.flink.table.types.logical.SymbolType
-
- SymbolType() - Constructor for class org.apache.flink.table.types.logical.SymbolType
-
- 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_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
-
- 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, int, boolean, boolean) - Static method in interface org.apache.flink.table.utils.print.PrintStyle
-
- tableauWithDataInferredColumnWidths(ResolvedSchema, RowDataToStringConverter) - Static method in interface org.apache.flink.table.utils.print.PrintStyle
-
- 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.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.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.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.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.api
-
- TableColumn.ComputedColumn - Class in org.apache.flink.table.api
-
Deprecated.
Representation of a computed column.
- TableColumn.MetadataColumn - Class in org.apache.flink.table.api
-
Deprecated.
Representation of a metadata column.
- TableColumn.PhysicalColumn - Class in org.apache.flink.table.api
-
Deprecated.
Representation of a physical column.
- 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, Throwable) - Constructor for exception org.apache.flink.table.api.TableException
-
- TableException(String) - Constructor for exception org.apache.flink.table.api.TableException
-
- tableExists(ObjectPath) - Method in interface org.apache.flink.table.catalog.Catalog
-
Check if a table or view exists in this catalog.
- TableFactory - Interface in org.apache.flink.table.factories
-
- 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
-
- TableFunctionDefinition(String, TableFunction<?>, TypeInformation<?>) - Constructor for class org.apache.flink.table.functions.TableFunctionDefinition
-
Deprecated.
- TableFunctionProvider<T> - Interface in org.apache.flink.table.connector.source
-
- TableNotExistException - Exception in org.apache.flink.table.api
-
Exception for an operation on a nonexistent table.
- TableNotExistException(String, String) - Constructor for exception org.apache.flink.table.api.TableNotExistException
-
- TableNotExistException(String, String, Throwable) - Constructor for exception org.apache.flink.table.api.TableNotExistException
-
- TableNotExistException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to operate on a table (or view) that doesn't exist.
- TableNotExistException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotExistException
-
- TableNotExistException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotExistException
-
- TableNotPartitionedException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to operate partition on a non-partitioned table.
- TableNotPartitionedException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotPartitionedException
-
- TableNotPartitionedException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TableNotPartitionedException
-
- TablePartitionedException - Exception in org.apache.flink.table.catalog.exceptions
-
Exception for trying to operate non-partitioned on a partitioned table.
- TablePartitionedException(String, ObjectPath) - Constructor for exception org.apache.flink.table.catalog.exceptions.TablePartitionedException
-
- TablePartitionedException(String, ObjectPath, Throwable) - Constructor for exception org.apache.flink.table.catalog.exceptions.TablePartitionedException
-
- TableRuntimeException - Exception in org.apache.flink.table.api
-
Exception for errors occurring in the runtime.
- TableRuntimeException(String, Throwable) - Constructor for exception org.apache.flink.table.api.TableRuntimeException
-
- TableRuntimeException(String) - Constructor for exception org.apache.flink.table.api.TableRuntimeException
-
- TableSchema - Class in org.apache.flink.table.api
-
- TableSchema(String[], TypeInformation<?>[]) - Constructor for class org.apache.flink.table.api.TableSchema
-
- TableSchema.Builder - Class in org.apache.flink.table.api
-
Deprecated.
- TableSchemaUtils - Class in org.apache.flink.table.utils
-
- TableSchemaUtils() - Constructor for class org.apache.flink.table.utils.TableSchemaUtils
-
- TableSink<T> - Interface in org.apache.flink.table.sinks
-
- TableSinkBase<T> - Class in org.apache.flink.table.sinks
-
- TableSinkBase() - Constructor for class org.apache.flink.table.sinks.TableSinkBase
-
Deprecated.
- TableSinkFactory<T> - Interface in org.apache.flink.table.factories
-
- TableSinkFactory.Context - Interface in org.apache.flink.table.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.sources
-
- TableSourceFactory<T> - Interface in org.apache.flink.table.factories
-
- TableSourceFactory.Context - Interface in org.apache.flink.table.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
-
- 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 a
Catalog
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(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a time WITHOUT time zone TIME(p)
where p
is the number of digits
of fractional seconds (=precision).
- TIME() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a time WITHOUT time zone TIME
with no fractional seconds by default.
- TIME_ATTRIBUTES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- 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(OffsetTime, int) - Constructor for class org.apache.flink.table.connector.source.lookup.cache.trigger.TimedCacheReloadTrigger
-
- TimedCacheReloadTrigger(LocalTime, int) - Constructor for class org.apache.flink.table.connector.source.lookup.cache.trigger.TimedCacheReloadTrigger
-
- TimeIndicatorTypeInfo - Class in org.apache.flink.table.typeutils
-
- TimeIndicatorTypeInfo(boolean) - Constructor for class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
-
Deprecated.
- TimeIntervalTypeInfo<T> - Class in org.apache.flink.table.typeutils
-
- TimeIntervalUnit - Enum in org.apache.flink.table.expressions
-
Units for working with time intervals.
- TimePointUnit - Enum in org.apache.flink.table.expressions
-
Units for working with points in time.
- TIMES - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TIMESTAMP(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITHOUT time zone TIMESTAMP(p)
where p
is the number
of digits of fractional seconds (=precision).
- TIMESTAMP() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITHOUT time zone TIMESTAMP
with 6 digits of fractional
seconds by default.
- TIMESTAMP_DIFF - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TIMESTAMP_LTZ(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH LOCAL time zone.
- TIMESTAMP_LTZ() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH LOCAL time zone.
- TIMESTAMP_WITH_LOCAL_TIME_ZONE(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH LOCAL time zone TIMESTAMP(p) WITH LOCAL TIME ZONE
where
p
is the number of digits of fractional seconds (=precision).
- TIMESTAMP_WITH_LOCAL_TIME_ZONE() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH LOCAL time zone TIMESTAMP WITH LOCAL TIME ZONE
with 6
digits of fractional seconds by default.
- TIMESTAMP_WITH_TIME_ZONE(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH time zone TIMESTAMP(p) WITH TIME ZONE
where p
is the number of digits of fractional seconds (=precision).
- TIMESTAMP_WITH_TIME_ZONE() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a timestamp WITH time zone TIMESTAMP WITH TIME ZONE
with 6 digits of
fractional seconds by default.
- 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
-
- TimestampExtractor - Class in org.apache.flink.table.sources.tsextractors
-
- TimestampExtractor() - Constructor for class org.apache.flink.table.sources.tsextractors.TimestampExtractor
-
Deprecated.
- TimestampExtractorUtils - Class in org.apache.flink.table.sources.tsextractors
-
- 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.descriptors.Rowtime
-
Deprecated.
Sets a custom timestamp extractor to be used for the rowtime attribute.
- timestampsFromField(String) - Method in class org.apache.flink.table.descriptors.Rowtime
-
Deprecated.
Sets a built-in timestamp extractor that converts an existing
Long
or
Types.SQL_TIMESTAMP
field into the rowtime attribute.
- timestampsFromSource() - Method in class org.apache.flink.table.descriptors.Rowtime
-
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 from 0000-01-01 00:00:00.000000000
to 9999-12-31 23:59:59.999999999
.
- TimestampType(boolean, TimestampKind, int) - Constructor for class org.apache.flink.table.types.logical.TimestampType
-
Internal constructor that allows attaching additional metadata about time attribute
properties.
- TimestampType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.TimestampType
-
- TimestampType(int) - Constructor for class org.apache.flink.table.types.logical.TimestampType
-
- TimestampType() - Constructor for class org.apache.flink.table.types.logical.TimestampType
-
- 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
-
Returns a type transformation that transforms data type to a new data type whose conversion
class is
Timestamp
/
Time
/
Date
if the
original data type is TIMESTAMP/TIME/DATE.
- 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 from 00:00:00.000000000
to 23:59:59.999999999
.
- TimeType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.TimeType
-
- TimeType(int) - Constructor for class org.apache.flink.table.types.logical.TimeType
-
- TimeType() - Constructor for class org.apache.flink.table.types.logical.TimeType
-
- TINYINT() - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a 1-byte signed integer with values from -128 to 127.
- TinyIntType - Class in org.apache.flink.table.types.logical
-
Logical type of a 1-byte signed integer with values from -128 to 127.
- TinyIntType(boolean) - Constructor for class org.apache.flink.table.types.logical.TinyIntType
-
- TinyIntType() - Constructor for class org.apache.flink.table.types.logical.TinyIntType
-
- to(int) - Static method in class org.apache.flink.table.types.inference.ConstantArgumentCount
-
- TO_BASE64 - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- TO_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
-
- 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(TypeSerializer<T>) - Method in class org.apache.flink.table.data.binary.BinaryRawValueData
-
- toBytes() - Method in class org.apache.flink.table.data.binary.BinaryStringData
-
- toBytes(TypeSerializer<T>) - Method in interface org.apache.flink.table.data.RawValueData
-
- toBytes() - Method in interface org.apache.flink.table.data.StringData
-
Converts this
StringData
object to a UTF-8 byte array.
- toDataType(DataTypeFactory) - Method in class org.apache.flink.table.types.UnresolvedDataType
-
Converts this instance to a resolved
DataType
possibly enriched with additional
nullability and conversion class information.
- toDataType(TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.LegacyTypeInfoDataTypeConverter
-
Deprecated.
- toDataType(LogicalType) - Static method in class org.apache.flink.table.types.utils.LogicalTypeDataTypeConverter
-
Returns the data type of a logical type without explicit conversions.
- toDataType(DataTypeFactory, TypeInformation<?>) - Static method in class org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
-
Converts the given
TypeInformation
into
DataType
.
- toDataType(DataTypeFactory, TypeInformation<?>, boolean) - Static method in class org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
-
Converts the given
TypeInformation
into
DataType
but allows to make all
fields nullable independent of the nullability in the serialization stack.
- toDoubleArray() - Method in interface org.apache.flink.table.data.ArrayData
-
- toDoubleArray() - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- toDoubleArray() - Method in class org.apache.flink.table.data.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
-
- 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(Object) - Method in interface org.apache.flink.table.connector.source.DynamicTableSource.DataStructureConverter
-
Converts the given object into an internal data structure.
- 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(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(LogicalType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
- toInternalDataType(DataType) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
- 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
-
- 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
-
- toObjectArray(LogicalType) - Method in class org.apache.flink.table.data.binary.BinaryArrayData
-
- toObjectArray() - Method in class org.apache.flink.table.data.GenericArrayData
-
- toObjectPath() - Method in class org.apache.flink.table.catalog.ObjectIdentifier
-
- toPersistedRowDataType() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Converts all persisted columns of this schema into a (possibly nested) row data type.
- toPhysicalRowDataType() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Converts all physical columns of this schema into a (possibly nested) row data type.
- toPhysicalRowDataType() - Method in class org.apache.flink.table.catalog.ResolvedSchema
-
Converts all physical columns of this schema into a (possibly nested) row data type.
- toProperties() - Method in interface org.apache.flink.table.catalog.CatalogTable
-
- toProperties() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
-
- 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.descriptors.Descriptor
-
Deprecated.
Converts this descriptor into a set of properties.
- toProperties() - Method in class org.apache.flink.table.descriptors.Rowtime
-
Deprecated.
Converts this descriptor into a set of properties.
- toProperties() - Method in class org.apache.flink.table.descriptors.Schema
-
Deprecated.
Converts this descriptor into a set of properties.
- toProperties() - Method in class org.apache.flink.table.sources.tsextractors.TimestampExtractor
-
Deprecated.
This method is a default implementation that uses java serialization and it is discouraged.
- toProperties() - Method in class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks
-
- toProperties() - Method in class org.apache.flink.table.sources.wmstrategies.WatermarkStrategy
-
This method is a default implementation that uses java serialization and it is discouraged.
- toResolvedCatalogTable() - Method in class org.apache.flink.table.catalog.ResolvedCatalogMaterializedTable
-
- toRowDataType() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Converts all columns of this schema into a (possibly nested) row data type.
- toRowType() - Method in class org.apache.flink.table.api.TableSchema
-
- toRowType(LogicalType) - Static method in class org.apache.flink.table.types.logical.utils.LogicalTypeUtils
-
Converts any logical type to a row type.
- toSchema() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
Helps to migrate to the new
Schema
class.
- toSchema(Map<String, String>) - Method in class org.apache.flink.table.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
).
- toString() - Method in class org.apache.flink.table.api.DataTypes.AbstractField
-
- toString() - Method in class org.apache.flink.table.api.DataTypes.Resolution
-
- toString() - Method in class org.apache.flink.table.api.Schema
-
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedColumn
-
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedComputedColumn
-
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedConstraint
-
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedMetadataColumn
-
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedPhysicalColumn
-
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedPrimaryKey
-
- toString() - Method in class org.apache.flink.table.api.Schema.UnresolvedWatermarkSpec
-
- toString() - Method in class org.apache.flink.table.api.TableColumn
-
Deprecated.
- toString() - Method in class org.apache.flink.table.api.TableSchema
-
Deprecated.
- toString() - Method in class org.apache.flink.table.api.WatermarkSpec
-
Deprecated.
- toString() - Method in class org.apache.flink.table.catalog.CatalogPartitionSpec
-
- toString() - Method in class org.apache.flink.table.catalog.Column
-
- toString() - Method in class org.apache.flink.table.catalog.DefaultCatalogMaterializedTable
-
- toString() - Method in class org.apache.flink.table.catalog.DefaultCatalogTable
-
- 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.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
-
- 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(String) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- toString(String, String) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- toString(Map<String, String>) - Static method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- toString() - Method in class org.apache.flink.table.expressions.AggregateExpression
-
- toString() - Method in class org.apache.flink.table.expressions.CallExpression
-
- toString() - Method in class org.apache.flink.table.expressions.FieldReferenceExpression
-
- toString() - Method in class org.apache.flink.table.expressions.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.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.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
-
- toTimestamp() - Method in class org.apache.flink.table.data.TimestampData
-
- toTimestampData(long, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
- toTimestampData(double, 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(DataType) - Method in class org.apache.flink.table.types.inference.transforms.DataTypeConversionClassTransformation
-
- transform(DataType) - Method in class org.apache.flink.table.types.inference.transforms.LegacyRawTypeTransformation
-
- transform(DataType) - Method in class org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
-
- transform(DataTypeFactory, DataType) - Method in class org.apache.flink.table.types.inference.transforms.LegacyToNonLegacyTransformation
-
- transform(DataType) - Method in interface org.apache.flink.table.types.inference.TypeTransformation
-
Transforms the given data type to a different data type.
- transform(DataTypeFactory, DataType) - Method in interface org.apache.flink.table.types.inference.TypeTransformation
-
Transforms the given data type to a different data type.
- transform(DataType, TypeTransformation...) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Transforms the given data type to a different data type using the given transformations.
- transform(DataTypeFactory, DataType, TypeTransformation...) - Static method in class org.apache.flink.table.types.utils.DataTypeUtils
-
Transforms the given data type to a different data type using the given transformations.
- transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - Method in class org.apache.flink.table.dataview.ListViewSerializer
-
Deprecated.
We need to override this as a LegacySerializerSnapshotTransformer
because in Flink
1.6.x and below, this serializer was incorrectly returning directly the snapshot of the
nested list serializer as its own snapshot.
- transformLegacySerializerSnapshot(TypeSerializerSnapshot<U>) - Method in class org.apache.flink.table.dataview.MapViewSerializer
-
Deprecated.
We need to override this as a LegacySerializerSnapshotTransformer
because in Flink
1.6.x and below, this serializer was incorrectly returning directly the snapshot of the
nested map serializer as its own snapshot.
- 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.
- TRUNCATE - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- truncate(TimestampData, int) - Static method in class org.apache.flink.table.utils.DateTimeUtils
-
- 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 - 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(DataType...) - Method in class org.apache.flink.table.functions.BuiltInFunctionDefinition.Builder
-
- typedArguments(List<DataType>) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
Sets the list of argument types for specifying a fixed, not overloaded, not vararg input
signature explicitly.
- typedArguments(DataType...) - Method in class org.apache.flink.table.types.inference.TypeInference.Builder
-
- TypedSetters - Interface in org.apache.flink.table.data.binary
-
Provide type specialized setters to reduce if/else and eliminate box and unbox.
- TypeInference - Class in org.apache.flink.table.types.inference
-
Provides logic for the type inference of function calls.
- TypeInference.Builder - Class in org.apache.flink.table.types.inference
-
- TypeInferenceExtractor - Class in org.apache.flink.table.types.extraction
-
- 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
to
DataType
.
- TypeInfoDataTypeConverter() - Constructor for class org.apache.flink.table.types.utils.TypeInfoDataTypeConverter
-
- TypeInformationRawType<T> - Class in org.apache.flink.table.types.logical
-
- TypeInformationRawType(boolean, TypeInformation<T>) - Constructor for class org.apache.flink.table.types.logical.TypeInformationRawType
-
Deprecated.
- TypeInformationRawType(TypeInformation<T>) - Constructor for class org.apache.flink.table.types.logical.TypeInformationRawType
-
Deprecated.
- TypeInformationRawType() - Constructor for class org.apache.flink.table.types.logical.TypeInformationRawType
-
Deprecated.
- 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
-
- Types - Class in org.apache.flink.table.api
-
- TypeStrategies - Class in org.apache.flink.table.types.inference
-
Strategies for inferring an output or accumulator data type of a function call.
- TypeStrategy - Interface in org.apache.flink.table.types.inference
-
Strategy for inferring the data type of a function call.
- TypeStringUtils - Class in org.apache.flink.table.utils
-
- TypeStringUtils() - Constructor for class org.apache.flink.table.utils.TypeStringUtils
-
Deprecated.
- TypeTransformation - Interface in org.apache.flink.table.types.inference
-
Transforms one data type to another.
- TypeTransformations - Class in org.apache.flink.table.types.inference
-
Transformations for transforming one data type to another.
- 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.
- validate() - Method in class org.apache.flink.table.factories.FactoryUtil.FactoryHelper
-
Validates the options of the factory.
- 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.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
-
- validateClassForRuntime(Class<? extends UserDefinedFunction>, String, Class<?>[], Class<?>, String) - Static method in class org.apache.flink.table.functions.UserDefinedFunctionHelper
-
- 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.
- validateDuration(String, boolean, int, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- validateDuration(String, boolean, int, long, long) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- 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(Factory, ReadableConfig) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Validates the required and optional ConfigOption
s of a factory.
- validateFactoryOptions(Set<ConfigOption<?>>, Set<ConfigOption<?>>, ReadableConfig) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Validates the required options and optional options.
- validateFixedIndexedProperties(String, boolean, Map<String, Consumer<String>>) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Validation for fixed indexed properties.
- validateFloat(String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Validates a float property.
- validateFloat(String, boolean, float) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Validates a float property.
- validateFloat(String, boolean, float, float) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Validates a float property.
- 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>, Set<String>) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Validates unconsumed option keys.
- validateUnconsumedKeys(String, Set<String>, Set<String>) - Static method in class org.apache.flink.table.factories.FactoryUtil
-
Validates unconsumed option keys.
- validateValue(String, String, boolean) - Method in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
Validates that a certain value is present under the given key.
- 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, Throwable) - Constructor for exception org.apache.flink.table.api.ValidationException
-
- ValidationException(String) - Constructor for exception org.apache.flink.table.api.ValidationException
-
- 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.ExtractionVersion
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.annotation.HintFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.annotation.InputGroup
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.api.constraints.Constraint.ConstraintType
-
Deprecated.
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.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(BinaryArrayData, BinaryArrayData) - Static method in class org.apache.flink.table.data.binary.BinaryMapData
-
- valueOf(String) - Static method in enum org.apache.flink.table.expressions.TimeIntervalUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.expressions.TimePointUnit
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.FunctionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.FunctionRequirement
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.python.BuiltInPythonAggregateFunction
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.python.PythonEnv.ExecType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.python.PythonFunctionKind
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.functions.python.utils.PythonFunctionUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum org.apache.flink.table.resource.ResourceType
-
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.
- values() - Static method in enum org.apache.flink.table.annotation.ExtractionVersion
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.table.annotation.HintFlag
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.table.annotation.InputGroup
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum org.apache.flink.table.api.constraints.Constraint.ConstraintType
-
Deprecated.
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Method in class org.apache.flink.table.api.dataview.MapView
-
Returns all the values in the map view.
- values() - Static method in enum org.apache.flink.table.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.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.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.
- valueType - Variable in class org.apache.flink.table.api.dataview.MapView
-
Deprecated.
- VAR_POP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- VAR_SAMP - Static variable in class org.apache.flink.table.functions.BuiltInFunctionDefinitions
-
- VARBINARY(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a variable-length binary string (=a sequence of bytes) VARBINARY(n)
where n
is the maximum number of bytes.
- VarBinaryType - Class in org.apache.flink.table.types.logical
-
Logical type of a variable-length binary string (=a sequence of bytes).
- VarBinaryType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.VarBinaryType
-
- VarBinaryType(int) - Constructor for class org.apache.flink.table.types.logical.VarBinaryType
-
- VarBinaryType() - Constructor for class org.apache.flink.table.types.logical.VarBinaryType
-
- VARCHAR(int) - Static method in class org.apache.flink.table.api.DataTypes
-
Data type of a variable-length character string VARCHAR(n)
where n
is the
maximum number of code points.
- VarCharType - Class in org.apache.flink.table.types.logical
-
Logical type of a variable-length character string.
- VarCharType(boolean, int) - Constructor for class org.apache.flink.table.types.logical.VarCharType
-
- VarCharType(int) - Constructor for class org.apache.flink.table.types.logical.VarCharType
-
- VarCharType() - Constructor for class org.apache.flink.table.types.logical.VarCharType
-
- varyingSequence(ArgumentTypeStrategy...) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a varying function signature like
f(INT, STRING, NUMERIC...)
using a
sequence of
ArgumentTypeStrategy
s.
- varyingSequence(String[], ArgumentTypeStrategy[]) - Static method in class org.apache.flink.table.types.inference.InputTypeStrategies
-
Strategy for a varying named function signature like
f(i INT, str STRING, num
NUMERIC...)
using a sequence of
ArgumentTypeStrategy
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...)
or
f(i INT, str STRING, num NUMERIC...)
using a sequence of
ArgumentTypeStrategy
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
-
- VaryingStringTypeStrategy - Class in org.apache.flink.table.types.inference.strategies
-
- 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(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.
- VIRTUAL - Static variable in class org.apache.flink.table.descriptors.DescriptorProperties
-
Deprecated.
- visit(CallExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(ValueLiteralExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(FieldReferenceExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(TypeLiteralExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(Expression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(NestedFieldReferenceExpression) - Method in class org.apache.flink.table.expressions.ExpressionDefaultVisitor
-
- visit(CallExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(ValueLiteralExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(FieldReferenceExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(TypeLiteralExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(Expression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(NestedFieldReferenceExpression) - Method in interface org.apache.flink.table.expressions.ExpressionVisitor
-
- visit(AtomicDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
-
- visit(CollectionDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
-
- visit(FieldsDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
-
- visit(KeyValueDataType) - Method in interface org.apache.flink.table.types.DataTypeVisitor
-
- visit(CharType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(VarCharType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(BooleanType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(BinaryType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(VarBinaryType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(DecimalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(TinyIntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(SmallIntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(IntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(BigIntType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(FloatType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(DoubleType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(DateType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(TimeType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(TimestampType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(ZonedTimestampType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(LocalZonedTimestampType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(YearMonthIntervalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(DayTimeIntervalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(ArrayType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(MultisetType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(MapType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(RowType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(DistinctType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(StructuredType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(NullType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(RawType<?>) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(SymbolType<?>) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(LogicalType) - Method in interface org.apache.flink.table.types.logical.LogicalTypeVisitor
-
- visit(CharType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(VarCharType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(BooleanType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(BinaryType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(VarBinaryType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(DecimalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(TinyIntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(SmallIntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(IntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(BigIntType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(FloatType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(DoubleType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(DateType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(TimeType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(TimestampType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(ZonedTimestampType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(LocalZonedTimestampType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(YearMonthIntervalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(DayTimeIntervalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(ArrayType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(MultisetType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(MapType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(RowType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(DistinctType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(StructuredType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(NullType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(RawType<?>) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(SymbolType<?>) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(LogicalType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDefaultVisitor
-
- visit(ArrayType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(MultisetType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(MapType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(RowType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(DistinctType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(StructuredType) - Method in class org.apache.flink.table.types.logical.utils.LogicalTypeDuplicator
-
- visit(AtomicDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
-
- visit(CollectionDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
-
- visit(FieldsDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
-
- visit(KeyValueDataType) - Method in class org.apache.flink.table.types.utils.DataTypeDefaultVisitor
-