Modifier and Type | Method and Description |
---|---|
static org.apache.arrow.vector.types.pojo.Field |
ArrowUtils.toArrowField(String fieldName,
DataType dataType) |
Modifier and Type | Method and Description |
---|---|
static Arrow2PaimonVectorConverter |
Arrow2PaimonVectorConverter.construct(DataType type) |
Modifier and Type | Method and Description |
---|---|
Set<DataType> |
CastRulePredicate.getTargetTypes() |
Modifier and Type | Method and Description |
---|---|
CastExecutor<Timestamp,Number> |
TimestampToNumericPrimitiveCastRule.create(DataType inputType,
DataType targetType) |
CastExecutor<Number,Timestamp> |
NumericPrimitiveToTimestamp.create(DataType inputType,
DataType targetType) |
CastExecutor<IN,OUT> |
CastRule.create(DataType inputType,
DataType targetType)
Create a
CastExecutor starting from the provided input type. |
CastExecutor<byte[],BinaryString> |
BinaryToStringCastRule.create(DataType inputType,
DataType targetType) |
static CastExecutor<?,?> |
CastExecutors.resolve(DataType inputType,
DataType outputType)
Resolve a
CastExecutor for the provided input type and target type. |
CastRulePredicate.Builder |
CastRulePredicate.Builder.target(DataType outputType) |
Modifier and Type | Method and Description |
---|---|
DataType |
PartitionInfo.getType(int i) |
Modifier and Type | Method and Description |
---|---|
static int |
BinaryArray.calculateFixLengthPartSize(DataType type)
It store real value when type is primitive.
|
static InternalArray.ElementGetter |
InternalArray.createElementGetter(DataType elementType)
Creates an accessor for getting elements in an internal array data structure at the given
position.
|
static InternalRow.FieldGetter |
InternalRow.createFieldGetter(DataType fieldType,
int fieldPos)
Creates an accessor for getting elements in an internal row data structure at the given
position.
|
static BinaryArrayWriter.NullSetter |
BinaryArrayWriter.createNullSetter(DataType elementType)
Creates an for accessor setting the elements of an array writer to
null during
runtime. |
static BinaryWriter.ValueSetter |
BinaryWriter.createValueSetter(DataType elementType)
Creates an accessor for setting the elements of a binary writer during runtime.
|
static BinaryWriter.ValueSetter |
BinaryWriter.createValueSetter(DataType elementType,
Serializer<?> serializer) |
static Class<?> |
InternalRow.getDataClass(DataType type)
Returns the data class for the given
DataType . |
void |
BinaryArrayWriter.setNullAt(int pos,
DataType type)
Deprecated.
Use
BinaryArrayWriter.createNullSetter(DataType) for avoiding logical types during
runtime. |
Map<?,?> |
BinaryMap.toJavaMap(DataType keyType,
DataType valueType) |
<T> T[] |
BinaryArray.toObjectArray(DataType elementType) |
static void |
BinaryWriter.write(BinaryWriter writer,
int pos,
Object o,
DataType type,
Serializer<?> serializer)
Deprecated.
Use
#createValueSetter(DataType) for avoiding logical types during
runtime. |
Modifier and Type | Method and Description |
---|---|
DataType[] |
InternalRowSerializer.fieldTypes() |
Modifier and Type | Method and Description |
---|---|
static Map<Object,Object> |
InternalMapSerializer.convertToJavaMap(InternalMap map,
DataType keyType,
DataType valueType)
Converts a
InternalMap into Java Map , the keys and values of the Java map
still holds objects of internal data structures. |
static <T> Serializer<T> |
InternalSerializers.create(DataType type)
Creates a
Serializer for internal data structures of the given DataType . |
Constructor and Description |
---|
InternalArraySerializer(DataType eleType) |
InternalMapSerializer(DataType keyType,
DataType valueType) |
InternalRowSerializer(DataType... types) |
InternalRowSerializer(DataType[] types,
Serializer<?>[] fieldSerializers) |
Modifier and Type | Method and Description |
---|---|
static DataType |
FileIndexCommon.getFieldType(Map<String,DataField> fields,
String columnsName) |
Modifier and Type | Method and Description |
---|---|
FileIndexer |
FileIndexerFactory.create(DataType type,
Options options) |
static FileIndexer |
FileIndexer.create(String type,
DataType dataType,
Options options) |
Modifier and Type | Method and Description |
---|---|
FileIndexer |
BitmapFileIndexFactory.create(DataType dataType,
Options options) |
static java.util.function.Function<Object,Object> |
BitmapFileIndex.getValueMapper(DataType dataType) |
Constructor and Description |
---|
BitmapFileIndex(DataType dataType,
Options options) |
BitmapFileIndexMeta(DataType dataType) |
BitmapFileIndexMeta(DataType dataType,
int rowCount,
int nonNullBitmapNumber,
boolean hasNullValue,
int nullValueOffset,
LinkedHashMap<Object,Integer> bitmapOffsets) |
Modifier and Type | Method and Description |
---|---|
FileIndexer |
BloomFilterFileIndexFactory.create(DataType type,
Options options) |
static FastHash |
FastHash.getHashFunction(DataType type) |
Constructor and Description |
---|
BloomFilterFileIndex(DataType dataType,
Options options) |
Modifier and Type | Method and Description |
---|---|
protected DataType |
LogicalTypeToDataType.defaultMethod(org.apache.flink.table.types.logical.LogicalType logicalType) |
static DataType |
LogicalTypeConversion.toDataType(org.apache.flink.table.types.logical.LogicalType logicalType) |
static DataType |
LogicalTypeConversion.toDataType(org.apache.flink.table.types.logical.LogicalType logicalType,
AtomicInteger currentHighestFieldId) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.ArrayType arrayType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.BigIntType bigIntType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.BinaryType binaryType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.BooleanType booleanType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.CharType charType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.DateType dateType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.DecimalType decimalType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.DoubleType doubleType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.FloatType floatType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.IntType intType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.LocalZonedTimestampType localZonedTimestampType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.MapType mapType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.MultisetType multisetType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.RowType rowType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.SmallIntType smallIntType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.TimestampType timestampType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.TimeType timeType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.TinyIntType tinyIntType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.VarBinaryType varBinaryType) |
DataType |
LogicalTypeToDataType.visit(org.apache.flink.table.types.logical.VarCharType varCharType) |
Modifier and Type | Method and Description |
---|---|
static org.apache.flink.table.types.logical.LogicalType |
LogicalTypeConversion.toLogicalType(DataType dataType) |
Modifier and Type | Method and Description |
---|---|
protected List<DataType> |
ActionBase.toPaimonTypes(List<org.apache.flink.table.types.DataType> flinkDataTypes)
|
Modifier and Type | Method and Description |
---|---|
protected boolean |
ActionBase.compatibleCheck(List<DataType> actualTypes,
List<DataType> expectedTypes)
Check whether each
DataType of actualTypes is compatible with that of expectedTypes
respectively. |
protected boolean |
ActionBase.compatibleCheck(List<DataType> actualTypes,
List<DataType> expectedTypes)
Check whether each
DataType of actualTypes is compatible with that of expectedTypes
respectively. |
Modifier and Type | Method and Description |
---|---|
DataType |
ComputedColumn.columnType() |
DataType |
CdcMetadataConverter.dataType() |
DataType |
CdcMetadataConverter.DatabaseNameConverter.dataType() |
DataType |
CdcMetadataConverter.TableNameConverter.dataType() |
DataType |
CdcMetadataConverter.SchemaNameConverter.dataType() |
DataType |
CdcMetadataConverter.OpTsConverter.dataType() |
DataType |
Expression.ReferencedField.fieldType() |
DataType |
Expression.outputType()
Return
DataType of computed value. |
DataType |
Expression.TemporalExpressionBase.outputType()
If not, this must be overridden!
|
DataType |
Expression.DateFormat.outputType() |
DataType |
Expression.Substring.outputType() |
DataType |
Expression.TruncateComputer.outputType() |
DataType |
Expression.CastExpression.outputType() |
DataType |
JdbcToPaimonTypeVisitor.visit(String type,
Integer length,
Integer scale,
TypeMapping typeMapping) |
Modifier and Type | Method and Description |
---|---|
static Expression |
Expression.truncate(String fieldReference,
DataType fieldType,
String... literals) |
Modifier and Type | Method and Description |
---|---|
static Expression.ReferencedField |
Expression.ReferencedField.checkArgument(Map<String,DataType> typeMapping,
boolean caseSensitive,
String... args) |
Expression |
Expression.ExpressionCreator.create(Map<String,DataType> typeMapping,
boolean caseSensitive,
String[] args) |
static Expression |
Expression.create(Map<String,DataType> typeMapping,
boolean caseSensitive,
String exprName,
String... args) |
Modifier and Type | Method and Description |
---|---|
static DataType |
DebeziumSchemaUtils.avroToPaimonDataType(org.apache.avro.Schema schema) |
static DataType |
DebeziumSchemaUtils.toDataType(String debeziumType,
String className,
Map<String,String> parameters) |
Modifier and Type | Method and Description |
---|---|
static DataType |
MySqlTypeUtils.toDataType(String type,
Integer length,
Integer scale,
TypeMapping typeMapping) |
Modifier and Type | Method and Description |
---|---|
static DataType |
PostgresTypeUtils.toDataType(String typeName,
Integer precision,
Integer scale,
TypeMapping typeMapping) |
Modifier and Type | Method and Description |
---|---|
static UpdatedDataFieldsProcessFunctionBase.ConvertAction |
UpdatedDataFieldsProcessFunctionBase.canConvert(DataType oldType,
DataType newType) |
RichCdcRecord.Builder |
RichCdcRecord.Builder.field(String name,
DataType type,
String value) |
RichCdcRecord.Builder |
RichCdcRecord.Builder.field(String name,
DataType type,
String value,
String description) |
Constructor and Description |
---|
InternalRowTypeSerializer(DataType... types) |
Modifier and Type | Method and Description |
---|---|
static DataType |
AvroSchemaConverter.extractKeyTypeToAvroMap(DataType type) |
static DataType |
AvroSchemaConverter.extractValueTypeToAvroMap(DataType type) |
Modifier and Type | Method and Description |
---|---|
static org.apache.avro.Schema |
AvroSchemaConverter.convertToSchema(DataType schema,
Map<String,String> rowNameMapping)
Converts Paimon
DataType (can be nested) into an Avro schema. |
static org.apache.avro.Schema |
AvroSchemaConverter.convertToSchema(DataType dataType,
String rowName,
Map<String,String> rowNameMapping)
Converts Paimon
DataType (can be nested) into an Avro schema. |
static DataType |
AvroSchemaConverter.extractKeyTypeToAvroMap(DataType type) |
static DataType |
AvroSchemaConverter.extractValueTypeToAvroMap(DataType type) |
static boolean |
AvroSchemaConverter.isArrayMap(DataType type) |
default T |
AvroSchemaVisitor.primitive(org.apache.avro.Schema primitive,
DataType type) |
default T |
AvroSchemaVisitor.visit(org.apache.avro.Schema schema,
DataType type) |
FieldWriter |
FieldWriterFactory.visitArray(org.apache.avro.Schema schema,
DataType elementType) |
FieldReader |
FieldReaderFactory.visitArray(org.apache.avro.Schema schema,
DataType elementType) |
T |
AvroSchemaVisitor.visitArray(org.apache.avro.Schema schema,
DataType elementType) |
FieldWriter |
FieldWriterFactory.visitArrayMap(org.apache.avro.Schema schema,
DataType keyType,
DataType valueType) |
FieldReader |
FieldReaderFactory.visitArrayMap(org.apache.avro.Schema schema,
DataType keyType,
DataType valueType) |
T |
AvroSchemaVisitor.visitArrayMap(org.apache.avro.Schema schema,
DataType keyType,
DataType valueType) |
FieldWriter |
FieldWriterFactory.visitMap(org.apache.avro.Schema schema,
DataType valueType) |
FieldReader |
FieldReaderFactory.visitMap(org.apache.avro.Schema schema,
DataType valueType) |
T |
AvroSchemaVisitor.visitMap(org.apache.avro.Schema schema,
DataType valueType) |
FieldWriter |
FieldWriterFactory.visitUnion(org.apache.avro.Schema schema,
DataType type) |
FieldReader |
FieldReaderFactory.visitUnion(org.apache.avro.Schema schema,
DataType type) |
T |
AvroSchemaVisitor.visitUnion(org.apache.avro.Schema schema,
DataType type) |
Modifier and Type | Method and Description |
---|---|
static DataType |
OrcFileFormat.refineDataType(DataType type) |
Modifier and Type | Method and Description |
---|---|
static DataType |
OrcFileFormat.refineDataType(DataType type) |
Modifier and Type | Method and Description |
---|---|
protected static org.apache.hadoop.hive.ql.io.sarg.PredicateLeaf.Type |
OrcPredicateFunctionVisitor.toOrcType(DataType type) |
Modifier and Type | Method and Description |
---|---|
static ColumnVector |
AbstractOrcColumnVector.createPaimonVector(org.apache.hadoop.hive.ql.exec.vector.ColumnVector vector,
DataType dataType) |
static org.apache.orc.TypeDescription |
OrcSplitReaderUtil.toOrcType(DataType type) |
Constructor and Description |
---|
RowDataVectorizer(String schema,
DataType[] fieldTypes) |
Modifier and Type | Method and Description |
---|---|
static org.apache.parquet.schema.Type |
ParquetSchemaConverter.convertToParquetType(String name,
DataType type) |
Modifier and Type | Method and Description |
---|---|
static ColumnReader |
ParquetSplitReaderUtil.createColumnReader(DataType fieldType,
org.apache.parquet.schema.Type type,
List<org.apache.parquet.column.ColumnDescriptor> columnDescriptors,
org.apache.parquet.column.page.PageReadStore pages,
ParquetField field,
int depth) |
static WritableColumnVector |
ParquetSplitReaderUtil.createWritableColumnVector(int batchSize,
DataType fieldType,
org.apache.parquet.schema.Type type,
List<org.apache.parquet.column.ColumnDescriptor> columnDescriptors,
int depth) |
Constructor and Description |
---|
NestedPrimitiveColumnReader(org.apache.parquet.column.ColumnDescriptor descriptor,
org.apache.parquet.column.page.PageReader pageReader,
boolean isUtcTimestamp,
org.apache.parquet.schema.Type parquetType,
DataType dataType,
boolean readRowField,
boolean readMapKey) |
Modifier and Type | Method and Description |
---|---|
DataType |
ParquetField.getType() |
Constructor and Description |
---|
ParquetField(DataType type,
int repetitionLevel,
int definitionLevel,
boolean required) |
ParquetGroupField(DataType type,
int repetitionLevel,
int definitionLevel,
boolean required,
List<ParquetField> children) |
ParquetPrimitiveField(DataType type,
boolean required,
org.apache.parquet.column.ColumnDescriptor descriptor,
int id) |
Modifier and Type | Method and Description |
---|---|
static DataType |
HiveTypeUtils.toPaimonType(String type)
Convert hive data type
TypeInfo to paimon data type DataType . |
static DataType |
HiveTypeUtils.toPaimonType(org.apache.hadoop.hive.serde2.typeinfo.TypeInfo typeInfo)
Convert hive data type
TypeInfo to paimon data type DataType . |
Modifier and Type | Method and Description |
---|---|
List<DataType> |
HiveSchema.fieldTypes() |
Modifier and Type | Method and Description |
---|---|
R |
SchemaVisitor.primitive(DataType primitive,
P partner) |
static org.apache.hadoop.hive.serde2.typeinfo.TypeInfo |
HiveTypeUtils.toTypeInfo(DataType logicalType)
Convert paimon data type
DataType to hive data type TypeInfo . |
static <P,T> T |
SchemaVisitor.visit(DataType type,
P partner,
SchemaVisitor<P,T> visitor,
SchemaVisitor.PartnerAccessors<P> accessors) |
Constructor and Description |
---|
SearchArgumentToPredicateConverter(org.apache.hadoop.hive.ql.io.sarg.SearchArgument searchArgument,
List<String> columnNames,
List<DataType> columnTypes,
Set<String> readColumnNames) |
Modifier and Type | Method and Description |
---|---|
static org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector |
PaimonObjectInspectorFactory.create(DataType logicalType) |
Constructor and Description |
---|
HivePaimonArray(DataType elementType,
List<Object> list) |
PaimonListObjectInspector(DataType elementType) |
PaimonMapObjectInspector(DataType keyType,
DataType valueType) |
Constructor and Description |
---|
PaimonInternalRowObjectInspector(List<String> fieldNames,
List<DataType> fieldTypes,
List<String> fieldComments) |
Modifier and Type | Method and Description |
---|---|
static ByteBuffer |
IcebergConversions.toByteBuffer(DataType type,
Object value) |
static Object |
IcebergConversions.toPaimonObject(DataType type,
byte[] bytes) |
Modifier and Type | Field and Description |
---|---|
protected DataType |
FieldAggregator.fieldType |
Modifier and Type | Method and Description |
---|---|
static FieldAggregator |
FieldAggregator.createFieldAggregator(DataType fieldType,
String strAgg,
boolean ignoreRetract,
boolean isPrimaryKey,
CoreOptions options,
String field) |
Modifier and Type | Method and Description |
---|---|
static MergeFunctionFactory<KeyValue> |
AggregateMergeFunction.factory(Options conf,
List<String> tableNames,
List<DataType> tableTypes,
List<String> primaryKeys) |
Constructor and Description |
---|
FieldAggregator(DataType dataType) |
FieldBoolAndAgg(DataType dataType) |
FieldBoolOrAgg(DataType dataType) |
FieldFirstNonNullValueAgg(DataType dataType) |
FieldFirstValueAgg(DataType dataType) |
FieldLastNonNullValueAgg(DataType dataType) |
FieldLastValueAgg(DataType dataType) |
FieldListaggAgg(DataType dataType,
CoreOptions options,
String field) |
FieldMaxAgg(DataType dataType) |
FieldMinAgg(DataType dataType) |
FieldPrimaryKeyAgg(DataType dataType) |
FieldProductAgg(DataType dataType) |
FieldSumAgg(DataType dataType) |
Modifier and Type | Method and Description |
---|---|
DataType |
FieldRef.type() |
DataType |
LeafPredicate.type() |
Modifier and Type | Method and Description |
---|---|
static int |
CompareUtils.compareLiteral(DataType type,
Object v1,
Object v2) |
static Object |
PredicateBuilder.convertJavaObject(DataType literalType,
Object o) |
abstract boolean |
LeafUnaryFunction.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount) |
boolean |
IsNull.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount) |
boolean |
IsNotNull.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount) |
boolean |
In.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
List<Object> literals) |
boolean |
LeafUnaryFunction.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
List<Object> literals) |
boolean |
NotIn.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
List<Object> literals) |
boolean |
NullFalseLeafBinaryFunction.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
List<Object> literals) |
abstract boolean |
LeafFunction.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
List<Object> literals) |
boolean |
Equal.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
Object literal) |
boolean |
Contains.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
Object patternLiteral) |
boolean |
EndsWith.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
Object patternLiteral) |
boolean |
NotEqual.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
Object literal) |
boolean |
GreaterThan.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
Object literal) |
boolean |
LessThan.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
Object literal) |
boolean |
StartsWith.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
Object patternLiteral) |
boolean |
GreaterOrEqual.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
Object literal) |
abstract boolean |
NullFalseLeafBinaryFunction.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
Object literal) |
boolean |
LessOrEqual.test(DataType type,
long rowCount,
Object min,
Object max,
Long nullCount,
Object literal) |
abstract boolean |
LeafUnaryFunction.test(DataType type,
Object value) |
boolean |
IsNull.test(DataType type,
Object field) |
boolean |
IsNotNull.test(DataType type,
Object field) |
boolean |
In.test(DataType type,
Object field,
List<Object> literals) |
boolean |
LeafUnaryFunction.test(DataType type,
Object value,
List<Object> literals) |
boolean |
NotIn.test(DataType type,
Object field,
List<Object> literals) |
boolean |
NullFalseLeafBinaryFunction.test(DataType type,
Object field,
List<Object> literals) |
abstract boolean |
LeafFunction.test(DataType type,
Object field,
List<Object> literals) |
boolean |
Equal.test(DataType type,
Object field,
Object literal) |
boolean |
Contains.test(DataType type,
Object field,
Object patternLiteral) |
boolean |
EndsWith.test(DataType type,
Object field,
Object patternLiteral) |
boolean |
NotEqual.test(DataType type,
Object field,
Object literal) |
boolean |
GreaterThan.test(DataType type,
Object field,
Object literal) |
boolean |
LessThan.test(DataType type,
Object field,
Object literal) |
boolean |
StartsWith.test(DataType type,
Object field,
Object patternLiteral) |
boolean |
GreaterOrEqual.test(DataType type,
Object field,
Object literal) |
abstract boolean |
NullFalseLeafBinaryFunction.test(DataType type,
Object field,
Object literal) |
boolean |
LessOrEqual.test(DataType type,
Object field,
Object literal) |
Constructor and Description |
---|
FieldRef(int index,
String name,
DataType type) |
LeafPredicate(LeafFunction function,
DataType type,
int fieldIndex,
String fieldName,
List<Object> literals) |
Modifier and Type | Field and Description |
---|---|
static List<Class<? extends DataType>> |
SchemaValidation.PRIMARY_KEY_UNSUPPORTED_LOGICAL_TYPES |
Modifier and Type | Method and Description |
---|---|
DataType |
SchemaChange.AddColumn.dataType() |
static DataType |
SchemaMergingUtils.merge(DataType base0,
DataType update0,
AtomicInteger highestFieldId,
boolean allowExplicitCast)
Merge the base data type and the update data type if possible.
|
DataType |
SchemaChange.UpdateColumnType.newDataType() |
Modifier and Type | Method and Description |
---|---|
static SchemaChange |
SchemaChange.addColumn(String fieldName,
DataType dataType) |
static SchemaChange |
SchemaChange.addColumn(String fieldName,
DataType dataType,
String comment) |
static SchemaChange |
SchemaChange.addColumn(String fieldName,
DataType dataType,
String comment,
SchemaChange.Move move) |
Schema.Builder |
Schema.Builder.column(String columnName,
DataType dataType)
Declares a column that is appended to this schema.
|
Schema.Builder |
Schema.Builder.column(String columnName,
DataType dataType,
String description)
Declares a column that is appended to this schema.
|
static DataType |
SchemaMergingUtils.merge(DataType base0,
DataType update0,
AtomicInteger highestFieldId,
boolean allowExplicitCast)
Merge the base data type and the update data type if possible.
|
static SchemaChange |
SchemaChange.updateColumnType(String fieldName,
DataType newDataType) |
static SchemaChange |
SchemaChange.updateColumnType(String fieldName,
DataType newDataType,
boolean keepNullability) |
Modifier and Type | Method and Description |
---|---|
static DataType |
SparkTypeUtils.toPaimonType(org.apache.spark.sql.types.DataType dataType) |
Modifier and Type | Method and Description |
---|---|
static org.apache.spark.sql.catalyst.util.MapData |
SparkInternalRow.fromPaimon(InternalMap map,
DataType mapType) |
static Object |
SparkInternalRow.fromPaimon(Object o,
DataType type) |
static org.apache.spark.sql.types.DataType |
SparkTypeUtils.fromPaimonType(DataType type) |
Constructor and Description |
---|
SparkArrayData(DataType elementType) |
Modifier and Type | Method and Description |
---|---|
void |
ColStats.deserializeFieldsFromString(DataType dataType) |
void |
ColStats.serializeFieldsToString(DataType dataType) |
Modifier and Type | Class and Description |
---|---|
class |
ArrayType
Data type of an array of elements with same subtype.
|
class |
BigIntType
Data type of an 8-byte signed integer with values from -9,223,372,036,854,775,808 to
9,223,372,036,854,775,807.
|
class |
BinaryType
Data type of a fixed-length binary string (=a sequence of bytes).
|
class |
BooleanType
Data type of a boolean with a (possibly) three-valued logic of
TRUE, FALSE, UNKNOWN . |
class |
CharType
Data type of a fixed-length character string.
|
class |
DateType
Data type of a date consisting of
year-month-day with values ranging from 0000-01-01 to 9999-12-31 . |
class |
DecimalType
Data type of a decimal number with fixed precision and scale.
|
class |
DoubleType
Data type of an 8-byte double precision floating point number.
|
class |
FloatType
Data type of a 4-byte single precision floating point number.
|
class |
IntType
Data type of a 4-byte signed integer with values from -2,147,483,648 to 2,147,483,647.
|
class |
LocalZonedTimestampType
Data type of a timestamp WITH LOCAL time zone consisting of
year-month-day
hour:minute:second[.fractional] zone with up to nanosecond precision and values ranging from
0000-01-01 00:00:00.000000000 +14:59 to 9999-12-31 23:59:59.999999999 -14:59 . |
class |
MapType
Data type of an associative array that maps keys (including
NULL ) to values (including
NULL ). |
class |
MultisetType
Data type of a multiset (=bag).
|
class |
RowType
Data type of a sequence of fields.
|
class |
SmallIntType
Data type of a 2-byte signed integer with values from -32,768 to 32,767.
|
class |
TimestampType
Data type of a timestamp WITHOUT time zone consisting of
year-month-day
hour:minute:second[.fractional] with up to nanosecond precision and values ranging from 0000-01-01 00:00:00.000000000 to 9999-12-31 23:59:59.999999999 . |
class |
TimeType
Data type of a time WITHOUT time zone consisting of
hour:minute:second[.fractional] with
up to nanosecond precision and values ranging from 00:00:00.000000000 to 23:59:59.999999999 . |
class |
TinyIntType
Data type of a 1-byte signed integer with values from -128 to 127.
|
class |
VarBinaryType
Data type of a variable-length binary string (=a sequence of bytes).
|
class |
VarCharType
Data type of a variable-length character string.
|
Modifier and Type | Method and Description |
---|---|
DataType |
DataType.copy()
Returns a deep copy of this type.
|
DataType |
BigIntType.copy(boolean isNullable) |
DataType |
BinaryType.copy(boolean isNullable) |
DataType |
DecimalType.copy(boolean isNullable) |
DataType |
MultisetType.copy(boolean isNullable) |
DataType |
FloatType.copy(boolean isNullable) |
DataType |
IntType.copy(boolean isNullable) |
abstract DataType |
DataType.copy(boolean isNullable)
Returns a deep copy of this type with possibly different nullability.
|
DataType |
TimestampType.copy(boolean isNullable) |
DataType |
MapType.copy(boolean isNullable) |
DataType |
BooleanType.copy(boolean isNullable) |
DataType |
RowType.copy(boolean isNullable) |
DataType |
TinyIntType.copy(boolean isNullable) |
DataType |
CharType.copy(boolean isNullable) |
DataType |
ArrayType.copy(boolean isNullable) |
DataType |
DateType.copy(boolean isNullable) |
DataType |
DoubleType.copy(boolean isNullable) |
DataType |
VarBinaryType.copy(boolean isNullable) |
DataType |
SmallIntType.copy(boolean isNullable) |
DataType |
LocalZonedTimestampType.copy(boolean isNullable) |
DataType |
TimeType.copy(boolean isNullable) |
DataType |
VarCharType.copy(boolean isNullable) |
protected DataType |
ReassignFieldId.defaultMethod(DataType dataType) |
DataType |
MultisetType.getElementType() |
DataType |
ArrayType.getElementType() |
DataType |
MapType.getKeyType() |
DataType |
RowType.getTypeAt(int i) |
DataType |
MapType.getValueType() |
DataType |
DataType.notNull() |
DataType |
DataType.nullable() |
static DataType |
DataTypeJsonParser.parseAtomicTypeSQLString(String string) |
static DataType |
DataTypeJsonParser.parseDataType(org.apache.paimon.shade.jackson2.com.fasterxml.jackson.databind.JsonNode json) |
static DataType |
ReassignFieldId.reassign(DataType input,
AtomicInteger fieldId) |
DataType |
DataField.type() |
DataType |
ReassignFieldId.visit(ArrayType arrayType) |
DataType |
ReassignFieldId.visit(MapType mapType) |
DataType |
ReassignFieldId.visit(MultisetType multisetType) |
DataType |
ReassignFieldId.visit(RowType rowType) |
Modifier and Type | Method and Description |
---|---|
List<DataType> |
RowType.getFieldTypes() |
static List<DataType> |
DataTypeChecks.getFieldTypes(DataType dataType)
Returns the field types of row and structured types.
|
static List<DataType> |
DataTypeChecks.getNestedTypes(DataType dataType) |
Modifier and Type | Method and Description |
---|---|
RowType |
RowType.appendDataField(String name,
DataType type) |
static ArrayType |
DataTypes.ARRAY(DataType element) |
protected abstract R |
DataTypeDefaultVisitor.defaultMethod(DataType dataType) |
protected DataType |
ReassignFieldId.defaultMethod(DataType dataType) |
boolean |
DataType.equalsIgnoreNullable(DataType o)
Compare two data types without nullable.
|
static DataField |
DataTypes.FIELD(int id,
String name,
DataType type) |
static DataField |
DataTypes.FIELD(int id,
String name,
DataType type,
String description) |
RowType.Builder |
RowType.Builder.field(String name,
DataType type) |
RowType.Builder |
RowType.Builder.field(String name,
DataType type,
String description) |
RowType.Builder |
RowType.Builder.fields(DataType... types) |
RowType.Builder |
RowType.Builder.fields(DataType[] types,
String[] names) |
static int |
DataTypeChecks.getFieldCount(DataType dataType)
Returns the field count of row and structured types.
|
static List<String> |
DataTypeChecks.getFieldNames(DataType dataType)
Returns the field names of row and structured types.
|
static List<DataType> |
DataTypeChecks.getFieldTypes(DataType dataType)
Returns the field types of row and structured types.
|
static OptionalInt |
DataTypes.getLength(DataType dataType) |
static int |
DataTypeChecks.getLength(DataType dataType) |
static List<DataType> |
DataTypeChecks.getNestedTypes(DataType dataType) |
static OptionalInt |
DataTypes.getPrecision(DataType dataType) |
static Integer |
DataTypeChecks.getPrecision(DataType dataType)
Returns the precision of all types that define a precision implicitly or explicitly.
|
static int |
DataTypeChecks.getScale(DataType dataType)
Returns the scale of all types that define a scale implicitly or explicitly.
|
static boolean |
DataTypeChecks.hasLength(DataType dataType,
int length) |
static boolean |
DataTypeChecks.hasPrecision(DataType dataType,
int precision)
Checks the precision of a type that defines a precision implicitly or explicitly.
|
static boolean |
DataTypeChecks.hasScale(DataType dataType,
int scale)
Checks the scale of all types that define a scale implicitly or explicitly.
|
static boolean |
DataTypeChecks.hasWellDefinedString(DataType dataType)
Checks whether the given
DataType has a well-defined string representation when
calling Object.toString() on the internal data structure. |
static boolean |
DataTypeChecks.isCompositeType(DataType dataType)
Checks if the given type is a composite type.
|
static MapType |
DataTypes.MAP(DataType keyType,
DataType valueType) |
static MultisetType |
DataTypes.MULTISET(DataType elementType) |
static RowType |
RowType.of(DataType... types) |
static RowType |
RowType.of(DataType[] types,
String[] names) |
static DataType |
ReassignFieldId.reassign(DataType input,
AtomicInteger fieldId) |
static RowType |
DataTypes.ROW(DataType... fieldTypes) |
static boolean |
DataTypeCasts.supportsCompatibleCast(DataType sourceType,
DataType targetType)
Returns whether the source type can be compatibly cast to the target type.
|
static boolean |
DataTypeCasts.supportsExplicitCast(DataType sourceType,
DataType targetType)
Returns whether the source type can be cast to the target type.
|
static boolean |
DataTypeCasts.supportsImplicitCast(DataType sourceType,
DataType targetType)
Returns whether the source type can be safely cast to the target type without loosing
information.
|
Modifier and Type | Method and Description |
---|---|
RowType.Builder |
RowType.Builder.fields(List<DataType> types) |
Constructor and Description |
---|
ArrayType(boolean isNullable,
DataType elementType) |
ArrayType(DataType elementType) |
DataField(int id,
String name,
DataType dataType) |
DataField(int id,
String name,
DataType type,
String description) |
MapType(boolean isNullable,
DataType keyType,
DataType valueType) |
MapType(DataType keyType,
DataType valueType) |
MultisetType(boolean isNullable,
DataType elementType) |
MultisetType(DataType elementType) |
Modifier and Type | Method and Description |
---|---|
DataType[] |
ObjectSerializer.fieldTypes() |
Modifier and Type | Method and Description |
---|---|
static Object |
TypeUtils.castFromCdcValueString(String s,
DataType type) |
static Object |
TypeUtils.castFromString(String s,
DataType type) |
static Object |
TypeUtils.castFromStringInternal(String s,
DataType type,
boolean isCdcValue) |
static Object |
InternalRowUtils.copy(Object o,
DataType type) |
static InternalArray |
InternalRowUtils.copyArray(InternalArray from,
DataType eleType) |
static ColumnVector |
VectorMappingUtils.createFixedVector(DataType dataType,
BinaryRow partition,
int index) |
static InternalRow.FieldGetter |
InternalRowUtils.createNullCheckingFieldGetter(DataType dataType,
int index) |
static Object |
InternalRowUtils.get(DataGetters dataGetters,
int pos,
DataType fieldType) |
static boolean |
TypeCheckUtils.isArray(DataType type) |
static boolean |
TypeCheckUtils.isBinaryString(DataType type) |
static boolean |
TypeCheckUtils.isBoolean(DataType type) |
static boolean |
TypeCheckUtils.isCharacterString(DataType type) |
static boolean |
TypeCheckUtils.isComparable(DataType type) |
static boolean |
TypeCheckUtils.isDecimal(DataType type) |
static boolean |
TypeCheckUtils.isInteger(DataType type) |
static boolean |
TypeUtils.isInteroperable(DataType t1,
DataType t2)
Can the two types operate with each other.
|
static boolean |
TypeCheckUtils.isLong(DataType type) |
static boolean |
TypeCheckUtils.isMap(DataType type) |
static boolean |
TypeCheckUtils.isMultiset(DataType type) |
static boolean |
TypeCheckUtils.isMutable(DataType type) |
static boolean |
TypeCheckUtils.isNumeric(DataType type) |
static boolean |
TypeUtils.isPrimitive(DataType type) |
static boolean |
TypeCheckUtils.isReference(DataType type) |
static boolean |
TypeCheckUtils.isRow(DataType type) |
static boolean |
TypeCheckUtils.isTemporal(DataType type) |
static boolean |
TypeCheckUtils.isTimePoint(DataType type) |
static boolean |
TypeCheckUtils.isTimestamp(DataType type) |
static boolean |
TypeCheckUtils.isTimestampWithLocalZone(DataType type) |
static byte[] |
BinaryStringUtils.toBinaryString(byte[] byteArrayTerm,
DataType type) |
static BinaryString |
BinaryStringUtils.toCharacterString(BinaryString strData,
DataType type) |
Modifier and Type | Method and Description |
---|---|
static InternalRow.FieldGetter[] |
InternalRowUtils.createFieldGetters(List<DataType> fieldTypes) |
Copyright © 2023–2024 The Apache Software Foundation. All rights reserved.