Modifier and Type | Method and Description |
---|---|
StringData |
EnrichedRowData.getString(int pos) |
Modifier and Type | Method and Description |
---|---|
static StringData |
StringData.fromBytes(byte[] bytes)
Creates an instance of
StringData from the given UTF-8 byte array. |
static StringData |
StringData.fromBytes(byte[] bytes,
int offset,
int numBytes)
Creates an instance of
StringData from the given UTF-8 byte array with offset and
number of bytes. |
static StringData |
StringData.fromString(String str)
Creates an instance of
StringData from the given String . |
StringData |
BoxedWrapperRowData.getString(int pos) |
StringData |
UpdatableRowData.getString(int pos) |
StringData |
GenericArrayData.getString(int pos) |
StringData |
ArrayData.getString(int pos)
Returns the string value at the given position.
|
StringData |
RowData.getString(int pos)
Returns the string value at the given position.
|
StringData |
GenericRowData.getString(int pos) |
Modifier and Type | Class and Description |
---|---|
class |
BinaryStringData
|
Modifier and Type | Method and Description |
---|---|
StringData |
BinaryRowData.getString(int pos) |
StringData |
NestedRowData.getString(int pos) |
StringData |
BinaryArrayData.getString(int pos) |
static StringData |
BinarySegmentUtils.readStringData(MemorySegment[] segments,
int baseOffset,
int fieldOffset,
long variablePartOffsetAndLen)
Get binary string, if len less than 8, will be include in variablePartOffsetAndLen.
|
Modifier and Type | Method and Description |
---|---|
int |
BinaryStringData.compareTo(StringData o)
Compares two strings lexicographically.
|
Modifier and Type | Method and Description |
---|---|
StringData |
ColumnarRowData.getString(int pos) |
StringData |
ColumnarArrayData.getString(int pos) |
Modifier and Type | Method and Description |
---|---|
StringData |
StringByteArrayConverter.toInternal(byte[] external) |
StringData |
StringStringConverter.toInternal(String external) |
Modifier and Type | Method and Description |
---|---|
byte[] |
StringByteArrayConverter.toExternal(StringData internal) |
String |
StringStringConverter.toExternal(StringData internal) |
Modifier and Type | Method and Description |
---|---|
StringData |
JoinedRowData.getString(int pos) |
StringData |
ProjectedRowData.getString(int pos) |
Modifier and Type | Method and Description |
---|---|
void |
BinaryWriter.writeString(int pos,
StringData value) |
Modifier and Type | Field and Description |
---|---|
StringData |
ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator.delimiter |
Modifier and Type | Field and Description |
---|---|
ListView<StringData> |
ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator.list |
ListView<StringData> |
ListAggWithRetractAggFunction.ListAggWithRetractAccumulator.list |
ListView<StringData> |
JsonArrayAggFunction.Accumulator.list |
MapView<StringData,StringData> |
JsonObjectAggFunction.Accumulator.map |
MapView<StringData,StringData> |
JsonObjectAggFunction.Accumulator.map |
ListView<StringData> |
ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator.retractList |
ListView<StringData> |
ListAggWithRetractAggFunction.ListAggWithRetractAccumulator.retractList |
Modifier and Type | Method and Description |
---|---|
StringData |
ListAggWithRetractAggFunction.getValue(ListAggWithRetractAggFunction.ListAggWithRetractAccumulator acc) |
StringData |
ListAggWsWithRetractAggFunction.getValue(ListAggWsWithRetractAggFunction.ListAggWsWithRetractAccumulator acc) |
Modifier and Type | Method and Description |
---|---|
StringData |
TypeOfFunction.eval(Object... unused) |
Modifier and Type | Method and Description |
---|---|
static void |
SortUtil.putStringNormalizedKey(StringData value,
MemorySegment target,
int offset,
int numBytes)
UTF-8 supports bytes comparison.
|
Modifier and Type | Method and Description |
---|---|
StringData |
StringDataSerializer.copy(StringData from) |
StringData |
StringDataSerializer.copy(StringData from,
StringData reuse) |
StringData |
StringDataSerializer.createInstance() |
StringData |
StringDataSerializer.deserialize(DataInputView source) |
StringData |
StringDataSerializer.deserialize(StringData record,
DataInputView source) |
static StringData |
StringDataSerializer.deserializeInternal(DataInputView source) |
Modifier and Type | Method and Description |
---|---|
TypeSerializer<StringData> |
StringDataTypeInfo.createSerializer(ExecutionConfig config) |
Class<StringData> |
StringDataTypeInfo.getTypeClass() |
TypeSerializerSnapshot<StringData> |
StringDataSerializer.snapshotConfiguration() |
Modifier and Type | Method and Description |
---|---|
StringData |
StringDataSerializer.copy(StringData from) |
StringData |
StringDataSerializer.copy(StringData from,
StringData reuse) |
StringData |
StringDataSerializer.deserialize(StringData record,
DataInputView source) |
void |
StringDataSerializer.serialize(StringData record,
DataOutputView target) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.