Uses of Class
org.apache.flink.table.runtime.typeutils.InternalTypeInfo
-
-
Uses of InternalTypeInfo in org.apache.flink.table.planner.plan.nodes.exec.batch
Methods in org.apache.flink.table.planner.plan.nodes.exec.batch with parameters of type InternalTypeInfo Modifier and Type Method Description Transformation<RowData>
BatchExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
-
Uses of InternalTypeInfo in org.apache.flink.table.planner.plan.nodes.exec.common
Methods in org.apache.flink.table.planner.plan.nodes.exec.common with parameters of type InternalTypeInfo Modifier and Type Method Description protected abstract Transformation<RowData>
CommonExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
Creates aTransformation
based on the givenInputFormat
. -
Uses of InternalTypeInfo in org.apache.flink.table.planner.plan.nodes.exec.stream
Methods in org.apache.flink.table.planner.plan.nodes.exec.stream with parameters of type InternalTypeInfo Modifier and Type Method Description Transformation<RowData>
StreamExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
-
Uses of InternalTypeInfo in org.apache.flink.table.planner.plan.utils
Methods in org.apache.flink.table.planner.plan.utils with parameters of type InternalTypeInfo Modifier and Type Method Description static RowDataKeySelector
KeySelectorUtil. getRowDataSelector(ClassLoader classLoader, int[] keyFields, InternalTypeInfo<RowData> rowType)
static RowDataKeySelector
KeySelectorUtil. getRowDataSelector(ClassLoader classLoader, int[] keyFields, InternalTypeInfo<RowData> rowType, Class<? extends RowData> outClass)
Create a RowDataKeySelector to extract keys from DataStream which type isInternalTypeInfo
ofRowData
. -
Uses of InternalTypeInfo in org.apache.flink.table.runtime.keyselector
Methods in org.apache.flink.table.runtime.keyselector that return InternalTypeInfo Modifier and Type Method Description InternalTypeInfo<RowData>
BinaryRowDataKeySelector. getProducedType()
InternalTypeInfo<RowData>
EmptyRowDataKeySelector. getProducedType()
InternalTypeInfo<RowData>
GenericRowDataKeySelector. getProducedType()
InternalTypeInfo<RowData>
RowDataKeySelector. getProducedType()
Constructors in org.apache.flink.table.runtime.keyselector with parameters of type InternalTypeInfo Constructor Description BinaryRowDataKeySelector(InternalTypeInfo<RowData> keyRowType, GeneratedProjection generatedProjection)
GenericRowDataKeySelector(InternalTypeInfo<RowData> keyRowType, RowDataSerializer keySerializer, GeneratedProjection generatedProjection)
-
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.deduplicate
Constructors in org.apache.flink.table.runtime.operators.deduplicate with parameters of type InternalTypeInfo Constructor Description ProcTimeDeduplicateKeepLastRowFunction(InternalTypeInfo<RowData> typeInfo, long stateRetentionTime, boolean generateUpdateBefore, boolean generateInsert, boolean inputInsertOnly, GeneratedRecordEqualiser genRecordEqualiser)
ProcTimeMiniBatchDeduplicateKeepLastRowFunction(InternalTypeInfo<RowData> typeInfo, TypeSerializer<RowData> serializer, long stateRetentionTime, boolean generateUpdateBefore, boolean generateInsert, boolean inputInsertOnly, GeneratedRecordEqualiser genRecordEqualiser)
RowTimeDeduplicateFunction(InternalTypeInfo<RowData> typeInfo, long minRetentionTime, int rowtimeIndex, boolean generateUpdateBefore, boolean generateInsert, boolean keepLastRow)
RowTimeMiniBatchDeduplicateFunction(InternalTypeInfo<RowData> typeInfo, TypeSerializer<RowData> serializer, long minRetentionTime, int rowtimeIndex, boolean generateUpdateBefore, boolean generateInsert, boolean keepLastRow)
RowTimeMiniBatchLatestChangeDeduplicateFunction(InternalTypeInfo<RowData> typeInfo, TypeSerializer<RowData> serializer, long minRetentionTime, int rowtimeIndex, boolean generateUpdateBefore, boolean generateInsert, boolean keepLastRow)
-
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.join.interval
-
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.join.stream
Fields in org.apache.flink.table.runtime.operators.join.stream declared as InternalTypeInfo Modifier and Type Field Description protected InternalTypeInfo<RowData>
AbstractStreamingJoinOperator. leftType
protected InternalTypeInfo<RowData>
AbstractStreamingJoinOperator. rightType
Methods in org.apache.flink.table.runtime.operators.join.stream with parameters of type InternalTypeInfo Modifier and Type Method Description static MiniBatchStreamingJoinOperator
MiniBatchStreamingJoinOperator. newMiniBatchStreamJoinOperator(FlinkJoinType joinType, InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, GeneratedJoinCondition generatedJoinCondition, JoinInputSideSpec leftInputSideSpec, JoinInputSideSpec rightInputSideSpec, boolean leftIsOuter, boolean rightIsOuter, boolean[] filterNullKeys, long leftStateRetentionTime, long rightStateRetentionTime, CoBundleTrigger<RowData,RowData> coBundleTrigger)
Constructors in org.apache.flink.table.runtime.operators.join.stream with parameters of type InternalTypeInfo Constructor Description AbstractStreamingJoinOperator(InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, GeneratedJoinCondition generatedJoinCondition, JoinInputSideSpec leftInputSideSpec, JoinInputSideSpec rightInputSideSpec, boolean[] filterNullKeys, long leftStateRetentionTime, long rightStateRetentionTime)
StreamingJoinOperator(InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, GeneratedJoinCondition generatedJoinCondition, JoinInputSideSpec leftInputSideSpec, JoinInputSideSpec rightInputSideSpec, boolean leftIsOuter, boolean rightIsOuter, boolean[] filterNullKeys, long leftStateRetentionTime, long rightStateRetentionTime)
StreamingSemiAntiJoinOperator(boolean isAntiJoin, InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, GeneratedJoinCondition generatedJoinCondition, JoinInputSideSpec leftInputSideSpec, JoinInputSideSpec rightInputSideSpec, boolean[] filterNullKeys, long leftStateRetentionTime, long rightStateRetentionTIme)
-
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing
Fields in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing declared as InternalTypeInfo Modifier and Type Field Description protected InternalTypeInfo<RowData>
AbstractAsyncStateStreamingJoinOperator. leftType
protected InternalTypeInfo<RowData>
AbstractAsyncStateStreamingJoinOperator. rightType
Constructors in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing with parameters of type InternalTypeInfo Constructor Description AbstractAsyncStateStreamingJoinOperator(InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, GeneratedJoinCondition generatedJoinCondition, JoinInputSideSpec leftInputSideSpec, JoinInputSideSpec rightInputSideSpec, boolean[] filterNullKeys, long leftStateRetentionTime, long rightStateRetentionTime)
AsyncStateStreamingJoinOperator(InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, GeneratedJoinCondition generatedJoinCondition, JoinInputSideSpec leftInputSideSpec, JoinInputSideSpec rightInputSideSpec, boolean leftIsOuter, boolean rightIsOuter, boolean[] filterNullKeys, long leftStateRetentionTime, long rightStateRetentionTime)
-
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state
Methods in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state with parameters of type InternalTypeInfo Modifier and Type Method Description static JoinRecordAsyncStateView
JoinRecordAsyncStateViews. create(StreamingRuntimeContext ctx, String stateName, JoinInputSideSpec inputSideSpec, InternalTypeInfo<RowData> recordType, long retentionTime)
Creates aJoinRecordAsyncStateView
depends onJoinInputSideSpec
.static OuterJoinRecordAsyncStateView
OuterJoinRecordAsyncStateViews. create(StreamingRuntimeContext ctx, String stateName, JoinInputSideSpec inputSideSpec, InternalTypeInfo<RowData> recordType, long retentionTime)
Creates aOuterJoinRecordAsyncStateView
depends onJoinInputSideSpec
. -
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.join.stream.state
Methods in org.apache.flink.table.runtime.operators.join.stream.state with parameters of type InternalTypeInfo Modifier and Type Method Description static JoinRecordStateView
JoinRecordStateViews. create(RuntimeContext ctx, String stateName, JoinInputSideSpec inputSideSpec, InternalTypeInfo<RowData> recordType, long retentionTime)
Creates aJoinRecordStateView
depends onJoinInputSideSpec
.static OuterJoinRecordStateView
OuterJoinRecordStateViews. create(RuntimeContext ctx, String stateName, JoinInputSideSpec inputSideSpec, InternalTypeInfo<RowData> recordType, long retentionTime)
Creates aOuterJoinRecordStateView
depends onJoinInputSideSpec
. -
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.join.stream.utils
Methods in org.apache.flink.table.runtime.operators.join.stream.utils that return InternalTypeInfo Modifier and Type Method Description InternalTypeInfo<RowData>
JoinInputSideSpec. getUniqueKeyType()
Returns theTypeInformation
of the unique key.Methods in org.apache.flink.table.runtime.operators.join.stream.utils with parameters of type InternalTypeInfo Modifier and Type Method Description static JoinInputSideSpec
JoinInputSideSpec. withUniqueKey(InternalTypeInfo<RowData> uniqueKeyType, KeySelector<RowData,RowData> uniqueKeySelector)
Creates aJoinInputSideSpec
that the input has an unique key.static JoinInputSideSpec
JoinInputSideSpec. withUniqueKeyContainedByJoinKey(InternalTypeInfo<RowData> uniqueKeyType, KeySelector<RowData,RowData> uniqueKeySelector)
Creates aJoinInputSideSpec
that input has an unique key and the unique key is contained by the join key. -
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.join.temporal
Constructors in org.apache.flink.table.runtime.operators.join.temporal with parameters of type InternalTypeInfo Constructor Description TemporalProcessTimeJoinOperator(InternalTypeInfo<RowData> rightType, GeneratedJoinCondition generatedJoinCondition, long minRetentionTime, long maxRetentionTime, boolean isLeftOuterJoin)
TemporalRowTimeJoinOperator(InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, GeneratedJoinCondition generatedJoinCondition, int leftTimeAttribute, int rightTimeAttribute, long minRetentionTime, long maxRetentionTime, boolean isLeftOuterJoin)
-
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.rank
Fields in org.apache.flink.table.runtime.operators.rank declared as InternalTypeInfo Modifier and Type Field Description protected InternalTypeInfo<RowData>
AbstractTopNFunction. inputRowType
Constructors in org.apache.flink.table.runtime.operators.rank with parameters of type InternalTypeInfo Constructor Description AppendOnlyFirstNFunction(StateTtlConfig ttlConfig, InternalTypeInfo<RowData> inputRowType, GeneratedRecordComparator sortKeyGeneratedRecordComparator, RowDataKeySelector sortKeySelector, RankType rankType, RankRange rankRange, boolean generateUpdateBefore, boolean outputRankNumber)
AppendOnlyTopNFunction(StateTtlConfig ttlConfig, InternalTypeInfo<RowData> inputRowType, GeneratedRecordComparator sortKeyGeneratedRecordComparator, RowDataKeySelector sortKeySelector, RankType rankType, RankRange rankRange, boolean generateUpdateBefore, boolean outputRankNumber, long cacheSize)
FastTop1Function(StateTtlConfig ttlConfig, InternalTypeInfo<RowData> inputRowType, GeneratedRecordComparator generatedSortKeyComparator, RowDataKeySelector sortKeySelector, RankType rankType, RankRange rankRange, boolean generateUpdateBefore, boolean outputRankNumber, long cacheSize)
RetractableTopNFunction(StateTtlConfig ttlConfig, InternalTypeInfo<RowData> inputRowType, ComparableRecordComparator comparableRecordComparator, RowDataKeySelector sortKeySelector, RankType rankType, RankRange rankRange, GeneratedRecordEqualiser generatedEqualiser, boolean generateUpdateBefore, boolean outputRankNumber)
UpdatableTopNFunction(StateTtlConfig ttlConfig, InternalTypeInfo<RowData> inputRowType, RowDataKeySelector rowKeySelector, GeneratedRecordComparator generatedRecordComparator, RowDataKeySelector sortKeySelector, RankType rankType, RankRange rankRange, boolean generateUpdateBefore, boolean outputRankNumber, long cacheSize)
-
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.sort
Constructors in org.apache.flink.table.runtime.operators.sort with parameters of type InternalTypeInfo Constructor Description ProcTimeSortOperator(InternalTypeInfo<RowData> inputRowType, GeneratedRecordComparator gComparator)
RowTimeSortOperator(InternalTypeInfo<RowData> inputRowType, int rowTimeIdx, GeneratedRecordComparator gComparator)
StreamSortOperator(InternalTypeInfo<RowData> inputRowType, GeneratedRecordComparator gComparator)
-
Uses of InternalTypeInfo in org.apache.flink.table.runtime.operators.values
Methods in org.apache.flink.table.runtime.operators.values that return InternalTypeInfo Modifier and Type Method Description InternalTypeInfo<RowData>
ValuesInputFormat. getProducedType()
Constructors in org.apache.flink.table.runtime.operators.values with parameters of type InternalTypeInfo Constructor Description ValuesInputFormat(GeneratedInput<GenericInputFormat<RowData>> generatedInput, InternalTypeInfo<RowData> returnType)
-
Uses of InternalTypeInfo in org.apache.flink.table.runtime.typeutils
Methods in org.apache.flink.table.runtime.typeutils that return InternalTypeInfo Modifier and Type Method Description static <T> InternalTypeInfo<T>
InternalTypeInfo. of(LogicalType type)
Creates type information for aLogicalType
that is represented by internal data structures.static InternalTypeInfo<RowData>
InternalTypeInfo. of(RowType type)
Creates type information for aRowType
represented by internal data structures.static InternalTypeInfo<RowData>
InternalTypeInfo. ofFields(LogicalType... fieldTypes)
Creates type information forRowType
represented by internal data structures.static InternalTypeInfo<RowData>
InternalTypeInfo. ofFields(LogicalType[] fieldTypes, String[] fieldNames)
Creates type information forRowType
represented by internal data structures.
-