Uses of Interface
org.apache.flink.table.data.columnar.vector.writable.WritableColumnVector
-
-
Uses of WritableColumnVector in org.apache.flink.formats.parquet
Methods in org.apache.flink.formats.parquet with parameters of type WritableColumnVector Modifier and Type Method Description protected ParquetVectorizedInputFormat.ParquetReaderBatch<RowData>
ParquetColumnarRowInputFormat. createReaderBatch(WritableColumnVector[] writableVectors, VectorizedColumnBatch columnarBatch, Pool.Recycler<ParquetVectorizedInputFormat.ParquetReaderBatch<RowData>> recycler)
protected abstract ParquetVectorizedInputFormat.ParquetReaderBatch<T>
ParquetVectorizedInputFormat. createReaderBatch(WritableColumnVector[] writableVectors, VectorizedColumnBatch columnarBatch, Pool.Recycler<ParquetVectorizedInputFormat.ParquetReaderBatch<T>> recycler)
Constructors in org.apache.flink.formats.parquet with parameters of type WritableColumnVector Constructor Description ParquetReaderBatch(WritableColumnVector[] writableVectors, VectorizedColumnBatch columnarBatch, Pool.Recycler<ParquetVectorizedInputFormat.ParquetReaderBatch<T>> recycler)
-
Uses of WritableColumnVector in org.apache.flink.formats.parquet.vector
Classes in org.apache.flink.formats.parquet.vector that implement WritableColumnVector Modifier and Type Class Description class
ParquetDecimalVector
Parquet write decimal as int32 and int64 and binary, this class wrap the real vector to provideDecimalColumnVector
interface.Methods in org.apache.flink.formats.parquet.vector that return WritableColumnVector Modifier and Type Method Description static WritableColumnVector
ParquetSplitReaderUtil. createWritableColumnVector(int batchSize, LogicalType fieldType, org.apache.parquet.schema.Type type, List<org.apache.parquet.column.ColumnDescriptor> columnDescriptors, int depth)
-
Uses of WritableColumnVector in org.apache.flink.formats.parquet.vector.reader
Classes in org.apache.flink.formats.parquet.vector.reader with type parameters of type WritableColumnVector Modifier and Type Class Description class
AbstractColumnReader<VECTOR extends WritableColumnVector>
AbstractColumnReader
.interface
ColumnReader<VECTOR extends WritableColumnVector>
Read a batch of records for a column toWritableColumnVector
from parquet data file.class
FixedLenBytesColumnReader<VECTOR extends WritableColumnVector>
Fixed length bytesColumnReader
, just for decimal.Methods in org.apache.flink.formats.parquet.vector.reader that return WritableColumnVector Modifier and Type Method Description WritableColumnVector
NestedPrimitiveColumnReader. readAndNewVector(int readNumber, WritableColumnVector vector)
Methods in org.apache.flink.formats.parquet.vector.reader with parameters of type WritableColumnVector Modifier and Type Method Description WritableColumnVector
NestedPrimitiveColumnReader. readAndNewVector(int readNumber, WritableColumnVector vector)
void
NestedColumnReader. readToVector(int readNumber, WritableColumnVector vector)
void
NestedPrimitiveColumnReader. readToVector(int readNumber, WritableColumnVector vector)
-
Uses of WritableColumnVector in org.apache.flink.table.data.columnar.vector.heap
Classes in org.apache.flink.table.data.columnar.vector.heap that implement WritableColumnVector Modifier and Type Class Description class
AbstractHeapVector
Heap vector that nullable shared structure.class
HeapArrayVector
This class represents a nullable heap array column vector.class
HeapBooleanVector
This class represents a nullable heap boolean column vector.class
HeapBytesVector
This class supports string and binary data by value reference -- i.e. each field is explicitly present, as opposed to provided by a dictionary reference.class
HeapByteVector
This class represents a nullable byte column vector.class
HeapDoubleVector
This class represents a nullable double precision floating point column vector.class
HeapFloatVector
This class represents a nullable double precision floating point column vector.class
HeapIntVector
This class represents a nullable int column vector.class
HeapLongVector
This class represents a nullable long column vector.class
HeapMapVector
This class represents a nullable heap map column vector.class
HeapRowVector
This class represents a nullable heap row column vector.class
HeapShortVector
This class represents a nullable short column vector.class
HeapTimestampVector
This class represents a nullable byte column vector.Methods in org.apache.flink.table.data.columnar.vector.heap that return WritableColumnVector Modifier and Type Method Description WritableColumnVector[]
HeapRowVector. getFields()
Methods in org.apache.flink.table.data.columnar.vector.heap with parameters of type WritableColumnVector Modifier and Type Method Description void
HeapRowVector. setFields(WritableColumnVector[] fields)
Constructors in org.apache.flink.table.data.columnar.vector.heap with parameters of type WritableColumnVector Constructor Description HeapRowVector(int len, WritableColumnVector... fields)
-
Uses of WritableColumnVector in org.apache.flink.table.data.columnar.vector.writable
Subinterfaces of WritableColumnVector in org.apache.flink.table.data.columnar.vector.writable Modifier and Type Interface Description interface
WritableBooleanVector
WritableBooleanColumnVector
.interface
WritableBytesVector
WritableBytesColumnVector
.interface
WritableByteVector
WritableByteColumnVector
.interface
WritableDoubleVector
WritableDoubleColumnVector
.interface
WritableFloatVector
WritableFloatColumnVector
.interface
WritableIntVector
WritableIntColumnVector
.interface
WritableLongVector
WritableLongColumnVector
.interface
WritableShortVector
WritableShortColumnVector
.interface
WritableTimestampVector
WritableTimestampColumnVector
.Classes in org.apache.flink.table.data.columnar.vector.writable that implement WritableColumnVector Modifier and Type Class Description class
AbstractWritableVector
Contains the shared structure forColumnVector
s, including NULL information and dictionary.
-