Modifier and Type | Method and Description |
---|---|
TimestampData |
EnrichedRowData.getTimestamp(int pos,
int precision) |
Modifier and Type | Method and Description |
---|---|
TimestampData |
ParquetDictionary.decodeToTimestamp(int id) |
Modifier and Type | Method and Description |
---|---|
static TimestampData |
TimestampColumnReader.decodeInt64ToTimestamp(boolean utcTimestamp,
org.apache.parquet.column.Dictionary dictionary,
int id,
org.apache.parquet.schema.LogicalTypeAnnotation.TimeUnit timeUnit) |
static TimestampData |
TimestampColumnReader.decodeInt96ToTimestamp(boolean utcTimestamp,
org.apache.parquet.column.Dictionary dictionary,
int id) |
static TimestampData |
TimestampColumnReader.int64ToTimestamp(boolean utcTimestamp,
long value,
org.apache.parquet.schema.LogicalTypeAnnotation.TimeUnit timeUnit) |
static TimestampData |
TimestampColumnReader.int96ToTimestamp(boolean utcTimestamp,
long nanosOfDay,
int julianDay) |
TimestampData |
ParquetDataColumnReader.readTimestamp() |
TimestampData |
ParquetDataColumnReaderFactory.DefaultParquetDataColumnReader.readTimestamp() |
TimestampData |
ParquetDataColumnReaderFactory.TypesFromInt96PageReader.readTimestamp() |
TimestampData |
ParquetDataColumnReader.readTimestamp(int id) |
TimestampData |
ParquetDataColumnReaderFactory.DefaultParquetDataColumnReader.readTimestamp(int id) |
TimestampData |
ParquetDataColumnReaderFactory.TypesFromInt96PageReader.readTimestamp(int id) |
Modifier and Type | Method and Description |
---|---|
TimestampData |
OrcNoHiveTimestampVector.getTimestamp(int i,
int precision) |
Modifier and Type | Method and Description |
---|---|
TimestampData |
OrcTimestampColumnVector.getTimestamp(int i,
int precision) |
TimestampData |
OrcLegacyTimestampColumnVector.getTimestamp(int i,
int precision) |
Modifier and Type | Method and Description |
---|---|
static TimestampData |
TimestampData.fromEpochMillis(long milliseconds)
Creates an instance of
TimestampData from milliseconds. |
static TimestampData |
TimestampData.fromEpochMillis(long milliseconds,
int nanosOfMillisecond)
Creates an instance of
TimestampData from milliseconds and a nanos-of-millisecond. |
static TimestampData |
TimestampData.fromInstant(Instant instant)
Creates an instance of
TimestampData from an instance of Instant . |
static TimestampData |
TimestampData.fromLocalDateTime(LocalDateTime dateTime)
Creates an instance of
TimestampData from an instance of LocalDateTime . |
static TimestampData |
TimestampData.fromTimestamp(Timestamp timestamp)
Creates an instance of
TimestampData from an instance of Timestamp . |
TimestampData |
UpdatableRowData.getTimestamp(int pos,
int precision) |
TimestampData |
BoxedWrapperRowData.getTimestamp(int pos,
int precision) |
TimestampData |
RowData.getTimestamp(int pos,
int precision)
Returns the timestamp value at the given position.
|
TimestampData |
GenericRowData.getTimestamp(int pos,
int precision) |
TimestampData |
GenericArrayData.getTimestamp(int pos,
int precision) |
TimestampData |
ArrayData.getTimestamp(int pos,
int precision)
Returns the timestamp value at the given position.
|
Modifier and Type | Method and Description |
---|---|
int |
TimestampData.compareTo(TimestampData that) |
void |
UpdatableRowData.setTimestamp(int pos,
TimestampData value,
int precision) |
void |
BoxedWrapperRowData.setTimestamp(int pos,
TimestampData value,
int precision) |
Modifier and Type | Method and Description |
---|---|
TimestampData |
NestedRowData.getTimestamp(int pos,
int precision) |
TimestampData |
BinaryArrayData.getTimestamp(int pos,
int precision) |
TimestampData |
BinaryRowData.getTimestamp(int pos,
int precision) |
static TimestampData |
BinarySegmentUtils.readTimestampData(MemorySegment[] segments,
int baseOffset,
long offsetAndNanos)
Gets an instance of
TimestampData from underlying MemorySegment . |
static TimestampData |
BinaryStringDataUtil.toTimestamp(BinaryStringData input,
int precision)
Used by
CAST(x as TIMESTAMP) . |
static TimestampData |
BinaryStringDataUtil.toTimestamp(BinaryStringData input,
int precision,
TimeZone timeZone)
Used by
CAST(x as TIMESTAMP_LTZ) . |
Modifier and Type | Method and Description |
---|---|
void |
TypedSetters.setTimestamp(int pos,
TimestampData value,
int precision)
Set Timestamp value.
|
void |
NestedRowData.setTimestamp(int pos,
TimestampData value,
int precision) |
void |
BinaryArrayData.setTimestamp(int pos,
TimestampData value,
int precision) |
void |
BinaryRowData.setTimestamp(int pos,
TimestampData value,
int precision) |
Modifier and Type | Method and Description |
---|---|
TimestampData |
ColumnarRowData.getTimestamp(int pos,
int precision) |
TimestampData |
ColumnarArrayData.getTimestamp(int pos,
int precision) |
Modifier and Type | Method and Description |
---|---|
void |
ColumnarRowData.setTimestamp(int pos,
TimestampData value,
int precision) |
void |
ColumnarArrayData.setTimestamp(int pos,
TimestampData value,
int precision) |
Modifier and Type | Method and Description |
---|---|
TimestampData |
Dictionary.decodeToTimestamp(int id) |
TimestampData |
TimestampColumnVector.getTimestamp(int i,
int precision) |
TimestampData |
VectorizedColumnBatch.getTimestamp(int rowId,
int colId,
int precision) |
Modifier and Type | Method and Description |
---|---|
TimestampData |
HeapTimestampVector.getTimestamp(int i,
int precision) |
Modifier and Type | Method and Description |
---|---|
void |
HeapTimestampVector.fill(TimestampData value) |
void |
HeapTimestampVector.setTimestamp(int i,
TimestampData timestamp) |
Modifier and Type | Method and Description |
---|---|
void |
WritableTimestampVector.fill(TimestampData value)
Fill the column vector with the provided value.
|
void |
WritableTimestampVector.setTimestamp(int rowId,
TimestampData timestamp)
Set
TimestampData at rowId with the provided value. |
Modifier and Type | Method and Description |
---|---|
TimestampData |
LocalZonedTimestampInstantConverter.toInternal(Instant external) |
TimestampData |
LocalZonedTimestampIntConverter.toInternal(Integer external) |
TimestampData |
TimestampLocalDateTimeConverter.toInternal(LocalDateTime external) |
TimestampData |
LocalZonedTimestampLongConverter.toInternal(Long external) |
TimestampData |
LocalZonedTimestampTimestampConverter.toInternal(Timestamp external) |
TimestampData |
TimestampTimestampConverter.toInternal(Timestamp external) |
Modifier and Type | Method and Description |
---|---|
LocalDateTime |
TimestampLocalDateTimeConverter.toExternal(TimestampData internal) |
Timestamp |
LocalZonedTimestampTimestampConverter.toExternal(TimestampData internal) |
Timestamp |
TimestampTimestampConverter.toExternal(TimestampData internal) |
Long |
LocalZonedTimestampLongConverter.toExternal(TimestampData internal) |
Instant |
LocalZonedTimestampInstantConverter.toExternal(TimestampData internal) |
Integer |
LocalZonedTimestampIntConverter.toExternal(TimestampData internal) |
Modifier and Type | Method and Description |
---|---|
TimestampData |
JoinedRowData.getTimestamp(int pos,
int precision) |
TimestampData |
ProjectedRowData.getTimestamp(int pos,
int precision) |
Modifier and Type | Method and Description |
---|---|
void |
BinaryWriter.writeTimestamp(int pos,
TimestampData value,
int precision) |
Modifier and Type | Method and Description |
---|---|
TimestampData |
ArrowTimestampColumnVector.getTimestamp(int i,
int precision) |
Modifier and Type | Method and Description |
---|---|
TimestampData |
SourceWatermarkFunction.eval() |
Modifier and Type | Method and Description |
---|---|
static void |
SortUtil.putTimestampNormalizedKey(TimestampData value,
MemorySegment target,
int offset,
int numBytes)
Support the compact precision TimestampData.
|
Modifier and Type | Method and Description |
---|---|
TimestampData |
TimestampDataSerializer.copy(TimestampData from) |
TimestampData |
TimestampDataSerializer.copy(TimestampData from,
TimestampData reuse) |
TimestampData |
TimestampDataSerializer.createInstance() |
TimestampData |
TimestampDataSerializer.deserialize(DataInputView source) |
TimestampData |
TimestampDataSerializer.deserialize(TimestampData reuse,
DataInputView source) |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<TimestampData> |
TimestampDataTypeInfo.createSerializer(ExecutionConfig config) |
TypeSerializer<TimestampData> |
TimestampDataTypeInfo.createSerializer(SerializerConfig config) |
TypeSerializer<TimestampData> |
TimestampDataSerializer.duplicate() |
Class<TimestampData> |
TimestampDataTypeInfo.getTypeClass() |
TypeSerializerSchemaCompatibility<TimestampData> |
TimestampDataSerializer.TimestampDataSerializerSnapshot.resolveSchemaCompatibility(TypeSerializerSnapshot<TimestampData> oldSerializerSnapshot) |
TypeSerializer<TimestampData> |
TimestampDataSerializer.TimestampDataSerializerSnapshot.restoreSerializer() |
TypeSerializerSnapshot<TimestampData> |
TimestampDataSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
TimestampData |
TimestampDataSerializer.copy(TimestampData from) |
TimestampData |
TimestampDataSerializer.copy(TimestampData from,
TimestampData reuse) |
TimestampData |
TimestampDataSerializer.deserialize(TimestampData reuse,
DataInputView source) |
void |
TimestampDataSerializer.serialize(TimestampData record,
DataOutputView target) |
Modifier and Type | Method and Description |
---|---|
TypeSerializerSchemaCompatibility<TimestampData> |
TimestampDataSerializer.TimestampDataSerializerSnapshot.resolveSchemaCompatibility(TypeSerializerSnapshot<TimestampData> oldSerializerSnapshot) |
Modifier and Type | Method and Description |
---|---|
static TimestampData |
DateTimeUtils.dateToTimestampWithLocalZone(int date,
TimeZone tz) |
static TimestampData |
DateTimeUtils.parseTimestampData(String dateStr) |
static TimestampData |
DateTimeUtils.parseTimestampData(String dateStr,
int precision) |
static TimestampData |
DateTimeUtils.parseTimestampData(String dateStr,
int precision,
TimeZone timeZone) |
static TimestampData |
DateTimeUtils.parseTimestampData(String dateStr,
String format) |
static TimestampData |
DateTimeUtils.timestampToTimestampWithLocalZone(TimestampData ts,
TimeZone tz) |
static TimestampData |
DateTimeUtils.timestampWithLocalZoneToTimestamp(TimestampData ts,
TimeZone tz) |
static TimestampData |
DateTimeUtils.timeToTimestampWithLocalZone(int time,
TimeZone tz) |
static TimestampData |
DateTimeUtils.toTimestampData(DecimalData v,
int precision) |
static TimestampData |
DateTimeUtils.toTimestampData(double v,
int precision) |
static TimestampData |
DateTimeUtils.toTimestampData(long v,
int precision) |
static TimestampData |
DateTimeUtils.truncate(TimestampData ts,
int precision) |
Modifier and Type | Method and Description |
---|---|
static long |
DateTimeUtils.extractFromTimestamp(DateTimeUtils.TimeUnitRange range,
TimestampData ts,
TimeZone tz) |
static String |
DateTimeUtils.formatTimestamp(TimestampData ts,
String format) |
static String |
DateTimeUtils.formatTimestamp(TimestampData ts,
String format,
TimeZone zone) |
static String |
DateTimeUtils.formatTimestamp(TimestampData ts,
TimeZone tz,
int precision) |
static TimestampData |
DateTimeUtils.timestampToTimestampWithLocalZone(TimestampData ts,
TimeZone tz) |
static int |
DateTimeUtils.timestampWithLocalZoneToDate(TimestampData ts,
TimeZone tz) |
static int |
DateTimeUtils.timestampWithLocalZoneToTime(TimestampData ts,
TimeZone tz) |
static TimestampData |
DateTimeUtils.timestampWithLocalZoneToTimestamp(TimestampData ts,
TimeZone tz) |
static TimestampData |
DateTimeUtils.truncate(TimestampData ts,
int precision) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.