Serialized Form
-
Package org.apache.flink.table.api
-
Class org.apache.flink.table.api.AmbiguousTableFactoryException extends RuntimeException implements Serializable
-
Serialized Fields
-
factories
List<TableFactory> factories
Deprecated. -
factoryClass
Class<? extends TableFactory> factoryClass
Deprecated. -
matchingFactories
List<? extends TableFactory> matchingFactories
Deprecated. -
properties
Map<String,String> properties
Deprecated.
-
-
-
Class org.apache.flink.table.api.CatalogNotExistException extends RuntimeException implements Serializable
-
Class org.apache.flink.table.api.ExpressionParserException extends RuntimeException implements Serializable
-
Class org.apache.flink.table.api.NoMatchingTableFactoryException extends RuntimeException implements Serializable
-
Class org.apache.flink.table.api.TableException extends RuntimeException implements Serializable
-
Class org.apache.flink.table.api.TableNotExistException extends RuntimeException implements Serializable
-
Class org.apache.flink.table.api.TableRuntimeException extends RuntimeException implements Serializable
-
Class org.apache.flink.table.api.ValidationException extends RuntimeException implements Serializable
-
-
Package org.apache.flink.table.catalog
-
Class org.apache.flink.table.catalog.ObjectIdentifier extends Object implements Serializable
-
Class org.apache.flink.table.catalog.ObjectPath extends Object implements Serializable
-
-
Package org.apache.flink.table.catalog.exceptions
-
Class org.apache.flink.table.catalog.exceptions.CatalogException extends RuntimeException implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.DatabaseAlreadyExistException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.DatabaseNotEmptyException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.DatabaseNotExistException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.FunctionAlreadyExistException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.FunctionNotExistException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.ModelAlreadyExistException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.ModelNotExistException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.PartitionAlreadyExistsException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.PartitionNotExistException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.PartitionSpecInvalidException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.ProcedureNotExistException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.TableAlreadyExistException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.TableNotExistException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.TableNotPartitionedException extends Exception implements Serializable
-
Class org.apache.flink.table.catalog.exceptions.TablePartitionedException extends Exception implements Serializable
-
-
Package org.apache.flink.table.connector
-
Package org.apache.flink.table.connector.sink
-
Package org.apache.flink.table.connector.source
-
Class org.apache.flink.table.connector.source.DynamicFilteringData extends Object implements Serializable
-
Serialized Fields
-
isFiltering
boolean isFiltering
Whether the data actually does filter. If false, everything is considered contained. -
rowType
RowType rowType
-
serializedData
List<byte[]> serializedData
Serialized rows for filtering. The types of the row values must be Flink internal data type, i.e. type returned by the FieldGetter. The list should be sorted and distinct. -
typeInfo
org.apache.flink.api.common.typeinfo.TypeInformation<RowData> typeInfo
-
-
-
Class org.apache.flink.table.connector.source.DynamicFilteringEvent extends Object implements Serializable
-
Serialized Fields
-
data
DynamicFilteringData data
-
-
-
-
Package org.apache.flink.table.connector.source.abilities
-
Package org.apache.flink.table.connector.source.lookup.cache
-
Class org.apache.flink.table.connector.source.lookup.cache.DefaultLookupCache extends Object implements Serializable
- serialVersionUID:
- 1L
-
-
Package org.apache.flink.table.connector.source.lookup.cache.trigger
-
Class org.apache.flink.table.connector.source.lookup.cache.trigger.PeriodicCacheReloadTrigger extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
reloadInterval
Duration reloadInterval
-
scheduleMode
PeriodicCacheReloadTrigger.ScheduleMode scheduleMode
-
-
Class org.apache.flink.table.connector.source.lookup.cache.trigger.TimedCacheReloadTrigger extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
reloadIntervalInDays
int reloadIntervalInDays
-
reloadTime
Temporal reloadTime
-
-
-
Package org.apache.flink.table.data
-
Package org.apache.flink.table.data.columnar.vector
-
Class org.apache.flink.table.data.columnar.vector.VectorizedColumnBatch extends Object implements Serializable
- serialVersionUID:
- 8180323238728166155L
-
Serialized Fields
-
columns
ColumnVector[] columns
-
numRows
int numRows
-
-
-
Package org.apache.flink.table.data.columnar.vector.heap
-
Class org.apache.flink.table.data.columnar.vector.heap.AbstractHeapVector extends AbstractWritableVector implements Serializable
-
Serialized Fields
-
dictionaryIds
HeapIntVector dictionaryIds
Reusable column for ids of dictionary. -
isNull
boolean[] isNull
-
len
int len
-
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapArrayVector extends AbstractHeapVector implements Serializable
-
Serialized Fields
-
child
ColumnVector child
-
lengths
long[] lengths
-
offsets
long[] offsets
-
size
int size
-
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapBooleanVector extends AbstractHeapVector implements Serializable
- serialVersionUID:
- 4131239076731313596L
-
Serialized Fields
-
vector
boolean[] vector
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapBytesVector extends AbstractHeapVector implements Serializable
- serialVersionUID:
- -8529155738773478597L
-
Serialized Fields
-
buffer
byte[] buffer
buffer to use when actually copying in data. -
capacity
int capacity
-
elementsAppended
int elementsAppended
Hang onto a byte array for holding smaller byte values. -
length
int[] length
The length of each field. -
start
int[] start
start offset of each field.
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapByteVector extends AbstractHeapVector implements Serializable
- serialVersionUID:
- 7216045902943789034L
-
Serialized Fields
-
vector
byte[] vector
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapDoubleVector extends AbstractHeapVector implements Serializable
- serialVersionUID:
- 6193940154117411328L
-
Serialized Fields
-
vector
double[] vector
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapFloatVector extends AbstractHeapVector implements Serializable
- serialVersionUID:
- 8928878923550041110L
-
Serialized Fields
-
vector
float[] vector
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapIntVector extends AbstractHeapVector implements Serializable
- serialVersionUID:
- -2749499358889718254L
-
Serialized Fields
-
vector
int[] vector
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapLongVector extends AbstractHeapVector implements Serializable
- serialVersionUID:
- 8534925169458006397L
-
Serialized Fields
-
vector
long[] vector
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapMapVector extends AbstractHeapVector implements Serializable
-
Serialized Fields
-
keys
ColumnVector keys
-
lengths
long[] lengths
-
offsets
long[] offsets
-
size
int size
-
values
ColumnVector values
-
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapRowVector extends AbstractHeapVector implements Serializable
-
Serialized Fields
-
fields
WritableColumnVector[] fields
-
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapShortVector extends AbstractHeapVector implements Serializable
- serialVersionUID:
- -8278486456144676292L
-
Serialized Fields
-
vector
short[] vector
-
-
Class org.apache.flink.table.data.columnar.vector.heap.HeapTimestampVector extends AbstractHeapVector implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
milliseconds
long[] milliseconds
-
nanoOfMilliseconds
int[] nanoOfMilliseconds
-
-
-
Package org.apache.flink.table.data.columnar.vector.writable
-
Class org.apache.flink.table.data.columnar.vector.writable.AbstractWritableVector extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
dictionary
Dictionary dictionary
The Dictionary for this column. If it's not null, will be used to decode the value in get(). -
noNulls
boolean noNulls
-
-
-
Package org.apache.flink.table.dataview
-
Class org.apache.flink.table.dataview.ListViewSerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<ListView<T>> implements Serializable
- serialVersionUID:
- -2030398712359267867L
-
Class org.apache.flink.table.dataview.ListViewTypeInfo extends org.apache.flink.api.common.typeinfo.TypeInformation<ListView<T>> implements Serializable
- serialVersionUID:
- 6468505781419989441L
-
Serialized Fields
-
elementType
org.apache.flink.api.common.typeinfo.TypeInformation<T> elementType
Deprecated. -
nullSerializer
boolean nullSerializer
Deprecated.
-
-
Class org.apache.flink.table.dataview.MapViewSerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<MapView<K,V>> implements Serializable
- serialVersionUID:
- -9007142882049098705L
-
Class org.apache.flink.table.dataview.MapViewTypeInfo extends org.apache.flink.api.common.typeinfo.TypeInformation<MapView<K,V>> implements Serializable
- serialVersionUID:
- -2883944144965318259L
-
Class org.apache.flink.table.dataview.NullAwareMapSerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<Map<K,V>> implements Serializable
- serialVersionUID:
- 5363147328373166590L
-
Class org.apache.flink.table.dataview.NullSerializer extends org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<Object> implements Serializable
- serialVersionUID:
- -5381596724707742625L
-
-
Package org.apache.flink.table.expressions
-
Class org.apache.flink.table.expressions.ExpressionParserException extends ExpressionParserException implements Serializable
-
-
Package org.apache.flink.table.factories
-
Class org.apache.flink.table.factories.AmbiguousTableFactoryException extends AmbiguousTableFactoryException implements Serializable
-
Class org.apache.flink.table.factories.NoMatchingTableFactoryException extends NoMatchingTableFactoryException implements Serializable
-
-
Package org.apache.flink.table.functions
-
Class org.apache.flink.table.functions.AggregateFunction extends ImperativeAggregateFunction<T,ACC> implements Serializable
-
Class org.apache.flink.table.functions.AsyncLookupFunction extends AsyncTableFunction<RowData> implements Serializable
-
Class org.apache.flink.table.functions.AsyncScalarFunction extends UserDefinedFunction implements Serializable
-
Class org.apache.flink.table.functions.AsyncTableFunction extends UserDefinedFunction implements Serializable
-
Class org.apache.flink.table.functions.FunctionIdentifier extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
functionName
String functionName
-
objectIdentifier
ObjectIdentifier objectIdentifier
-
-
Class org.apache.flink.table.functions.ImperativeAggregateFunction extends UserDefinedFunction implements Serializable
-
Class org.apache.flink.table.functions.LookupFunction extends TableFunction<RowData> implements Serializable
-
Class org.apache.flink.table.functions.ProcessTableFunction extends UserDefinedFunction implements Serializable
-
Class org.apache.flink.table.functions.ScalarFunction extends UserDefinedFunction implements Serializable
-
Class org.apache.flink.table.functions.TableAggregateFunction extends ImperativeAggregateFunction<T,ACC> implements Serializable
-
Class org.apache.flink.table.functions.TableFunction extends UserDefinedFunction implements Serializable
-
Class org.apache.flink.table.functions.TemporalTableFunction extends TableFunction<org.apache.flink.types.Row> implements Serializable
-
Class org.apache.flink.table.functions.UserDefinedFunction extends Object implements Serializable
-
-
Package org.apache.flink.table.functions.python
-
Class org.apache.flink.table.functions.python.PythonAggregateFunction extends AggregateFunction implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
accumulatorType
DataType accumulatorType
-
accumulatorTypeString
String accumulatorTypeString
-
deterministic
boolean deterministic
-
inputTypes
DataType[] inputTypes
-
inputTypesString
String[] inputTypesString
-
name
String name
-
pythonEnv
PythonEnv pythonEnv
-
pythonFunctionKind
PythonFunctionKind pythonFunctionKind
-
resultType
DataType resultType
-
resultTypeString
String resultTypeString
-
serializedAggregateFunction
byte[] serializedAggregateFunction
-
takesRowAsInput
boolean takesRowAsInput
-
-
Class org.apache.flink.table.functions.python.PythonAggregateFunctionInfo extends PythonFunctionInfo implements Serializable
-
Serialized Fields
-
distinct
boolean distinct
-
filterArg
int filterArg
-
-
-
Class org.apache.flink.table.functions.python.PythonEnv extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
execType
PythonEnv.ExecType execType
The execution type of the Python worker, it defines how to execute the Python functions.
-
-
Class org.apache.flink.table.functions.python.PythonFunctionInfo extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
inputs
Object[] inputs
The input arguments, it could be an input offset of the input row or the execution result of another python function described as PythonFunctionInfo. -
pythonFunction
PythonFunction pythonFunction
The python function to be executed.
-
-
Class org.apache.flink.table.functions.python.PythonScalarFunction extends ScalarFunction implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
deterministic
boolean deterministic
-
inputTypes
DataType[] inputTypes
-
inputTypesString
String[] inputTypesString
-
name
String name
-
pythonEnv
PythonEnv pythonEnv
-
pythonFunctionKind
PythonFunctionKind pythonFunctionKind
-
resultType
DataType resultType
-
resultTypeString
String resultTypeString
-
serializedScalarFunction
byte[] serializedScalarFunction
-
takesRowAsInput
boolean takesRowAsInput
-
-
Class org.apache.flink.table.functions.python.PythonTableAggregateFunction extends TableAggregateFunction implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
accumulatorType
DataType accumulatorType
-
accumulatorTypeString
String accumulatorTypeString
-
deterministic
boolean deterministic
-
inputTypes
DataType[] inputTypes
-
inputTypesString
String[] inputTypesString
-
name
String name
-
pythonEnv
PythonEnv pythonEnv
-
pythonFunctionKind
PythonFunctionKind pythonFunctionKind
-
resultType
DataType resultType
-
resultTypeString
String resultTypeString
-
serializedTableAggregateFunction
byte[] serializedTableAggregateFunction
-
takesRowAsInput
boolean takesRowAsInput
-
-
Class org.apache.flink.table.functions.python.PythonTableFunction extends TableFunction<org.apache.flink.types.Row> implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
deterministic
boolean deterministic
-
inputTypes
DataType[] inputTypes
-
inputTypesString
String[] inputTypesString
-
name
String name
-
pythonEnv
PythonEnv pythonEnv
-
pythonFunctionKind
PythonFunctionKind pythonFunctionKind
-
resultType
DataType resultType
-
resultTypeString
String resultTypeString
-
serializedTableFunction
byte[] serializedTableFunction
-
takesRowAsInput
boolean takesRowAsInput
-
-
-
Package org.apache.flink.table.legacy.sources.tsextractors
-
Class org.apache.flink.table.legacy.sources.tsextractors.TimestampExtractor extends Object implements Serializable
-
-
Package org.apache.flink.table.legacy.types.logical
-
Class org.apache.flink.table.legacy.types.logical.TypeInformationRawType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
typeInfo
org.apache.flink.api.common.typeinfo.TypeInformation<T> typeInfo
Deprecated.
-
-
-
Package org.apache.flink.table.module
-
Class org.apache.flink.table.module.ModuleException extends RuntimeException implements Serializable
-
-
Package org.apache.flink.table.refresh
-
Package org.apache.flink.table.sources.wmstrategies
-
Class org.apache.flink.table.sources.wmstrategies.PreserveWatermarks extends WatermarkStrategy implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.sources.wmstrategies.WatermarkStrategy extends Object implements Serializable
-
-
Package org.apache.flink.table.types
-
Class org.apache.flink.table.types.AtomicDataType extends DataType implements Serializable
-
Class org.apache.flink.table.types.CollectionDataType extends DataType implements Serializable
-
Serialized Fields
-
elementDataType
DataType elementDataType
-
-
-
Class org.apache.flink.table.types.DataType extends Object implements Serializable
-
Serialized Fields
-
conversionClass
Class<?> conversionClass
-
logicalType
LogicalType logicalType
-
-
-
Class org.apache.flink.table.types.FieldsDataType extends DataType implements Serializable
-
Class org.apache.flink.table.types.KeyValueDataType extends DataType implements Serializable
-
-
Package org.apache.flink.table.types.logical
-
Class org.apache.flink.table.types.logical.ArrayType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
elementType
LogicalType elementType
-
-
Class org.apache.flink.table.types.logical.BigIntType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.types.logical.BinaryType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
length
int length
-
-
Class org.apache.flink.table.types.logical.BooleanType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.types.logical.CharType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
length
int length
-
-
Class org.apache.flink.table.types.logical.DateType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.types.logical.DayTimeIntervalType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
dayPrecision
int dayPrecision
-
fractionalPrecision
int fractionalPrecision
-
resolution
DayTimeIntervalType.DayTimeResolution resolution
-
-
Class org.apache.flink.table.types.logical.DecimalType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
precision
int precision
-
scale
int scale
-
-
Class org.apache.flink.table.types.logical.DistinctType extends UserDefinedType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
sourceType
LogicalType sourceType
-
-
Class org.apache.flink.table.types.logical.DoubleType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.types.logical.FloatType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.types.logical.IntType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.types.logical.LegacyTypeInformationType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
typeInfo
org.apache.flink.api.common.typeinfo.TypeInformation<T> typeInfo
-
-
Class org.apache.flink.table.types.logical.LocalZonedTimestampType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
kind
TimestampKind kind
-
precision
int precision
-
-
Class org.apache.flink.table.types.logical.LogicalType extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
isNullable
boolean isNullable
-
typeRoot
LogicalTypeRoot typeRoot
-
-
Class org.apache.flink.table.types.logical.MapType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
keyType
LogicalType keyType
-
valueType
LogicalType valueType
-
-
Class org.apache.flink.table.types.logical.MultisetType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
elementType
LogicalType elementType
-
-
Class org.apache.flink.table.types.logical.NullType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.types.logical.RawType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.types.logical.RowType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
fields
List<RowType.RowField> fields
-
-
Class org.apache.flink.table.types.logical.RowType.RowField extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
description
String description
-
name
String name
-
type
LogicalType type
-
-
Class org.apache.flink.table.types.logical.SmallIntType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.types.logical.StructuredType extends UserDefinedType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
attributes
List<StructuredType.StructuredAttribute> attributes
-
comparison
StructuredType.StructuredComparison comparison
-
implementationClass
Class<?> implementationClass
-
isInstantiable
boolean isInstantiable
-
superType
StructuredType superType
-
-
Class org.apache.flink.table.types.logical.StructuredType.StructuredAttribute extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
description
String description
-
name
String name
-
type
LogicalType type
-
-
Class org.apache.flink.table.types.logical.SymbolType extends LogicalType implements Serializable
- serialVersionUID:
- 2L
-
Class org.apache.flink.table.types.logical.TimestampType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
kind
TimestampKind kind
-
precision
int precision
-
-
Class org.apache.flink.table.types.logical.TimeType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
precision
int precision
-
-
Class org.apache.flink.table.types.logical.TinyIntType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Class org.apache.flink.table.types.logical.UnresolvedUserDefinedType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
unresolvedIdentifier
UnresolvedIdentifier unresolvedIdentifier
-
-
Class org.apache.flink.table.types.logical.UserDefinedType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
description
String description
-
isFinal
boolean isFinal
-
objectIdentifier
ObjectIdentifier objectIdentifier
-
-
Class org.apache.flink.table.types.logical.VarBinaryType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
length
int length
-
-
Class org.apache.flink.table.types.logical.VarCharType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
length
int length
-
-
Class org.apache.flink.table.types.logical.YearMonthIntervalType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
resolution
YearMonthIntervalType.YearMonthResolution resolution
-
yearPrecision
int yearPrecision
-
-
Class org.apache.flink.table.types.logical.ZonedTimestampType extends LogicalType implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
kind
TimestampKind kind
-
precision
int precision
-
-
-
Package org.apache.flink.table.typeutils
-
Class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo extends org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo<Timestamp> implements Serializable
-
Serialized Fields
-
isEventTime
boolean isEventTime
Deprecated.
-
-
-
Class org.apache.flink.table.typeutils.TimeIntervalTypeInfo extends org.apache.flink.api.common.typeinfo.TypeInformation<T> implements Serializable
- serialVersionUID:
- -1816179424364825258L
-
-
Package org.apache.flink.table.watermark
-
Class org.apache.flink.table.watermark.WatermarkParams extends Object implements Serializable
- serialVersionUID:
- 1L
-
Serialized Fields
-
alignGroupName
String alignGroupName
-
alignMaxDrift
Duration alignMaxDrift
-
alignUpdateInterval
Duration alignUpdateInterval
-
emitStrategy
WatermarkEmitStrategy emitStrategy
-
sourceIdleTimeout
long sourceIdleTimeout
-
-
-
Package org.apache.flink.table.workflow
-
Class org.apache.flink.table.workflow.WorkflowException extends org.apache.flink.util.FlinkException implements Serializable
- serialVersionUID:
- 1L
-