Uses of Interface
org.apache.flink.table.data.RowData
-
-
Uses of RowData in org.apache.flink.connector.base.table
Methods in org.apache.flink.connector.base.table that return types with arguments of type RowData Modifier and Type Method Description EncodingFormat<SerializationSchema<RowData>>
AsyncDynamicTableSinkFactory.AsyncDynamicSinkContext. getEncodingFormat()
-
Uses of RowData in org.apache.flink.connector.datagen.table
Methods in org.apache.flink.connector.datagen.table that return types with arguments of type RowData Modifier and Type Method Description DataGeneratorSource<RowData>
DataGenTableSource. createSource()
-
Uses of RowData in org.apache.flink.connector.datagen.table.types
Methods in org.apache.flink.connector.datagen.table.types that return RowData Modifier and Type Method Description RowData
RowDataGenerator. next()
-
Uses of RowData in org.apache.flink.connector.file.table
Classes in org.apache.flink.connector.file.table that implement RowData Modifier and Type Class Description class
EnrichedRowData
Methods in org.apache.flink.connector.file.table that return RowData Modifier and Type Method Description RowData
EnrichedRowData. getRow(int pos, int numFields)
RowData
RowDataPartitionComputer. projectColumnsToWrite(RowData in)
Methods in org.apache.flink.connector.file.table that return types with arguments of type RowData Modifier and Type Method Description BulkWriter<RowData>
FileSystemTableSink.ProjectionBulkFactory. create(FSDataOutputStream out)
TypeInformation<RowData>
DeserializationSchemaAdapter. getProducedType()
RecordAndPosition<RowData>
ColumnarRowIterator. next()
Methods in org.apache.flink.connector.file.table with parameters of type RowData Modifier and Type Method Description void
SerializationSchemaAdapter. encode(RowData element, OutputStream stream)
static EnrichedRowData
EnrichedRowData. from(RowData fixedRow, List<String> producedRowFields, List<String> mutableRowFields, List<String> fixedRowFields)
Creates a newEnrichedRowData
with the providedfixedRow
as the immutable static row, and uses theproducedRowFields
,fixedRowFields
andmutableRowFields
arguments to compute the indexes mapping.LinkedHashMap<String,String>
RowDataPartitionComputer. generatePartValues(RowData in)
String
FileSystemTableSink.TableBucketAssigner. getBucketId(RowData element, BucketAssigner.Context context)
RowData
RowDataPartitionComputer. projectColumnsToWrite(RowData in)
EnrichedRowData
EnrichedRowData. replaceMutableRow(RowData mutableRow)
Replaces the mutableRowData
backing thisEnrichedRowData
.boolean
FileSystemTableSink.TableRollingPolicy. shouldRollOnEvent(PartFileInfo<String> partFileState, RowData element)
Constructors in org.apache.flink.connector.file.table with parameters of type RowData Constructor Description EnrichedRowData(RowData fixedRow, int[] indexMapping)
Constructor parameters in org.apache.flink.connector.file.table with type arguments of type RowData Constructor Description DeserializationSchemaAdapter(DeserializationSchema<RowData> deserializationSchema)
FileSystemTableSource(ObjectIdentifier tableIdentifier, DataType physicalRowDataType, List<String> partitionKeys, ReadableConfig tableOptions, DecodingFormat<BulkFormat<RowData,FileSourceSplit>> bulkReaderFormat, DecodingFormat<DeserializationSchema<RowData>> deserializationFormat)
ProjectionBulkFactory(BulkWriter.Factory<RowData> factory, RowDataPartitionComputer computer)
SerializationSchemaAdapter(SerializationSchema<RowData> serializationSchema)
TableBucketAssigner(PartitionComputer<RowData> computer)
-
Uses of RowData in org.apache.flink.connector.file.table.batch
Method parameters in org.apache.flink.connector.file.table.batch with type arguments of type RowData Modifier and Type Method Description static DataStreamSink<Row>
BatchSink. createBatchNoCompactSink(DataStream<RowData> dataStream, DynamicTableSink.DataStructureConverter converter, FileSystemOutputFormat<Row> fileSystemOutputFormat, int parallelism, boolean parallelismConfigured)
-
Uses of RowData in org.apache.flink.connector.file.table.factories
Methods in org.apache.flink.connector.file.table.factories that return types with arguments of type RowData Modifier and Type Method Description BulkDecodingFormat<RowData>
BulkReaderFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
Creates aBulkDecodingFormat
from the given context and format options. -
Uses of RowData in org.apache.flink.connector.testframe.external.sink
Methods in org.apache.flink.connector.testframe.external.sink that return types with arguments of type RowData Modifier and Type Method Description ExternalSystemDataReader<RowData>
TableSinkExternalContext. createSinkRowDataReader(TestingSinkSettings sinkOptions, DataType dataType)
Create a new split in the external system and return a data writer corresponding to the new split. -
Uses of RowData in org.apache.flink.connector.testframe.external.source
Methods in org.apache.flink.connector.testframe.external.source that return types with arguments of type RowData Modifier and Type Method Description ExternalSystemSplitDataWriter<RowData>
TableSourceExternalContext. createSplitRowDataWriter(TestingSourceSettings sourceOptions, DataType dataType)
Create a new split in the external system and return a data writer for writingRowData
corresponding to the new split. -
Uses of RowData in org.apache.flink.connectors.hive
Methods in org.apache.flink.connectors.hive that return types with arguments of type RowData Modifier and Type Method Description HiveSource<RowData>
HiveSourceBuilder. buildWithDefaultBulkFormat()
Builds HiveSource with default built-in BulkFormat that returns records in type of RowData.protected BulkFormat<RowData,HiveSourceSplit>
HiveSourceBuilder. createDefaultBulkFormat()
protected DataStream<RowData>
HiveTableSource. getDataStream(ProviderContext providerContext, StreamExecutionEnvironment execEnv)
PartitionReader<P,RowData>
FileSystemLookupFunction. getPartitionReader()
TypeInformation<RowData>
FileSystemLookupFunction. getResultType()
Methods in org.apache.flink.connectors.hive with parameters of type RowData Modifier and Type Method Description LinkedHashMap<String,String>
HiveRowDataPartitionComputer. generatePartValues(RowData in)
Constructor parameters in org.apache.flink.connectors.hive with type arguments of type RowData Constructor Description FileSystemLookupFunction(PartitionFetcher<P> partitionFetcher, PartitionFetcher.Context<P> fetcherContext, PartitionReader<P,RowData> partitionReader, RowType rowType, int[] lookupKeys, Duration reloadInterval)
-
Uses of RowData in org.apache.flink.connectors.hive.read
Methods in org.apache.flink.connectors.hive.read that return RowData Modifier and Type Method Description RowData
HiveMapredSplitReader. nextRecord(RowData reuse)
RowData
HiveTableInputFormat. nextRecord(RowData reuse)
RowData
HiveVectorizedOrcSplitReader. nextRecord(RowData reuse)
RowData
HiveVectorizedParquetSplitReader. nextRecord(RowData reuse)
RowData
SplitReader. nextRecord(RowData reuse)
Reads the next record from the input.RowData
HiveInputFormatPartitionReader. read(RowData reuse)
Methods in org.apache.flink.connectors.hive.read that return types with arguments of type RowData Modifier and Type Method Description CompactReader<RowData>
HiveCompactReaderFactory. create(CompactContext context)
BulkFormat.Reader<RowData>
HiveInputFormat. createReader(Configuration config, HiveSourceSplit split)
TypeInformation<RowData>
HiveInputFormat. getProducedType()
BulkFormat.Reader<RowData>
HiveInputFormat. restoreReader(Configuration config, HiveSourceSplit split)
Methods in org.apache.flink.connectors.hive.read with parameters of type RowData Modifier and Type Method Description RowData
HiveMapredSplitReader. nextRecord(RowData reuse)
RowData
HiveTableInputFormat. nextRecord(RowData reuse)
RowData
HiveVectorizedOrcSplitReader. nextRecord(RowData reuse)
RowData
HiveVectorizedParquetSplitReader. nextRecord(RowData reuse)
RowData
SplitReader. nextRecord(RowData reuse)
Reads the next record from the input.RowData
HiveInputFormatPartitionReader. read(RowData reuse)
void
HiveVectorizedOrcSplitReader. seekToRow(long rowCount, RowData reuse)
void
HiveVectorizedParquetSplitReader. seekToRow(long rowCount, RowData reuse)
default void
SplitReader. seekToRow(long rowCount, RowData reuse)
Seek to a particular row number. -
Uses of RowData in org.apache.flink.connectors.hive.write
Methods in org.apache.flink.connectors.hive.write that return types with arguments of type RowData Modifier and Type Method Description HadoopPathBasedBulkWriter<RowData>
HiveBulkWriterFactory. create(org.apache.hadoop.fs.Path targetPath, org.apache.hadoop.fs.Path inProgressPath)
Function<RowData,org.apache.hadoop.io.Writable>
HiveWriterFactory. createRowDataConverter()
-
Uses of RowData in org.apache.flink.formats.avro
Methods in org.apache.flink.formats.avro that return RowData Modifier and Type Method Description RowData
AvroRowDataDeserializationSchema. deserialize(byte[] message)
Methods in org.apache.flink.formats.avro that return types with arguments of type RowData Modifier and Type Method Description BulkDecodingFormat<RowData>
AvroFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DecodingFormat<DeserializationSchema<RowData>>
AvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
AvroFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
AvroFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
TypeInformation<RowData>
AvroRowDataDeserializationSchema. getProducedType()
Methods in org.apache.flink.formats.avro with parameters of type RowData Modifier and Type Method Description boolean
AvroRowDataDeserializationSchema. isEndOfStream(RowData nextElement)
byte[]
AvroRowDataSerializationSchema. serialize(RowData row)
Constructor parameters in org.apache.flink.formats.avro with type arguments of type RowData Constructor Description AvroRowDataDeserializationSchema(DeserializationSchema<org.apache.avro.generic.GenericRecord> nestedSchema, AvroToRowDataConverters.AvroToRowDataConverter runtimeConverter, TypeInformation<RowData> typeInfo)
Creates a Avro deserialization schema for the given logical type.AvroRowDataDeserializationSchema(RowType rowType, TypeInformation<RowData> typeInfo)
Creates an Avro deserialization schema for the given logical type.AvroRowDataDeserializationSchema(RowType rowType, TypeInformation<RowData> typeInfo, AvroFormatOptions.AvroEncoding encoding)
Creates an Avro deserialization schema for the given logical type.AvroRowDataDeserializationSchema(RowType rowType, TypeInformation<RowData> typeInfo, AvroFormatOptions.AvroEncoding encoding, boolean legacyTimestampMapping)
Creates an Avro deserialization schema for the given logical type. -
Uses of RowData in org.apache.flink.formats.avro.registry.confluent
Methods in org.apache.flink.formats.avro.registry.confluent that return types with arguments of type RowData Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
RegistryAvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
RegistryAvroFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
-
Uses of RowData in org.apache.flink.formats.avro.registry.confluent.debezium
Methods in org.apache.flink.formats.avro.registry.confluent.debezium that return RowData Modifier and Type Method Description RowData
DebeziumAvroDeserializationSchema. deserialize(byte[] message)
Methods in org.apache.flink.formats.avro.registry.confluent.debezium that return types with arguments of type RowData Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
DebeziumAvroFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
DebeziumAvroFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
TypeInformation<RowData>
DebeziumAvroDeserializationSchema. getProducedType()
Methods in org.apache.flink.formats.avro.registry.confluent.debezium with parameters of type RowData Modifier and Type Method Description boolean
DebeziumAvroDeserializationSchema. isEndOfStream(RowData nextElement)
byte[]
DebeziumAvroSerializationSchema. serialize(RowData rowData)
Method parameters in org.apache.flink.formats.avro.registry.confluent.debezium with type arguments of type RowData Modifier and Type Method Description void
DebeziumAvroDeserializationSchema. deserialize(byte[] message, Collector<RowData> out)
Constructor parameters in org.apache.flink.formats.avro.registry.confluent.debezium with type arguments of type RowData Constructor Description DebeziumAvroDeserializationSchema(RowType rowType, TypeInformation<RowData> producedTypeInfo, String schemaRegistryUrl, String schemaString, Map<String,?> registryConfigs)
-
Uses of RowData in org.apache.flink.formats.csv
Methods in org.apache.flink.formats.csv that return RowData Modifier and Type Method Description RowData
CsvRowDataDeserializationSchema. deserialize(byte[] message)
Methods in org.apache.flink.formats.csv that return types with arguments of type RowData Modifier and Type Method Description static BulkWriter.Factory<RowData>
PythonCsvUtils. createCsvBulkWriterFactory(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.dataformat.csv.CsvSchema schema, DataType physicalDataType)
Util for creating aBulkWriter.Factory
that wrapsCsvBulkWriter.forSchema(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.dataformat.csv.CsvMapper, org.apache.flink.shaded.jackson2.com.fasterxml.jackson.dataformat.csv.CsvSchema, org.apache.flink.formats.common.Converter<T, R, C>, C, org.apache.flink.core.fs.FSDataOutputStream)
.BulkDecodingFormat<RowData>
CsvFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DecodingFormat<DeserializationSchema<RowData>>
CsvFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
CsvFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
CsvFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
BulkFormat<RowData,FileSourceSplit>
CsvFileFormatFactory.CsvBulkDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType physicalDataType, int[][] projections)
TypeInformation<RowData>
CsvRowDataDeserializationSchema. getProducedType()
Methods in org.apache.flink.formats.csv with parameters of type RowData Modifier and Type Method Description boolean
CsvRowDataDeserializationSchema. isEndOfStream(RowData nextElement)
byte[]
CsvRowDataSerializationSchema. serialize(RowData row)
Constructor parameters in org.apache.flink.formats.csv with type arguments of type RowData Constructor Description Builder(RowType rowType, TypeInformation<RowData> resultTypeInfo)
Creates a CSV deserialization schema for the givenTypeInformation
with optional parameters.Builder(RowType rowReadType, RowType rowResultType, TypeInformation<RowData> resultTypeInfo)
Creates a CSV deserialization schema for the givenTypeInformation
with optional parameters. -
Uses of RowData in org.apache.flink.formats.json
Methods in org.apache.flink.formats.json that return RowData Modifier and Type Method Description RowData
JsonRowDataDeserializationSchema. convertToRowData(org.apache.flink.shaded.jackson2.com.fasterxml.jackson.databind.JsonNode message)
RowData
JsonParserRowDataDeserializationSchema. deserialize(byte[] message)
RowData
JsonRowDataDeserializationSchema. deserialize(byte[] message)
Methods in org.apache.flink.formats.json that return types with arguments of type RowData Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
JsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
JsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
TypeInformation<RowData>
AbstractJsonDeserializationSchema. getProducedType()
Methods in org.apache.flink.formats.json with parameters of type RowData Modifier and Type Method Description boolean
AbstractJsonDeserializationSchema. isEndOfStream(RowData nextElement)
byte[]
JsonRowDataSerializationSchema. serialize(RowData row)
Constructor parameters in org.apache.flink.formats.json with type arguments of type RowData Constructor Description AbstractJsonDeserializationSchema(RowType rowType, TypeInformation<RowData> resultTypeInfo, boolean failOnMissingField, boolean ignoreParseErrors, TimestampFormat timestampFormat)
JsonParserRowDataDeserializationSchema(RowType rowType, TypeInformation<RowData> resultTypeInfo, boolean failOnMissingField, boolean ignoreParseErrors, TimestampFormat timestampFormat)
JsonParserRowDataDeserializationSchema(RowType rowType, TypeInformation<RowData> resultTypeInfo, boolean failOnMissingField, boolean ignoreParseErrors, TimestampFormat timestampFormat, String[][] projectedFields)
JsonRowDataDeserializationSchema(RowType rowType, TypeInformation<RowData> resultTypeInfo, boolean failOnMissingField, boolean ignoreParseErrors, TimestampFormat timestampFormat)
-
Uses of RowData in org.apache.flink.formats.json.canal
Methods in org.apache.flink.formats.json.canal that return RowData Modifier and Type Method Description RowData
CanalJsonDeserializationSchema. deserialize(byte[] message)
Methods in org.apache.flink.formats.json.canal that return types with arguments of type RowData Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
CanalJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
CanalJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DeserializationSchema<RowData>
CanalJsonDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType physicalDataType, int[][] projections)
TypeInformation<RowData>
CanalJsonDeserializationSchema. getProducedType()
Methods in org.apache.flink.formats.json.canal with parameters of type RowData Modifier and Type Method Description boolean
CanalJsonDeserializationSchema. isEndOfStream(RowData nextElement)
byte[]
CanalJsonSerializationSchema. serialize(RowData row)
Method parameters in org.apache.flink.formats.json.canal with type arguments of type RowData Modifier and Type Method Description static CanalJsonDeserializationSchema.Builder
CanalJsonDeserializationSchema. builder(DataType physicalDataType, List<org.apache.flink.formats.json.canal.CanalJsonDecodingFormat.ReadableMetadata> requestedMetadata, TypeInformation<RowData> producedTypeInfo)
Creates A builder for building aCanalJsonDeserializationSchema
.void
CanalJsonDeserializationSchema. deserialize(byte[] message, Collector<RowData> out)
-
Uses of RowData in org.apache.flink.formats.json.debezium
Methods in org.apache.flink.formats.json.debezium that return RowData Modifier and Type Method Description RowData
DebeziumJsonDeserializationSchema. deserialize(byte[] message)
Methods in org.apache.flink.formats.json.debezium that return types with arguments of type RowData Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
DebeziumJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
DebeziumJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DeserializationSchema<RowData>
DebeziumJsonDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType physicalDataType, int[][] projections)
TypeInformation<RowData>
DebeziumJsonDeserializationSchema. getProducedType()
Methods in org.apache.flink.formats.json.debezium with parameters of type RowData Modifier and Type Method Description boolean
DebeziumJsonDeserializationSchema. isEndOfStream(RowData nextElement)
byte[]
DebeziumJsonSerializationSchema. serialize(RowData rowData)
Method parameters in org.apache.flink.formats.json.debezium with type arguments of type RowData Modifier and Type Method Description void
DebeziumJsonDeserializationSchema. deserialize(byte[] message, Collector<RowData> out)
Constructor parameters in org.apache.flink.formats.json.debezium with type arguments of type RowData Constructor Description DebeziumJsonDeserializationSchema(DataType physicalDataType, List<org.apache.flink.formats.json.debezium.DebeziumJsonDecodingFormat.ReadableMetadata> requestedMetadata, TypeInformation<RowData> producedTypeInfo, boolean schemaInclude, boolean ignoreParseErrors, TimestampFormat timestampFormat)
-
Uses of RowData in org.apache.flink.formats.json.maxwell
Methods in org.apache.flink.formats.json.maxwell that return RowData Modifier and Type Method Description RowData
MaxwellJsonDeserializationSchema. deserialize(byte[] message)
Methods in org.apache.flink.formats.json.maxwell that return types with arguments of type RowData Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
MaxwellJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
MaxwellJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DeserializationSchema<RowData>
MaxwellJsonDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType physicalDataType, int[][] projections)
TypeInformation<RowData>
MaxwellJsonDeserializationSchema. getProducedType()
Methods in org.apache.flink.formats.json.maxwell with parameters of type RowData Modifier and Type Method Description boolean
MaxwellJsonDeserializationSchema. isEndOfStream(RowData nextElement)
byte[]
MaxwellJsonSerializationSchema. serialize(RowData element)
Method parameters in org.apache.flink.formats.json.maxwell with type arguments of type RowData Modifier and Type Method Description void
MaxwellJsonDeserializationSchema. deserialize(byte[] message, Collector<RowData> out)
Constructor parameters in org.apache.flink.formats.json.maxwell with type arguments of type RowData Constructor Description MaxwellJsonDeserializationSchema(DataType physicalDataType, List<org.apache.flink.formats.json.maxwell.MaxwellJsonDecodingFormat.ReadableMetadata> requestedMetadata, TypeInformation<RowData> producedTypeInfo, boolean ignoreParseErrors, TimestampFormat timestampFormat)
-
Uses of RowData in org.apache.flink.formats.json.ogg
Methods in org.apache.flink.formats.json.ogg that return RowData Modifier and Type Method Description RowData
OggJsonDeserializationSchema. deserialize(byte[] message)
Methods in org.apache.flink.formats.json.ogg that return types with arguments of type RowData Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
OggJsonFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
OggJsonFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DeserializationSchema<RowData>
OggJsonDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType physicalDataType)
TypeInformation<RowData>
OggJsonDeserializationSchema. getProducedType()
Methods in org.apache.flink.formats.json.ogg with parameters of type RowData Modifier and Type Method Description boolean
OggJsonDeserializationSchema. isEndOfStream(RowData nextElement)
byte[]
OggJsonSerializationSchema. serialize(RowData rowData)
Method parameters in org.apache.flink.formats.json.ogg with type arguments of type RowData Modifier and Type Method Description void
OggJsonDeserializationSchema. deserialize(byte[] message, Collector<RowData> out)
Constructor parameters in org.apache.flink.formats.json.ogg with type arguments of type RowData Constructor Description OggJsonDeserializationSchema(DataType physicalDataType, List<org.apache.flink.formats.json.ogg.OggJsonDecodingFormat.ReadableMetadata> requestedMetadata, TypeInformation<RowData> producedTypeInfo, boolean ignoreParseErrors, TimestampFormat timestampFormat)
-
Uses of RowData in org.apache.flink.formats.parquet
Methods in org.apache.flink.formats.parquet that return types with arguments of type RowData Modifier and Type Method Description BulkDecodingFormat<RowData>
ParquetFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
ParquetFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
protected ParquetVectorizedInputFormat.ParquetReaderBatch<RowData>
ParquetColumnarRowInputFormat. createReaderBatch(WritableColumnVector[] writableVectors, VectorizedColumnBatch columnarBatch, Pool.Recycler<ParquetVectorizedInputFormat.ParquetReaderBatch<RowData>> recycler)
BulkFormat<RowData,FileSourceSplit>
ParquetFileFormatFactory.ParquetBulkDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context sourceContext, DataType producedDataType, int[][] projections)
TypeInformation<RowData>
ParquetColumnarRowInputFormat. getProducedType()
Method parameters in org.apache.flink.formats.parquet with type arguments of type RowData Modifier and Type Method Description static <SplitT extends FileSourceSplit>
ParquetColumnarRowInputFormat<SplitT>ParquetColumnarRowInputFormat. createPartitionedFormat(org.apache.hadoop.conf.Configuration hadoopConfig, RowType producedRowType, TypeInformation<RowData> producedTypeInfo, List<String> partitionKeys, PartitionFieldExtractor<SplitT> extractor, int batchSize, boolean isUtcTimestamp, boolean isCaseSensitive)
Create a partitionedParquetColumnarRowInputFormat
, the partition columns can be generated byPath
.protected ParquetVectorizedInputFormat.ParquetReaderBatch<RowData>
ParquetColumnarRowInputFormat. createReaderBatch(WritableColumnVector[] writableVectors, VectorizedColumnBatch columnarBatch, Pool.Recycler<ParquetVectorizedInputFormat.ParquetReaderBatch<RowData>> recycler)
Constructor parameters in org.apache.flink.formats.parquet with type arguments of type RowData Constructor Description ParquetColumnarRowInputFormat(org.apache.hadoop.conf.Configuration hadoopConfig, RowType projectedType, TypeInformation<RowData> producedTypeInfo, int batchSize, boolean isUtcTimestamp, boolean isCaseSensitive)
Constructor to create parquet format without extra fields. -
Uses of RowData in org.apache.flink.formats.parquet.row
Methods in org.apache.flink.formats.parquet.row that return types with arguments of type RowData Modifier and Type Method Description org.apache.parquet.hadoop.ParquetWriter<RowData>
ParquetRowDataBuilder.FlinkParquetBuilder. createWriter(org.apache.parquet.io.OutputFile out)
static ParquetWriterFactory<RowData>
ParquetRowDataBuilder. createWriterFactory(RowType rowType, org.apache.hadoop.conf.Configuration conf, boolean utcTimestamp)
Create a parquetBulkWriter.Factory
.protected org.apache.parquet.hadoop.api.WriteSupport<RowData>
ParquetRowDataBuilder. getWriteSupport(org.apache.hadoop.conf.Configuration conf)
Methods in org.apache.flink.formats.parquet.row with parameters of type RowData Modifier and Type Method Description void
ParquetRowDataWriter. write(RowData record)
It writes a record to Parquet. -
Uses of RowData in org.apache.flink.formats.protobuf
Methods in org.apache.flink.formats.protobuf that return types with arguments of type RowData Modifier and Type Method Description BulkDecodingFormat<RowData>
PbFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DecodingFormat<DeserializationSchema<RowData>>
PbFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
PbFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
PbFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
DeserializationSchema<RowData>
PbDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType producedDataType)
SerializationSchema<RowData>
PbEncodingFormat. createRuntimeEncoder(DynamicTableSink.Context context, DataType consumedDataType)
-
Uses of RowData in org.apache.flink.formats.protobuf.deserialize
Methods in org.apache.flink.formats.protobuf.deserialize that return RowData Modifier and Type Method Description RowData
ProtoToRowConverter. convertProtoBinaryToRow(byte[] data)
RowData
PbRowDataDeserializationSchema. deserialize(byte[] message)
Methods in org.apache.flink.formats.protobuf.deserialize that return types with arguments of type RowData Modifier and Type Method Description TypeInformation<RowData>
PbRowDataDeserializationSchema. getProducedType()
Methods in org.apache.flink.formats.protobuf.deserialize with parameters of type RowData Modifier and Type Method Description boolean
PbRowDataDeserializationSchema. isEndOfStream(RowData nextElement)
Constructor parameters in org.apache.flink.formats.protobuf.deserialize with type arguments of type RowData Constructor Description PbRowDataDeserializationSchema(RowType rowType, TypeInformation<RowData> resultTypeInfo, PbFormatConfig formatConfig)
-
Uses of RowData in org.apache.flink.formats.protobuf.serialize
Methods in org.apache.flink.formats.protobuf.serialize with parameters of type RowData Modifier and Type Method Description byte[]
RowToProtoConverter. convertRowToProtoBinary(RowData rowData)
byte[]
PbRowDataSerializationSchema. serialize(RowData element)
-
Uses of RowData in org.apache.flink.formats.raw
Methods in org.apache.flink.formats.raw that return RowData Modifier and Type Method Description RowData
RawFormatDeserializationSchema. deserialize(byte[] message)
Methods in org.apache.flink.formats.raw that return types with arguments of type RowData Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
RawFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<SerializationSchema<RowData>>
RawFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
TypeInformation<RowData>
RawFormatDeserializationSchema. getProducedType()
Methods in org.apache.flink.formats.raw with parameters of type RowData Modifier and Type Method Description boolean
RawFormatDeserializationSchema. isEndOfStream(RowData nextElement)
byte[]
RawFormatSerializationSchema. serialize(RowData row)
Constructor parameters in org.apache.flink.formats.raw with type arguments of type RowData Constructor Description RawFormatDeserializationSchema(LogicalType deserializedType, TypeInformation<RowData> producedTypeInfo, String charsetName, boolean isBigEndian)
-
Uses of RowData in org.apache.flink.legacy.table.connector.source
Methods in org.apache.flink.legacy.table.connector.source that return types with arguments of type RowData Modifier and Type Method Description SourceFunction<RowData>
SourceFunctionProvider. createSourceFunction()
Deprecated.Creates aSourceFunction
instance.Method parameters in org.apache.flink.legacy.table.connector.source with type arguments of type RowData Modifier and Type Method Description static SourceFunctionProvider
SourceFunctionProvider. of(SourceFunction<RowData> sourceFunction, boolean isBounded)
Deprecated.Helper method for creating a static provider.static SourceFunctionProvider
SourceFunctionProvider. of(SourceFunction<RowData> sourceFunction, boolean isBounded, Integer sourceParallelism)
Deprecated.Helper method for creating a Source provider with a provided source parallelism. -
Uses of RowData in org.apache.flink.orc
Methods in org.apache.flink.orc that return RowData Modifier and Type Method Description RowData
OrcColumnarRowSplitReader. nextRecord(RowData reuse)
Methods in org.apache.flink.orc that return types with arguments of type RowData Modifier and Type Method Description BulkDecodingFormat<RowData>
OrcFileFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
EncodingFormat<BulkWriter.Factory<RowData>>
OrcFileFormatFactory. createEncodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
AbstractOrcFileInputFormat.OrcReaderBatch<RowData,BatchT>
OrcColumnarRowInputFormat. createReaderBatch(SplitT split, OrcVectorizedBatchWrapper<BatchT> orcBatch, Pool.Recycler<AbstractOrcFileInputFormat.OrcReaderBatch<RowData,BatchT>> recycler, int batchSize)
BulkFormat<RowData,FileSourceSplit>
OrcFileFormatFactory.OrcBulkDecodingFormat. createRuntimeDecoder(DynamicTableSource.Context sourceContext, DataType producedDataType, int[][] projections)
TypeInformation<RowData>
OrcColumnarRowInputFormat. getProducedType()
Methods in org.apache.flink.orc with parameters of type RowData Modifier and Type Method Description RowData
OrcColumnarRowSplitReader. nextRecord(RowData reuse)
Method parameters in org.apache.flink.orc with type arguments of type RowData Modifier and Type Method Description static <SplitT extends FileSourceSplit>
OrcColumnarRowInputFormat<org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch,SplitT>OrcColumnarRowInputFormat. createPartitionedFormat(OrcShim<org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch> shim, org.apache.hadoop.conf.Configuration hadoopConfig, RowType tableType, List<String> partitionKeys, PartitionFieldExtractor<SplitT> extractor, int[] selectedFields, List<OrcFilters.Predicate> conjunctPredicates, int batchSize, Function<RowType,TypeInformation<RowData>> rowTypeInfoFactory)
Create a partitionedOrcColumnarRowInputFormat
, the partition columns can be generated by split.AbstractOrcFileInputFormat.OrcReaderBatch<RowData,BatchT>
OrcColumnarRowInputFormat. createReaderBatch(SplitT split, OrcVectorizedBatchWrapper<BatchT> orcBatch, Pool.Recycler<AbstractOrcFileInputFormat.OrcReaderBatch<RowData,BatchT>> recycler, int batchSize)
Constructor parameters in org.apache.flink.orc with type arguments of type RowData Constructor Description OrcColumnarRowInputFormat(OrcShim<BatchT> shim, org.apache.hadoop.conf.Configuration hadoopConfig, org.apache.orc.TypeDescription schema, int[] selectedFields, List<OrcFilters.Predicate> conjunctPredicates, int batchSize, ColumnBatchFactory<BatchT,SplitT> batchFactory, TypeInformation<RowData> producedTypeInfo)
-
Uses of RowData in org.apache.flink.orc.nohive
Methods in org.apache.flink.orc.nohive that return types with arguments of type RowData Modifier and Type Method Description BulkWriter<RowData>
OrcNoHiveBulkWriterFactory. create(FSDataOutputStream out)
Method parameters in org.apache.flink.orc.nohive with type arguments of type RowData Modifier and Type Method Description static <SplitT extends FileSourceSplit>
OrcColumnarRowInputFormat<?,SplitT>OrcNoHiveColumnarRowInputFormat. createPartitionedFormat(org.apache.hadoop.conf.Configuration hadoopConfig, RowType tableType, List<String> partitionKeys, PartitionFieldExtractor<SplitT> extractor, int[] selectedFields, List<OrcFilters.Predicate> conjunctPredicates, int batchSize, Function<RowType,TypeInformation<RowData>> rowTypeInfoFactory)
Create a partitionedOrcColumnarRowInputFormat
, the partition columns can be generated by split. -
Uses of RowData in org.apache.flink.orc.vector
Methods in org.apache.flink.orc.vector with parameters of type RowData Modifier and Type Method Description void
RowDataVectorizer. vectorize(RowData row, org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch batch)
-
Uses of RowData in org.apache.flink.python.util
Method parameters in org.apache.flink.python.util with type arguments of type RowData Modifier and Type Method Description void
PythonConnectorUtils.RowRowMapper. processElement(Row row, ProcessFunction.Context ctx, Collector<RowData> out)
-
Uses of RowData in org.apache.flink.streaming.api.utils
Methods in org.apache.flink.streaming.api.utils that return RowData Modifier and Type Method Description RowData
PythonTypeUtils.RowDataDataConverter. toInternal(Object[] value)
Methods in org.apache.flink.streaming.api.utils with parameters of type RowData Modifier and Type Method Description Object[]
PythonTypeUtils.RowDataDataConverter. toExternal(RowData value)
-
Uses of RowData in org.apache.flink.table.api.internal
Methods in org.apache.flink.table.api.internal that return types with arguments of type RowData Modifier and Type Method Description CloseableIterator<RowData>
TableResultImpl. collectInternal()
CloseableIterator<RowData>
TableResultInternal. collectInternal()
Returns an iterator that returns the iterator with the internal row data type.CloseableIterator<RowData>
ResultProvider. toInternalIterator()
Returns the select result as row iterator using internal data types.CloseableIterator<RowData>
StaticResultProvider. toInternalIterator()
Constructor parameters in org.apache.flink.table.api.internal with type arguments of type RowData Constructor Description StaticResultProvider(List<Row> rows, Function<Row,RowData> externalToInternalConverter)
-
Uses of RowData in org.apache.flink.table.catalog.hive.client
Methods in org.apache.flink.table.catalog.hive.client that return types with arguments of type RowData Modifier and Type Method Description BulkWriter.Factory<RowData>
HiveShim. createOrcBulkWriterFactory(org.apache.hadoop.conf.Configuration conf, String schema, LogicalType[] fieldTypes)
Create orcBulkWriter.Factory
for different hive versions.BulkWriter.Factory<RowData>
HiveShimV100. createOrcBulkWriterFactory(org.apache.hadoop.conf.Configuration conf, String schema, LogicalType[] fieldTypes)
BulkWriter.Factory<RowData>
HiveShimV200. createOrcBulkWriterFactory(org.apache.hadoop.conf.Configuration conf, String schema, LogicalType[] fieldTypes)
-
Uses of RowData in org.apache.flink.table.client.gateway
Methods in org.apache.flink.table.client.gateway that return RowData Modifier and Type Method Description RowData
StatementResult. next()
Constructor parameters in org.apache.flink.table.client.gateway with type arguments of type RowData Constructor Description StatementResult(ResolvedSchema resultSchema, CloseableIterator<RowData> resultProvider, boolean isQueryResult, ResultKind resultKind, JobID jobID)
StatementResult(ResolvedSchema resultSchema, CloseableIterator<RowData> resultProvider, boolean isQueryResult, ResultKind resultKind, JobID jobID, RowDataToStringConverter toStringConverter)
-
Uses of RowData in org.apache.flink.table.client.gateway.result
Fields in org.apache.flink.table.client.gateway.result with type parameters of type RowData Modifier and Type Field Description protected List<RowData>
MaterializedCollectResultBase. materializedTable
Materialized table that is continuously updated by inserts and deletes.Methods in org.apache.flink.table.client.gateway.result that return types with arguments of type RowData Modifier and Type Method Description protected List<RowData>
MaterializedCollectResultBase. getMaterializedTable()
TypedResult<List<RowData>>
ChangelogCollectResult. retrieveChanges()
TypedResult<List<RowData>>
ChangelogResult. retrieveChanges()
Retrieves the available result records.List<RowData>
MaterializedCollectResultBase. retrievePage(int page)
List<RowData>
MaterializedResult. retrievePage(int page)
Retrieves a page of a snapshotted result.Methods in org.apache.flink.table.client.gateway.result with parameters of type RowData Modifier and Type Method Description protected void
ChangelogCollectResult. processRecord(RowData row)
protected abstract void
CollectResultBase. processRecord(RowData row)
protected void
MaterializedCollectBatchResult. processRecord(RowData row)
protected void
MaterializedCollectStreamResult. processRecord(RowData row)
-
Uses of RowData in org.apache.flink.table.connector.sink
Methods in org.apache.flink.table.connector.sink that return types with arguments of type RowData Modifier and Type Method Description OutputFormat<RowData>
OutputFormatProvider. createOutputFormat()
Creates anOutputFormat
instance.Sink<RowData>
SinkV2Provider. createSink()
Method parameters in org.apache.flink.table.connector.sink with type arguments of type RowData Modifier and Type Method Description default DataStreamSink<?>
DataStreamSinkProvider. consumeDataStream(DataStream<RowData> dataStream)
Deprecated.UseDataStreamSinkProvider.consumeDataStream(ProviderContext, DataStream)
and correctly set a unique identifier for each data stream transformation.default DataStreamSink<?>
DataStreamSinkProvider. consumeDataStream(ProviderContext providerContext, DataStream<RowData> dataStream)
Consumes the given JavaDataStream
and returns the sink transformationDataStreamSink
.static OutputFormatProvider
OutputFormatProvider. of(OutputFormat<RowData> outputFormat)
Helper method for creating a static provider.static OutputFormatProvider
OutputFormatProvider. of(OutputFormat<RowData> outputFormat, Integer sinkParallelism)
Helper method for creating a static provider with a provided sink parallelism.static SinkV2Provider
SinkV2Provider. of(Sink<RowData> sink)
Helper method for creating a static provider.static SinkV2Provider
SinkV2Provider. of(Sink<RowData> sink, Integer sinkParallelism)
Helper method for creating a Sink provider with a provided sink parallelism. -
Uses of RowData in org.apache.flink.table.connector.sink.legacy
Methods in org.apache.flink.table.connector.sink.legacy that return types with arguments of type RowData Modifier and Type Method Description SinkFunction<RowData>
SinkFunctionProvider. createSinkFunction()
Deprecated.Creates aSinkFunction
instance.Method parameters in org.apache.flink.table.connector.sink.legacy with type arguments of type RowData Modifier and Type Method Description static SinkFunctionProvider
SinkFunctionProvider. of(SinkFunction<RowData> sinkFunction)
Deprecated.Helper method for creating a static provider.static SinkFunctionProvider
SinkFunctionProvider. of(SinkFunction<RowData> sinkFunction, Integer sinkParallelism)
Deprecated.Helper method for creating a SinkFunction provider with a provided sink parallelism. -
Uses of RowData in org.apache.flink.table.connector.source
Methods in org.apache.flink.table.connector.source that return types with arguments of type RowData Modifier and Type Method Description InputFormat<RowData,?>
InputFormatProvider. createInputFormat()
Creates anInputFormat
instance.Source<RowData,?,?>
SourceProvider. createSource()
Creates aSource
instance.Collection<RowData>
DynamicFilteringData. getData()
default DataStream<RowData>
DataStreamScanProvider. produceDataStream(StreamExecutionEnvironment execEnv)
Deprecated.default DataStream<RowData>
DataStreamScanProvider. produceDataStream(ProviderContext providerContext, StreamExecutionEnvironment execEnv)
Creates a scan JavaDataStream
from aStreamExecutionEnvironment
.Methods in org.apache.flink.table.connector.source with parameters of type RowData Modifier and Type Method Description boolean
DynamicFilteringData. contains(RowData row)
Returns true if the dynamic filtering data contains the specific row.Method parameters in org.apache.flink.table.connector.source with type arguments of type RowData Modifier and Type Method Description static InputFormatProvider
InputFormatProvider. of(InputFormat<RowData,?> inputFormat)
Helper method for creating a static provider.static InputFormatProvider
InputFormatProvider. of(InputFormat<RowData,?> inputFormat, Integer sourceParallelism)
Helper method for creating a static provider with a provided source parallelism.static SourceProvider
SourceProvider. of(Source<RowData,?,?> source)
Helper method for creating a static provider.static SourceProvider
SourceProvider. of(Source<RowData,?,?> source, Integer sourceParallelism)
Helper method for creating a Source provider with a provided source parallelism.Constructor parameters in org.apache.flink.table.connector.source with type arguments of type RowData Constructor Description DynamicFilteringData(TypeInformation<RowData> typeInfo, RowType rowType, List<byte[]> serializedData, boolean isFiltering)
-
Uses of RowData in org.apache.flink.table.connector.source.abilities
Method parameters in org.apache.flink.table.connector.source.abilities with type arguments of type RowData Modifier and Type Method Description void
SupportsWatermarkPushDown. applyWatermark(WatermarkStrategy<RowData> watermarkStrategy)
Provides aWatermarkStrategy
which defines how to generateWatermark
s in the stream source. -
Uses of RowData in org.apache.flink.table.connector.source.lookup.cache
Methods in org.apache.flink.table.connector.source.lookup.cache that return types with arguments of type RowData Modifier and Type Method Description Collection<RowData>
DefaultLookupCache. getIfPresent(RowData key)
Collection<RowData>
LookupCache. getIfPresent(RowData key)
Returns the value associated with key in this cache, or null if there is no cached value for key.Collection<RowData>
DefaultLookupCache. put(RowData key, Collection<RowData> value)
Collection<RowData>
LookupCache. put(RowData key, Collection<RowData> value)
Associates the specified value rows with the specified key row in the cache.Methods in org.apache.flink.table.connector.source.lookup.cache with parameters of type RowData Modifier and Type Method Description Collection<RowData>
DefaultLookupCache. getIfPresent(RowData key)
Collection<RowData>
LookupCache. getIfPresent(RowData key)
Returns the value associated with key in this cache, or null if there is no cached value for key.void
DefaultLookupCache. invalidate(RowData key)
void
LookupCache. invalidate(RowData key)
Discards any cached value for the specified key.Collection<RowData>
DefaultLookupCache. put(RowData key, Collection<RowData> value)
Collection<RowData>
LookupCache. put(RowData key, Collection<RowData> value)
Associates the specified value rows with the specified key row in the cache.Method parameters in org.apache.flink.table.connector.source.lookup.cache with type arguments of type RowData Modifier and Type Method Description Collection<RowData>
DefaultLookupCache. put(RowData key, Collection<RowData> value)
Collection<RowData>
LookupCache. put(RowData key, Collection<RowData> value)
Associates the specified value rows with the specified key row in the cache. -
Uses of RowData in org.apache.flink.table.data
Classes in org.apache.flink.table.data that implement RowData Modifier and Type Class Description class
BoxedWrapperRowData
An implementation ofRowData
which also is also backed by an array of JavaObject
, just similar toGenericRowData
.class
GenericRowData
An internal data structure representing data ofRowType
and other (possibly nested) structured types such asStructuredType
.class
UpdatableRowData
Methods in org.apache.flink.table.data that return RowData Modifier and Type Method Description RowData
ArrayData. getRow(int pos, int numFields)
Returns the row value at the given position.RowData
BoxedWrapperRowData. getRow(int pos, int numFields)
RowData
GenericArrayData. getRow(int pos, int numFields)
RowData
GenericRowData. getRow(int pos, int numFields)
RowData
RowData. getRow(int pos, int numFields)
Returns the row value at the given position.RowData
UpdatableRowData. getRow()
RowData
UpdatableRowData. getRow(int pos, int numFields)
Methods in org.apache.flink.table.data with parameters of type RowData Modifier and Type Method Description Object
RowData.FieldGetter. getFieldOrNull(RowData row)
Constructors in org.apache.flink.table.data with parameters of type RowData Constructor Description UpdatableRowData(RowData row, int arity)
-
Uses of RowData in org.apache.flink.table.data.binary
Classes in org.apache.flink.table.data.binary that implement RowData Modifier and Type Class Description class
BinaryRowData
An implementation ofRowData
which is backed byMemorySegment
instead of Object.class
NestedRowData
Its memory storage structure is exactly the same withBinaryRowData
.Methods in org.apache.flink.table.data.binary that return RowData Modifier and Type Method Description RowData
BinaryArrayData. getRow(int pos, int numFields)
RowData
BinaryRowData. getRow(int pos, int numFields)
RowData
NestedRowData. getRow(int pos, int numFields)
static RowData
BinarySegmentUtils. readRowData(MemorySegment[] segments, int numFields, int baseOffset, long offsetAndSize)
Gets an instance ofRowData
from underlyingMemorySegment
.Methods in org.apache.flink.table.data.binary with parameters of type RowData Modifier and Type Method Description NestedRowData
NestedRowData. copy(RowData reuse)
-
Uses of RowData in org.apache.flink.table.data.columnar
Classes in org.apache.flink.table.data.columnar that implement RowData Modifier and Type Class Description class
ColumnarRowData
Columnar row to support access to vector column data.Methods in org.apache.flink.table.data.columnar that return RowData Modifier and Type Method Description RowData
ColumnarArrayData. getRow(int pos, int numFields)
RowData
ColumnarRowData. getRow(int pos, int numFields)
-
Uses of RowData in org.apache.flink.table.data.columnar.vector
Methods in org.apache.flink.table.data.columnar.vector that return RowData Modifier and Type Method Description RowData
VectorizedColumnBatch. getRow(int rowId, int colId)
-
Uses of RowData in org.apache.flink.table.data.conversion
Methods in org.apache.flink.table.data.conversion that return RowData Modifier and Type Method Description RowData
RowRowConverter. toInternal(Row external)
RowData
StructuredObjectConverter. toInternal(T external)
Methods in org.apache.flink.table.data.conversion with parameters of type RowData Modifier and Type Method Description Row
RowRowConverter. toExternal(RowData internal)
T
StructuredObjectConverter. toExternal(RowData internal)
-
Uses of RowData in org.apache.flink.table.data.util
Methods in org.apache.flink.table.data.util with parameters of type RowData Modifier and Type Method Description static boolean
RowDataUtil. isAccumulateMsg(RowData row)
Returns true if the message is eitherRowKind.INSERT
orRowKind.UPDATE_AFTER
, which refers to an accumulate operation of aggregation.static boolean
RowDataUtil. isRetractMsg(RowData row)
Returns true if the message is eitherRowKind.DELETE
orRowKind.UPDATE_BEFORE
, which refers to a retract operation of aggregation.External
DataFormatConverters.DataFormatConverter. toExternal(RowData row, int column)
Given a internalType row, convert the value at column `column` to its external(Java) equivalent. -
Uses of RowData in org.apache.flink.table.data.utils
Classes in org.apache.flink.table.data.utils that implement RowData Modifier and Type Class Description class
JoinedRowData
class
ProjectedRowData
Methods in org.apache.flink.table.data.utils that return RowData Modifier and Type Method Description RowData
JoinedRowData. getRow(int pos, int numFields)
RowData
ProjectedRowData. getRow(int pos, int numFields)
Methods in org.apache.flink.table.data.utils with parameters of type RowData Modifier and Type Method Description JoinedRowData
JoinedRowData. replace(RowData row1, RowData row2)
Replaces theRowData
backing thisJoinedRowData
.ProjectedRowData
ProjectedRowData. replaceRow(RowData row)
Replaces the underlyingRowData
backing thisProjectedRowData
.Constructors in org.apache.flink.table.data.utils with parameters of type RowData Constructor Description JoinedRowData(RowData row1, RowData row2)
Creates a newJoinedRowData
of kindRowKind.INSERT
backed by {@param row1} and {@param row2}.JoinedRowData(RowKind rowKind, RowData row1, RowData row2)
Creates a newJoinedRowData
of kind {@param rowKind} backed by {@param row1} and {@param row2}. -
Uses of RowData in org.apache.flink.table.data.writer
Methods in org.apache.flink.table.data.writer with parameters of type RowData Modifier and Type Method Description void
BinaryWriter. writeRow(int pos, RowData value, RowDataSerializer serializer)
-
Uses of RowData in org.apache.flink.table.endpoint.hive.util
Method parameters in org.apache.flink.table.endpoint.hive.util with type arguments of type RowData Modifier and Type Method Description static org.apache.hive.service.rpc.thrift.TRowSet
ThriftObjectConversions. toTRowSet(org.apache.hive.service.rpc.thrift.TProtocolVersion version, ResolvedSchema schema, List<RowData> data)
Similar toSerDeUtils.toThriftPayload(Object, ObjectInspector, int)
that converts the returned Rows to JSON string. -
Uses of RowData in org.apache.flink.table.examples.java.connectors
Methods in org.apache.flink.table.examples.java.connectors that return RowData Modifier and Type Method Description RowData
ChangelogCsvDeserializer. deserialize(byte[] message)
Methods in org.apache.flink.table.examples.java.connectors that return types with arguments of type RowData Modifier and Type Method Description DecodingFormat<DeserializationSchema<RowData>>
ChangelogCsvFormatFactory. createDecodingFormat(DynamicTableFactory.Context context, ReadableConfig formatOptions)
SourceReader<RowData,SocketSource.DummySplit>
SocketSource. createReader(SourceReaderContext readerContext)
DeserializationSchema<RowData>
ChangelogCsvFormat. createRuntimeDecoder(DynamicTableSource.Context context, DataType producedDataType)
TypeInformation<RowData>
ChangelogCsvDeserializer. getProducedType()
TypeInformation<RowData>
SocketSource. getProducedType()
Methods in org.apache.flink.table.examples.java.connectors with parameters of type RowData Modifier and Type Method Description boolean
ChangelogCsvDeserializer. isEndOfStream(RowData nextElement)
Constructor parameters in org.apache.flink.table.examples.java.connectors with type arguments of type RowData Constructor Description ChangelogCsvDeserializer(List<LogicalType> parsingTypes, DynamicTableSource.DataStructureConverter converter, TypeInformation<RowData> producedTypeInfo, String columnDelimiter)
SocketDynamicTableSource(String hostname, int port, byte byteDelimiter, DecodingFormat<DeserializationSchema<RowData>> decodingFormat, DataType producedDataType)
SocketSource(String hostname, int port, byte byteDelimiter, DeserializationSchema<RowData> deserializer)
-
Uses of RowData in org.apache.flink.table.examples.java.functions
Methods in org.apache.flink.table.examples.java.functions that return RowData Modifier and Type Method Description RowData
InternalRowMergerFunction. eval(RowData r1, RowData r2)
Methods in org.apache.flink.table.examples.java.functions with parameters of type RowData Modifier and Type Method Description RowData
InternalRowMergerFunction. eval(RowData r1, RowData r2)
-
Uses of RowData in org.apache.flink.table.functions
Methods in org.apache.flink.table.functions that return types with arguments of type RowData Modifier and Type Method Description abstract CompletableFuture<Collection<RowData>>
AsyncLookupFunction. asyncLookup(RowData keyRow)
Asynchronously lookup rows matching the lookup keys.abstract Collection<RowData>
LookupFunction. lookup(RowData keyRow)
Synchronously lookup rows matching the lookup keys.Methods in org.apache.flink.table.functions with parameters of type RowData Modifier and Type Method Description abstract CompletableFuture<Collection<RowData>>
AsyncLookupFunction. asyncLookup(RowData keyRow)
Asynchronously lookup rows matching the lookup keys.abstract Collection<RowData>
LookupFunction. lookup(RowData keyRow)
Synchronously lookup rows matching the lookup keys.Method parameters in org.apache.flink.table.functions with type arguments of type RowData Modifier and Type Method Description void
AsyncLookupFunction. eval(CompletableFuture<Collection<RowData>> future, Object... keys)
InvokesAsyncLookupFunction.asyncLookup(org.apache.flink.table.data.RowData)
and chains futures. -
Uses of RowData in org.apache.flink.table.gateway.api.results
Methods in org.apache.flink.table.gateway.api.results that return types with arguments of type RowData Modifier and Type Method Description List<RowData>
ResultSet. getData()
All the data in the current results.List<RowData>
ResultSetImpl. getData()
Constructor parameters in org.apache.flink.table.gateway.api.results with type arguments of type RowData Constructor Description ResultSetImpl(ResultSet.ResultType resultType, Long nextToken, ResolvedSchema resultSchema, List<RowData> data, RowDataToStringConverter converter, boolean isQueryResult, JobID jobID, ResultKind resultKind)
-
Uses of RowData in org.apache.flink.table.gateway.rest.serde
Methods in org.apache.flink.table.gateway.rest.serde that return types with arguments of type RowData Modifier and Type Method Description List<RowData>
ResultInfo. getData()
Get the data. -
Uses of RowData in org.apache.flink.table.gateway.rest.util
Methods in org.apache.flink.table.gateway.rest.util that return RowData Modifier and Type Method Description RowData
RowDataLocalTimeZoneConverter. convertTimeZoneRowData(RowData rowData)
Methods in org.apache.flink.table.gateway.rest.util with parameters of type RowData Modifier and Type Method Description RowData
RowDataLocalTimeZoneConverter. convertTimeZoneRowData(RowData rowData)
-
Uses of RowData in org.apache.flink.table.gateway.service.result
Methods in org.apache.flink.table.gateway.service.result that return types with arguments of type RowData Modifier and Type Method Description List<RowData>
NotReadyResult. getData()
Optional<List<RowData>>
ResultStore. retrieveRecords()
Method parameters in org.apache.flink.table.gateway.service.result with type arguments of type RowData Modifier and Type Method Description static ResultFetcher
ResultFetcher. fromResults(OperationHandle operationHandle, ResolvedSchema resultSchema, List<RowData> results)
static ResultFetcher
ResultFetcher. fromResults(OperationHandle operationHandle, ResolvedSchema resultSchema, List<RowData> results, JobID jobID, ResultKind resultKind)
Constructor parameters in org.apache.flink.table.gateway.service.result with type arguments of type RowData Constructor Description ResultStore(CloseableIterator<RowData> result, int maxBufferSize)
-
Uses of RowData in org.apache.flink.table.jdbc
Constructor parameters in org.apache.flink.table.jdbc with type arguments of type RowData Constructor Description FlinkResultSet(Statement statement, CloseableResultIterator<RowData> iterator, ResolvedSchema schema)
-
Uses of RowData in org.apache.flink.table.jdbc.utils
Methods in org.apache.flink.table.jdbc.utils that return RowData Modifier and Type Method Description RowData
CollectionResultIterator. next()
RowData
StatementResultIterator. next()
Constructor parameters in org.apache.flink.table.jdbc.utils with type arguments of type RowData Constructor Description CollectionResultIterator(Iterator<RowData> iterator)
-
Uses of RowData in org.apache.flink.table.planner.codegen
Methods in org.apache.flink.table.planner.codegen that return types with arguments of type RowData Modifier and Type Method Description static GeneratedFunction<AsyncFunction<RowData,RowData>>
AsyncCodeGenerator. generateFunction(String name, RowType inputType, RowType returnType, List<org.apache.calcite.rex.RexNode> calcProjection, boolean retainHeader, ReadableConfig tableConfig, ClassLoader classLoader)
Creates a generated function which produces anAsyncFunction
which executes the calc projections.static GeneratedFunction<AsyncFunction<RowData,RowData>>
AsyncCodeGenerator. generateFunction(String name, RowType inputType, RowType returnType, List<org.apache.calcite.rex.RexNode> calcProjection, boolean retainHeader, ReadableConfig tableConfig, ClassLoader classLoader)
Creates a generated function which produces anAsyncFunction
which executes the calc projections. -
Uses of RowData in org.apache.flink.table.planner.connectors
Methods in org.apache.flink.table.planner.connectors that return types with arguments of type RowData Modifier and Type Method Description Transformation<RowData>
TransformationScanProvider. createTransformation(ProviderContext providerContext)
Creates aTransformation
instance.Transformation<RowData>
TransformationSinkProvider.Context. getInputTransformation()
Input transformation to transform. -
Uses of RowData in org.apache.flink.table.planner.functions.casting
Methods in org.apache.flink.table.planner.functions.casting with parameters of type RowData Modifier and Type Method Description String[]
RowDataToStringConverterImpl. convert(RowData rowData)
-
Uses of RowData in org.apache.flink.table.planner.plan.fusion
Methods in org.apache.flink.table.planner.plan.fusion that return types with arguments of type RowData Modifier and Type Method Description Class<? extends RowData>
OpFusionCodegenSpec. getInputRowDataClass(int inputId)
-
Uses of RowData in org.apache.flink.table.planner.plan.nodes.exec.batch
Methods in org.apache.flink.table.planner.plan.nodes.exec.batch that return types with arguments of type RowData Modifier and Type Method Description protected Transformation<RowData>
BatchExecSink. applyUpsertMaterialize(Transformation<RowData> inputTransform, int[] primaryKeys, int sinkParallelism, ExecNodeConfig config, ClassLoader classLoader, RowType physicalRowType, int[] inputUpsertKey)
protected Transformation<RowData>
BatchExecLegacyTableSourceScan. createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv, ExecNodeConfig config, ClassLoader classLoader, Transformation<?> sourceTransform, org.apache.calcite.rex.RexNode rowtimeExpression)
Transformation<RowData>
BatchExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
protected Transformation<RowData>
BatchExecLookupJoin. createSyncLookupJoinWithState(Transformation<RowData> inputTransformation, org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled, boolean lookupKeyContainsPrimaryKey)
protected Transformation<RowData>
BatchExecBoundedStreamScan. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecExchange. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecExecutionOrderEnforcer. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecHashAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecHashJoin. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecHashWindowAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecInputAdapter. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecLegacyTableSourceScan. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecLimit. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
Transformation<RowData>
BatchExecLookupJoin. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecMultipleInput. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecNestedLoopJoin. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecOverAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecPythonGroupAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecPythonGroupWindowAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecPythonOverAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecRank. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecScriptTransform. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecSort. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecSortAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecSortLimit. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecSortMergeJoin. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecSortWindowAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecTableSourceScan. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecValues. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecWindowTableFunction. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecWindowTableFunction. translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config, RowType inputRowType, Transformation<RowData> inputTransform)
Method parameters in org.apache.flink.table.planner.plan.nodes.exec.batch with type arguments of type RowData Modifier and Type Method Description protected Transformation<RowData>
BatchExecSink. applyUpsertMaterialize(Transformation<RowData> inputTransform, int[] primaryKeys, int sinkParallelism, ExecNodeConfig config, ClassLoader classLoader, RowType physicalRowType, int[] inputUpsertKey)
Transformation<RowData>
BatchExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
Transformation<RowData>
BatchExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
protected Transformation<RowData>
BatchExecLookupJoin. createSyncLookupJoinWithState(Transformation<RowData> inputTransformation, org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled, boolean lookupKeyContainsPrimaryKey)
protected Transformation<RowData>
BatchExecWindowTableFunction. translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config, RowType inputRowType, Transformation<RowData> inputTransform)
-
Uses of RowData in org.apache.flink.table.planner.plan.nodes.exec.batch.runtimefilter
Methods in org.apache.flink.table.planner.plan.nodes.exec.batch.runtimefilter that return types with arguments of type RowData Modifier and Type Method Description protected Transformation<RowData>
BatchExecGlobalRuntimeFilterBuilder. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecLocalRuntimeFilterBuilder. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
BatchExecRuntimeFilter. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
-
Uses of RowData in org.apache.flink.table.planner.plan.nodes.exec.common
Methods in org.apache.flink.table.planner.plan.nodes.exec.common that return types with arguments of type RowData Modifier and Type Method Description protected abstract Transformation<RowData>
CommonExecSink. applyUpsertMaterialize(Transformation<RowData> inputTransform, int[] primaryKeys, int sinkParallelism, ExecNodeConfig config, ClassLoader classLoader, RowType physicalRowType, int[] inputUpsertKey)
protected abstract Transformation<RowData>
CommonExecLegacyTableSourceScan. createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv, ExecNodeConfig config, ClassLoader classLoader, Transformation<?> sourceTransform, org.apache.calcite.rex.RexNode rowtimeExpression)
protected abstract Transformation<RowData>
CommonExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
Creates aTransformation
based on the givenInputFormat
.protected Transformation<RowData>
CommonExecLookupJoin. createJoinTransformation(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config, boolean upsertMaterialize, boolean lookupKeyContainsPrimaryKey)
protected Transformation<RowData>
CommonExecTableSourceScan. createSourceFunctionTransformation(StreamExecutionEnvironment env, SourceFunction<RowData> function, boolean isBounded, String operatorName, TypeInformation<RowData> outputTypeInfo, int sourceParallelism, boolean sourceParallelismConfigured)
Deprecated.This method relies on theSourceFunction
API, which is due to be removed.protected ProcessFunction<RowData,RowData>
CommonExecLookupJoin. createSyncLookupJoinFunction(org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled)
protected ProcessFunction<RowData,RowData>
CommonExecLookupJoin. createSyncLookupJoinFunction(org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled)
protected abstract Transformation<RowData>
CommonExecLookupJoin. createSyncLookupJoinWithState(Transformation<RowData> inputTransformation, org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled, boolean lookupKeyContainsPrimaryKey)
protected Transformation<RowData>
CommonExecMatch. translateOrder(Transformation<RowData> inputTransform, RowType inputRowType, ExecNodeConfig config)
static Tuple2<Pattern<RowData,RowData>,List<String>>
CommonExecMatch. translatePattern(MatchSpec matchSpec, ReadableConfig config, ClassLoader classLoader, RelBuilder relBuilder, RowType inputRowType)
static Tuple2<Pattern<RowData,RowData>,List<String>>
CommonExecMatch. translatePattern(MatchSpec matchSpec, ReadableConfig config, ClassLoader classLoader, RelBuilder relBuilder, RowType inputRowType)
protected Transformation<RowData>
CommonExecAsyncCalc. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecCalc. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecCorrelate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecExpand. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecLegacyTableSourceScan. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecMatch. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecPythonCalc. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecPythonCorrelate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecTableSourceScan. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecUnion. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecValues. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
CommonExecWindowTableFunction. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected abstract Transformation<RowData>
CommonExecWindowTableFunction. translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config, RowType inputRowType, Transformation<RowData> inputTransform)
Method parameters in org.apache.flink.table.planner.plan.nodes.exec.common with type arguments of type RowData Modifier and Type Method Description protected abstract Transformation<RowData>
CommonExecSink. applyUpsertMaterialize(Transformation<RowData> inputTransform, int[] primaryKeys, int sinkParallelism, ExecNodeConfig config, ClassLoader classLoader, RowType physicalRowType, int[] inputUpsertKey)
protected abstract Transformation<RowData>
CommonExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
Creates aTransformation
based on the givenInputFormat
.protected abstract Transformation<RowData>
CommonExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
Creates aTransformation
based on the givenInputFormat
.protected Transformation<Object>
CommonExecSink. createSinkTransformation(StreamExecutionEnvironment streamExecEnv, ExecNodeConfig config, ClassLoader classLoader, Transformation<RowData> inputTransform, DynamicTableSink tableSink, int rowtimeFieldIndex, boolean upsertMaterialize, int[] inputUpsertKey)
protected Transformation<RowData>
CommonExecTableSourceScan. createSourceFunctionTransformation(StreamExecutionEnvironment env, SourceFunction<RowData> function, boolean isBounded, String operatorName, TypeInformation<RowData> outputTypeInfo, int sourceParallelism, boolean sourceParallelismConfigured)
Deprecated.This method relies on theSourceFunction
API, which is due to be removed.protected Transformation<RowData>
CommonExecTableSourceScan. createSourceFunctionTransformation(StreamExecutionEnvironment env, SourceFunction<RowData> function, boolean isBounded, String operatorName, TypeInformation<RowData> outputTypeInfo, int sourceParallelism, boolean sourceParallelismConfigured)
Deprecated.This method relies on theSourceFunction
API, which is due to be removed.protected abstract Transformation<RowData>
CommonExecLookupJoin. createSyncLookupJoinWithState(Transformation<RowData> inputTransformation, org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled, boolean lookupKeyContainsPrimaryKey)
protected Transformation<RowData>
CommonExecMatch. translateOrder(Transformation<RowData> inputTransform, RowType inputRowType, ExecNodeConfig config)
protected abstract Transformation<RowData>
CommonExecWindowTableFunction. translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config, RowType inputRowType, Transformation<RowData> inputTransform)
-
Uses of RowData in org.apache.flink.table.planner.plan.nodes.exec.stream
Methods in org.apache.flink.table.planner.plan.nodes.exec.stream that return types with arguments of type RowData Modifier and Type Method Description protected Transformation<RowData>
StreamExecSink. applyUpsertMaterialize(Transformation<RowData> inputTransform, int[] primaryKeys, int sinkParallelism, ExecNodeConfig config, ClassLoader classLoader, RowType physicalRowType, int[] inputUpsertKey)
protected Transformation<RowData>
StreamExecLegacyTableSourceScan. createConversionTransformationIfNeeded(StreamExecutionEnvironment streamExecEnv, ExecNodeConfig config, ClassLoader classLoader, Transformation<?> sourceTransform, org.apache.calcite.rex.RexNode rowtimeExpression)
Transformation<RowData>
StreamExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
protected Transformation<RowData>
StreamExecLookupJoin. createSyncLookupJoinWithState(Transformation<RowData> inputTransformation, org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled, boolean lookupKeyContainsPrimaryKey)
Transformation<RowData>
StreamExecMatch. translateOrder(Transformation<RowData> inputTransform, RowType inputRowType, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecChangelogNormalize. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecDataStreamScan. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecDeduplicate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecDropUpdateBefore. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecExchange. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecGlobalGroupAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecGlobalWindowAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecGroupAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecGroupTableAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecGroupWindowAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecIncrementalGroupAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecIntervalJoin. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecJoin. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecLimit. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecLocalGroupAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecLocalWindowAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
Transformation<RowData>
StreamExecLookupJoin. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecMiniBatchAssigner. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecMultipleInput. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecOverAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecPythonGroupAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecPythonGroupTableAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecPythonGroupWindowAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecPythonOverAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecRank. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecSort. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecSortLimit. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecTemporalJoin. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecTemporalSort. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecWatermarkAssigner. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecWindowAggregate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecWindowDeduplicate. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecWindowJoin. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecWindowRank. translateToPlanInternal(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecWindowTableFunction. translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config, RowType inputRowType, Transformation<RowData> inputTransform)
Method parameters in org.apache.flink.table.planner.plan.nodes.exec.stream with type arguments of type RowData Modifier and Type Method Description protected Transformation<RowData>
StreamExecSink. applyUpsertMaterialize(Transformation<RowData> inputTransform, int[] primaryKeys, int sinkParallelism, ExecNodeConfig config, ClassLoader classLoader, RowType physicalRowType, int[] inputUpsertKey)
Transformation<RowData>
StreamExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
Transformation<RowData>
StreamExecTableSourceScan. createInputFormatTransformation(StreamExecutionEnvironment env, InputFormat<RowData,?> inputFormat, InternalTypeInfo<RowData> outputTypeInfo, String operatorName)
protected Transformation<RowData>
StreamExecLookupJoin. createSyncLookupJoinWithState(Transformation<RowData> inputTransformation, org.apache.calcite.plan.RelOptTable temporalTable, ExecNodeConfig config, ClassLoader classLoader, Map<Integer,LookupJoinUtil.LookupKey> allLookupKeys, TableFunction<?> syncLookupFunction, RelBuilder relBuilder, RowType inputRowType, RowType tableSourceRowType, RowType resultRowType, boolean isLeftOuterJoin, boolean isObjectReuseEnabled, boolean lookupKeyContainsPrimaryKey)
Transformation<RowData>
StreamExecMatch. translateOrder(Transformation<RowData> inputTransform, RowType inputRowType, ExecNodeConfig config)
protected Transformation<RowData>
StreamExecWindowTableFunction. translateWithUnalignedWindow(org.apache.flink.table.planner.delegation.PlannerBase planner, ExecNodeConfig config, RowType inputRowType, Transformation<RowData> inputTransform)
-
Uses of RowData in org.apache.flink.table.planner.plan.utils
Fields in org.apache.flink.table.planner.plan.utils with type parameters of type RowData Modifier and Type Field Description AsyncRetryStrategy<RowData>
AsyncUtil.Options. asyncRetryStrategy
Methods in org.apache.flink.table.planner.plan.utils that return types with arguments of type RowData Modifier and Type Method Description static CoBundleTrigger<RowData,RowData>
MinibatchUtil. createMiniBatchCoTrigger(ReadableConfig config)
Creates a MiniBatch trigger depends on the config for two input.static CoBundleTrigger<RowData,RowData>
MinibatchUtil. createMiniBatchCoTrigger(ReadableConfig config)
Creates a MiniBatch trigger depends on the config for two input.static CountBundleTrigger<RowData>
MinibatchUtil. createMiniBatchTrigger(ReadableConfig config)
Creates a MiniBatch trigger depends on the config for one input.Method parameters in org.apache.flink.table.planner.plan.utils with type arguments of type RowData 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
.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
.Constructor parameters in org.apache.flink.table.planner.plan.utils with type arguments of type RowData Constructor Description Options(int asyncBufferCapacity, long asyncTimeout, AsyncDataStream.OutputMode asyncOutputMode, AsyncRetryStrategy<RowData> asyncRetryStrategy)
-
Uses of RowData in org.apache.flink.table.runtime.arrow
Methods in org.apache.flink.table.runtime.arrow that return RowData Modifier and Type Method Description RowData
ArrowReader. read(int rowId)
Read the specified row from underlying Arrow format data.Methods in org.apache.flink.table.runtime.arrow that return types with arguments of type RowData Modifier and Type Method Description static ArrowWriter<RowData>
ArrowUtils. createRowDataArrowWriter(org.apache.arrow.vector.VectorSchemaRoot root, RowType rowType)
Creates anArrowWriter
for the specifiedVectorSchemaRoot
. -
Uses of RowData in org.apache.flink.table.runtime.arrow.serializers
Methods in org.apache.flink.table.runtime.arrow.serializers that return RowData Modifier and Type Method Description RowData
ArrowSerializer. read(int i)
Methods in org.apache.flink.table.runtime.arrow.serializers that return types with arguments of type RowData Modifier and Type Method Description ArrowWriter<RowData>
ArrowSerializer. createArrowWriter()
Creates anArrowWriter
.Methods in org.apache.flink.table.runtime.arrow.serializers with parameters of type RowData Modifier and Type Method Description void
ArrowSerializer. write(RowData element)
-
Uses of RowData in org.apache.flink.table.runtime.arrow.sources
Methods in org.apache.flink.table.runtime.arrow.sources that return types with arguments of type RowData Modifier and Type Method Description DataStream<RowData>
ArrowTableSource. getDataStream(StreamExecutionEnvironment execEnv)
TypeInformation<RowData>
ArrowSourceFunction. getProducedType()
Deprecated.Method parameters in org.apache.flink.table.runtime.arrow.sources with type arguments of type RowData Modifier and Type Method Description void
ArrowSourceFunction. run(SourceFunction.SourceContext<RowData> ctx)
Deprecated. -
Uses of RowData in org.apache.flink.table.runtime.arrow.writers
Methods in org.apache.flink.table.runtime.arrow.writers that return types with arguments of type RowData Modifier and Type Method Description static ArrayWriter<RowData>
ArrayWriter. forRow(org.apache.arrow.vector.complex.ListVector listVector, ArrowFieldWriter<ArrayData> elementWriter)
static BigIntWriter<RowData>
BigIntWriter. forRow(org.apache.arrow.vector.BigIntVector bigIntVector)
static BinaryWriter<RowData>
BinaryWriter. forRow(org.apache.arrow.vector.FixedSizeBinaryVector fixedSizeBinaryVector)
static BooleanWriter<RowData>
BooleanWriter. forRow(org.apache.arrow.vector.BitVector bitVector)
static DateWriter<RowData>
DateWriter. forRow(org.apache.arrow.vector.DateDayVector dateDayVector)
static DecimalWriter<RowData>
DecimalWriter. forRow(org.apache.arrow.vector.DecimalVector decimalVector, int precision, int scale)
static DoubleWriter<RowData>
DoubleWriter. forRow(org.apache.arrow.vector.Float8Vector doubleVector)
static FloatWriter<RowData>
FloatWriter. forRow(org.apache.arrow.vector.Float4Vector floatVector)
static IntWriter<RowData>
IntWriter. forRow(org.apache.arrow.vector.IntVector intVector)
static MapWriter<RowData>
MapWriter. forRow(org.apache.arrow.vector.complex.MapVector mapVector, ArrowFieldWriter<ArrayData> keyWriter, ArrowFieldWriter<ArrayData> valueWriter)
static RowWriter<RowData>
RowWriter. forRow(org.apache.arrow.vector.complex.StructVector structVector, ArrowFieldWriter<RowData>[] fieldsWriters)
static SmallIntWriter<RowData>
SmallIntWriter. forRow(org.apache.arrow.vector.SmallIntVector intVector)
static TimestampWriter<RowData>
TimestampWriter. forRow(org.apache.arrow.vector.ValueVector valueVector, int precision)
static TimeWriter<RowData>
TimeWriter. forRow(org.apache.arrow.vector.ValueVector valueVector)
static TinyIntWriter<RowData>
TinyIntWriter. forRow(org.apache.arrow.vector.TinyIntVector tinyIntVector)
static VarBinaryWriter<RowData>
VarBinaryWriter. forRow(org.apache.arrow.vector.VarBinaryVector varBinaryVector)
static VarCharWriter<RowData>
VarCharWriter. forRow(org.apache.arrow.vector.VarCharVector varCharVector)
-
Uses of RowData in org.apache.flink.table.runtime.context
Methods in org.apache.flink.table.runtime.context that return RowData Modifier and Type Method Description RowData
ExecutionContext. currentKey()
RowData
ExecutionContextImpl. currentKey()
Methods in org.apache.flink.table.runtime.context with parameters of type RowData Modifier and Type Method Description void
ExecutionContext. setCurrentKey(RowData key)
Sets current key.void
ExecutionContextImpl. setCurrentKey(RowData key)
-
Uses of RowData in org.apache.flink.table.runtime.functions.aggregate
Methods in org.apache.flink.table.runtime.functions.aggregate that return RowData Modifier and Type Method Description RowData
FirstValueAggFunction. createAccumulator()
RowData
LastValueAggFunction. createAccumulator()
Methods in org.apache.flink.table.runtime.functions.aggregate with parameters of type RowData Modifier and Type Method Description void
FirstValueAggFunction. accumulate(RowData rowData, Object value)
void
FirstValueAggFunction. accumulate(RowData rowData, Object value, Long order)
void
FirstValueAggFunction. accumulate(RowData rowData, StringData value)
void
FirstValueAggFunction. accumulate(RowData rowData, StringData value, Long order)
void
LastValueAggFunction. accumulate(RowData rowData, Object value)
void
LastValueAggFunction. accumulate(RowData rowData, Object value, Long order)
T
FirstValueAggFunction. getValue(RowData acc)
T
LastValueAggFunction. getValue(RowData rowData)
void
FirstValueAggFunction. resetAccumulator(RowData rowData)
void
LastValueAggFunction. resetAccumulator(RowData rowData)
-
Uses of RowData in org.apache.flink.table.runtime.functions.table.lookup
Methods in org.apache.flink.table.runtime.functions.table.lookup that return types with arguments of type RowData Modifier and Type Method Description CompletableFuture<Collection<RowData>>
CachingAsyncLookupFunction. asyncLookup(RowData keyRow)
Collection<RowData>
CachingLookupFunction. lookup(RowData keyRow)
Methods in org.apache.flink.table.runtime.functions.table.lookup with parameters of type RowData Modifier and Type Method Description CompletableFuture<Collection<RowData>>
CachingAsyncLookupFunction. asyncLookup(RowData keyRow)
Collection<RowData>
CachingLookupFunction. lookup(RowData keyRow)
-
Uses of RowData in org.apache.flink.table.runtime.functions.table.lookup.fullcache
Fields in org.apache.flink.table.runtime.functions.table.lookup.fullcache with type parameters of type RowData Modifier and Type Field Description protected ConcurrentHashMap<RowData,Collection<RowData>>
CacheLoader. cache
protected ConcurrentHashMap<RowData,Collection<RowData>>
CacheLoader. cache
Methods in org.apache.flink.table.runtime.functions.table.lookup.fullcache that return types with arguments of type RowData Modifier and Type Method Description ConcurrentHashMap<RowData,Collection<RowData>>
CacheLoader. getCache()
ConcurrentHashMap<RowData,Collection<RowData>>
CacheLoader. getCache()
Collection<RowData>
LookupFullCache. getIfPresent(RowData key)
Collection<RowData>
LookupFullCache. put(RowData key, Collection<RowData> value)
Methods in org.apache.flink.table.runtime.functions.table.lookup.fullcache with parameters of type RowData Modifier and Type Method Description Collection<RowData>
LookupFullCache. getIfPresent(RowData key)
void
LookupFullCache. invalidate(RowData key)
Collection<RowData>
LookupFullCache. put(RowData key, Collection<RowData> value)
Method parameters in org.apache.flink.table.runtime.functions.table.lookup.fullcache with type arguments of type RowData Modifier and Type Method Description Collection<RowData>
LookupFullCache. put(RowData key, Collection<RowData> value)
-
Uses of RowData in org.apache.flink.table.runtime.functions.table.lookup.fullcache.inputformat
-
Uses of RowData in org.apache.flink.table.runtime.generated
Classes in org.apache.flink.table.runtime.generated with type parameters of type RowData Modifier and Type Interface Description interface
Projection<IN extends RowData,OUT extends RowData>
Interface for code generated projection, which will map a RowData to another one.interface
Projection<IN extends RowData,OUT extends RowData>
Interface for code generated projection, which will map a RowData to another one.Methods in org.apache.flink.table.runtime.generated that return RowData Modifier and Type Method Description RowData
AggsHandleFunctionBase. createAccumulators()
Initializes the accumulators and save them to a accumulators row.RowData
NamespaceAggsHandleFunctionBase. createAccumulators()
Initializes the accumulators and save them to a accumulators row.RowData
AggsHandleFunctionBase. getAccumulators()
Gets the current accumulators (saved in a row) which contains the current aggregated results.RowData
NamespaceAggsHandleFunctionBase. getAccumulators()
Gets the current accumulators (saved in a row) which contains the current aggregated results.RowData
AggsHandleFunction. getValue()
Gets the result of the aggregation from the current accumulators.RowData
NamespaceAggsHandleFunction. getValue(N namespace)
Gets the result of the aggregation from the current accumulators and namespace properties (like window start).Methods in org.apache.flink.table.runtime.generated that return types with arguments of type RowData Modifier and Type Method Description WatermarkGenerator<RowData>
GeneratedWatermarkGeneratorSupplier. createWatermarkGenerator(WatermarkGeneratorSupplier.Context context)
Methods in org.apache.flink.table.runtime.generated with parameters of type RowData Modifier and Type Method Description void
AggsHandleFunctionBase. accumulate(RowData input)
Accumulates the input values to the accumulators.void
NamespaceAggsHandleFunctionBase. accumulate(RowData inputRow)
Accumulates the input values to the accumulators.boolean
FilterCondition. apply(RowData in)
boolean
JoinCondition. apply(RowData in1, RowData in2)
int
RecordComparator. compare(RowData o1, RowData o2)
abstract Long
WatermarkGenerator. currentWatermark(RowData row)
Returns the watermark for the current row or null if no watermark should be generated.void
NamespaceTableAggsHandleFunction. emitValue(N namespace, RowData key, Collector<RowData> out)
Emits the result of the aggregation from the current accumulators and namespace properties (like window start).void
TableAggsHandleFunction. emitValue(Collector<RowData> out, RowData currentKey, boolean isRetract)
Emit the result of the table aggregation through the collector.boolean
RecordEqualiser. equals(RowData row1, RowData row2)
Returnstrue
if the rows are equal to each other andfalse
otherwise.void
AggsHandleFunctionBase. merge(RowData accumulators)
Merges the other accumulators into current accumulators.void
NamespaceAggsHandleFunctionBase. merge(N namespace, RowData otherAcc)
Merges the other accumulators into current accumulators.void
GeneratedWatermarkGeneratorSupplier.DefaultWatermarkGenerator. onEvent(RowData event, long eventTimestamp, WatermarkOutput output)
void
NormalizedKeyComputer. putKey(RowData record, MemorySegment target, int offset)
Writes a normalized key for the given record into the targetMemorySegment
.void
AggsHandleFunctionBase. retract(RowData input)
Retracts the input values from the accumulators.void
NamespaceAggsHandleFunctionBase. retract(RowData inputRow)
Retracts the input values from the accumulators.void
AggsHandleFunctionBase. setAccumulators(RowData accumulators)
Set the current accumulators (saved in a row) which contains the current aggregated results.void
NamespaceAggsHandleFunctionBase. setAccumulators(N namespace, RowData accumulators)
Set the current accumulators (saved in a row) which contains the current aggregated results.Method parameters in org.apache.flink.table.runtime.generated with type arguments of type RowData Modifier and Type Method Description void
NamespaceTableAggsHandleFunction. emitValue(N namespace, RowData key, Collector<RowData> out)
Emits the result of the aggregation from the current accumulators and namespace properties (like window start).void
TableAggsHandleFunction. emitValue(Collector<RowData> out, RowData currentKey, boolean isRetract)
Emit the result of the table aggregation through the collector. -
Uses of RowData in org.apache.flink.table.runtime.hashtable
Classes in org.apache.flink.table.runtime.hashtable with type parameters of type RowData Modifier and Type Class Description class
WrappedRowIterator<T extends RowData>
WrapMutableObjectIterator
to javaRowIterator
.Methods in org.apache.flink.table.runtime.hashtable that return RowData Modifier and Type Method Description RowData
ProbeIterator. current()
RowData
BinaryHashTable. getCurrentProbeRow()
RowData
LongHybridHashTable. getCurrentProbeRow()
Methods in org.apache.flink.table.runtime.hashtable with parameters of type RowData Modifier and Type Method Description abstract long
LongHybridHashTable. getBuildLongKey(RowData row)
For code gen get build side long key.abstract long
LongHybridHashTable. getProbeLongKey(RowData row)
For code gen get probe side long key.void
LongHybridHashTable. insertIntoProbeBuffer(RowData probeRecord)
If the probe row corresponding partition has been spilled to disk, just call this method spill probe row to disk.abstract BinaryRowData
LongHybridHashTable. probeToBinary(RowData row)
For code gen probe side to BinaryRowData.void
BinaryHashTable. putBuildRow(RowData row)
Put a build side row to hash table.void
ProbeIterator. setInstance(RowData instance)
boolean
BinaryHashTable. tryProbe(RowData record)
Find matched build side rows for a probe row.boolean
LongHybridHashTable. tryProbe(RowData record)
Constructor parameters in org.apache.flink.table.runtime.hashtable with type arguments of type RowData Constructor Description BinaryHashTable(Object owner, boolean compressionEnabled, int compressionBlockSize, AbstractRowDataSerializer buildSideSerializer, AbstractRowDataSerializer probeSideSerializer, Projection<RowData,BinaryRowData> buildSideProjection, Projection<RowData,BinaryRowData> probeSideProjection, MemoryManager memManager, long reservedMemorySize, IOManager ioManager, int avgRecordLen, long buildRowCount, boolean useBloomFilters, HashJoinType type, JoinCondition condFunc, boolean reverseJoin, boolean[] filterNulls, boolean tryDistinctBuildRow)
-
Uses of RowData in org.apache.flink.table.runtime.keyselector
Methods in org.apache.flink.table.runtime.keyselector that return RowData Modifier and Type Method Description RowData
BinaryRowDataKeySelector. getKey(RowData value)
RowData
EmptyRowDataKeySelector. getKey(RowData value)
RowData
GenericRowDataKeySelector. getKey(RowData value)
Methods in org.apache.flink.table.runtime.keyselector that return types with arguments of type RowData Modifier and Type Method Description InternalTypeInfo<RowData>
BinaryRowDataKeySelector. getProducedType()
InternalTypeInfo<RowData>
EmptyRowDataKeySelector. getProducedType()
InternalTypeInfo<RowData>
GenericRowDataKeySelector. getProducedType()
InternalTypeInfo<RowData>
RowDataKeySelector. getProducedType()
Methods in org.apache.flink.table.runtime.keyselector with parameters of type RowData Modifier and Type Method Description RowData
BinaryRowDataKeySelector. getKey(RowData value)
RowData
EmptyRowDataKeySelector. getKey(RowData value)
RowData
GenericRowDataKeySelector. getKey(RowData value)
Constructor parameters in org.apache.flink.table.runtime.keyselector with type arguments of type RowData Constructor Description BinaryRowDataKeySelector(InternalTypeInfo<RowData> keyRowType, GeneratedProjection generatedProjection)
GenericRowDataKeySelector(InternalTypeInfo<RowData> keyRowType, RowDataSerializer keySerializer, GeneratedProjection generatedProjection)
-
Uses of RowData in org.apache.flink.table.runtime.operators.aggregate
Methods in org.apache.flink.table.runtime.operators.aggregate that return RowData Modifier and Type Method Description RowData
MiniBatchGlobalGroupAggFunction. addInput(RowData previousAcc, RowData input)
ThepreviousAcc
is accumulator, but input is a row in <key, accumulator> schema, the specific generatedMiniBatchGlobalGroupAggFunction.localAgg
will project theinput
to accumulator in merge method.RowData
MiniBatchIncrementalGroupAggFunction. addInput(RowData previousAcc, RowData input)
RowData
MiniBatchLocalGroupAggFunction. addInput(RowData previousAcc, RowData input)
Methods in org.apache.flink.table.runtime.operators.aggregate that return types with arguments of type RowData Modifier and Type Method Description List<RowData>
MiniBatchGroupAggFunction. addInput(List<RowData> value, RowData input)
Methods in org.apache.flink.table.runtime.operators.aggregate with parameters of type RowData Modifier and Type Method Description RowData
MiniBatchGlobalGroupAggFunction. addInput(RowData previousAcc, RowData input)
ThepreviousAcc
is accumulator, but input is a row in <key, accumulator> schema, the specific generatedMiniBatchGlobalGroupAggFunction.localAgg
will project theinput
to accumulator in merge method.List<RowData>
MiniBatchGroupAggFunction. addInput(List<RowData> value, RowData input)
RowData
MiniBatchIncrementalGroupAggFunction. addInput(RowData previousAcc, RowData input)
RowData
MiniBatchLocalGroupAggFunction. addInput(RowData previousAcc, RowData input)
void
GroupAggFunction. processElement(RowData input, KeyedProcessFunction.Context ctx, Collector<RowData> out)
void
GroupTableAggFunction. processElement(RowData input, KeyedProcessFunction.Context ctx, Collector<RowData> out)
abstract boolean
RecordCounter. recordCountIsZero(RowData acc)
We store the counter in the accumulator.Method parameters in org.apache.flink.table.runtime.operators.aggregate with type arguments of type RowData Modifier and Type Method Description List<RowData>
MiniBatchGroupAggFunction. addInput(List<RowData> value, RowData input)
void
MiniBatchGlobalGroupAggFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
MiniBatchGlobalGroupAggFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
MiniBatchGlobalGroupAggFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
MiniBatchGroupAggFunction. finishBundle(Map<RowData,List<RowData>> buffer, Collector<RowData> out)
void
MiniBatchGroupAggFunction. finishBundle(Map<RowData,List<RowData>> buffer, Collector<RowData> out)
void
MiniBatchGroupAggFunction. finishBundle(Map<RowData,List<RowData>> buffer, Collector<RowData> out)
void
MiniBatchIncrementalGroupAggFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
MiniBatchIncrementalGroupAggFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
MiniBatchIncrementalGroupAggFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
MiniBatchLocalGroupAggFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
MiniBatchLocalGroupAggFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
MiniBatchLocalGroupAggFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
GroupAggFunction. processElement(RowData input, KeyedProcessFunction.Context ctx, Collector<RowData> out)
void
GroupTableAggFunction. processElement(RowData input, KeyedProcessFunction.Context ctx, Collector<RowData> out)
Constructor parameters in org.apache.flink.table.runtime.operators.aggregate with type arguments of type RowData Constructor Description MiniBatchIncrementalGroupAggFunction(GeneratedAggsHandleFunction genPartialAggsHandler, GeneratedAggsHandleFunction genFinalAggsHandler, KeySelector<RowData,RowData> finalKeySelector, long stateRetentionTime)
MiniBatchIncrementalGroupAggFunction(GeneratedAggsHandleFunction genPartialAggsHandler, GeneratedAggsHandleFunction genFinalAggsHandler, KeySelector<RowData,RowData> finalKeySelector, long stateRetentionTime)
-
Uses of RowData in org.apache.flink.table.runtime.operators.aggregate.window
Fields in org.apache.flink.table.runtime.operators.aggregate.window with type parameters of type RowData Modifier and Type Field Description protected TimestampedCollector<RowData>
LocalSlicingWindowAggOperator. collector
This is used for emitting elements with a given timestamp.Methods in org.apache.flink.table.runtime.operators.aggregate.window that return types with arguments of type RowData Modifier and Type Method Description WindowAggOperator<RowData,?>
WindowAggOperatorBuilder. build()
Method parameters in org.apache.flink.table.runtime.operators.aggregate.window with type arguments of type RowData Modifier and Type Method Description WindowAggOperatorBuilder
WindowAggOperatorBuilder. aggregate(GeneratedNamespaceAggsHandleFunction<?> generatedAggregateFunction, AbstractRowDataSerializer<RowData> accSerializer)
WindowAggOperatorBuilder
WindowAggOperatorBuilder. globalAggregate(GeneratedNamespaceAggsHandleFunction<?> localGeneratedAggregateFunction, GeneratedNamespaceAggsHandleFunction<?> globalGeneratedAggregateFunction, GeneratedNamespaceAggsHandleFunction<?> stateGeneratedAggregateFunction, AbstractRowDataSerializer<RowData> accSerializer)
WindowAggOperatorBuilder
WindowAggOperatorBuilder. inputSerializer(AbstractRowDataSerializer<RowData> inputSerializer)
WindowAggOperatorBuilder
WindowAggOperatorBuilder. keySerializer(PagedTypeSerializer<RowData> keySerializer)
void
LocalSlicingWindowAggOperator. processElement(StreamRecord<RowData> element)
-
Uses of RowData in org.apache.flink.table.runtime.operators.aggregate.window.buffers
Methods in org.apache.flink.table.runtime.operators.aggregate.window.buffers with parameters of type RowData Modifier and Type Method Description void
RecordsWindowBuffer. addElement(RowData key, long sliceEnd, RowData element)
void
WindowBuffer. addElement(RowData key, long window, RowData element)
Adds an element with associated key into the buffer.Method parameters in org.apache.flink.table.runtime.operators.aggregate.window.buffers with type arguments of type RowData Modifier and Type Method Description WindowBuffer
RecordsWindowBuffer.Factory. create(Object operatorOwner, MemoryManager memoryManager, long memorySize, RuntimeContext runtimeContext, WindowTimerService<Long> timerService, KeyedStateBackend<RowData> stateBackend, WindowState<Long> windowState, boolean isEventTime, ZoneId shiftTimeZone)
WindowBuffer
RecordsWindowBuffer.LocalFactory. create(Object operatorOwner, MemoryManager memoryManager, long memorySize, RuntimeContext runtimeContext, Collector<RowData> collector, ZoneId shiftTimeZone)
WindowBuffer
WindowBuffer.Factory. create(Object operatorOwner, MemoryManager memoryManager, long memorySize, RuntimeContext runtimeContext, WindowTimerService<Long> timerService, KeyedStateBackend<RowData> stateBackend, WindowState<Long> windowState, boolean isEventTime, ZoneId shiftTimeZone)
Creates aWindowBuffer
that buffers elements in memory before flushing.WindowBuffer
WindowBuffer.LocalFactory. create(Object operatorOwner, MemoryManager memoryManager, long memorySize, RuntimeContext runtimeContext, Collector<RowData> collector, ZoneId shiftTimeZone)
Creates aWindowBuffer
for local window that buffers elements in memory before flushing. -
Uses of RowData in org.apache.flink.table.runtime.operators.aggregate.window.combines
Method parameters in org.apache.flink.table.runtime.operators.aggregate.window.combines with type arguments of type RowData Modifier and Type Method Description void
AggCombiner. combine(WindowKey windowKey, Iterator<RowData> records)
void
GlobalAggCombiner. combine(WindowKey windowKey, Iterator<RowData> localAccs)
void
LocalAggCombiner. combine(WindowKey windowKey, Iterator<RowData> records)
RecordsCombiner
AggCombiner.Factory. createRecordsCombiner(RuntimeContext runtimeContext, WindowTimerService<Long> timerService, KeyedStateBackend<RowData> stateBackend, WindowState<Long> windowState, boolean isEventTime)
RecordsCombiner
GlobalAggCombiner.Factory. createRecordsCombiner(RuntimeContext runtimeContext, WindowTimerService<Long> timerService, KeyedStateBackend<RowData> stateBackend, WindowState<Long> windowState, boolean isEventTime)
RecordsCombiner
LocalAggCombiner.Factory. createRecordsCombiner(RuntimeContext runtimeContext, Collector<RowData> collector)
Constructor parameters in org.apache.flink.table.runtime.operators.aggregate.window.combines with type arguments of type RowData Constructor Description LocalAggCombiner(NamespaceAggsHandleFunction<Long> aggregator, Collector<RowData> collector)
-
Uses of RowData in org.apache.flink.table.runtime.operators.aggregate.window.processors
Fields in org.apache.flink.table.runtime.operators.aggregate.window.processors with type parameters of type RowData Modifier and Type Field Description protected TypeSerializer<RowData>
AbstractWindowAggProcessor. accSerializer
protected MergingWindowProcessFunction<RowData,TimeWindow>
UnsliceWindowAggProcessor. windowFunction
Methods in org.apache.flink.table.runtime.operators.aggregate.window.processors with parameters of type RowData Modifier and Type Method Description protected void
AbstractWindowAggProcessor. collect(RowData aggResult)
Send result to downstream.boolean
AbstractSliceWindowAggProcessor. processElement(RowData key, RowData element)
boolean
UnsliceWindowAggProcessor. processElement(RowData key, RowData element)
-
Uses of RowData in org.apache.flink.table.runtime.operators.calc.async
Methods in org.apache.flink.table.runtime.operators.calc.async with parameters of type RowData Modifier and Type Method Description void
AsyncFunctionRunner. asyncInvoke(RowData input, ResultFuture<RowData> resultFuture)
Method parameters in org.apache.flink.table.runtime.operators.calc.async with type arguments of type RowData Modifier and Type Method Description void
AsyncFunctionRunner. asyncInvoke(RowData input, ResultFuture<RowData> resultFuture)
void
DelegatingAsyncResultFuture. setOutputFactory(Function<Object,RowData> outputFactory)
boolean
RetryPredicates.EmptyResponseResultStrategy. test(Collection<RowData> c)
Constructor parameters in org.apache.flink.table.runtime.operators.calc.async with type arguments of type RowData Constructor Description AsyncFunctionRunner(GeneratedFunction<AsyncFunction<RowData,RowData>> generatedFetcher)
AsyncFunctionRunner(GeneratedFunction<AsyncFunction<RowData,RowData>> generatedFetcher)
-
Uses of RowData in org.apache.flink.table.runtime.operators.deduplicate
Methods in org.apache.flink.table.runtime.operators.deduplicate that return RowData Modifier and Type Method Description RowData
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction. addInput(RowData value, RowData input)
RowData
ProcTimeMiniBatchDeduplicateKeepLastRowFunction. addInput(RowData value, RowData input)
RowData
RowTimeMiniBatchLatestChangeDeduplicateFunction. addInput(RowData value, RowData input)
Methods in org.apache.flink.table.runtime.operators.deduplicate that return types with arguments of type RowData Modifier and Type Method Description List<RowData>
RowTimeMiniBatchDeduplicateFunction. addInput(List<RowData> value, RowData input)
Methods in org.apache.flink.table.runtime.operators.deduplicate with parameters of type RowData Modifier and Type Method Description RowData
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction. addInput(RowData value, RowData input)
RowData
ProcTimeMiniBatchDeduplicateKeepLastRowFunction. addInput(RowData value, RowData input)
List<RowData>
RowTimeMiniBatchDeduplicateFunction. addInput(List<RowData> value, RowData input)
RowData
RowTimeMiniBatchLatestChangeDeduplicateFunction. addInput(RowData value, RowData input)
static void
RowTimeDeduplicateFunction. deduplicateOnRowTime(ValueState<RowData> state, RowData currentRow, Collector<RowData> out, boolean generateUpdateBefore, boolean generateInsert, int rowtimeIndex, boolean keepLastRow)
Processes element to deduplicate on keys with row time semantic, sends current element if it is last or first row, retracts previous element if needed.static boolean
DeduplicateFunctionHelper. isDuplicate(RowData preRow, RowData currentRow, int rowtimeIndex, boolean keepLastRow)
Returns current row is duplicate row or not compared to previous row.void
ProcTimeDeduplicateKeepFirstRowFunction. processElement(RowData input, KeyedProcessFunction.Context ctx, Collector<RowData> out)
void
ProcTimeDeduplicateKeepLastRowFunction. processElement(RowData input, KeyedProcessFunction.Context ctx, Collector<RowData> out)
void
RowTimeDeduplicateFunction. processElement(RowData input, KeyedProcessFunction.Context ctx, Collector<RowData> out)
Method parameters in org.apache.flink.table.runtime.operators.deduplicate with type arguments of type RowData Modifier and Type Method Description List<RowData>
RowTimeMiniBatchDeduplicateFunction. addInput(List<RowData> value, RowData input)
static void
RowTimeDeduplicateFunction. deduplicateOnRowTime(ValueState<RowData> state, RowData currentRow, Collector<RowData> out, boolean generateUpdateBefore, boolean generateInsert, int rowtimeIndex, boolean keepLastRow)
Processes element to deduplicate on keys with row time semantic, sends current element if it is last or first row, retracts previous element if needed.static void
RowTimeDeduplicateFunction. deduplicateOnRowTime(ValueState<RowData> state, RowData currentRow, Collector<RowData> out, boolean generateUpdateBefore, boolean generateInsert, int rowtimeIndex, boolean keepLastRow)
Processes element to deduplicate on keys with row time semantic, sends current element if it is last or first row, retracts previous element if needed.void
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
ProcTimeMiniBatchDeduplicateKeepLastRowFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
ProcTimeMiniBatchDeduplicateKeepLastRowFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
ProcTimeMiniBatchDeduplicateKeepLastRowFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
RowTimeMiniBatchDeduplicateFunction. finishBundle(Map<RowData,List<RowData>> buffer, Collector<RowData> out)
void
RowTimeMiniBatchDeduplicateFunction. finishBundle(Map<RowData,List<RowData>> buffer, Collector<RowData> out)
void
RowTimeMiniBatchDeduplicateFunction. finishBundle(Map<RowData,List<RowData>> buffer, Collector<RowData> out)
void
RowTimeMiniBatchLatestChangeDeduplicateFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
RowTimeMiniBatchLatestChangeDeduplicateFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
RowTimeMiniBatchLatestChangeDeduplicateFunction. finishBundle(Map<RowData,RowData> buffer, Collector<RowData> out)
void
ProcTimeDeduplicateKeepFirstRowFunction. processElement(RowData input, KeyedProcessFunction.Context ctx, Collector<RowData> out)
void
ProcTimeDeduplicateKeepLastRowFunction. processElement(RowData input, KeyedProcessFunction.Context ctx, Collector<RowData> out)
void
RowTimeDeduplicateFunction. processElement(RowData input, KeyedProcessFunction.Context ctx, Collector<RowData> out)
Constructor parameters in org.apache.flink.table.runtime.operators.deduplicate with type arguments of type RowData Constructor Description ProcTimeDeduplicateKeepLastRowFunction(InternalTypeInfo<RowData> typeInfo, long stateRetentionTime, boolean generateUpdateBefore, boolean generateInsert, boolean inputInsertOnly, GeneratedRecordEqualiser genRecordEqualiser)
ProcTimeMiniBatchDeduplicateKeepFirstRowFunction(TypeSerializer<RowData> serializer, long stateRetentionTime)
ProcTimeMiniBatchDeduplicateKeepLastRowFunction(InternalTypeInfo<RowData> typeInfo, TypeSerializer<RowData> serializer, 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)
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)
RowTimeMiniBatchLatestChangeDeduplicateFunction(InternalTypeInfo<RowData> typeInfo, TypeSerializer<RowData> serializer, long minRetentionTime, int rowtimeIndex, boolean generateUpdateBefore, boolean generateInsert, boolean keepLastRow)
-
Uses of RowData in org.apache.flink.table.runtime.operators.deduplicate.window
Methods in org.apache.flink.table.runtime.operators.deduplicate.window that return types with arguments of type RowData Modifier and Type Method Description WindowAggOperator<RowData,?>
RowTimeWindowDeduplicateOperatorBuilder. build()
Method parameters in org.apache.flink.table.runtime.operators.deduplicate.window with type arguments of type RowData Modifier and Type Method Description RowTimeWindowDeduplicateOperatorBuilder
RowTimeWindowDeduplicateOperatorBuilder. inputSerializer(AbstractRowDataSerializer<RowData> inputSerializer)
RowTimeWindowDeduplicateOperatorBuilder
RowTimeWindowDeduplicateOperatorBuilder. keySerializer(PagedTypeSerializer<RowData> keySerializer)
-
Uses of RowData in org.apache.flink.table.runtime.operators.deduplicate.window.combines
Method parameters in org.apache.flink.table.runtime.operators.deduplicate.window.combines with type arguments of type RowData Modifier and Type Method Description void
RowTimeDeduplicateRecordsCombiner. combine(WindowKey windowKey, Iterator<RowData> records)
RecordsCombiner
RowTimeDeduplicateRecordsCombiner.Factory. createRecordsCombiner(RuntimeContext runtimeContext, WindowTimerService<Long> timerService, KeyedStateBackend<RowData> stateBackend, WindowState<Long> windowState, boolean isEventTime)
Constructor parameters in org.apache.flink.table.runtime.operators.deduplicate.window.combines with type arguments of type RowData Constructor Description Factory(TypeSerializer<RowData> recordSerializer, int rowtimeIndex, boolean keepLastRow)
RowTimeDeduplicateRecordsCombiner(WindowTimerService<Long> timerService, StateKeyContext keyContext, WindowValueState<Long> dataState, int rowtimeIndex, boolean keepLastRow, TypeSerializer<RowData> recordSerializer)
-
Uses of RowData in org.apache.flink.table.runtime.operators.deduplicate.window.processors
Methods in org.apache.flink.table.runtime.operators.deduplicate.window.processors with parameters of type RowData Modifier and Type Method Description boolean
RowTimeWindowDeduplicateProcessor. processElement(RowData key, RowData element)
Constructor parameters in org.apache.flink.table.runtime.operators.deduplicate.window.processors with type arguments of type RowData Constructor Description RowTimeWindowDeduplicateProcessor(TypeSerializer<RowData> inputSerializer, WindowBuffer.Factory bufferFactory, int windowEndIndex, ZoneId shiftTimeZone)
-
Uses of RowData in org.apache.flink.table.runtime.operators.dynamicfiltering
Method parameters in org.apache.flink.table.runtime.operators.dynamicfiltering with type arguments of type RowData Modifier and Type Method Description void
DynamicFilteringDataCollectorOperator. processElement(StreamRecord<RowData> element)
-
Uses of RowData in org.apache.flink.table.runtime.operators.fusion
Constructor parameters in org.apache.flink.table.runtime.operators.fusion with type arguments of type RowData Constructor Description FusionStreamOperatorBase(StreamOperatorParameters<RowData> parameters, int numberOfInputs)
-
Uses of RowData in org.apache.flink.table.runtime.operators.hive.script
Method parameters in org.apache.flink.table.runtime.operators.hive.script with type arguments of type RowData Modifier and Type Method Description void
HiveScriptTransformOperator. processElement(StreamRecord<RowData> element)
Constructor parameters in org.apache.flink.table.runtime.operators.hive.script with type arguments of type RowData Constructor Description HiveScriptTransformOutReadThread(org.apache.hadoop.hive.ql.exec.RecordReader recordReader, LogicalType outputType, org.apache.hadoop.hive.serde2.AbstractSerDe outSerDe, org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector structObjectInspector, StreamRecordCollector<RowData> collector)
-
Uses of RowData in org.apache.flink.table.runtime.operators.join
Methods in org.apache.flink.table.runtime.operators.join that return RowData Modifier and Type Method Description RowData
SortMergeJoinIterator. getProbeRow()
RowData
OuterJoinPaddingUtil. padLeft(RowData leftRow)
Returns a padding result with the given left row.RowData
OuterJoinPaddingUtil. padRight(RowData rightRow)
Returns a padding result with the given right row.Methods in org.apache.flink.table.runtime.operators.join with parameters of type RowData Modifier and Type Method Description boolean
JoinConditionWithNullFilters. apply(RowData left, RowData right)
abstract void
HashJoinOperator. join(RowIterator<BinaryRowData> buildIter, RowData probeRow)
RowData
OuterJoinPaddingUtil. padLeft(RowData leftRow)
Returns a padding result with the given left row.RowData
OuterJoinPaddingUtil. padRight(RowData rightRow)
Returns a padding result with the given right row.void
SortMergeJoinFunction. processElement1(RowData element)
void
SortMergeJoinFunction. processElement2(RowData element)
Method parameters in org.apache.flink.table.runtime.operators.join with type arguments of type RowData Modifier and Type Method Description void
HashJoinOperator. processElement1(StreamRecord<RowData> element)
void
SortMergeJoinOperator. processElement1(StreamRecord<RowData> element)
void
HashJoinOperator. processElement2(StreamRecord<RowData> element)
void
SortMergeJoinOperator. processElement2(StreamRecord<RowData> element)
-
Uses of RowData in org.apache.flink.table.runtime.operators.join.interval
Methods in org.apache.flink.table.runtime.operators.join.interval that return RowData Modifier and Type Method Description RowData
PaddingLeftMapFunction. map(RowData value)
RowData
PaddingRightMapFunction. map(RowData value)
Methods in org.apache.flink.table.runtime.operators.join.interval that return types with arguments of type RowData Modifier and Type Method Description TypeInformation<RowData>
FilterAllFlatMapFunction. getProducedType()
TypeInformation<RowData>
IntervalJoinFunction. getProducedType()
TypeInformation<RowData>
PaddingLeftMapFunction. getProducedType()
TypeInformation<RowData>
PaddingRightMapFunction. getProducedType()
Methods in org.apache.flink.table.runtime.operators.join.interval with parameters of type RowData Modifier and Type Method Description void
FilterAllFlatMapFunction. flatMap(RowData value, Collector<RowData> out)
void
IntervalJoinFunction. join(RowData first, RowData second, Collector<RowData> out)
RowData
PaddingLeftMapFunction. map(RowData value)
RowData
PaddingRightMapFunction. map(RowData value)
void
IntervalJoinFunction. setJoinKey(RowData currentKey)
Method parameters in org.apache.flink.table.runtime.operators.join.interval with type arguments of type RowData Modifier and Type Method Description void
FilterAllFlatMapFunction. flatMap(RowData value, Collector<RowData> out)
void
IntervalJoinFunction. join(RowData first, RowData second, Collector<RowData> out)
Constructor parameters in org.apache.flink.table.runtime.operators.join.interval with type arguments of type RowData Constructor Description FilterAllFlatMapFunction(InternalTypeInfo<RowData> inputTypeInfo)
IntervalJoinFunction(GeneratedJoinCondition joinCondition, InternalTypeInfo<RowData> returnTypeInfo, boolean[] filterNulls)
PaddingLeftMapFunction(OuterJoinPaddingUtil paddingUtil, InternalTypeInfo<RowData> returnType)
PaddingRightMapFunction(OuterJoinPaddingUtil paddingUtil, InternalTypeInfo<RowData> returnType)
ProcTimeIntervalJoin(FlinkJoinType joinType, long leftLowerBound, long leftUpperBound, long minCleanUpInterval, InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, IntervalJoinFunction genJoinFunc)
RowTimeIntervalJoin(FlinkJoinType joinType, long leftLowerBound, long leftUpperBound, long allowedLateness, long minCleanUpInterval, InternalTypeInfo<RowData> leftType, InternalTypeInfo<RowData> rightType, IntervalJoinFunction joinFunc, int leftTimeIdx, int rightTimeIdx)
-
Uses of RowData in org.apache.flink.table.runtime.operators.join.lookup
Fields in org.apache.flink.table.runtime.operators.join.lookup with type parameters of type RowData Modifier and Type Field Description protected ListenableCollector<RowData>
LookupJoinRunner. collector
Methods in org.apache.flink.table.runtime.operators.join.lookup that return types with arguments of type RowData Modifier and Type Method Description CompletableFuture<Collection<RowData>>
RetryableAsyncLookupFunctionDelegator. asyncLookup(RowData keyRow)
TableFunctionResultFuture<RowData>
AsyncLookupJoinRunner. createFetcherResultFuture(Configuration parameters)
TableFunctionResultFuture<RowData>
AsyncLookupJoinWithCalcRunner. createFetcherResultFuture(Configuration parameters)
Collector<RowData>
LookupJoinRunner. getFetcherCollector()
Collector<RowData>
LookupJoinWithCalcRunner. getFetcherCollector()
AsyncRetryPredicate<RowData>
ResultRetryStrategy. getRetryPredicate()
Collection<RowData>
RetryableLookupFunctionDelegator. lookup(RowData keyRow)
Methods in org.apache.flink.table.runtime.operators.join.lookup with parameters of type RowData Modifier and Type Method Description void
AsyncLookupJoinRunner. asyncInvoke(RowData input, ResultFuture<RowData> resultFuture)
CompletableFuture<Collection<RowData>>
RetryableAsyncLookupFunctionDelegator. asyncLookup(RowData keyRow)
void
LookupJoinRunner. doFetch(RowData in)
Collection<RowData>
RetryableLookupFunctionDelegator. lookup(RowData keyRow)
void
LookupJoinRunner. padNullForLeftJoin(RowData in, Collector<RowData> out)
boolean
LookupJoinRunner. preFilter(RowData in)
void
LookupJoinRunner. prepareCollector(RowData in, Collector<RowData> out)
void
KeyedLookupJoinWrapper. processElement(RowData in, KeyedProcessFunction.Context ctx, Collector<RowData> out)
void
LookupJoinRunner. processElement(RowData in, ProcessFunction.Context ctx, Collector<RowData> out)
Method parameters in org.apache.flink.table.runtime.operators.join.lookup with type arguments of type RowData Modifier and Type Method Description void
AsyncLookupJoinRunner. asyncInvoke(RowData input, ResultFuture<RowData> resultFuture)
static ResultRetryStrategy
ResultRetryStrategy. fixedDelayRetry(int maxAttempts, long backoffTimeMillis, Predicate<Collection<RowData>> resultPredicate)
Create a fixed-delay retry strategy by given params.void
LookupJoinRunner. padNullForLeftJoin(RowData in, Collector<RowData> out)
void
LookupJoinRunner. prepareCollector(RowData in, Collector<RowData> out)
void
KeyedLookupJoinWrapper. processElement(RowData in, KeyedProcessFunction.Context ctx, Collector<RowData> out)
void
LookupJoinRunner. processElement(RowData in, ProcessFunction.Context ctx, Collector<RowData> out)
-
Uses of RowData in org.apache.flink.table.runtime.operators.join.stream
Fields in org.apache.flink.table.runtime.operators.join.stream with type parameters of type RowData Modifier and Type Field Description protected TimestampedCollector<RowData>
AbstractStreamingJoinOperator. collector
protected InternalTypeInfo<RowData>
AbstractStreamingJoinOperator. leftType
protected InternalTypeInfo<RowData>
AbstractStreamingJoinOperator. rightType
Methods in org.apache.flink.table.runtime.operators.join.stream with parameters of type RowData Modifier and Type Method Description protected void
StreamingJoinOperator. processElement(RowData input, JoinRecordStateView inputSideStateView, JoinRecordStateView otherSideStateView, boolean inputIsLeft, boolean isSuppress)
Method parameters in org.apache.flink.table.runtime.operators.join.stream with type arguments of type RowData 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)
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)
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)
void
MiniBatchStreamingJoinOperator. processElement1(StreamRecord<RowData> element)
void
StreamingJoinOperator. processElement1(StreamRecord<RowData> element)
void
StreamingSemiAntiJoinOperator. processElement1(StreamRecord<RowData> element)
Process an input element and output incremental joined records, retraction messages will be sent in some scenarios.void
MiniBatchStreamingJoinOperator. processElement2(StreamRecord<RowData> element)
void
StreamingJoinOperator. processElement2(StreamRecord<RowData> element)
void
StreamingSemiAntiJoinOperator. processElement2(StreamRecord<RowData> element)
Process an input element and output incremental joined records, retraction messages will be sent in some scenarios.Constructor parameters in org.apache.flink.table.runtime.operators.join.stream with type arguments of type RowData 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 RowData in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing
Fields in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing with type parameters of type RowData Modifier and Type Field Description protected TimestampedCollector<RowData>
AbstractAsyncStateStreamingJoinOperator. collector
protected InternalTypeInfo<RowData>
AbstractAsyncStateStreamingJoinOperator. leftType
protected InternalTypeInfo<RowData>
AbstractAsyncStateStreamingJoinOperator. rightType
Method parameters in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing with type arguments of type RowData Modifier and Type Method Description void
AsyncStateStreamingJoinOperator. processElement1(StreamRecord<RowData> element)
void
AsyncStateStreamingJoinOperator. processElement2(StreamRecord<RowData> element)
Constructor parameters in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing with type arguments of type RowData 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 RowData 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 RowData Modifier and Type Method Description StateFuture<Void>
JoinRecordAsyncStateView. addRecord(RowData record)
Add a new record to the state view.default StateFuture<Void>
OuterJoinRecordAsyncStateView. addRecord(RowData record)
StateFuture<Void>
OuterJoinRecordAsyncStateView. addRecord(RowData record, int numOfAssociations)
Adds a new record with the number of associations to the state view.StateFuture<Void>
JoinRecordAsyncStateView. retractRecord(RowData record)
Retract the record from the state view.StateFuture<Void>
OuterJoinRecordAsyncStateView. updateNumOfAssociations(RowData record, int numOfAssociations)
Updates the number of associations belongs to the record.Method parameters in org.apache.flink.table.runtime.operators.join.stream.asyncprocessing.state with type arguments of type RowData 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
.StateFuture<List<OuterRecord>>
JoinRecordAsyncStateView. findMatchedRecords(Function<RowData,Boolean> condition)
Find all the records matched the condition under the current context (i.e. join key).default StateFuture<List<OuterRecord>>
OuterJoinRecordAsyncStateView. findMatchedRecords(Function<RowData,Boolean> condition)
StateFuture<List<OuterRecord>>
OuterJoinRecordAsyncStateView. findMatchedRecordsAndNumOfAssociations(Function<RowData,Boolean> condition)
Find all the records matched the condition and the corresponding number of associations under the current context (i.e. join key). -
Uses of RowData in org.apache.flink.table.runtime.operators.join.stream.bundle
Fields in org.apache.flink.table.runtime.operators.join.stream.bundle with type parameters of type RowData Modifier and Type Field Description protected Map<RowData,T>
BufferBundle. bundle
Methods in org.apache.flink.table.runtime.operators.join.stream.bundle that return types with arguments of type RowData Modifier and Type Method Description Set<RowData>
BufferBundle. getJoinKeys()
Get the joinKeys in bufferBundle.Set<RowData>
InputSideHasUniqueKeyBundle. getJoinKeys()
abstract Map<RowData,List<RowData>>
BufferBundle. getRecords()
Get records associated with joinKeys from bufferBundle.abstract Map<RowData,List<RowData>>
BufferBundle. getRecords()
Get records associated with joinKeys from bufferBundle.Map<RowData,List<RowData>>
InputSideHasNoUniqueKeyBundle. getRecords()
Map<RowData,List<RowData>>
InputSideHasNoUniqueKeyBundle. getRecords()
Map<RowData,List<RowData>>
InputSideHasUniqueKeyBundle. getRecords()
Map<RowData,List<RowData>>
InputSideHasUniqueKeyBundle. getRecords()
Map<RowData,List<RowData>>
JoinKeyContainsUniqueKeyBundle. getRecords()
Map<RowData,List<RowData>>
JoinKeyContainsUniqueKeyBundle. getRecords()
abstract Map<RowData,List<RowData>>
BufferBundle. getRecordsWithJoinKey(RowData joinKey)
Get records associated with joinKeys from bufferBundle.abstract Map<RowData,List<RowData>>
BufferBundle. getRecordsWithJoinKey(RowData joinKey)
Get records associated with joinKeys from bufferBundle.Map<RowData,List<RowData>>
InputSideHasNoUniqueKeyBundle. getRecordsWithJoinKey(RowData joinKey)
Map<RowData,List<RowData>>
InputSideHasNoUniqueKeyBundle. getRecordsWithJoinKey(RowData joinKey)
Map<RowData,List<RowData>>
InputSideHasUniqueKeyBundle. getRecordsWithJoinKey(RowData joinKey)
Map<RowData,List<RowData>>
InputSideHasUniqueKeyBundle. getRecordsWithJoinKey(RowData joinKey)
Map<RowData,List<RowData>>
JoinKeyContainsUniqueKeyBundle. getRecordsWithJoinKey(RowData joinKey)
Map<RowData,List<RowData>>
JoinKeyContainsUniqueKeyBundle. getRecordsWithJoinKey(RowData joinKey)
Methods in org.apache.flink.table.runtime.operators.join.stream.bundle with parameters of type RowData Modifier and Type Method Description abstract int
BufferBundle. addRecord(RowData joinKey, RowData uniqueKey, RowData record)
Adds a record into the bufferBundle when processing element in a stream and this function would return the size of the bufferBundle.int
InputSideHasNoUniqueKeyBundle. addRecord(RowData joinKey, RowData uniqueKey, RowData record)
The structure of the bundle: first-level key is the joinKey while the second-level key is the hash value of the record.int
InputSideHasUniqueKeyBundle. addRecord(RowData joinKey, RowData uniqueKey, RowData record)
int
JoinKeyContainsUniqueKeyBundle. addRecord(RowData joinKey, RowData uniqueKey, RowData record)
abstract Map<RowData,List<RowData>>
BufferBundle. getRecordsWithJoinKey(RowData joinKey)
Get records associated with joinKeys from bufferBundle.Map<RowData,List<RowData>>
InputSideHasNoUniqueKeyBundle. getRecordsWithJoinKey(RowData joinKey)
Map<RowData,List<RowData>>
InputSideHasUniqueKeyBundle. getRecordsWithJoinKey(RowData joinKey)
Map<RowData,List<RowData>>
JoinKeyContainsUniqueKeyBundle. getRecordsWithJoinKey(RowData joinKey)
-
Uses of RowData in org.apache.flink.table.runtime.operators.join.stream.state
Methods in org.apache.flink.table.runtime.operators.join.stream.state that return types with arguments of type RowData Modifier and Type Method Description Iterable<RowData>
JoinRecordStateView. getRecords()
Gets all the records under the current context (i.e. join key).Iterable<Tuple2<RowData,Integer>>
OuterJoinRecordStateView. getRecordsAndNumOfAssociations()
Gets all the records and number of associations under the current context (i.e. join key).Methods in org.apache.flink.table.runtime.operators.join.stream.state with parameters of type RowData Modifier and Type Method Description void
JoinRecordStateView. addRecord(RowData record)
Add a new record to the state view.void
OuterJoinRecordStateView. addRecord(RowData record, int numOfAssociations)
Adds a new record with the number of associations to the state view.void
JoinRecordStateView. retractRecord(RowData record)
Retract the record from the state view.void
OuterJoinRecordStateView. updateNumOfAssociations(RowData record, int numOfAssociations)
Updates the number of associations belongs to the record.Method parameters in org.apache.flink.table.runtime.operators.join.stream.state with type arguments of type RowData 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 RowData in org.apache.flink.table.runtime.operators.join.stream.utils
Fields in org.apache.flink.table.runtime.operators.join.stream.utils declared as RowData Modifier and Type Field Description RowData
OuterRecord. record
Methods in org.apache.flink.table.runtime.operators.join.stream.utils that return RowData Modifier and Type Method Description RowData
OuterRecord. getRecord()
Methods in org.apache.flink.table.runtime.operators.join.stream.utils that return types with arguments of type RowData Modifier and Type Method Description Iterable<RowData>
AssociatedRecords. getRecords()
Gets the iterable of records.KeySelector<RowData,RowData>
JoinInputSideSpec. getUniqueKeySelector()
Returns theKeySelector
to extract unique key from the input row.KeySelector<RowData,RowData>
JoinInputSideSpec. getUniqueKeySelector()
Returns theKeySelector
to extract unique key from the input row.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 RowData Modifier and Type Method Description abstract void
JoinHelper. addRecord(STATE_VIEW stateView, RowData record)
abstract void
JoinHelper. addRecordInOuterSide(OUTER_STATE_VIEW stateView, RowData record, int numOfAssociations)
static StateFuture<AssociatedRecords>
AssociatedRecords. fromAsyncStateView(RowData input, boolean inputIsLeft, JoinRecordAsyncStateView otherSideAsyncStateView, JoinCondition joinCondition)
Creates anAssociatedRecords
which represents the records associated to the input row.static AssociatedRecords
AssociatedRecords. fromSyncStateView(RowData input, boolean inputIsLeft, JoinRecordStateView otherSideStateView,
-