Constructor and Description |
---|
ArrowUtils() |
Modifier and Type | Method and Description |
---|---|
static void |
checkArrowUsable() |
static org.apache.flink.table.runtime.arrow.ArrowUtils.CustomIterator<byte[]> |
collectAsPandasDataFrame(Table table,
int maxArrowBatchSize)
Convert Flink table to Pandas DataFrame.
|
static AbstractArrowTableSource |
createArrowTableSource(DataType dataType,
String fileName) |
static ColumnVector |
createColumnVector(org.apache.arrow.vector.ValueVector vector,
LogicalType fieldType) |
static ArrowFieldReader |
createRowArrowFieldReader(org.apache.arrow.vector.ValueVector vector,
LogicalType fieldType) |
static RowArrowReader |
createRowArrowReader(org.apache.arrow.vector.VectorSchemaRoot root,
RowType rowType)
Creates an
ArrowReader for the specified VectorSchemaRoot . |
static ArrowWriter<Row> |
createRowArrowWriter(org.apache.arrow.vector.VectorSchemaRoot root,
RowType rowType)
Creates an
ArrowWriter for the specified VectorSchemaRoot . |
static RowDataArrowReader |
createRowDataArrowReader(org.apache.arrow.vector.VectorSchemaRoot root,
RowType rowType)
Creates an
ArrowReader for blink planner for the specified VectorSchemaRoot . |
static ArrowWriter<RowData> |
createRowDataArrowWriter(org.apache.arrow.vector.VectorSchemaRoot root,
RowType rowType)
Creates an
ArrowWriter for blink planner for the specified VectorSchemaRoot . |
static org.apache.arrow.memory.RootAllocator |
getRootAllocator() |
static byte[][] |
readArrowBatches(ReadableByteChannel channel) |
static org.apache.arrow.vector.types.pojo.Schema |
toArrowSchema(RowType rowType)
Returns the Arrow schema of the specified type.
|
public static org.apache.arrow.memory.RootAllocator getRootAllocator()
public static void checkArrowUsable()
public static org.apache.arrow.vector.types.pojo.Schema toArrowSchema(RowType rowType)
public static ArrowWriter<Row> createRowArrowWriter(org.apache.arrow.vector.VectorSchemaRoot root, RowType rowType)
ArrowWriter
for the specified VectorSchemaRoot
.public static ArrowWriter<RowData> createRowDataArrowWriter(org.apache.arrow.vector.VectorSchemaRoot root, RowType rowType)
ArrowWriter
for blink planner for the specified VectorSchemaRoot
.public static RowArrowReader createRowArrowReader(org.apache.arrow.vector.VectorSchemaRoot root, RowType rowType)
ArrowReader
for the specified VectorSchemaRoot
.public static ArrowFieldReader createRowArrowFieldReader(org.apache.arrow.vector.ValueVector vector, LogicalType fieldType)
public static RowDataArrowReader createRowDataArrowReader(org.apache.arrow.vector.VectorSchemaRoot root, RowType rowType)
ArrowReader
for blink planner for the specified VectorSchemaRoot
.public static ColumnVector createColumnVector(org.apache.arrow.vector.ValueVector vector, LogicalType fieldType)
public static AbstractArrowTableSource createArrowTableSource(DataType dataType, String fileName) throws IOException
IOException
public static byte[][] readArrowBatches(ReadableByteChannel channel) throws IOException
IOException
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.