All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractCatalog |
Abstract class for catalogs.
|
AbstractCatalogStore |
The AbstractCatalogStore class is an abstract base class for implementing a catalog store.
|
AbstractDataType<T extends AbstractDataType<T>> |
Highest abstraction that describes the data type of a value in the table ecosystem.
|
AbstractHeapVector |
Heap vector that nullable shared structure.
|
AbstractWritableVector |
Contains the shared structure for ColumnVector s, including NULL information and
dictionary.
|
AdaptedCallContext |
Helper context that deals with adapted arguments.
|
AggregateExpression |
Resolved and validated expression for calling an aggregate function.
|
AggregateFunction<T,ACC> |
Base class for a user-defined aggregate function.
|
AggregateFunctionDefinition |
Deprecated.
|
AmbiguousTableFactoryException |
Deprecated.
|
AmbiguousTableFactoryException |
Exception for finding more than one TableFactory for the given properties.
|
AndArgumentTypeStrategy |
Strategy for inferring and validating an argument using a conjunction of multiple ArgumentTypeStrategy s into one like f(NUMERIC && LITERAL)
|
AnyArgumentTypeStrategy |
Strategy for an argument that can be of any type.
|
ArgumentCount |
Defines the count of accepted arguments (including open intervals) that a function can take.
|
ArgumentHint |
A hint that provides additional information about an argument.
|
ArgumentMappingTypeStrategy |
Type strategy that returns the n-th input argument, mapping it with the provided function.
|
ArgumentTrait |
|
ArgumentTypeStrategy |
Strategy for inferring and validating a single input argument type of a function call.
|
ArrayAppendPrependTypeStrategy |
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.
|
ArrayColumnVector |
Array column vector.
|
ArrayComparableElementArgumentTypeStrategy |
An ArgumentTypeStrategy that checks if the input argument is an ARRAY type and check
whether its' elements are comparable.
|
ArrayData |
Base interface of an internal data structure representing data of ArrayType .
|
ArrayData.ElementGetter |
Accessor for getting the elements of an array during runtime.
|
ArrayElementTypeStrategy |
|
ArrayOfStringArgumentTypeStrategy |
Strategy for an argument that must be an array of strings.
|
ArrayType |
Logical type of an array of elements with same subtype.
|
AsyncLookupFunction |
A wrapper class of AsyncTableFunction for asynchronously lookup rows matching the lookup
keys from external system.
|
AsyncLookupFunctionProvider |
|
AsyncScalarFunction |
Base class for a user-defined scalar function which returns results asynchronously.
|
AsyncTableFunction<T> |
Base class for a user-defined asynchronous table function.
|
AsyncTableFunctionProvider<T> |
Deprecated.
|
AtomicDataType |
A data type that does not contain further data types (e.g.
|
BigIntType |
Logical type of an 8-byte signed integer with values from -9,223,372,036,854,775,808 to
9,223,372,036,854,775,807.
|
BinaryArrayData |
A binary implementation of ArrayData which is backed by MemorySegment s.
|
BinaryFormat |
Binary format spanning MemorySegment s.
|
BinaryMapData |
[4 byte(keyArray size in bytes)] + [Key BinaryArray] + [Value BinaryArray].
|
BinaryRawValueData<T> |
A lazily binary implementation of RawValueData which is backed by MemorySegment s
and generic Object .
|
BinaryRowData |
An implementation of RowData which is backed by MemorySegment instead of Object.
|
BinarySection |
A basic implementation of BinaryFormat which describe a section of memory.
|
BinarySegmentUtils |
Utilities for binary data segments which heavily uses MemorySegment .
|
BinaryStringData |
A lazily binary implementation of StringData which is backed by MemorySegment s
and String .
|
BinaryType |
Logical type of a fixed-length binary string (=a sequence of bytes).
|
BooleanColumnVector |
Boolean column vector.
|
BooleanType |
Logical type of a boolean with a (possibly) three-valued logic of TRUE, FALSE, UNKNOWN .
|
BuiltInFunctionDefinition |
Definition of a built-in function.
|
BuiltInFunctionDefinition.Builder |
Builder for fluent definition of built-in functions.
|
BuiltInFunctionDefinitions |
Dictionary of function definitions for all built-in functions.
|
BuiltInPythonAggregateFunction |
The list of the built-in aggregate functions which can be mixed with the Python UDAF.
|
ByteColumnVector |
Byte column vector.
|
BytesColumnVector |
|
BytesColumnVector.Bytes |
Bytes data.
|
CacheReloadTrigger |
Customized trigger for reloading lookup table entries.
|
CacheReloadTrigger.Context |
|
CallContext |
|
CallExpression |
Resolved and validated call expression for calling a function.
|
CastExecutor<IN,OUT> |
Interface to model a function that performs the casting of a value from one type to another.
|
Catalog |
This interface is responsible for reading and writing metadata such as database/table/views/UDFs
from a registered catalog.
|
CatalogBaseTable |
A common parent that describes the unresolved metadata of a table or view in a catalog.
|
CatalogBaseTable.TableKind |
|
CatalogChange |
|
CatalogChange.CatalogCommentChange |
A catalog change to modify the comment.
|
CatalogChange.CatalogConfigurationChange |
A catalog change to modify the catalog configuration.
|
CatalogColumnStatistics |
Column statistics of a table or partition.
|
CatalogColumnStatisticsDataBase |
Column statistics value base class.
|
CatalogColumnStatisticsDataBinary |
Column statistics value of binary type.
|
CatalogColumnStatisticsDataBoolean |
Column statistics value of boolean type.
|
CatalogColumnStatisticsDataDate |
Column statistics value of date type.
|
CatalogColumnStatisticsDataDouble |
Column statistics value of double type.
|
CatalogColumnStatisticsDataLong |
Column statistics value of long type.
|
CatalogColumnStatisticsDataString |
Column statistics value of string type.
|
CatalogDatabase |
Interface of a database in a catalog.
|
CatalogDescriptor |
Describes a Catalog with the catalog name and configuration.
|
CatalogException |
A catalog-related, runtime exception.
|
CatalogFactory |
A factory to create configured catalog instances based on string-based properties.
|
CatalogFactory.Context |
Context provided when a catalog is created.
|
CatalogFunction |
Interface for a function in a catalog.
|
CatalogMaterializedTable |
Represents the unresolved metadata of a materialized table in a Catalog .
|
CatalogMaterializedTable.Builder |
|
CatalogMaterializedTable.LogicalRefreshMode |
The logical refresh mode of materialized table.
|
CatalogMaterializedTable.RefreshMode |
The physical refresh mode of materialized table.
|
CatalogMaterializedTable.RefreshStatus |
Background refresh pipeline status of materialized table.
|
CatalogModel |
Interface for a model in a catalog.
|
CatalogNotExistException |
Exception for an operation on a nonexistent catalog.
|
CatalogPartition |
Represents a partition object in catalog.
|
CatalogPartitionSpec |
Represents a partition spec object in catalog.
|
CatalogPropertiesUtil |
Utilities for de/serializing Catalog objects into a map of string properties.
|
CatalogStore |
Represents the storage where persists all Catalog s.
|
CatalogStoreFactory |
A factory to create configured catalog store instances based on string-based properties.
|
CatalogStoreFactory.Context |
Context provided when a catalog store is created.
|
CatalogStoreHolder |
|
CatalogStoreHolder.Builder |
|
CatalogTable |
Represents the unresolved metadata of a table in a Catalog .
|
CatalogTable.Builder |
Builder for configuring and creating instances of CatalogTable .
|
CatalogTableStatistics |
Statistics for a non-partitioned table or a partition of a partitioned table.
|
CatalogView |
Represents the unresolved metadata of a view in a Catalog .
|
ChangelogMode |
The set of changes contained in a changelog.
|
ChangelogMode.Builder |
|
CharType |
Logical type of a fixed-length character string.
|
ClassDataTypeConverter |
Class-based data type extractor that supports extraction of clearly identifiable data types for
input and output conversion.
|
CollectionDataType |
A data type that contains an element type (e.g.
|
CollectTypeStrategy |
|
Column |
|
Column.ComputedColumn |
Representation of a computed column.
|
Column.MetadataColumn |
Representation of a metadata column.
|
Column.PhysicalColumn |
Representation of a physical column.
|
ColumnarArrayData |
Columnar array to support access to vector column data.
|
ColumnarMapData |
Columnar map to support access to vector column data.
|
ColumnarRowData |
Columnar row to support access to vector column data.
|
ColumnStats |
Column statistics.
|
ColumnStats.Builder |
ColumnStats builder.
|
ColumnVector |
Nullable column vector.
|
CommonArgumentTypeStrategy |
Argument type strategy that checks and casts for a common, least restrictive type of all
arguments.
|
CommonArrayInputTypeStrategy |
|
CommonCatalogOptions |
A collection of ConfigOption which are consistently used in multiple catalogs.
|
CommonCollectionInputTypeStrategy |
|
CommonInputTypeStrategy |
|
CommonMapInputTypeStrategy |
|
CommonModuleOptions |
A collection of ConfigOption which are consistently used in multiple modules.
|
CommonTypeStrategy |
Type strategy that returns a common, least restrictive type of selected arguments.
|
ComparableTypeStrategy |
An InputTypeStrategy that checks if all input arguments can be compared with each other
with the minimal provided comparison.
|
CompositeArgumentTypeStrategy |
Strategy that checks that the argument has a composite type.
|
ConnectorDescriptorValidator |
Deprecated. |
ConstantArgumentCount |
|
Constraint |
Integrity constraints, generally referred to simply as constraints, define the valid states of
SQL-data by constraining the values in the base tables.
|
Constraint |
Deprecated.
|
Constraint.ConstraintType |
Type of the constraint.
|
Constraint.ConstraintType |
Type of the constraint.
|
ConstraintArgumentTypeStrategy |
Strategy for an argument that must fulfill a given constraint.
|
ContinuousRefreshHandler |
Embedded continuous refresh handler of Flink streaming job for materialized table.
|
ContinuousRefreshHandlerSerializer |
|
CoreModule |
Module of default core metadata in Flink.
|
CoreModuleFactory |
|
CreatePeriodicRefreshWorkflow |
|
CreateRefreshWorkflow |
|
DatabaseAlreadyExistException |
Exception for trying to create a database that already exists.
|
DatabaseNotEmptyException |
Exception for trying to drop on a database that is not empty.
|
DatabaseNotExistException |
Exception for trying to operate on a database that doesn't exist.
|
DataType |
Describes the data type of a value in the table ecosystem.
|
DataTypeConversionClassTransformation |
This type transformation transforms the specified data types to a new one with the expected
conversion class.
|
DataTypeDefaultVisitor<R> |
|
DataTypeExtractor |
Reflection-based utility that analyzes a given Type , method, or class
to extract a (possibly nested) DataType from it.
|
DataTypeFactory |
Factory for creating fully resolved data types that can be used for planning.
|
DataTypeHint |
A hint that influences the reflection-based extraction of a DataType .
|
DataTypeQueryable |
Indicates that a DataType can be retrieved from a class that implements this interfaces.
|
DataTypes |
A DataType can be used to declare input and/or output types of operations.
|
DataTypes.AbstractField |
Common helper class for resolved and unresolved fields of a row or structured type.
|
DataTypes.Field |
Helper class for defining the field of a row or structured type.
|
DataTypes.Resolution |
Helper class for defining the resolution of an interval.
|
DataTypes.UnresolvedField |
Helper class for defining the unresolved field of a row or structured type.
|
DataTypeUtils |
|
DataTypeVisitor<R> |
|
DataView |
|
Date |
Class representing a date value in statistics.
|
DateTimeUtils |
Utility functions for datetime types: date, time, timestamp.
|
DateTimeUtils.TimeUnit |
Enumeration of time units used to construct an interval.
|
DateTimeUtils.TimeUnitRange |
A range of time units.
|
DateType |
Logical type of a date consisting of year-month-day with values ranging from
0000-01-01 to 9999-12-31 .
|
DayTimeIntervalType |
Logical type for a group of day-time interval types.
|
DayTimeIntervalType.DayTimeResolution |
Supported resolutions of this type.
|
DecimalColumnVector |
Decimal column vector.
|
DecimalData |
An internal data structure representing data of DecimalType .
|
DecimalType |
Logical type of a decimal number with fixed precision and scale.
|
DecodingFormat<I> |
|
DecodingFormatFactory<I> |
|
DefaultCatalogMaterializedTable |
|
DefaultCatalogModel |
A catalog model implementation.
|
DefaultCatalogTable |
|
DefaultLookupCache |
|
DefaultLookupCache.Builder |
|
DefaultResolvedCatalogModel |
A validated CatalogModel that is backed by the original metadata coming from the Catalog but resolved by the framework.
|
DefinedFieldMapping |
Deprecated.
|
DefinedProctimeAttribute |
Deprecated.
|
DefinedRowtimeAttributes |
Deprecated.
|
DeleteRefreshWorkflow<T extends RefreshHandler> |
|
Descriptor |
Deprecated.
|
DescriptorProperties |
Deprecated.
|
DescriptorValidator |
Deprecated.
|
DeserializationFormatFactory |
|
Dictionary |
The interface for dictionary in AbstractColumnVector to decode dictionary encoded values.
|
DistinctType |
Logical type of a user-defined distinct type.
|
DistinctType.Builder |
|
DoubleColumnVector |
Double column vector.
|
DoubleType |
Logical type of an 8-byte double precision floating point number.
|
DynamicFilteringData |
Data for dynamic filtering.
|
DynamicFilteringEvent |
|
DynamicTableFactory |
Base interface for configuring a dynamic table connector for an external storage system from
catalog and session information.
|
DynamicTableFactory.Context |
Provides catalog and session information describing the dynamic table to be accessed.
|
DynamicTableSink |
Sink of a dynamic table to an external storage system.
|
DynamicTableSink.Context |
|
DynamicTableSink.DataStructureConverter |
Converter for mapping between Flink's internal data structures and objects specified by the
given DataType that can be passed into a runtime implementation.
|
DynamicTableSink.SinkRuntimeProvider |
Provides actual runtime implementation for writing the data.
|
DynamicTableSinkFactory |
|
DynamicTableSource |
Source of a dynamic table from an external storage system.
|
DynamicTableSource.Context |
|
DynamicTableSource.DataStructureConverter |
Converter for mapping between objects and Flink's internal data structures during runtime.
|
DynamicTableSourceFactory |
|
EncodingFormat<I> |
|
EncodingFormatFactory<I> |
|
EncodingUtils |
General utilities for string-encoding.
|
ExplicitArgumentTypeStrategy |
Strategy for an argument that corresponds to an explicitly defined type.
|
ExplicitTypeStrategy |
Type strategy that returns a fixed DataType .
|
Expression |
General interface for all kinds of expressions.
|
ExpressionDefaultVisitor<T> |
|
ExpressionParserException |
Deprecated.
|
ExpressionParserException |
Exception for all errors occurring during expression parsing.
|
ExpressionUtils |
|
ExpressionVisitor<R> |
|
ExtractionUtils |
Utilities for performing reflection tasks.
|
ExtractionUtils.AssigningConstructor |
|
ExtractionUtils.Autoboxing |
Checks the relation between primitive and boxed types.
|
ExtractionVersion |
Logical version that describes the expected behavior of the reflection-based data type
extraction.
|
Factory |
Base interface for all kind of factories that create object instances from a list of key-value
pairs in Flink's Table & SQL API.
|
FactoryUtil |
|
FactoryUtil.CatalogFactoryHelper |
|
FactoryUtil.CatalogStoreFactoryHelper |
|
FactoryUtil.DefaultCatalogContext |
|
FactoryUtil.DefaultCatalogStoreContext |
|
FactoryUtil.DefaultDynamicTableContext |
|
FactoryUtil.DefaultModuleContext |
|
FactoryUtil.FactoryHelper<F extends Factory> |
Base helper utility for validating all options for a Factory .
|
FactoryUtil.ModuleFactoryHelper |
|
FactoryUtil.TableFactoryHelper |
|
FamilyArgumentTypeStrategy |
Strategy for an argument that corresponds to a given LogicalTypeFamily and nullability.
|
FieldComputer<T> |
Deprecated.
|
FieldReferenceExpression |
A reference to a field in an input.
|
FieldsDataType |
A data type that contains field data types (i.e. row and structured type).
|
FileBasedStatisticsReportableInputFormat |
Extension of input format which is able to report estimated statistics for file based connector.
|
FileSystemValidator |
Deprecated.
|
FilterableTableSource<T> |
Deprecated.
|
FirstTypeStrategy |
Type strategy that returns the first type that could be inferred.
|
FloatColumnVector |
Float column vector.
|
FloatType |
Logical type of a 4-byte single precision floating point number.
|
ForceNullableTypeStrategy |
Forces a given type strategy to be nullable.
|
Format |
Base interface for connector formats.
|
FormatFactory |
|
FullCachingLookupProvider |
A LookupFunctionProvider that never lookup in external system on cache miss and provides
a cache for holding all entries in the external system.
|
FunctionAlreadyExistException |
Exception for trying to create a function that already exists.
|
FunctionContext |
A FunctionContext allows to obtain global runtime information about the context in which
the user-defined function is executed.
|
FunctionDefinition |
Definition of a function.
|
FunctionDefinitionFactory |
|
FunctionDefinitionFactory.Context |
Context provided when a function definition is created.
|
FunctionHint |
|
FunctionHints |
|
FunctionIdentifier |
Identifies a system function with function name or a catalog function with a fully qualified
identifier.
|
FunctionKind |
|
FunctionLanguage |
|
FunctionNotExistException |
Exception for trying to operate on a function that doesn't exist.
|
FunctionRequirement |
|
GenericArrayData |
An internal data structure representing data of ArrayType .
|
GenericMapData |
|
GenericRowData |
An internal data structure representing data of RowType and other (possibly nested)
structured types such as StructuredType .
|
HeapArrayVector |
This class represents a nullable heap array column vector.
|
HeapBooleanVector |
This class represents a nullable heap boolean column vector.
|
HeapBytesVector |
This class supports string and binary data by value reference -- i.e. each field is explicitly
present, as opposed to provided by a dictionary reference.
|
HeapByteVector |
This class represents a nullable byte column vector.
|
HeapDoubleVector |
This class represents a nullable double precision floating point column vector.
|
HeapFloatVector |
This class represents a nullable double precision floating point column vector.
|
HeapIntVector |
This class represents a nullable int column vector.
|
HeapLongVector |
This class represents a nullable long column vector.
|
HeapMapVector |
This class represents a nullable heap map column vector.
|
HeapRowVector |
This class represents a nullable heap row column vector.
|
HeapShortVector |
This class represents a nullable short column vector.
|
HeapTimestampVector |
This class represents a nullable byte column vector.
|
HintFlag |
Three-valued flag for representing TRUE , FALSE , and UNKNOWN .
|
HiveAggDecimalPlusTypeStrategy |
Type strategy that returns the result type of a decimal addition, used internally for
implementing native SUM/AVG aggregations on a Decimal type.
|
ImperativeAggregateFunction<T,ACC> |
|
IndexArgumentTypeStrategy |
|
InputFormatProvider |
Provider of an InputFormat instance as a runtime implementation for ScanTableSource .
|
InputGroup |
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 |
Strategies for inferring and validating input arguments in a function call.
|
InputTypeStrategy |
Strategy for inferring and validating input arguments in a function call.
|
IntColumnVector |
Int column vector.
|
IntervalFreshness |
|
IntervalFreshness.TimeUnit |
An enumeration of time unit representing the unit of interval freshness.
|
IntervalFreshnessUtils |
|
IntType |
Logical type of a 4-byte signed integer with values from -2,147,483,648 to 2,147,483,647.
|
ItemAtIndexArgumentTypeStrategy |
|
ItemAtTypeStrategy |
|
JoinedRowData |
An implementation of RowData which is backed by two concatenated RowData .
|
JsonExistsOnError |
|
JsonOnNull |
|
JsonQueryOnEmptyOrError |
|
JsonQueryOnErrorEmptyArgumentTypeStrategy |
|
JsonQueryWrapper |
|
JsonType |
|
JsonValueOnEmptyOrError |
|
KeyValueDataType |
A data type that contains a key and value data type (e.g.
|
LazyBinaryFormat<T> |
An abstract implementation fo BinaryFormat which is lazily serialized into binary or
lazily deserialized into Java object.
|
LeadLagInputTypeStrategy |
|
LegacyRawTypeTransformation |
This type transformation transforms the LEGACY('RAW', ...) type to the RAW(..., ?)
|
LegacyToNonLegacyTransformation |
|
LegacyTypeInfoDataTypeConverter |
Deprecated.
|
LegacyTypeInformationType<T> |
This type is a temporary solution to fully support the old type system stack through the new
stack.
|
LegacyUserDefinedFunctionInference |
Deprecated. |
LimitableTableSource<T> |
Deprecated.
|
ListView<T> |
|
ListViewSerializer<T> |
Deprecated. |
ListViewSerializerSnapshot<T> |
Deprecated. |
ListViewTypeInfo<T> |
Deprecated. |
LiteralArgumentTypeStrategy |
Strategy that checks if an argument is a literal.
|
LocalZonedTimestampType |
Logical type of a timestamp WITH LOCAL time zone consisting of year-month-day
hour:minute:second[.fractional] zone with up to nanosecond precision and values ranging from
0000-01-01 00:00:00.000000000 +14:59 to 9999-12-31 23:59:59.999999999 -14:59 .
|
LogicalType |
A logical type that describes the data type of a value.
|
LogicalTypeCasts |
|
LogicalTypeChecks |
Utilities for checking LogicalType and avoiding a lot of type casting and repetitive
work.
|
LogicalTypeDataTypeConverter |
|
LogicalTypeDefaultVisitor<R> |
|
LogicalTypeDuplicator |
|
LogicalTypeFamily |
An enumeration of logical type families for clustering LogicalTypeRoot s into categories.
|
LogicalTypeMerging |
|
LogicalTypeParser |
|
LogicalTypeRoot |
An enumeration of logical type roots containing static information about logical data types.
|
LogicalTypeUtils |
|
LogicalTypeVisitor<R> |
|
LongColumnVector |
Long column vector.
|
LookupableTableSource<T> |
Deprecated.
|
LookupCache |
A semi-persistent mapping from keys to values for storing entries of lookup table.
|
LookupFunction |
A wrapper class of TableFunction for synchronously lookup rows matching the lookup keys
from external system.
|
LookupFunctionProvider |
|
LookupOptions |
Predefined options for lookup table.
|
LookupOptions.LookupCacheType |
Types of the lookup cache.
|
LookupOptions.ReloadStrategy |
|
LookupTableSource |
A DynamicTableSource that looks up rows of an external storage system by one or more keys
during runtime.
|
LookupTableSource.LookupContext |
|
LookupTableSource.LookupRuntimeProvider |
Provides actual runtime implementation for reading the data.
|
MapColumnVector |
Map column vector.
|
MapData |
|
MappingTypeStrategy |
|
MapType |
Logical type of an associative array that maps keys (including NULL ) to values (including
NULL ).
|
MapView<K,V> |
|
MapViewSerializer<K,V> |
Deprecated. |
MapViewSerializerSnapshot<K,V> |
Deprecated. |
MapViewTypeInfo<K,V> |
Deprecated. |
MatchFamilyTypeStrategy |
Type strategy that returns the given argument if it is of the same logical type family.
|
MissingTypeStrategy |
Placeholder for a missing type strategy.
|
ModelAlreadyExistException |
Exception for trying to create a model that already exists.
|
ModelNotExistException |
Exception for trying to operate on a model that doesn't exist.
|
ModifyRefreshWorkflow<T extends RefreshHandler> |
|
Module |
Modules define a set of metadata, including functions, user defined types, operators, rules, etc.
|
ModuleException |
Exception related to modules.
|
ModuleFactory |
A factory to create configured module instances based on string-based properties.
|
ModuleFactory.Context |
Context provided when a module is created.
|
MultisetType |
Logical type of a multiset (=bag).
|
NestedFieldReferenceExpression |
A reference to a nested field in an input.
|
NestedFieldsProjectableTableSource<T> |
Deprecated.
|
NestedRowData |
Its memory storage structure is exactly the same with BinaryRowData .
|
NoMatchingTableFactoryException |
Deprecated.
|
NoMatchingTableFactoryException |
Exception for not finding a TableFactory for the given properties.
|
NullableIfArgsTypeStrategy |
A type strategy that can be used to make a result type nullable if any or all of the selected
input arguments are nullable.
|
NullAwareGetters |
Provides null related getters.
|
NullAwareMapSerializer<K,V> |
Deprecated. |
NullAwareMapSerializerSnapshot<K,V> |
Deprecated. |
NullSerializer |
A serializer for null.
|
NullSerializer.NullSerializerSnapshot |
Serializer configuration snapshot for compatibility and format evolution.
|
NullType |
Logical type for representing untyped NULL values.
|
ObjectIdentifier |
Identifies an object in a catalog.
|
ObjectPath |
A database name and object (table/view/function) name combo in a catalog.
|
OrArgumentTypeStrategy |
Strategy for inferring and validating an argument using a disjunction of multiple ArgumentTypeStrategy s into one like f(NUMERIC || STRING) .
|
OrInputTypeStrategy |
Strategy for inferring and validating the input using a disjunction of multiple InputTypeStrategy s into one like f(NUMERIC) || f(STRING) .
|
OutputArgumentTypeStrategy |
Strategy for inferring an unknown argument type from the function's output DataType if
available.
|
OutputFormatProvider |
Provider of an OutputFormat instance as a runtime implementation for DynamicTableSink .
|
OverTypeStrategy |
|
OverWindowRange |
|
OverwritableTableSink |
Deprecated.
|
ParallelismProvider |
Parallelism provider for other connector providers.
|
PartialCachingAsyncLookupProvider |
|
PartialCachingLookupProvider |
|
PartitionableTableSink |
Deprecated.
|
PartitionableTableSource |
Deprecated.
|
PartitionAlreadyExistsException |
Exception for trying to create a partition that already exists.
|
PartitionNotExistException |
Exception for operation on a partition that doesn't exist.
|
PartitionPathUtils |
Utils for file system.
|
PartitionSpecInvalidException |
Exception for invalid PartitionSpec compared with partition key list of a partitioned Table.
|
PercentageArgumentTypeStrategy |
|
PercentageArrayArgumentTypeStrategy |
|
PeriodicCacheReloadTrigger |
|
PeriodicCacheReloadTrigger.ScheduleMode |
Defines the mode how to schedule cache reloads.
|
PreserveWatermarks |
A strategy which indicates the watermarks should be preserved from the underlying datastream.
|
PrintStyle |
|
Procedure |
Base interface representing a stored procedure that can be executed by Flink.
|
ProcedureDefinition |
Definition of a procedure.
|
ProcedureHint |
A hint that influences the reflection-based extraction of arguments and output for constructing
the TypeInference logic of a Procedure .
|
ProcedureHints |
|
ProcedureNotExistException |
Exception for trying to operate on a procedure that doesn't exist.
|
ProcessTableFunction<T> |
Base class for a user-defined process table function.
|
ProcessTableFunction.Context |
Context that can be added as a first argument to the eval() method for additional information
about the input tables and other services provided by the framework.
|
ProjectableDecodingFormat<I> |
|
ProjectableTableSource<T> |
Deprecated.
|
ProjectedRowData |
An implementation of RowData which provides a projected view of the underlying RowData .
|
Projection |
Projection represents a list of (possibly nested) indexes that can be used to project
data types.
|
PythonAggregateFunction |
The wrapper of user defined python aggregate function.
|
PythonAggregateFunctionInfo |
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.
|
PythonEnv |
Python execution environments.
|
PythonEnv.ExecType |
The Execution type specifies how to execute the Python function.
|
PythonFunction |
The base interface of a wrapper of a Python function.
|
PythonFunctionInfo |
PythonFunctionInfo contains the execution information of a Python function, such as: the actual
Python function, the input arguments, etc.
|
PythonFunctionKind |
Categorizes the Python functions.
|
PythonFunctionUtils |
Utilities for creating PythonFunction from the fully qualified name of a Python function.
|
PythonScalarFunction |
The wrapper of user defined python scalar function.
|
PythonTableAggregateFunction |
The wrapper of user defined python table aggregate function.
|
PythonTableFunction |
The wrapper of user defined python table function.
|
RawContentStyle |
Print only the result content as raw form. column delimiter is ",", row delimiter is "\n".
|
RawType<T> |
Logical type of an arbitrary serialized type.
|
RawValueData<T> |
An internal data structure representing data of RawType .
|
RefreshHandler |
This interface represents the meta information of current materialized table background refresh
pipeline.
|
RefreshHandlerSerializer<T extends RefreshHandler> |
This interface is used to serialize and deserialize the RefreshHandler .
|
RefreshWorkflow |
RefreshWorkflow is the basic interface that provide the related information to operate
the refresh workflow of CatalogMaterializedTable , the operation of refresh workflow
include create, modify, drop, etc.
|
ReinterpretCastInputTypeStrategy |
|
RepeatingSequenceInputTypeStrategy |
|
ResolvedCatalogBaseTable<T extends CatalogBaseTable> |
A common parent that describes the resolved metadata of a table or view in a catalog.
|
ResolvedCatalogMaterializedTable |
|
ResolvedCatalogModel |
A validated CatalogModel that is backed by the original metadata coming from the Catalog but resolved by the framework.
|
ResolvedCatalogTable |
A validated CatalogTable that is backed by the original metadata coming from the Catalog but resolved by the framework.
|
ResolvedCatalogView |
A validated CatalogView that is backed by the original metadata coming from the Catalog but resolved by the framework.
|
ResolvedExpression |
Expression that has been fully resolved and validated.
|
ResolvedFieldReference |
A reference to a field in an input which has been resolved.
|
ResolvedSchema |
Schema of a table or view consisting of columns, constraints, and watermark specifications.
|
ResourceType |
An enum that represents the type of resource.
|
ResourceUri |
Description of resource information.
|
ResumeRefreshWorkflow<T extends RefreshHandler> |
|
RootArgumentTypeStrategy |
Strategy for an argument that corresponds to a given LogicalTypeRoot and nullability.
|
RowColumnVector |
Row column vector.
|
RowData |
Base interface for an internal data structure representing data of RowType and other
(possibly nested) structured types such as StructuredType in the table ecosystem.
|
RowData.FieldGetter |
Accessor for getting the field of a row during runtime.
|
RowDataToStringConverter |
Interface to convert RowData to String using the SQL casting rules.
|
RowLevelModificationScanContext |
The context is intended to provide the relevant table scan information needed by the sink to
perform row-level update/delete.
|
Rowtime |
Deprecated.
|
RowtimeAttributeDescriptor |
Deprecated.
|
RowtimeTypeStrategy |
|
RowType |
Logical type of a sequence of fields.
|
RowType.RowField |
|
RuntimeConverter |
Base interface for converting data during runtime.
|
RuntimeConverter.Context |
Context for conversions during runtime.
|
ScalarFunction |
Base class for a user-defined scalar function.
|
ScalarFunctionDefinition |
Deprecated.
|
ScanTableSource |
|
ScanTableSource.ScanContext |
|
ScanTableSource.ScanRuntimeProvider |
Provides actual runtime implementation for reading the data.
|
Schema |
Schema of a table or view.
|
Schema |
Deprecated.
|
Schema.Builder |
A builder for constructing an immutable but still unresolved Schema .
|
Schema.UnresolvedColumn |
Super class for all kinds of columns in an unresolved schema.
|
Schema.UnresolvedComputedColumn |
Declaration of a computed column that will be resolved to Column.ComputedColumn during
schema resolution.
|
Schema.UnresolvedConstraint |
Super class for all kinds of constraints in an unresolved schema.
|
Schema.UnresolvedMetadataColumn |
Declaration of a metadata column that will be resolved to Column.MetadataColumn during
schema resolution.
|
Schema.UnresolvedPhysicalColumn |
Declaration of a physical column that will be resolved to Column.PhysicalColumn during
schema resolution.
|
Schema.UnresolvedPrimaryKey |
Declaration of a primary key that will be resolved to UniqueConstraint during schema
resolution.
|
Schema.UnresolvedWatermarkSpec |
Declaration of a watermark strategy that will be resolved to WatermarkSpec during
schema resolution.
|
SchemaResolver |
|
SequenceInputTypeStrategy |
Strategy for inferring and validating a function signature like f(STRING, NUMERIC) or
f(s STRING, n NUMERIC) using a sequence of ArgumentTypeStrategy s.
|
SerializationFormatFactory |
|
ShortColumnVector |
Short column vector.
|
Signature |
Describes the signature of a function.
|
Signature.Argument |
Representation of a single argument in a signature.
|
SinkStagingContext |
|
SinkV2Provider |
|
SmallIntType |
Logical type of a 2-byte signed integer with values from -32,768 to 32,767.
|
SourceProvider |
Provider of a Source instance as a runtime implementation for ScanTableSource .
|
SpecializedFunction |
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 |
Serializable factory that can be passed into a UserDefinedFunction for evaluating
previously defined expression during runtime.
|
SpecializedFunction.ExpressionEvaluatorFactory |
|
SpecializedFunction.SpecializedContext |
Provides call and session information for the specialized function.
|
SpecificInputTypeStrategies |
|
SpecificTypeStrategies |
Entry point for specific type strategies not covered in TypeStrategies .
|
SqlCallExpression |
A call to a SQL expression.
|
SqlCallSyntax |
|
StagedTable |
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.
|
StateHint |
A hint that declares an intermediate result (i.e. state entry) that is managed by the framework
(i.e.
|
StateTypeStrategy |
Strategy for inferring a function call's intermediate result data type (i.e. state entry).
|
StaticArgument |
Describes an argument in a static signature that is not overloaded and does not support varargs.
|
StaticArgumentTrait |
|
StringData |
|
StructuredType |
Logical type of a user-defined object structured type.
|
StructuredType.Builder |
|
StructuredType.StructuredAttribute |
|
StructuredType.StructuredComparison |
Defines equality properties for scalar evaluation.
|
SubQueryInputTypeStrategy |
|
SubsequenceInputTypeStrategy |
An InputTypeStrategy that lets you apply other strategies for subsequences of the actual
arguments.
|
SubsequenceInputTypeStrategy.SubsequenceStrategyBuilder |
|
SupportsAggregatePushDown |
|
SupportsBucketing |
|
SupportsDeletePushDown |
Enables to push down filters decomposed from the WHERE clause in delete statement to
DynamicTableSink .
|
SupportsDynamicFiltering |
Pushes dynamic filter into ScanTableSource , the table source can filter the partitions
even the input data in runtime to reduce scan I/O.
|
SupportsFilterPushDown |
|
SupportsFilterPushDown.Result |
Result of a filter push down.
|
SupportsLimitPushDown |
Enables to push down a limit (the expected maximum number of produced records) into a ScanTableSource .
|
SupportsLookupCustomShuffle |
This interface is designed to allow connectors to provide a custom partitioning strategy for the
data that is fed into the LookupTableSource .
|
SupportsLookupCustomShuffle.InputDataPartitioner |
This interface is responsible for providing custom partitioning logic for the RowData
records.
|
SupportsOverwrite |
|
SupportsPartitioning |
|
SupportsPartitionPushDown |
Enables to pass available partitions to the planner and push down partitions into a ScanTableSource .
|
SupportsProjectionPushDown |
Enables to push down a (possibly nested) projection into a ScanTableSource .
|
SupportsReadingMetadata |
|
SupportsRowLevelDelete |
Interface for DynamicTableSink s that support delete existing data according to row-level
changes.
|
SupportsRowLevelDelete.RowLevelDeleteInfo |
The information that guides the planner on how to rewrite the delete statement.
|
SupportsRowLevelDelete.RowLevelDeleteMode |
Type of delete modes that the sink expects for delete purpose.
|
SupportsRowLevelModificationScan |
|
SupportsRowLevelModificationScan.RowLevelModificationType |
Type of the row-level modification for table.
|
SupportsRowLevelUpdate |
Interface for DynamicTableSink s that support update existing data according to row-level
changes.
|
SupportsRowLevelUpdate.RowLevelUpdateInfo |
The information that guides the planner on how to rewrite the update statement.
|
SupportsRowLevelUpdate.RowLevelUpdateMode |
Type of update modes that the sink expects for update purpose.
|
SupportsSourceWatermark |
Enables to fully rely on the watermark strategy provided by the ScanTableSource itself.
|
SupportsStaging |
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 |
The context is intended to tell DynamicTableSink the type of this operation.
|
SupportsStaging.StagingPurpose |
The type of operation the staging sink is for.
|
SupportsStatisticReport |
|
SupportsTruncate |
Enables to delete all existing data in a DynamicTableSink table using TRUNCATE
TABLE statement.
|
SupportsWatermarkPushDown |
|
SupportsWritingMetadata |
|
SuspendRefreshWorkflow<T extends RefreshHandler> |
|
SymbolArgumentTypeStrategy<T extends Enum<? extends TableSymbol>> |
Strategy for a symbol argument of a specific TableSymbol enum.
|
SymbolType<T extends TableSymbol> |
Logical type for representing symbol values.
|
SystemTypeInference |
Extends the TypeInference function-aware by additional system columns and validation.
|
TableAggregateFunction<T,ACC> |
Base class for a user-defined table aggregate function.
|
TableAggregateFunction.RetractableCollector<T> |
Collects a record and forwards it.
|
TableAggregateFunctionDefinition |
Deprecated.
|
TableAlreadyExistException |
Exception for trying to create a table (or view) that already exists.
|
TableauStyle |
Print the result and content as tableau form.
|
TableChange |
|
TableChange.AddColumn |
A table change to add a column.
|
TableChange.AddDistribution |
A table change to add a distribution.
|
TableChange.AddUniqueConstraint |
A table change to add a unique constraint.
|
TableChange.AddWatermark |
A table change to add a watermark.
|
TableChange.After |
Column position AFTER means the specified column should be put after the given `column`.
|
TableChange.CatalogTableChange |
|
TableChange.ColumnPosition |
The position of the modified or added column.
|
TableChange.DropColumn |
A table change to drop the column.
|
TableChange.DropConstraint |
A table change to drop the constraints.
|
TableChange.DropDistribution |
A table change to drop a table's distribution.
|
TableChange.DropWatermark |
A table change to drop the watermark.
|
TableChange.First |
Column position FIRST means the specified column should be the first column.
|
TableChange.MaterializedTableChange |
|
TableChange.ModifyColumn |
A base schema change to modify a column.
|
TableChange.ModifyColumnComment |
A table change to modify the column comment.
|
TableChange.ModifyColumnName |
A table change to modify the column name.
|
TableChange.ModifyColumnPosition |
A table change to modify the column position.
|
TableChange.ModifyDefinitionQuery |
A table change to modify the definition query.
|
TableChange.ModifyDistribution |
A table change to modify a distribution.
|
TableChange.ModifyPhysicalColumnType |
A table change that modify the physical column data type.
|
TableChange.ModifyRefreshHandler |
A table change to modify materialized table refresh handler.
|
TableChange.ModifyRefreshStatus |
A table change to modify materialized table refresh status.
|
TableChange.ModifyUniqueConstraint |
A table change to modify a unique constraint.
|
TableChange.ModifyWatermark |
A table change to modify the watermark.
|
TableChange.ResetOption |
A table change to reset the table option.
|
TableChange.SetOption |
A table change to set the table option.
|
TableColumn |
Deprecated.
|
TableColumn.ComputedColumn |
Representation of a computed column.
|
TableColumn.MetadataColumn |
Representation of a metadata column.
|
TableColumn.PhysicalColumn |
Representation of a physical column.
|
TableConnectorUtils |
Utilities for table sources and sinks.
|
TableDistribution |
Defines whether the given table is distributed across buckets using a specified algorithm and
given columns.
|
TableDistribution.Kind |
Distribution kind.
|
TableException |
General Exception for all errors during table handling.
|
TableFactory |
Deprecated.
|
TableFactoryService |
Deprecated. |
TableFunction<T> |
Base class for a user-defined table function.
|
TableFunctionDefinition |
Deprecated.
|
TableFunctionProvider<T> |
Deprecated.
|
TableNotExistException |
Exception for an operation on a nonexistent table.
|
TableNotExistException |
Exception for trying to operate on a table (or view) that doesn't exist.
|
TableNotPartitionedException |
Exception for trying to operate partition on a non-partitioned table.
|
TablePartitionedException |
Exception for trying to operate non-partitioned on a partitioned table.
|
TableRuntimeException |
Exception for errors occurring in the runtime.
|
TableSchema |
Deprecated.
|
TableSchema.Builder |
|
TableSchemaUtils |
|
TableSemantics |
Provides call information about the table that has been passed to a table argument.
|
TableSink<T> |
Deprecated.
|
TableSinkBase<T> |
Deprecated.
|
TableSinkFactory<T> |
Deprecated.
|
TableSinkFactory.Context |
Context of table sink creation.
|
TableSinkFactoryContextImpl |
Deprecated. |
TableSource<T> |
Deprecated.
|
TableSourceFactory<T> |
Deprecated.
|
TableSourceFactory.Context |
Context of table source creation.
|
TableSourceFactoryContextImpl |
Deprecated. |
TableSourceValidation |
|
TableStats |
Table statistics.
|
TableSymbol |
The base interface for all table symbols.
|
TemporalTableFunction |
Class representing temporal table function over some history table.
|
TemporaryOperationListener |
This interface is for a Catalog to listen on temporary object operations.
|
ThreadLocalCache<K,V> |
Provides a thread local cache with a maximum cache size per thread.
|
TimedCacheReloadTrigger |
A trigger that reloads at a specific time and repeats for the given interval in days.
|
TimeIndicatorTypeInfo |
Deprecated.
|
TimeIntervalTypeInfo<T> |
Deprecated.
|
TimeIntervalUnit |
Units for working with time intervals.
|
TimePointUnit |
Units for working with points in time.
|
TimestampColumnVector |
Timestamp column vector.
|
TimestampData |
|
TimestampExtractor |
Deprecated.
|
TimestampExtractorUtils |
|
TimestampKind |
Internal timestamp kind for attaching time attribute metadata to timestamps with or without a
time zone.
|
TimestampType |
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 .
|
TimeType |
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 .
|
TinyIntType |
Logical type of a 1-byte signed integer with values from -128 to 127.
|
ToTimestampLtzTypeStrategy |
Type strategy of TO_TIMESTAMP_LTZ .
|
TypeConversions |
|
TypedSetters |
Provide type specialized setters to reduce if/else and eliminate box and unbox.
|
TypeInference |
Provides logic for the type inference of function calls.
|
TypeInference.Builder |
|
TypeInferenceExtractor |
|
TypeInferenceUtil |
Utility for performing type inference.
|
TypeInferenceUtil.Result |
The result of a type inference run.
|
TypeInferenceUtil.SurroundingInfo |
Information what the outer world (i.e. an outer wrapping call) expects from the current
function call.
|
TypeInfoDataTypeConverter |
Converter from TypeInformation to DataType .
|
TypeInformationRawType<T> |
Deprecated.
|
TypeLiteralArgumentTypeStrategy |
Strategy that checks if an argument is a type literal.
|
TypeLiteralExpression |
Expression that wraps DataType as a literal.
|
TypeMappingUtils |
|
Types |
Deprecated.
|
TypeStrategies |
Strategies for inferring an output or accumulator data type of a function call.
|
TypeStrategy |
Strategy for inferring a function call's result data type.
|
TypeStringUtils |
Deprecated.
|
TypeTransformation |
Transforms one data type to another.
|
TypeTransformations |
Transformations for transforming one data type to another.
|
UniqueConstraint |
A unique key constraint.
|
UniqueConstraint |
Deprecated.
|
UnknownCallContext |
|
UnresolvedDataType |
Partially resolved data type that requires a lookup in a catalog or configuration before creating
the corresponding LogicalType .
|
UnresolvedIdentifier |
Identifier of an object, such as table, view, function or type in a catalog.
|
UnresolvedUserDefinedType |
|
UserDefinedFunction |
Base class for all user-defined functions.
|
UserDefinedFunctionHelper |
|
UserDefinedType |
Logical type of a user-defined representation for one or more built-in types.
|
ValidationException |
Exception for all errors occurring during validation phase.
|
ValueDataTypeConverter |
Value-based data type extractor that supports extraction of clearly identifiable data types for
input conversion.
|
ValueLiteralExpression |
Expression for constant literal values.
|
VarBinaryType |
Logical type of a variable-length binary string (=a sequence of bytes).
|
VarCharType |
Logical type of a variable-length character string.
|
VaryingSequenceInputTypeStrategy |
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.
|
VaryingStringTypeStrategy |
|
VectorizedColumnBatch |
A VectorizedColumnBatch is a set of rows, organized with each column as a vector.
|
WatermarkEmitStrategy |
The strategy for emitting watermark.
|
WatermarkParams |
Pojo class for watermark configs from table options or 'OPTIONS' hint.
|
WatermarkParams.WatermarkParamsBuilder |
Builder of WatermarkHintParams.
|
WatermarkSpec |
|
WatermarkSpec |
Deprecated.
|
WatermarkStrategy |
Provides a strategy to generate watermarks for a rowtime attribute.
|
WildcardInputTypeStrategy |
Strategy that does not perform any modification or validation of the input.
|
WindowTimeIndictorInputTypeStrategy |
|
WorkflowException |
A workflow-related operation exception to materialized table, including create, suspend, resume,
drop workflow operation, etc.
|
WorkflowScheduler<T extends RefreshHandler> |
This interface is used to interact with specific workflow scheduler services that support
creating, modifying, and deleting refreshed workflow of Materialized Table.
|
WorkflowSchedulerFactory |
|
WorkflowSchedulerFactory.Context |
Context provided when a workflow scheduler is created.
|
WorkflowSchedulerFactoryUtil |
|
WorkflowSchedulerFactoryUtil.DefaultWorkflowSchedulerContext |
|
WorkflowSchedulerFactoryUtil.WorkflowSchedulerFactoryHelper |
|
WritableBooleanVector |
|
WritableBytesVector |
|
WritableByteVector |
|
WritableColumnVector |
|
WritableDoubleVector |
|
WritableFloatVector |
|
WritableIntVector |
|
WritableLongVector |
|
WritableShortVector |
|
WritableTimestampVector |
|
YearMonthIntervalType |
Logical type for a group of year-month interval types.
|
YearMonthIntervalType.YearMonthResolution |
Supported resolutions of this type.
|
ZonedTimestampType |
Logical type of a timestamp WITH time zone consisting of year-month-day
hour:minute:second[.fractional] zone with up to nanosecond precision and values ranging from
0000-01-01 00:00:00.000000000 +14:59 to 9999-12-31 23:59:59.999999999 -14:59 .
|