public class CatalystGroupConverter extends CatalystConverter
parquet.io.api.GroupConverter
that is able to convert a Parquet record
to a Row
object.
Constructor and Description |
---|
CatalystGroupConverter(org.apache.spark.sql.catalyst.expressions.Attribute[] attributes)
This constructor is used for the root converter only!
|
CatalystGroupConverter(org.apache.spark.sql.catalyst.types.StructField[] schema,
int index,
CatalystConverter parent) |
CatalystGroupConverter(org.apache.spark.sql.catalyst.types.StructField[] schema,
int index,
CatalystConverter parent,
scala.collection.mutable.ArrayBuffer<Object> current,
scala.collection.mutable.ArrayBuffer<org.apache.spark.sql.catalyst.expressions.Row> buffer) |
Modifier and Type | Method and Description |
---|---|
void |
end() |
parquet.io.api.Converter |
getConverter(int fieldIndex) |
org.apache.spark.sql.catalyst.expressions.Row |
getCurrentRecord()
Should only be called in the root (group) converter!
|
int |
size()
The number of fields this group has
|
void |
start() |
ARRAY_CONTAINS_NULL_BAG_SCHEMA_NAME, ARRAY_ELEMENTS_SCHEMA_NAME, MAP_KEY_SCHEMA_NAME, MAP_SCHEMA_NAME, MAP_VALUE_SCHEMA_NAME
public CatalystGroupConverter(org.apache.spark.sql.catalyst.types.StructField[] schema, int index, CatalystConverter parent, scala.collection.mutable.ArrayBuffer<Object> current, scala.collection.mutable.ArrayBuffer<org.apache.spark.sql.catalyst.expressions.Row> buffer)
public CatalystGroupConverter(org.apache.spark.sql.catalyst.types.StructField[] schema, int index, CatalystConverter parent)
public CatalystGroupConverter(org.apache.spark.sql.catalyst.expressions.Attribute[] attributes)
public int size()
CatalystConverter
public org.apache.spark.sql.catalyst.expressions.Row getCurrentRecord()
CatalystConverter
getCurrentRecord
in class CatalystConverter
public parquet.io.api.Converter getConverter(int fieldIndex)
getConverter
in class parquet.io.api.GroupConverter
public void start()
start
in class parquet.io.api.GroupConverter
public void end()
end
in class parquet.io.api.GroupConverter