Instance Constructors
-
new
OffHeapColumnVector(capacity: Int, type: DataType)
Value Members
-
final
def
!=(arg0: Any): Boolean
-
final
def
##(): Int
-
final
def
==(arg0: Any): Boolean
-
final
def
anyNullsSet(): Boolean
-
final
def
appendArray(length: Int): Int
-
final
def
appendBoolean(v: Boolean): Int
-
final
def
appendBooleans(count: Int, v: Boolean): Int
-
final
def
appendByte(v: Byte): Int
-
final
def
appendByteArray(value: Array[Byte], offset: Int, length: Int): Int
-
final
def
appendBytes(length: Int, src: Array[Byte], offset: Int): Int
-
final
def
appendBytes(count: Int, v: Byte): Int
-
final
def
appendDouble(v: Double): Int
-
final
def
appendDoubles(length: Int, src: Array[Double], offset: Int): Int
-
final
def
appendDoubles(count: Int, v: Double): Int
-
final
def
appendFloat(v: Float): Int
-
final
def
appendFloats(count: Int, v: Float): Int
-
final
def
appendInt(v: Int): Int
-
final
def
appendInts(length: Int, src: Array[Int], offset: Int): Int
-
final
def
appendInts(count: Int, v: Int): Int
-
final
def
appendLong(v: Long): Int
-
final
def
appendLongs(length: Int, src: Array[Long], offset: Int): Int
-
final
def
appendLongs(count: Int, v: Long): Int
-
final
def
appendNotNull(): Int
-
final
def
appendNotNulls(count: Int): Int
-
final
def
appendNull(): Int
-
final
def
appendNulls(count: Int): Int
-
final
def
appendShort(v: Short): Int
-
final
def
appendShorts(length: Int, src: Array[Short], offset: Int): Int
-
final
def
appendShorts(count: Int, v: Short): Int
-
final
def
appendStruct(isNull: Boolean): Int
-
-
final
def
asInstanceOf[T0]: T0
-
def
clone(): AnyRef
-
def
close(): Unit
-
final
def
dataType(): DataType
-
final
def
eq(arg0: AnyRef): Boolean
-
def
equals(arg0: Any): Boolean
-
def
finalize(): Unit
-
final
def
getArray(rowId: Int): Array
-
def
getArrayLength(rowId: Int): Int
-
def
getArrayOffset(rowId: Int): Int
-
final
def
getBinary(rowId: Int): Array[Byte]
-
def
getBoolean(rowId: Int): Boolean
-
def
getByte(rowId: Int): Byte
-
final
def
getChildColumn(ordinal: Int): ColumnVector
-
final
def
getClass(): Class[_]
-
final
def
getDecimal(rowId: Int, precision: Int, scale: Int): Decimal
-
def
getDictId(rowId: Int): Int
-
-
def
getDouble(rowId: Int): Double
-
final
def
getElementsAppended(): Int
-
def
getFloat(rowId: Int): Float
-
def
getInt(rowId: Int): Int
-
def
getLong(rowId: Int): Long
-
def
getMap(ordinal: Int): MapData
-
def
getShort(rowId: Int): Short
-
def
getStruct(rowId: Int, size: Int): ColumnarBatch.Row
-
def
getStruct(rowId: Int): ColumnarBatch.Row
-
final
def
getUTF8String(rowId: Int): UTF8String
-
def
hasDictionary(): Boolean
-
def
hashCode(): Int
-
final
def
isArray(): Boolean
-
final
def
isInstanceOf[T0]: Boolean
-
def
isNullAt(rowId: Int): Boolean
-
def
loadBytes(array: Array): Unit
-
final
def
ne(arg0: AnyRef): Boolean
-
final
def
notify(): Unit
-
final
def
notifyAll(): Unit
-
def
nullsNativeAddress(): Long
-
final
def
numNulls(): Int
-
def
putArray(rowId: Int, offset: Int, length: Int): Unit
-
def
putBoolean(rowId: Int, value: Boolean): Unit
-
def
putBooleans(rowId: Int, count: Int, value: Boolean): Unit
-
def
putByte(rowId: Int, value: Byte): Unit
-
def
putByteArray(rowId: Int, value: Array[Byte], offset: Int, length: Int): Int
-
final
def
putByteArray(rowId: Int, value: Array[Byte]): Int
-
def
putBytes(rowId: Int, count: Int, src: Array[Byte], srcIndex: Int): Unit
-
def
putBytes(rowId: Int, count: Int, value: Byte): Unit
-
final
def
putDecimal(rowId: Int, value: Decimal, precision: Int): Unit
-
def
putDouble(rowId: Int, value: Double): Unit
-
def
putDoubles(rowId: Int, count: Int, src: Array[Byte], srcIndex: Int): Unit
-
def
putDoubles(rowId: Int, count: Int, src: Array[Double], srcIndex: Int): Unit
-
def
putDoubles(rowId: Int, count: Int, value: Double): Unit
-
def
putFloat(rowId: Int, value: Float): Unit
-
def
putFloats(rowId: Int, count: Int, src: Array[Byte], srcIndex: Int): Unit
-
def
putFloats(rowId: Int, count: Int, src: Array[Float], srcIndex: Int): Unit
-
def
putFloats(rowId: Int, count: Int, value: Float): Unit
-
def
putInt(rowId: Int, value: Int): Unit
-
def
putInts(rowId: Int, count: Int, src: Array[Int], srcIndex: Int): Unit
-
def
putInts(rowId: Int, count: Int, value: Int): Unit
-
def
putIntsLittleEndian(rowId: Int, count: Int, src: Array[Byte], srcIndex: Int): Unit
-
def
putLong(rowId: Int, value: Long): Unit
-
def
putLongs(rowId: Int, count: Int, src: Array[Long], srcIndex: Int): Unit
-
def
putLongs(rowId: Int, count: Int, value: Long): Unit
-
def
putLongsLittleEndian(rowId: Int, count: Int, src: Array[Byte], srcIndex: Int): Unit
-
def
putNotNull(rowId: Int): Unit
-
def
putNotNulls(rowId: Int, count: Int): Unit
-
def
putNull(rowId: Int): Unit
-
def
putNulls(rowId: Int, count: Int): Unit
-
def
putShort(rowId: Int, value: Short): Unit
-
def
putShorts(rowId: Int, count: Int, src: Array[Short], srcIndex: Int): Unit
-
def
putShorts(rowId: Int, count: Int, value: Short): Unit
-
def
reserve(requiredCapacity: Int): Unit
-
def
reserveDictionaryIds(capacity: Int): ColumnVector
-
def
reserveInternal(newCapacity: Int): Unit
-
def
reset(): Unit
-
def
setDictionary(dictionary: Dictionary): Unit
-
final
def
setIsConstant(): Unit
-
final
def
synchronized[T0](arg0: ⇒ T0): T0
-
def
toString(): String
-
def
valuesNativeAddress(): Long
-
final
def
wait(): Unit
-
final
def
wait(arg0: Long, arg1: Int): Unit
-
final
def
wait(arg0: Long): Unit
Inherited from AutoCloseable
Inherited from Any