store

package
v0.0.0-...-1e7f4ca Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Sep 19, 2023 License: Apache-2.0 Imports: 32 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

View Source
var (
	BOOLEAN_INSTANCE_SIZE   int32                    = util.SizeOf(&BooleanColumnWriter{})
	BOOLEAN_COLUMN_ENCODING *metadata.ColumnEncoding = metadata.NewColumnEncoding(metadata.DIRECT, 0)
)
View Source
var (
	W_BYTE_INSTANCE_SIZE int32                    = util.SizeOf(&ByteColumnWriter{})
	BYTE_COLUMN_ENCODING *metadata.ColumnEncoding = metadata.NewColumnEncoding(metadata.DIRECT, 0)
)
View Source
var (
	BYTE_INSTANCE_SIZE     int32 = util.SizeOf(&ByteOutputStream{})
	BYTE_MIN_REPEAT_SIZE   int32 = 3
	BYTE_UNMATCHABLE_VALUE int32 = math.MaxInt32
)
View Source
var (
	CHUNKED_INSTANCE_SIZE  int32 = util.SizeOf(&ChunkedSliceOutput{})
	MINIMUM_CHUNK_SIZE     int32 = 4096
	MAXIMUM_CHUNK_SIZE     int32 = 16 * 1024 * 1024
	MAX_UNUSED_BUFFER_SIZE int32 = 128
)
View Source
var (
	DECAYTDIGEST_RESCALE_THRESHOLD_SECONDS int64   = 50 //@VisibleForTesting
	ZERO_WEIGHT_THRESHOLD                  float64 = 1e-5
	SCALE_FACTOR                           float64 = 1 / ZERO_WEIGHT_THRESHOLD
)
View Source
var (
	LONG_MASK uint64 = 0x80_80_80_80_80_80_80_80
	INT_MASK  uint32 = 0x80_80_80_80
)
View Source
var (
	EXTRA_COMPRESSION_SPACE int32 = 16
	COMPRESSION_LEVEL       int   = 4
)
View Source
var (
	DICTIONARY_INSTANCE_SIZE            int32   = util.SizeOf(&DictionaryBuilder{})
	DICTIONARY_FILL_RATIO               float32 = 0.75
	DICTIONARY_EMPTY_SLOT               int32   = -1
	DICTIONARY_NULL_POSITION            int32   = 0
	DICTIONARY_EXPECTED_BYTES_PER_ENTRY int32   = 32
)
View Source
var (
	DICTIONARY_MIN_COMPRESSION_RATIO float64       = 1.25
	DICTIONARY_MEMORY_MAX_RANGE      util.DataSize = util.Ofds(4, util.MB)
	DIRECT_COLUMN_SIZE_RANGE         util.DataSize = util.Ofds(4, util.MB)
)
View Source
var (
	DOUBLE_INSTANCE_SIZE   int32                    = util.SizeOf(&DoubleColumnWriter{})
	DOUBLE_COLUMN_ENCODING *metadata.ColumnEncoding = metadata.NewColumnEncoding(metadata.DIRECT, 0)
)
View Source
var (
	FLOAT_INSTANCE_SIZE   int32                    = util.SizeOf(&FloatColumnWriter{})
	FLOAT_COLUMN_ENCODING *metadata.ColumnEncoding = metadata.NewColumnEncoding(metadata.DIRECT, 0)
)
View Source
var (
	LONGV1_MIN_REPEAT_SIZE  int32 = 3
	LONGV1_MAX_LITERAL_SIZE int32 = 128
)
View Source
var (
	LONGINPUTV2_MIN_REPEAT_SIZE  int32 = 3
	LONGINPUTV2_MAX_LITERAL_SIZE int32 = 512
)
View Source
var (
	LONG_OUTPUTV1_INSTANCE_SIZE           int32 = util.SizeOf(&LongOutputStreamV1{})
	LONG_OUTPUTV1_MIN_REPEAT_SIZE         int32 = 3
	LONG_OUTPUTV1_UNMATCHABLE_DELTA_VALUE int64 = math.MaxInt64
	LONG_OUTPUTV1_MAX_DELTA               int32 = 127
	LONG_OUTPUTV1_MIN_DELTA               int32 = -128
)
View Source
var (
	LONG_OUTPUTV2_INSTANCE_SIZE           int32 = util.SizeOf(&LongOutputStreamV2{})
	LONG_OUTPUTV2_MAX_SCOPE               int32 = 512
	LONG_OUTPUTV2_MIN_REPEAT              int32 = 3
	LONG_OUTPUTV2_MAX_SHORT_REPEAT_LENGTH int32 = 10
)
View Source
var (
	MOTHOUTPUT_INSTANCE_SIZE         int32 = util.SizeOf(&MothOutputBuffer{})
	INITIAL_BUFFER_SIZE              int32 = 256
	DIRECT_FLUSH_SIZE                int32 = 32 * 1024
	MINIMUM_OUTPUT_BUFFER_CHUNK_SIZE int32 = 4 * 1024
	MAXIMUM_OUTPUT_BUFFER_CHUNK_SIZE int32 = 1024 * 1024
)
View Source
var (
	MAX_BATCH_SIZE           int32 = 8196
	INITIAL_BATCH_SIZE       int32 = 1
	BATCH_SIZE_GROWTH_FACTOR int32 = 2
	// mothReaderlog                      *Logger = Logger.get(MothReader.class)
	CURRENT_MAJOR_VERSION uint32 = 0
	CURRENT_MINOR_VERSION uint32 = 12
	EXPECTED_FOOTER_SIZE  int64  = 16 * 1024
)
View Source
var (
	DEFAULT_BLOOM_FILTERS_ENABLED  bool          = false
	DEFAULT_MAX_MERGE_DISTANCE     util.DataSize = util.Ofds(1, util.MB)
	DEFAULT_MAX_BUFFER_SIZE        util.DataSize = util.Ofds(8, util.MB)
	DEFAULT_TINY_STRIPE_THRESHOLD  util.DataSize = util.Ofds(8, util.MB)
	DEFAULT_STREAM_BUFFER_SIZE     util.DataSize = util.Ofds(8, util.MB)
	DEFAULT_MAX_BLOCK_SIZE         util.DataSize = util.Ofds(16, util.MB)
	DEFAULT_LAZY_READ_SMALL_RANGES bool          = true
	DEFAULT_NESTED_LAZY            bool          = true
)
View Source
var (
	MOTHWRITER_INSTANCE_SIZE                int32  = util.SizeOf(&MothWriter{})
	MOTHDB_MOTH_WRITER_VERSION_METADATA_KEY string = "moth.writer.version"
	MOTHDB_MOTH_WRITER_VERSION              string
)
View Source
var (
	DEFAULT_MAX_STRING_STATISTICS_LIMIT util.DataSize = util.Ofds(64, util.B) //@VisibleForTesting
	DEFAULT_MAX_COMPRESSION_BUFFER_SIZE util.DataSize = util.Ofds(256, util.KB)
	DEFAULT_BLOOM_FILTER_FPP            float64       = 0.05
	DEFAULT_STRIPE_MIN_SIZE             util.DataSize = util.Ofds(32, util.MB)
	DEFAULT_STRIPE_MAX_SIZE             util.DataSize = util.Ofds(64, util.MB)
	DEFAULT_STRIPE_MAX_ROW_COUNT        int32         = 10_000_000
	DEFAULT_ROW_GROUP_MAX_ROW_COUNT     int32         = 10_000
	DEFAULT_DICTIONARY_MAX_MEMORY       util.DataSize = util.Ofds(16, util.MB)
)
View Source
var (
	SLICE_DICTIONARY_COLUMN_READER_INSTANCE_SIZE int32   = util.SizeOf(&SliceDictionaryColumnReader{})
	EMPTY_DICTIONARY_DATA                        []byte  = make([]byte, 0)
	EMPTY_DICTIONARY_OFFSETS                     []int32 = make([]int32, 2)
)
View Source
var (
	SLICEDICTIONARY_INSTANCE_SIZE                             int32 = util.SizeOf(&SliceDictionaryColumnWriter{})
	SLICEDICTIONARY_DIRECT_CONVERSION_CHUNK_MAX_LOGICAL_BYTES int32 = util.Int32Exact(int64(32 * util.MB.Bytes()))
)
View Source
var (
	SLICE_DIRECT_COLUMN_READER_INSTANCE_SIZE int32 = util.SizeOf(&SliceDirectColumnReader{})
	ONE_GIGABYTE                             int32 = util.Int32Exact(int64(util.GB.Bytes()))
)
View Source
var (
	STRUCT_INSTANCE_SIZE   int32                    = util.SizeOf(&StructColumnWriter{})
	STRUCT_COLUMN_ENCODING *metadata.ColumnEncoding = metadata.NewColumnEncoding(metadata.DIRECT, 0)
)
View Source
var (
	DEFAULT_COMPRESSION float64 = 100
	FORMAT_TAG          byte    = 0
	T_DIGEST_SIZE       int32   = util.SizeOf(&TDigest{})
	INITIAL_CAPACITY    int32   = 1
	FUDGE_FACTOR        int32   = 10
)
View Source
var (
	// *LocalDateTime = LocalDateTime.of(2015, 1, 1, 0, 0, 0, 0)
	MOTH_EPOCH = time.Date(2015, 1, 1, 0, 0, 0, 0, time.Local)
	// .toEpochSecond(ZoneOffset.UTC)
	BASE_INSTANT_IN_SECONDS               int64 = MOTH_EPOCH.UTC().Unix()
	TIMESTAMP_COLUMN_READER_INSTANCE_SIZE int32 = util.SizeOf(&TimestampColumnReader{})

	POWERS_OF_TEN []int32 = []int32{
		1,
		10,
		100,
		1_000,
		10_000,
		100_000,
		1_000_000,
		10_000_000,
		100_000_000,
	}
)
View Source
var (
	TIMESTAMP_INSTANCE_SIZE         int32 = util.SizeOf(&TimestampColumnWriter{})
	TIMESTAMP_MOTH_EPOCH_IN_SECONDS int64 = int64(time.Date(2015, 1, 1, 0, 0, 0, 0, time.UTC).Second())
)
View Source
var BOOLEAN_OUTPUT_INSTANCE_SIZE int32 = util.SizeOf(&BooleanOutputStream{})
View Source
var BOOL_COLUMN_INSTANCE_SIZE int32 = util.SizeOf(&BooleanColumnReader{})
View Source
var BYTE_ARRAY_OUTPUT_INSTANCE_SIZE int32 = util.SizeOf(&ByteArrayOutputStream{})
View Source
var BYTE_COLUMN_INSTANCE_SIZE int32 = util.SizeOf(&ByteColumnReader{})
View Source
var BYTE_IN_REPEAT_SIZE int32 = 3
View Source
var CLOSED_STRIPE_INSTANCE_SIZE int32 = util.SizeOf(&ClosedStripe{}) + util.SizeOf(&metadata.StripeInformation{})
View Source
var DECIMAL_COLUMN_SIZE int32 = util.SizeOf(&DecimalColumnReader{})
View Source
var DECIMAL_INSTANCE_SIZE int32 = util.SizeOf(&DecimalColumnWriter{})
View Source
var DECIMAL_OUTPUT_INSTANCE_SIZE int32 = util.SizeOf(&DecimalOutputStream{})
View Source
var DOUBLE_COLUMN_INSTANCE_SIZE int32 = util.SizeOf(&DoubleColumnReader{})
View Source
var DOUBLE_IN_BUFFER_SIZE int32 = 128
View Source
var DOUBLE_OUT_INSTANCE_SIZE int32 = util.SizeOf(&DoubleOutputStream{})
View Source
var EXPECTED_COMPRESSION_RATIO int32 = 5
View Source
var FLOAT_BUFFER_SIZE int32 = 128
View Source
var FLOAT_COLUMN_READER_INSTANCE_SIZE int32 = util.SizeOf(&FloatColumnReader{})
View Source
var FLOAT_OUT_INSTANCE_SIZE int32 = util.SizeOf(&FloatOutputStream{})
View Source
var HIGH_BIT_MASK int32 = 0b1000_0000

private static final int HIGH_BIT_MASK = 0b1000_0000;

View Source
var LIST_COLUMN_READER_INSTANCE_SIZE int32 = util.SizeOf(&ListColumnReader{})
View Source
var LIST_INSTANCE_SIZE int32 = util.SizeOf(&ListColumnWriter{})
View Source
var LONG_COLUMN_READER_INSTANCE_SIZE int32 = util.SizeOf(&LongColumnReader{})
View Source
var LONG_INSTANCE_SIZE int32 = util.SizeOf(&LongColumnWriter{})
View Source
var MAP_COLUMN_READER_INSTANCE_SIZE int32 = util.SizeOf(&MapColumnReader{})
View Source
var MAP_INSTANCE_SIZE int32 = util.SizeOf(&MapColumnWriter{})
View Source
var MAX_BUFFERED_POSITIONS int32 = 512
View Source
var MAX_BUFFER_SIZE int32 = 4 * 1024 * 1024
View Source
var MIN_REPEAT_SIZE int32 = 3
View Source
var MOTH_DATA_SINK_INSTANCE_SIZE int32 = util.SizeOf(&OutputStreamMothDataSink{})
View Source
var MR_INSTANCE_SIZE int32 = util.SizeOf(&MothRecordReader{})
View Source
var PRESENT_INSTANCE_SIZE int32 = util.SizeOf(&PresentOutputStream{})
View Source
var RESCALE_THRESHOLD_SECONDS int64 = 50
View Source
var RowGroup_CMP *rowGroupCmp = newRowGroupCmp()
View Source
var SERIALIZATIONUTILS_BUFFER_SIZE int32 = 64

SerializationUtils 类

View Source
var SLICE_COLUMN_READER_INSTANCE_SIZE int32 = util.SizeOf(&SliceColumnReader{})
View Source
var SLICE_DIRECT_INSTANCE_SIZE int32 = util.SizeOf(&SliceDirectColumnWriter{})
View Source
var STRUCT_COLUMN_READER_INSTANCE_SIZE int32 = util.SizeOf(&StructColumnReader{})
View Source
var UNION_COLUMN_READER_INSTANCE_SIZE int32 = util.SizeOf(&UnionColumnReader{})

Functions

func ComputeTruncatedLength

func ComputeTruncatedLength(slice *slice.Slice, offset int32, length int32, maxCodePointCount int32, isCharType bool) int32

func ConvertLengthVectorToOffsetVector

func ConvertLengthVectorToOffsetVector(vector []int32)

func CreateInputStreamCheckpoint

func CreateInputStreamCheckpoint(compressed bool, positionsList *ColumnPositionsList) int64

func CreateInputStreamCheckpoint2

func CreateInputStreamCheckpoint2(compressedBlockOffset int32, decompressedOffset int32) int64

func CreateInputStreamPositionList

func CreateInputStreamPositionList(compressed bool, inputStreamCheckpoint int64) *util.ArrayList[int32]

func CreateMothDecompressor

func CreateMothDecompressor(mothDataSourceId *common.MothDataSourceId, compression metadata.CompressionKind, bufferSize int32) *optional.Optional[MothDecompressor]

func CreateMothReader

func CreateMothReader(mothDataSource MothDataSource, options *MothReaderOptions) *optional.Optional[*MothReader]

func DecodeBitWidth

func DecodeBitWidth(n FixedBitSizes_V1) int32

* * Decodes the ordinal fixed bit value to actual fixed bit width value.

func DecodeCompressedBlockOffset

func DecodeCompressedBlockOffset(inputStreamCheckpoint int64) int32

func DecodeDecompressedOffset

func DecodeDecompressedOffset(inputStreamCheckpoint int64) int32

func EstimateIndexBytesPerValue

func EstimateIndexBytesPerValue(dictionaryEntries int32) int32

func GetClosestAlignedFixedBits

func GetClosestAlignedFixedBits(n int32) int32

func GetClosestFixedBits

func GetClosestFixedBits(width int32) int32

* * Gets the closest supported fixed bit width for the specified bit width.

func GetDiskRangeSlice

func GetDiskRangeSlice(diskRange *DiskRange, buffers map[*DiskRange]*slice.Slice) *slice.Slice

func GetStreamCheckpoints

func GetStreamCheckpoints(columns util.SetInterface[metadata.MothColumnId], columnTypes *metadata.ColumnMetadata[*metadata.MothType], compressed bool, rowGroupId int32, columnEncodings *metadata.ColumnMetadata[*metadata.ColumnEncoding], streams map[StreamId]*metadata.Stream, columnIndexes map[StreamId]*util.ArrayList[*metadata.RowGroupIndex]) map[StreamId]StreamCheckpoint

func InvalidStreamType

func InvalidStreamType(column *MothColumn, kind block.Type)

func IsSafeSubtract

func IsSafeSubtract(left int64, right int64) bool

func MergeAdjacentDiskRanges

func MergeAdjacentDiskRanges(diskRanges *util.ArrayList[*DiskRange], maxMergeDistance util.DataSize, maxReadSize util.DataSize) *util.ArrayList[*DiskRange]

func MinNonNullValueSize

func MinNonNullValueSize(nonNullCount int32) int32

func ReadSignedVInt

func ReadSignedVInt(inputStream *MothInputStream) int64

func ReadUnsignedVInt

func ReadUnsignedVInt(inputStream *MothInputStream) int64

func ReadVInt

func ReadVInt(signed bool, inputStream *MothInputStream) int64

func SumDefault

func SumDefault(lm LongInputStream, items int32) int64

func UnpackByteNulls

func UnpackByteNulls(values []byte, isNull []bool) []byte

func UnpackInt128Nulls

func UnpackInt128Nulls(values []int64, isNull []bool) []int64

func UnpackIntNulls

func UnpackIntNulls(values []int32, isNull []bool) []int32

func UnpackLengthNulls

func UnpackLengthNulls(values []int32, isNull []bool, nonNullCount int32)

func UnpackLongNulls

func UnpackLongNulls(values []int64, isNull []bool) []int64

func UnpackShortNulls

func UnpackShortNulls(values []int16, isNull []bool) []int16

func VerifyStreamType

func VerifyStreamType(column *MothColumn, actual block.Type, validTypes util.Predicate[block.Type])

func WriteVLong

func WriteVLong(buffer mothio.DataOutput, value int64, signed bool)

func WriteVLongUnsigned

func WriteVLongUnsigned(output mothio.DataOutput, value int64)

func ZigzagDecode

func ZigzagDecode(value int64) int64

func ZigzagEncode

func ZigzagEncode(value int64) int64

Types

type AbstractDiskMothDataReader

type AbstractDiskMothDataReader struct {
	// 继承
	MothDataReader
	// contains filtered or unexported fields
}

type AbstractMothDataSource

type AbstractMothDataSource struct {
	// 继承
	MothDataSource
	// contains filtered or unexported fields
}

func NewAbstractMothDataSource

func NewAbstractMothDataSource(id *common.MothDataSourceId, estimatedSize int64, options *MothReaderOptions) *AbstractMothDataSource

type BooleanColumnReader

type BooleanColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewBooleanColumnReader

func NewBooleanColumnReader(kind block.Type, column *MothColumn, memoryContext memory.LocalMemoryContext) *BooleanColumnReader

func (*BooleanColumnReader) Close

func (br *BooleanColumnReader) Close()

@Override

func (*BooleanColumnReader) GetRetainedSizeInBytes

func (br *BooleanColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*BooleanColumnReader) PrepareNextRead

func (br *BooleanColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*BooleanColumnReader) ReadBlock

func (br *BooleanColumnReader) ReadBlock() block.Block

@Override

func (*BooleanColumnReader) StartRowGroup

func (br *BooleanColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*BooleanColumnReader) StartStripe

func (br *BooleanColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*BooleanColumnReader) String

func (br *BooleanColumnReader) String() string

@Override

type BooleanColumnWriter

type BooleanColumnWriter struct {
	// 继承
	ColumnWriter
	// contains filtered or unexported fields
}

func NewBooleanColumnWriter

func NewBooleanColumnWriter(columnId metadata.MothColumnId, kind block.Type, compression metadata.CompressionKind, bufferSize int32) *BooleanColumnWriter

func (*BooleanColumnWriter) BeginRowGroup

func (br *BooleanColumnWriter) BeginRowGroup()

@Override

func (*BooleanColumnWriter) Close

func (br *BooleanColumnWriter) Close()

@Override

func (*BooleanColumnWriter) FinishRowGroup

@Override

func (*BooleanColumnWriter) GetBloomFilters

func (br *BooleanColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*BooleanColumnWriter) GetBufferedBytes

func (br *BooleanColumnWriter) GetBufferedBytes() int64

@Override

func (*BooleanColumnWriter) GetColumnEncodings

func (br *BooleanColumnWriter) GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding

@Override

func (*BooleanColumnWriter) GetColumnStripeStatistics

func (br *BooleanColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*BooleanColumnWriter) GetDataStreams

func (br *BooleanColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*BooleanColumnWriter) GetIndexStreams

func (br *BooleanColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*BooleanColumnWriter) GetNestedColumnWriters

func (br *BooleanColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

@Override

func (*BooleanColumnWriter) GetRetainedBytes

func (br *BooleanColumnWriter) GetRetainedBytes() int64

@Override

func (*BooleanColumnWriter) Reset

func (br *BooleanColumnWriter) Reset()

@Override

func (*BooleanColumnWriter) WriteBlock

func (br *BooleanColumnWriter) WriteBlock(block block.Block)

@Override

type BooleanInputStream

type BooleanInputStream struct {
	// 继承
	ValueInputStream[*BooleanStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewBooleanInputStream

func NewBooleanInputStream(byteStream *MothInputStream) *BooleanInputStream

public NEWBooleanInputStream(MothInputStream byteStream)

{
    this.byteStream = new ByteInputStream(byteStream);
}

func (*BooleanInputStream) CountBitsSet

func (bi *BooleanInputStream) CountBitsSet(items int32) int32
	return count;
}

func (*BooleanInputStream) GetSetBits

func (bi *BooleanInputStream) GetSetBits(batchSize int32) []byte

func (*BooleanInputStream) GetSetBits2

func (bi *BooleanInputStream) GetSetBits2(vector []byte, batchSize int32)
	// the tail
	int remaining = batchSize - offset;
	if (remaining > 0) {
		byte data = byteStream.next();
		int value = data >>> (8 - remaining);
		switch (remaining) {
			case 7:
				vector[offset++] = (byte) ((value & 64) >>> 6);
				// fall through
			case 6:
				vector[offset++] = (byte) ((value & 32) >>> 5);
				// fall through
			case 5:
				vector[offset++] = (byte) ((value & 16) >>> 4);
				// fall through
			case 4:
				vector[offset++] = (byte) ((value & 8) >>> 3);
				// fall through
			case 3:
				vector[offset++] = (byte) ((value & 4) >>> 2);
				// fall through
			case 2:
				vector[offset++] = (byte) ((value & 2) >>> 1);
				// fall through
			case 1:
				vector[offset++] = (byte) ((value & 1) >>> 0);
		}
		this.data = (byte) (data << remaining);
		bitsInData = 8 - remaining;
	}
}

func (*BooleanInputStream) GetUnsetBits

func (bi *BooleanInputStream) GetUnsetBits(batchSize int32, vector []bool) int32

func (*BooleanInputStream) NextBit

func (bi *BooleanInputStream) NextBit() bool

func (*BooleanInputStream) ReadByte

func (bi *BooleanInputStream) ReadByte()

func (*BooleanInputStream) SeekToCheckpoint

func (bi *BooleanInputStream) SeekToCheckpoint(checkpoint StreamCheckpoint)

func (*BooleanInputStream) Skip

func (bi *BooleanInputStream) Skip(items int64)

func (*BooleanInputStream) SkipInt32

func (bi *BooleanInputStream) SkipInt32(items int32)
		if (items != 0) {
			readByte();
			data <<= items;
			bitsInData -= items;
		}
	}
}

type BooleanOutputStream

type BooleanOutputStream struct {
	// 继承
	ValueOutputStream[*BooleanStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewBooleanOutputStream

func NewBooleanOutputStream(compression metadata.CompressionKind, bufferSize int32) *BooleanOutputStream

func NewBooleanOutputStream2

func NewBooleanOutputStream2(buffer *MothOutputBuffer) *BooleanOutputStream

func NewBooleanOutputStream3

func NewBooleanOutputStream3(byteOutputStream *ByteOutputStream) *BooleanOutputStream

func (*BooleanOutputStream) Close

func (bm *BooleanOutputStream) Close()

@Override

func (*BooleanOutputStream) GetBufferedBytes

func (bm *BooleanOutputStream) GetBufferedBytes() int64

@Override

func (*BooleanOutputStream) GetCheckpoints

@Override

func (*BooleanOutputStream) GetRetainedBytes

func (bm *BooleanOutputStream) GetRetainedBytes() int64

@Override

func (*BooleanOutputStream) GetStreamDataOutput

func (bm *BooleanOutputStream) GetStreamDataOutput(columnId metadata.MothColumnId) *StreamDataOutput

@Override

func (*BooleanOutputStream) RecordCheckpoint

func (bm *BooleanOutputStream) RecordCheckpoint()

@Override

func (*BooleanOutputStream) Reset

func (bm *BooleanOutputStream) Reset()

@Override

func (*BooleanOutputStream) WriteBoolean

func (bm *BooleanOutputStream) WriteBoolean(value bool)

type BooleanStreamCheckpoint

type BooleanStreamCheckpoint struct {
	// 继承
	StreamCheckpoint
	// contains filtered or unexported fields
}

func NewBooleanStreamCheckpoint

func NewBooleanStreamCheckpoint(offset int32, byteStreamCheckpoint *ByteStreamCheckpoint) *BooleanStreamCheckpoint

func NewBooleanStreamCheckpoint2

func NewBooleanStreamCheckpoint2(compressed bool, positionsList *ColumnPositionsList) *BooleanStreamCheckpoint

func (*BooleanStreamCheckpoint) GetByteStreamCheckpoint

func (bt *BooleanStreamCheckpoint) GetByteStreamCheckpoint() *ByteStreamCheckpoint

func (*BooleanStreamCheckpoint) GetOffset

func (bt *BooleanStreamCheckpoint) GetOffset() int32

func (*BooleanStreamCheckpoint) String

func (bt *BooleanStreamCheckpoint) String() string

func (*BooleanStreamCheckpoint) ToPositionList

func (bt *BooleanStreamCheckpoint) ToPositionList(compressed bool) *util.ArrayList[int32]

type BufferWriter

type BufferWriter struct {
	// contains filtered or unexported fields
}

func CreateBufferWriter

func CreateBufferWriter(baseBuf []byte) *BufferWriter

func NewBufferWriter

func NewBufferWriter(bufferSize int) *BufferWriter

func (*BufferWriter) Bytes

func (br *BufferWriter) Bytes() []byte

func (*BufferWriter) Size

func (br *BufferWriter) Size() int32

func (*BufferWriter) Write

func (br *BufferWriter) Write(p []byte) (n int, err error)

type Builder

type Builder struct {
	// contains filtered or unexported fields
}

func Build

func Build() *Builder

func BuilderFrom

func BuilderFrom(options *MothWriterOptions) *Builder

func NewBuilder

func NewBuilder(options *MothWriterOptions) *Builder

func (*Builder) Build

func (br *Builder) Build() *MothWriterOptions

func (*Builder) SetBloomFilterColumns

func (br *Builder) SetBloomFilterColumns(bloomFilterColumns util.SetInterface[string]) *Builder

func (*Builder) SetBloomFilterFpp

func (br *Builder) SetBloomFilterFpp(bloomFilterFpp float64) *Builder

func (*Builder) SetDictionaryMaxMemory

func (br *Builder) SetDictionaryMaxMemory(dictionaryMaxMemory util.DataSize) *Builder

func (*Builder) SetMaxCompressionBufferSize

func (br *Builder) SetMaxCompressionBufferSize(maxCompressionBufferSize util.DataSize) *Builder

func (*Builder) SetMaxStringStatisticsLimit

func (br *Builder) SetMaxStringStatisticsLimit(maxStringStatisticsLimit util.DataSize) *Builder

func (*Builder) SetRowGroupMaxRowCount

func (br *Builder) SetRowGroupMaxRowCount(rowGroupMaxRowCount int32) *Builder

func (*Builder) SetStripeMaxRowCount

func (br *Builder) SetStripeMaxRowCount(stripeMaxRowCount int32) *Builder

func (*Builder) SetStripeMaxSize

func (br *Builder) SetStripeMaxSize(stripeMaxSize util.DataSize) *Builder

func (*Builder) SetStripeMinSize

func (br *Builder) SetStripeMinSize(stripeMinSize util.DataSize) *Builder

func (*Builder) SetWriterIdentification

func (br *Builder) SetWriterIdentification(writerIdentification metadata.WriterIdentification) *Builder

type ByteArrayInputStream

type ByteArrayInputStream struct {
	// 继承
	ValueInputStream[*ByteArrayStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewByteArrayInputStream

func NewByteArrayInputStream(inputStream *MothInputStream) *ByteArrayInputStream

func (*ByteArrayInputStream) Next

func (bm *ByteArrayInputStream) Next(length int) []byte

func (*ByteArrayInputStream) Next2

func (bm *ByteArrayInputStream) Next2(data []byte, offset int, length int)

func (*ByteArrayInputStream) SeekToCheckpoint

func (bm *ByteArrayInputStream) SeekToCheckpoint(checkpoint StreamCheckpoint)

@Override

func (*ByteArrayInputStream) Skip

func (bm *ByteArrayInputStream) Skip(skipSize int64)

@Override

type ByteArrayOutputStream

type ByteArrayOutputStream struct {
	// 继承
	ValueOutputStream[*ByteArrayStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewByteArrayOutputStream

func NewByteArrayOutputStream(compression metadata.CompressionKind, bufferSize int32) *ByteArrayOutputStream

func NewByteArrayOutputStream2

func NewByteArrayOutputStream2(compression metadata.CompressionKind, bufferSize int32, streamKind metadata.StreamKind) *ByteArrayOutputStream

func (*ByteArrayOutputStream) Close

func (bm *ByteArrayOutputStream) Close()

@Override

func (*ByteArrayOutputStream) GetBufferedBytes

func (bm *ByteArrayOutputStream) GetBufferedBytes() int64

@Override

func (*ByteArrayOutputStream) GetCheckpoints

@Override

func (*ByteArrayOutputStream) GetRetainedBytes

func (bm *ByteArrayOutputStream) GetRetainedBytes() int64

@Override

func (*ByteArrayOutputStream) GetStreamDataOutput

func (bm *ByteArrayOutputStream) GetStreamDataOutput(columnId metadata.MothColumnId) *StreamDataOutput

@Override

func (*ByteArrayOutputStream) RecordCheckpoint

func (bm *ByteArrayOutputStream) RecordCheckpoint()

@Override

func (*ByteArrayOutputStream) Reset

func (bm *ByteArrayOutputStream) Reset()

@Override

func (*ByteArrayOutputStream) WriteSlice

func (bm *ByteArrayOutputStream) WriteSlice(value *slice.Slice)

type ByteArrayStreamCheckpoint

type ByteArrayStreamCheckpoint struct {
	// 继承
	StreamCheckpoint
	// contains filtered or unexported fields
}

func NewByteArrayStreamCheckpoint

func NewByteArrayStreamCheckpoint(inputStreamCheckpoint int64) *ByteArrayStreamCheckpoint

func NewByteArrayStreamCheckpoint2

func NewByteArrayStreamCheckpoint2(compressed bool, positionsList *ColumnPositionsList) *ByteArrayStreamCheckpoint

func (*ByteArrayStreamCheckpoint) GetInputStreamCheckpoint

func (bt *ByteArrayStreamCheckpoint) GetInputStreamCheckpoint() int64

func (*ByteArrayStreamCheckpoint) String

func (bt *ByteArrayStreamCheckpoint) String() string

func (*ByteArrayStreamCheckpoint) ToPositionList

func (bt *ByteArrayStreamCheckpoint) ToPositionList(compressed bool) *util.ArrayList[int32]

type ByteColumnReader

type ByteColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewByteColumnReader

func NewByteColumnReader(kind block.Type, column *MothColumn, memoryContext memory.LocalMemoryContext) *ByteColumnReader

func (*ByteColumnReader) Close

func (br *ByteColumnReader) Close()

@Override

func (*ByteColumnReader) GetRetainedSizeInBytes

func (br *ByteColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*ByteColumnReader) PrepareNextRead

func (br *ByteColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*ByteColumnReader) ReadBlock

func (br *ByteColumnReader) ReadBlock() block.Block

@Override

func (*ByteColumnReader) StartRowGroup

func (br *ByteColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*ByteColumnReader) StartStripe

func (br *ByteColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*ByteColumnReader) String

func (br *ByteColumnReader) String() string

@Override

type ByteColumnWriter

type ByteColumnWriter struct {

	//继承
	ColumnWriter
	// contains filtered or unexported fields
}

func NewByteColumnWriter

func NewByteColumnWriter(columnId metadata.MothColumnId, kind block.Type, compression metadata.CompressionKind, bufferSize int32) *ByteColumnWriter

func (*ByteColumnWriter) BeginRowGroup

func (br *ByteColumnWriter) BeginRowGroup()

@Override

func (*ByteColumnWriter) Close

func (br *ByteColumnWriter) Close()

@Override

func (*ByteColumnWriter) FinishRowGroup

@Override

func (*ByteColumnWriter) GetBloomFilters

func (br *ByteColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*ByteColumnWriter) GetBufferedBytes

func (br *ByteColumnWriter) GetBufferedBytes() int64

@Override

func (*ByteColumnWriter) GetColumnEncodings

func (br *ByteColumnWriter) GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding

@Override

func (*ByteColumnWriter) GetColumnStripeStatistics

func (br *ByteColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*ByteColumnWriter) GetDataStreams

func (br *ByteColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*ByteColumnWriter) GetIndexStreams

func (br *ByteColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*ByteColumnWriter) GetNestedColumnWriters

func (br *ByteColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

@Override

func (*ByteColumnWriter) GetRetainedBytes

func (br *ByteColumnWriter) GetRetainedBytes() int64

@Override

func (*ByteColumnWriter) Reset

func (br *ByteColumnWriter) Reset()

@Override

func (*ByteColumnWriter) WriteBlock

func (br *ByteColumnWriter) WriteBlock(block block.Block)

@Override

type ByteInputStream

type ByteInputStream struct {
	// 继承
	ValueInputStream[*ByteStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewByteInputStream

func NewByteInputStream(input *MothInputStream) *ByteInputStream

func (*ByteInputStream) Next

func (bm *ByteInputStream) Next() byte

func (*ByteInputStream) Next2

func (bm *ByteInputStream) Next2(items int32) []byte

func (*ByteInputStream) Next3

func (bm *ByteInputStream) Next3(values []byte, items int32)

func (*ByteInputStream) SeekToCheckpoint

func (bm *ByteInputStream) SeekToCheckpoint(checkpoint StreamCheckpoint)

@Override

func (*ByteInputStream) Skip

func (bm *ByteInputStream) Skip(items int64)

@Override

type ByteOutputStream

type ByteOutputStream struct {
	//
	ValueOutputStream[*ByteStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewByteOutputStream

func NewByteOutputStream(compression metadata.CompressionKind, bufferSize int32) *ByteOutputStream

func NewByteOutputStream2

func NewByteOutputStream2(buffer *MothOutputBuffer) *ByteOutputStream

func (*ByteOutputStream) Close

func (bm *ByteOutputStream) Close()

@Override

func (*ByteOutputStream) GetBufferedBytes

func (bm *ByteOutputStream) GetBufferedBytes() int64

@Override

func (*ByteOutputStream) GetCheckpoints

func (bm *ByteOutputStream) GetCheckpoints() *util.ArrayList[*ByteStreamCheckpoint]

@Override

func (*ByteOutputStream) GetRetainedBytes

func (bm *ByteOutputStream) GetRetainedBytes() int64

@Override

func (*ByteOutputStream) GetStreamDataOutput

func (bm *ByteOutputStream) GetStreamDataOutput(columnId metadata.MothColumnId) *StreamDataOutput

@Override

func (*ByteOutputStream) RecordCheckpoint

func (bm *ByteOutputStream) RecordCheckpoint()

@Override

func (*ByteOutputStream) Reset

func (bm *ByteOutputStream) Reset()

@Override

func (*ByteOutputStream) WriteByte

func (bm *ByteOutputStream) WriteByte(value byte)

type ByteStreamCheckpoint

type ByteStreamCheckpoint struct {
	// 继承
	StreamCheckpoint
	// contains filtered or unexported fields
}

func NewByteStreamCheckpoint

func NewByteStreamCheckpoint(offset int32, inputStreamCheckpoint int64) *ByteStreamCheckpoint

func NewByteStreamCheckpoint2

func NewByteStreamCheckpoint2(compressed bool, positionsList *ColumnPositionsList) *ByteStreamCheckpoint

func (*ByteStreamCheckpoint) GetInputStreamCheckpoint

func (bt *ByteStreamCheckpoint) GetInputStreamCheckpoint() int64

func (*ByteStreamCheckpoint) GetOffset

func (bt *ByteStreamCheckpoint) GetOffset() int32

func (*ByteStreamCheckpoint) String

func (bt *ByteStreamCheckpoint) String() string

func (*ByteStreamCheckpoint) ToPositionList

func (bt *ByteStreamCheckpoint) ToPositionList(compressed bool) *util.ArrayList[int32]

type CachingMothDataSource

type CachingMothDataSource struct {
	// 继承
	MothDataSource
	// contains filtered or unexported fields
}

func NewCachingMothDataSource

func NewCachingMothDataSource(dataSource MothDataSource, regionFinder RegionFinder) *CachingMothDataSource

func (*CachingMothDataSource) Close

func (ce *CachingMothDataSource) Close()

@Override

func (*CachingMothDataSource) GetEstimatedSize

func (ce *CachingMothDataSource) GetEstimatedSize() int64

@Override

func (*CachingMothDataSource) GetId

@Override

func (*CachingMothDataSource) GetReadBytes

func (ce *CachingMothDataSource) GetReadBytes() int64

@Override

func (*CachingMothDataSource) GetReadTimeNanos

func (ce *CachingMothDataSource) GetReadTimeNanos() int64

@Override

func (*CachingMothDataSource) GetRetainedSize

func (ce *CachingMothDataSource) GetRetainedSize() int64

@Override

func (*CachingMothDataSource) ReadFully

func (ce *CachingMothDataSource) ReadFully(position int64, length int32) *slice.Slice

@Override

func (*CachingMothDataSource) ReadFully2

func (ce *CachingMothDataSource) ReadFully2(diskRanges map[StreamId]*DiskRange) map[StreamId]MothDataReader

@Override

func (*CachingMothDataSource) ReadTail

func (ce *CachingMothDataSource) ReadTail(length int32) *slice.Slice

@Override

func (*CachingMothDataSource) String

func (ce *CachingMothDataSource) String() string

@Override

type CheckpointInputStreamSource

type CheckpointInputStreamSource[C StreamCheckpoint] struct {
	// 继承
	InputStreamSource
	// contains filtered or unexported fields
}
type S interface {
	~any
}

type C interface {
	~any
}

public class CheckpointInputStreamSource<S extends ValueInputStream<C>, C extends StreamCheckpoint> implements InputStreamSource<S>

func CreateCheckpointStreamSource

func CreateCheckpointStreamSource[C StreamCheckpoint](stream IValueInputStream, checkpoint C) *CheckpointInputStreamSource[C]

func NewCheckpointInputStreamSource

func NewCheckpointInputStreamSource[C StreamCheckpoint](stream IValueInputStream, checkpoint C) *CheckpointInputStreamSource[C]

func (*CheckpointInputStreamSource[C]) OpenStream

func (ce *CheckpointInputStreamSource[C]) OpenStream() IValueInputStream

@Nullable @Override

func (*CheckpointInputStreamSource[C]) String

func (ce *CheckpointInputStreamSource[C]) String() string

@Override

type ChunkSupplier

type ChunkSupplier struct {
	// contains filtered or unexported fields
}

func NewChunkSupplier

func NewChunkSupplier(minChunkSize int32, maxChunkSize int32) *ChunkSupplier

func (*ChunkSupplier) Get

func (cr *ChunkSupplier) Get() []byte

func (*ChunkSupplier) Reset

func (cr *ChunkSupplier) Reset()

type ChunkedSliceOutput

type ChunkedSliceOutput struct {
	// 继承
	slice.SliceOutput
	// contains filtered or unexported fields
}

func NewChunkedSliceOutput

func NewChunkedSliceOutput(minChunkSize int32, maxChunkSize int32) *ChunkedSliceOutput

func (*ChunkedSliceOutput) AppendByte

func (ct *ChunkedSliceOutput) AppendByte(value byte) slice.SliceOutput

@Override

func (*ChunkedSliceOutput) AppendBytes

func (ct *ChunkedSliceOutput) AppendBytes(source []byte, sourceIndex int32, length int32) slice.SliceOutput

@Override

func (*ChunkedSliceOutput) AppendBytes2

func (ct *ChunkedSliceOutput) AppendBytes2(source []byte) slice.SliceOutput

@Override

func (*ChunkedSliceOutput) AppendDouble

func (ct *ChunkedSliceOutput) AppendDouble(value float64) slice.SliceOutput

@Override

func (*ChunkedSliceOutput) AppendInt

func (ct *ChunkedSliceOutput) AppendInt(value int32) slice.SliceOutput

@Override

func (*ChunkedSliceOutput) AppendLong

func (ct *ChunkedSliceOutput) AppendLong(value int64) slice.SliceOutput

@Override

func (*ChunkedSliceOutput) AppendShort

func (ct *ChunkedSliceOutput) AppendShort(value int16) slice.SliceOutput

@Override

func (*ChunkedSliceOutput) AppendSlice

func (ct *ChunkedSliceOutput) AppendSlice(slice *slice.Slice) slice.SliceOutput

@Override

func (*ChunkedSliceOutput) GetRetainedSize

func (ct *ChunkedSliceOutput) GetRetainedSize() int64

@Override

func (*ChunkedSliceOutput) GetSlices

func (ct *ChunkedSliceOutput) GetSlices() *util.ArrayList[*slice.Slice]

func (*ChunkedSliceOutput) GetUnderlyingSlice

func (ct *ChunkedSliceOutput) GetUnderlyingSlice() *slice.Slice

@Override

func (*ChunkedSliceOutput) IsWritable

func (ct *ChunkedSliceOutput) IsWritable() bool

@Override

func (*ChunkedSliceOutput) Reset

func (ct *ChunkedSliceOutput) Reset()

@Override

func (*ChunkedSliceOutput) Reset2

func (ct *ChunkedSliceOutput) Reset2(position int32)

@Override

func (*ChunkedSliceOutput) Size

func (ct *ChunkedSliceOutput) Size() int32

@Override

func (*ChunkedSliceOutput) Slice

func (ct *ChunkedSliceOutput) Slice() *slice.Slice

@Override

func (*ChunkedSliceOutput) String

func (ct *ChunkedSliceOutput) String() string

@Override

func (*ChunkedSliceOutput) ToString

func (ct *ChunkedSliceOutput) ToString() string

@Override

func (*ChunkedSliceOutput) WritableBytes

func (ct *ChunkedSliceOutput) WritableBytes() int32

@Override

func (*ChunkedSliceOutput) Write

func (ct *ChunkedSliceOutput) Write(b byte)

@Override

func (*ChunkedSliceOutput) WriteByte

func (ct *ChunkedSliceOutput) WriteByte(b byte) error

@Override

func (*ChunkedSliceOutput) WriteBytes

func (ct *ChunkedSliceOutput) WriteBytes(source []byte)

@Override

func (*ChunkedSliceOutput) WriteBytes2

func (ct *ChunkedSliceOutput) WriteBytes2(source []byte, sourceIndex int32, length int32)

@Override

func (*ChunkedSliceOutput) WriteDouble

func (ct *ChunkedSliceOutput) WriteDouble(value float64)

@Override

func (*ChunkedSliceOutput) WriteFloat

func (ct *ChunkedSliceOutput) WriteFloat(value float32)

@Override

func (*ChunkedSliceOutput) WriteInputStream

func (ct *ChunkedSliceOutput) WriteInputStream(in mothio.InputStream, length int32)

@Override

func (*ChunkedSliceOutput) WriteInt

func (ct *ChunkedSliceOutput) WriteInt(value int32)

@Override

func (*ChunkedSliceOutput) WriteLong

func (ct *ChunkedSliceOutput) WriteLong(value int64)

@Override

func (*ChunkedSliceOutput) WriteShort

func (ct *ChunkedSliceOutput) WriteShort(value int16)

@Override

func (*ChunkedSliceOutput) WriteSlice

func (ct *ChunkedSliceOutput) WriteSlice(source *slice.Slice)

@Override

func (*ChunkedSliceOutput) WriteSlice2

func (ct *ChunkedSliceOutput) WriteSlice2(source *slice.Slice, sourceIndex int32, length int32)

@Override

func (*ChunkedSliceOutput) WriteZero

func (ct *ChunkedSliceOutput) WriteZero(length int32)

@Override

type ClosedStripe

type ClosedStripe struct {
	// contains filtered or unexported fields
}

func NewClosedStripe

func NewClosedStripe(stripeInformation *metadata.StripeInformation, statistics *metadata.StripeStatistics) *ClosedStripe

func (*ClosedStripe) GetRetainedSizeInBytes

func (ce *ClosedStripe) GetRetainedSizeInBytes() int64

func (*ClosedStripe) GetStatistics

func (ce *ClosedStripe) GetStatistics() *metadata.StripeStatistics

func (*ClosedStripe) GetStripeInformation

func (ce *ClosedStripe) GetStripeInformation() *metadata.StripeInformation

type ColumnPositionsList

type ColumnPositionsList struct {
	// contains filtered or unexported fields
}

func NewColumnPositionsList

func NewColumnPositionsList(columnId metadata.MothColumnId, columnType metadata.MothTypeKind, positionsList *util.ArrayList[int32]) *ColumnPositionsList

func (*ColumnPositionsList) GetIndex

func (ct *ColumnPositionsList) GetIndex() int32

func (*ColumnPositionsList) HasNextPosition

func (ct *ColumnPositionsList) HasNextPosition() bool

func (*ColumnPositionsList) NextPosition

func (ct *ColumnPositionsList) NextPosition() int32

type ColumnReader

type ColumnReader interface {
	ReadBlock() block.Block
	PrepareNextRead(batchSize int32)
	StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])
	StartRowGroup(dataStreamSources *InputStreamSources)
	Close()
	GetRetainedSizeInBytes() int64
}

func CreateColumnReader

func CreateColumnReader(kind block.Type, column *MothColumn, projectedLayout ProjectedLayout, memoryContext memory.AggregatedMemoryContext, blockFactory *MothBlockFactory, fieldMapperFactory FieldMapperFactory) ColumnReader

type ColumnWriter

type ColumnWriter interface {
	GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

	GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding
	BeginRowGroup()
	WriteBlock(block block.Block)
	FinishRowGroup() map[metadata.MothColumnId]*metadata.ColumnStatistics
	Close()
	GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

	/**
	 * Write index streams to the output and return the streams in the
	 * order in which they were written.  The ordering is critical because
	 * the stream only contain a length with no offset.
	 */
	GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]
	GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

	/**
	 * Get the data streams to be written.
	 */
	GetDataStreams() *util.ArrayList[*StreamDataOutput]

	/**
	 * This method returns the size of the flushed data plus any unflushed data.
	 * If the output is compressed, flush data size is the size after compression.
	 */
	GetBufferedBytes() int64
	GetRetainedBytes() int64
	Reset()
}

func CreateColumnWriter

func CreateColumnWriter(columnId metadata.MothColumnId, mothTypes *metadata.ColumnMetadata[*metadata.MothType], kind block.Type, compression metadata.CompressionKind, bufferSize int32, stringStatisticsLimit util.DataSize, bloomFilterBuilder func() metadata.BloomFilterBuilder) ColumnWriter

type CompressedMetadataWriter

type CompressedMetadataWriter struct {
	// contains filtered or unexported fields
}

func NewCompressedMetadataWriter

func NewCompressedMetadataWriter(metadataWriter metadata.MetadataWriter, compression metadata.CompressionKind, bufferSize int32) *CompressedMetadataWriter

func (*CompressedMetadataWriter) GetMothMetadataVersion

func (cr *CompressedMetadataWriter) GetMothMetadataVersion() []uint32

func (*CompressedMetadataWriter) WriteBloomFilters

func (cr *CompressedMetadataWriter) WriteBloomFilters(bloomFilters *util.ArrayList[*metadata.BloomFilter]) *slice.Slice

func (*CompressedMetadataWriter) WriteFooter

func (cr *CompressedMetadataWriter) WriteFooter(footer *metadata.Footer) *slice.Slice

func (*CompressedMetadataWriter) WriteMetadata

func (cr *CompressedMetadataWriter) WriteMetadata(metadata *metadata.Metadata) *slice.Slice

func (*CompressedMetadataWriter) WritePostscript

func (cr *CompressedMetadataWriter) WritePostscript(footerLength int32, metadataLength int32, compression metadata.CompressionKind, compressionBlockSize int32) *slice.Slice

func (*CompressedMetadataWriter) WriteRowIndexes

func (cr *CompressedMetadataWriter) WriteRowIndexes(rowGroupIndexes *util.ArrayList[*metadata.RowGroupIndex]) *slice.Slice

func (*CompressedMetadataWriter) WriteStripeFooter

func (cr *CompressedMetadataWriter) WriteStripeFooter(footer *metadata.StripeFooter) *slice.Slice

type CompressedMothChunkLoader

type CompressedMothChunkLoader struct {
	// 继承
	MothChunkLoader
	// contains filtered or unexported fields
}

func NewCompressedMothChunkLoader

func NewCompressedMothChunkLoader(dataReader MothDataReader, decompressor MothDecompressor, memoryContext memory.AggregatedMemoryContext) *CompressedMothChunkLoader

func (*CompressedMothChunkLoader) GetLastCheckpoint

func (cr *CompressedMothChunkLoader) GetLastCheckpoint() int64

@Override

func (*CompressedMothChunkLoader) GetMothDataSourceId

func (cr *CompressedMothChunkLoader) GetMothDataSourceId() *common.MothDataSourceId

@Override

func (*CompressedMothChunkLoader) HasNextChunk

func (cr *CompressedMothChunkLoader) HasNextChunk() bool

@Override

func (*CompressedMothChunkLoader) NextChunk

func (cr *CompressedMothChunkLoader) NextChunk() *slice.Slice

@Override

func (*CompressedMothChunkLoader) SeekToCheckpoint

func (cr *CompressedMothChunkLoader) SeekToCheckpoint(checkpoint int64)

@Override

func (*CompressedMothChunkLoader) ToString

func (cr *CompressedMothChunkLoader) ToString() string

@Override

type Compressor

type Compressor interface {
	MaxCompressedLength(uncompressedSize int32) int32

	/**
	 * @return number of bytes written to the output
	 */
	Compress(input []byte, inputOffset int32, inputLength int32, output []byte, outputOffset int32, maxOutputLength int32) int32

	Compress2(input *bytes.Buffer, output *bytes.Buffer)
}

压缩

func NewDeflateCompressor

func NewDeflateCompressor() Compressor

func NewLz4Compressor

func NewLz4Compressor() Compressor

func NewSnappyCompressor

func NewSnappyCompressor() Compressor

type DataSupplier

type DataSupplier[T basic.Object] struct {
	// contains filtered or unexported fields
}

func NewDataSupplier

func NewDataSupplier[T basic.Object](data T) *DataSupplier[T]

func (*DataSupplier[T]) Get

func (s *DataSupplier[T]) Get() T

type DecayCounter

type DecayCounter struct {
	// contains filtered or unexported fields
}

func NewDecayCounter

func NewDecayCounter(alpha float64) *DecayCounter

func NewDecayCounter2

func NewDecayCounter2(alpha float64, ticker Ticker) *DecayCounter

func NewDecayCounter3

func NewDecayCounter3(count float64, alpha float64, ticker Ticker, landmarkInSeconds int64) *DecayCounter

func (*DecayCounter) Add

func (dr *DecayCounter) Add(value int64)

func (*DecayCounter) Duplicate

func (dr *DecayCounter) Duplicate() *DecayCounter

func (*DecayCounter) GetAlpha

func (dr *DecayCounter) GetAlpha() float64

func (*DecayCounter) GetCount

func (dr *DecayCounter) GetCount() float64

@Managed

func (*DecayCounter) GetRate

func (dr *DecayCounter) GetRate() float64

@Managed

func (*DecayCounter) Merge

func (dr *DecayCounter) Merge(decayCounter *DecayCounter)

func (*DecayCounter) Reset

func (dr *DecayCounter) Reset()

@Managed

func (*DecayCounter) ResetTo

func (dr *DecayCounter) ResetTo(counter *DecayCounter)

@Deprecated

func (*DecayCounter) Snapshot

func (dr *DecayCounter) Snapshot() *DecayCounterSnapshot

func (*DecayCounter) String

func (dr *DecayCounter) String() string

@Override

type DecayCounterSnapshot

type DecayCounterSnapshot struct {
	// contains filtered or unexported fields
}

func NewDecayCounterSnapshot

func NewDecayCounterSnapshot(count float64, rate float64) *DecayCounterSnapshot

func (*DecayCounterSnapshot) GetCount

func (dt *DecayCounterSnapshot) GetCount() float64

@JsonProperty

func (*DecayCounterSnapshot) GetRate

func (dt *DecayCounterSnapshot) GetRate() float64

@JsonProperty

func (*DecayCounterSnapshot) String

func (dt *DecayCounterSnapshot) String() string

@Override

type DecayTDigest

type DecayTDigest struct {
	// contains filtered or unexported fields
}

func NewDecayTDigest

func NewDecayTDigest(compression float64, alpha float64) *DecayTDigest

func NewDecayTDigest2

func NewDecayTDigest2(compression float64, alpha float64, ticker Ticker) *DecayTDigest

func NewDecayTDigest3

func NewDecayTDigest3(digest *TDigest, alpha float64, ticker Ticker) *DecayTDigest

func NewDecayTDigest4

func NewDecayTDigest4(digest *TDigest, alpha float64, ticker Ticker, landmarkInSeconds int64) *DecayTDigest

func (*DecayTDigest) Add

func (dt *DecayTDigest) Add(value float64)

func (*DecayTDigest) Add2

func (dt *DecayTDigest) Add2(value float64, wt float64)

func (*DecayTDigest) Duplicate

func (dt *DecayTDigest) Duplicate() *DecayTDigest

func (*DecayTDigest) GetCount

func (dt *DecayTDigest) GetCount() float64

func (*DecayTDigest) GetMax

func (dt *DecayTDigest) GetMax() float64

func (*DecayTDigest) GetMin

func (dt *DecayTDigest) GetMin() float64

func (*DecayTDigest) ValueAt

func (dt *DecayTDigest) ValueAt(quantile float64) float64

func (*DecayTDigest) ValuesAt

func (dt *DecayTDigest) ValuesAt(quantiles *util.ArrayList[float64]) util.List[float64]

type DecimalColumnReader

type DecimalColumnReader struct {
	//继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewDecimalColumnReader

func NewDecimalColumnReader(kind block.Type, column *MothColumn, memoryContext memory.LocalMemoryContext) *DecimalColumnReader

func (*DecimalColumnReader) Close

func (dr *DecimalColumnReader) Close()

@Override

func (*DecimalColumnReader) GetRetainedSizeInBytes

func (dr *DecimalColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*DecimalColumnReader) PrepareNextRead

func (dr *DecimalColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*DecimalColumnReader) ReadBlock

func (dr *DecimalColumnReader) ReadBlock() block.Block

@Override

func (*DecimalColumnReader) StartRowGroup

func (dr *DecimalColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*DecimalColumnReader) StartStripe

func (dr *DecimalColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*DecimalColumnReader) String

func (dr *DecimalColumnReader) String() string

@Override

type DecimalColumnWriter

type DecimalColumnWriter struct {
	// 继承
	ColumnWriter
	// contains filtered or unexported fields
}

func NewDecimalColumnWriter

func NewDecimalColumnWriter(columnId metadata.MothColumnId, kind block.Type, compression metadata.CompressionKind, bufferSize int32) *DecimalColumnWriter

func (*DecimalColumnWriter) BeginRowGroup

func (dr *DecimalColumnWriter) BeginRowGroup()

@Override

func (*DecimalColumnWriter) Close

func (dr *DecimalColumnWriter) Close()

@Override

func (*DecimalColumnWriter) FinishRowGroup

@Override

func (*DecimalColumnWriter) GetBloomFilters

func (dr *DecimalColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*DecimalColumnWriter) GetBufferedBytes

func (dr *DecimalColumnWriter) GetBufferedBytes() int64

@Override

func (*DecimalColumnWriter) GetColumnEncodings

func (dr *DecimalColumnWriter) GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding

@Override

func (*DecimalColumnWriter) GetColumnStripeStatistics

func (dr *DecimalColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*DecimalColumnWriter) GetDataStreams

func (dr *DecimalColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*DecimalColumnWriter) GetIndexStreams

func (dr *DecimalColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*DecimalColumnWriter) GetNestedColumnWriters

func (dr *DecimalColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

@Override

func (*DecimalColumnWriter) GetRetainedBytes

func (dr *DecimalColumnWriter) GetRetainedBytes() int64

@Override

func (*DecimalColumnWriter) Reset

func (dr *DecimalColumnWriter) Reset()

@Override

func (*DecimalColumnWriter) WriteBlock

func (dr *DecimalColumnWriter) WriteBlock(b block.Block)

@Override

type DecimalInputStream

type DecimalInputStream struct {
	// 继承
	ValueInputStream[*DecimalStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewDecimalInputStream

func NewDecimalInputStream(chunkLoader MothChunkLoader) *DecimalInputStream

func (*DecimalInputStream) NextLongDecimal

func (dm *DecimalInputStream) NextLongDecimal(result []int64, batchSize int32)

@SuppressWarnings("PointlessBitwiseExpression")

func (*DecimalInputStream) NextShortDecimal

func (dm *DecimalInputStream) NextShortDecimal(result []int64, batchSize int32)

@SuppressWarnings("PointlessBitwiseExpression")

func (*DecimalInputStream) SeekToCheckpoint

func (dm *DecimalInputStream) SeekToCheckpoint(ct StreamCheckpoint)

@Override

func (*DecimalInputStream) Skip

func (dm *DecimalInputStream) Skip(items int64)

@Override

type DecimalOutputStream

type DecimalOutputStream struct {
	//继承
	ValueOutputStream[*DecimalStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewDecimalOutputStream

func NewDecimalOutputStream(compression metadata.CompressionKind, bufferSize int32) *DecimalOutputStream

func (*DecimalOutputStream) Close

func (dm *DecimalOutputStream) Close()

@Override

func (*DecimalOutputStream) GetBufferedBytes

func (dm *DecimalOutputStream) GetBufferedBytes() int64

@Override

func (*DecimalOutputStream) GetCheckpoints

@Override

func (*DecimalOutputStream) GetRetainedBytes

func (dm *DecimalOutputStream) GetRetainedBytes() int64

@Override

func (*DecimalOutputStream) GetStreamDataOutput

func (dm *DecimalOutputStream) GetStreamDataOutput(columnId metadata.MothColumnId) *StreamDataOutput

@Override

func (*DecimalOutputStream) RecordCheckpoint

func (dm *DecimalOutputStream) RecordCheckpoint()

@Override

func (*DecimalOutputStream) Reset

func (dm *DecimalOutputStream) Reset()

@Override

func (*DecimalOutputStream) WriteUnscaledValue

func (dm *DecimalOutputStream) WriteUnscaledValue(decimal *block.Int128)

func (*DecimalOutputStream) WriteUnscaledValue2

func (dm *DecimalOutputStream) WriteUnscaledValue2(value int64)

type DecimalStreamCheckpoint

type DecimalStreamCheckpoint struct {
	// 继承
	StreamCheckpoint
	// contains filtered or unexported fields
}

func NewDecimalStreamCheckpoint

func NewDecimalStreamCheckpoint(inputStreamCheckpoint int64) *DecimalStreamCheckpoint

func NewDecimalStreamCheckpoint2

func NewDecimalStreamCheckpoint2(compressed bool, positionsList *ColumnPositionsList) *DecimalStreamCheckpoint

func (*DecimalStreamCheckpoint) GetInputStreamCheckpoint

func (dt *DecimalStreamCheckpoint) GetInputStreamCheckpoint() int64

func (*DecimalStreamCheckpoint) String

func (bt *DecimalStreamCheckpoint) String() string

func (*DecimalStreamCheckpoint) ToPositionList

func (dt *DecimalStreamCheckpoint) ToPositionList(compressed bool) *util.ArrayList[int32]

type Decompressor

type Decompressor interface {
	/**
	 * @return number of bytes written to the output
	 */
	Decompress(input []byte, inputOffset int32, inputLength int32, output []byte, outputOffset int32, maxOutputLength int32) int32

	// Decompress2(input ByteBuffer, output ByteBuffer)
	Decompress2(input bytes.Buffer, output bytes.Buffer)
}

type DeflateCompressor

type DeflateCompressor struct {
	// 继承
	Compressor
}

func (*DeflateCompressor) Compress

func (dr *DeflateCompressor) Compress(input []byte, inputOffset int32, inputLength int32, output []byte, outputOffset int32, maxOutputLength int32) int32

@Override

func (*DeflateCompressor) Decompress2

func (dr *DeflateCompressor) Decompress2(input *bytes.Buffer, output *bytes.Buffer)

@Override

func (*DeflateCompressor) MaxCompressedLength

func (dr *DeflateCompressor) MaxCompressedLength(uncompressedSize int32) int32

@Override

type DictionaryBuilder

type DictionaryBuilder struct {
	// contains filtered or unexported fields
}

func NewDictionaryBuilder

func NewDictionaryBuilder(expectedSize int32) *DictionaryBuilder

func (*DictionaryBuilder) Clear

func (dr *DictionaryBuilder) Clear()

func (*DictionaryBuilder) Contains

func (dr *DictionaryBuilder) Contains(block block.Block, position int32) bool

func (*DictionaryBuilder) GetElementBlock

func (dr *DictionaryBuilder) GetElementBlock() block.Block

func (*DictionaryBuilder) GetEntryCount

func (dr *DictionaryBuilder) GetEntryCount() int32

func (*DictionaryBuilder) GetRetainedSizeInBytes

func (dr *DictionaryBuilder) GetRetainedSizeInBytes() int64

func (*DictionaryBuilder) GetSizeInBytes

func (dr *DictionaryBuilder) GetSizeInBytes() int64

func (*DictionaryBuilder) PutIfAbsent

func (dr *DictionaryBuilder) PutIfAbsent(block block.Block, position int32) int32

type DictionaryColumn

type DictionaryColumn interface {
	GetValueCount() int64
	GetNonNullValueCount() int64
	GetRawBytes() int64
	GetDictionaryEntries() int32
	GetDictionaryBytes() int32
	GetIndexBytes() int32
	TryConvertToDirect(maxDirectBytes int32) *optional.OptionalInt
	GetBufferedBytes() int64
}

type DictionaryColumnManager

type DictionaryColumnManager struct {
	// contains filtered or unexported fields
}

func NewDictionaryColumnManager

func NewDictionaryColumnManager(dictionaryColumn DictionaryColumn) *DictionaryColumnManager

func (*DictionaryColumnManager) GetBufferedBytes

func (dr *DictionaryColumnManager) GetBufferedBytes() int64

func (*DictionaryColumnManager) GetCompressionRatio

func (dr *DictionaryColumnManager) GetCompressionRatio() float64

func (*DictionaryColumnManager) GetDictionaryBytes

func (dr *DictionaryColumnManager) GetDictionaryBytes() int32

func (*DictionaryColumnManager) GetDictionaryBytesPerFutureRow

func (dr *DictionaryColumnManager) GetDictionaryBytesPerFutureRow() float64

func (*DictionaryColumnManager) GetIndexBytes

func (dr *DictionaryColumnManager) GetIndexBytes() int32

func (*DictionaryColumnManager) GetIndexBytesPerRow

func (dr *DictionaryColumnManager) GetIndexBytesPerRow() float64

func (*DictionaryColumnManager) GetRawBytes

func (dr *DictionaryColumnManager) GetRawBytes() int64

func (*DictionaryColumnManager) GetRawBytesPerRow

func (dr *DictionaryColumnManager) GetRawBytesPerRow() float64

func (*DictionaryColumnManager) IsDirectEncoded

func (dr *DictionaryColumnManager) IsDirectEncoded() bool

func (*DictionaryColumnManager) TryConvertToDirect

func (dr *DictionaryColumnManager) TryConvertToDirect(maxDirectBytes int32) *optional.OptionalInt

func (*DictionaryColumnManager) UpdateHistory

func (dr *DictionaryColumnManager) UpdateHistory(rowCount int32)

type DictionaryCompressionOptimizer

type DictionaryCompressionOptimizer struct {
	// contains filtered or unexported fields
}

func NewDictionaryCompressionOptimizer

func NewDictionaryCompressionOptimizer(writers util.SetInterface[*SliceDictionaryColumnWriter], stripeMinBytes int32, stripeMaxBytes int32, stripeMaxRowCount int32, dictionaryMemoryMaxBytes int32) *DictionaryCompressionOptimizer

func (*DictionaryCompressionOptimizer) FinalOptimize

func (dr *DictionaryCompressionOptimizer) FinalOptimize(bufferedBytes int32)

func (*DictionaryCompressionOptimizer) GetDictionaryMemoryBytes

func (dr *DictionaryCompressionOptimizer) GetDictionaryMemoryBytes() int32

func (*DictionaryCompressionOptimizer) IsFull

func (dr *DictionaryCompressionOptimizer) IsFull(bufferedBytes int64) bool

func (*DictionaryCompressionOptimizer) Optimize

func (dr *DictionaryCompressionOptimizer) Optimize(bufferedBytes int32, stripeRowCount int32)

func (*DictionaryCompressionOptimizer) Reset

func (dr *DictionaryCompressionOptimizer) Reset()

func (*DictionaryCompressionOptimizer) TryConvertToDirect

func (dr *DictionaryCompressionOptimizer) TryConvertToDirect(dictionaryWriter *DictionaryColumnManager, maxDirectBytes int32) *optional.OptionalInt

type DictionaryCompressionProjection

type DictionaryCompressionProjection struct {
	// contains filtered or unexported fields
}

func NewDictionaryCompressionProjection

func NewDictionaryCompressionProjection(columnToConvert *DictionaryColumnManager, predictedFileCompressionRatio float64) *DictionaryCompressionProjection

func (*DictionaryCompressionProjection) GetColumnToConvert

func (dn *DictionaryCompressionProjection) GetColumnToConvert() *DictionaryColumnManager

func (*DictionaryCompressionProjection) GetPredictedFileCompressionRatio

func (dn *DictionaryCompressionProjection) GetPredictedFileCompressionRatio() float64

type DictionaryRowGroup

type DictionaryRowGroup struct {
	// contains filtered or unexported fields
}

func NewDictionaryRowGroup

func NewDictionaryRowGroup(dictionaryIndexes *array.IntBigArray, valueCount int32, columnStatistics *metadata.ColumnStatistics) *DictionaryRowGroup

func (*DictionaryRowGroup) GetColumnStatistics

func (dp *DictionaryRowGroup) GetColumnStatistics() *metadata.ColumnStatistics

func (*DictionaryRowGroup) GetDictionaryIndexes

func (dp *DictionaryRowGroup) GetDictionaryIndexes() *array.IntBigArray

func (*DictionaryRowGroup) GetValueCount

func (dp *DictionaryRowGroup) GetValueCount() int32

type DiskMothDataReader

type DiskMothDataReader struct {
	// 继承
	AbstractDiskMothDataReader
	// contains filtered or unexported fields
}

func NewDiskMothDataReader

func NewDiskMothDataReader(parent *FileMothDataSource, diskRange *DiskRange) *DiskMothDataReader

func (*DiskMothDataReader) GetMaxBufferSize

func (ar *DiskMothDataReader) GetMaxBufferSize() int32

@Override

func (*DiskMothDataReader) GetMothDataSourceId

func (ar *DiskMothDataReader) GetMothDataSourceId() *common.MothDataSourceId

@Override

func (*DiskMothDataReader) GetRetainedSize

func (ar *DiskMothDataReader) GetRetainedSize() int64

@Override

func (*DiskMothDataReader) GetSize

func (ar *DiskMothDataReader) GetSize() int32

@Override

func (*DiskMothDataReader) Read

func (dr *DiskMothDataReader) Read(position int64, buffer []byte, bufferOffset int32, length int32)

@Override

func (*DiskMothDataReader) SeekBuffer

func (ar *DiskMothDataReader) SeekBuffer(newPosition int32) *slice.Slice

@Override

func (*DiskMothDataReader) String

func (dr *DiskMothDataReader) String() string

@Override

type DiskRange

type DiskRange struct {
	// contains filtered or unexported fields
}

func NewDiskRange

func NewDiskRange(offset int64, length int32) *DiskRange

func (*DiskRange) Contains

func (de *DiskRange) Contains(diskRange *DiskRange) bool

func (*DiskRange) Equals

func (de *DiskRange) Equals(obj *DiskRange) bool

@Override

func (*DiskRange) GetEnd

func (de *DiskRange) GetEnd() int64

func (*DiskRange) GetLength

func (de *DiskRange) GetLength() int32

func (*DiskRange) GetOffset

func (de *DiskRange) GetOffset() int64

func (*DiskRange) Span

func (de *DiskRange) Span(otherDiskRange *DiskRange) *DiskRange

func (*DiskRange) String

func (de *DiskRange) String() string

@Override

type DiskRangeCmp

type DiskRangeCmp struct {
	// 继承
	util.Compare[*DiskRange]
}

disk range 比较类

func NewDiskRangeCmp

func NewDiskRangeCmp() *DiskRangeCmp

func (*DiskRangeCmp) Cmp

func (r *DiskRangeCmp) Cmp(i, j *DiskRange) int

type Distribution

type Distribution struct {
	// contains filtered or unexported fields
}

func NewDistribution

func NewDistribution() *Distribution

func NewDistribution2

func NewDistribution2(alpha float64) *Distribution

func NewDistribution3

func NewDistribution3(digest *DecayTDigest, total *DecayCounter) *Distribution

func (*Distribution) Add

func (dn *Distribution) Add(value int64)

func (*Distribution) Add2

func (dn *Distribution) Add2(value int64, count int64)

func (*Distribution) Duplicate

func (dn *Distribution) Duplicate() *Distribution

func (*Distribution) GetAvg

func (dn *Distribution) GetAvg() float64

@Managed

func (*Distribution) GetCount

func (dn *Distribution) GetCount() float64

@Managed

func (*Distribution) GetMax

func (dn *Distribution) GetMax() float64

@Managed

func (*Distribution) GetMin

func (dn *Distribution) GetMin() float64

@Managed

func (*Distribution) GetP01

func (dn *Distribution) GetP01() float64

@Managed

func (*Distribution) GetP05

func (dn *Distribution) GetP05() float64

@Managed

func (*Distribution) GetP10

func (dn *Distribution) GetP10() float64

@Managed

func (*Distribution) GetP25

func (dn *Distribution) GetP25() float64

@Managed

func (*Distribution) GetP50

func (dn *Distribution) GetP50() float64

@Managed

func (*Distribution) GetP75

func (dn *Distribution) GetP75() float64

@Managed

func (*Distribution) GetP90

func (dn *Distribution) GetP90() float64

@Managed

func (*Distribution) GetP95

func (dn *Distribution) GetP95() float64

@Managed

func (*Distribution) GetP99

func (dn *Distribution) GetP99() float64

@Managed

func (*Distribution) GetPercentiles

func (dn *Distribution) GetPercentiles() map[float64]float64

@Managed

func (*Distribution) GetPercentiles2

func (dn *Distribution) GetPercentiles2(percentiles *util.ArrayList[float64]) util.List[float64]

func (*Distribution) GetTotal

func (dn *Distribution) GetTotal() float64

@Managed

func (*Distribution) Snapshot

func (dn *Distribution) Snapshot() *DistributionSnapshot

type DistributionSnapshot

type DistributionSnapshot struct {
	// contains filtered or unexported fields
}

func NewDistributionSnapshot

func NewDistributionSnapshot(count float64, total float64, p01 float64, p05 float64, p10 float64, p25 float64, p50 float64, p75 float64, p90 float64, p95 float64, p99 float64, min float64, max float64, avg float64) *DistributionSnapshot

func (*DistributionSnapshot) GetAvg

func (dt *DistributionSnapshot) GetAvg() float64

@JsonProperty

func (*DistributionSnapshot) GetCount

func (dt *DistributionSnapshot) GetCount() float64

@JsonProperty

func (*DistributionSnapshot) GetMax

func (dt *DistributionSnapshot) GetMax() float64

@JsonProperty

func (*DistributionSnapshot) GetMin

func (dt *DistributionSnapshot) GetMin() float64

@JsonProperty

func (*DistributionSnapshot) GetP01

func (dt *DistributionSnapshot) GetP01() float64

@JsonProperty

func (*DistributionSnapshot) GetP05

func (dt *DistributionSnapshot) GetP05() float64

@JsonProperty

func (*DistributionSnapshot) GetP10

func (dt *DistributionSnapshot) GetP10() float64

@JsonProperty

func (*DistributionSnapshot) GetP25

func (dt *DistributionSnapshot) GetP25() float64

@JsonProperty

func (*DistributionSnapshot) GetP50

func (dt *DistributionSnapshot) GetP50() float64

@JsonProperty

func (*DistributionSnapshot) GetP75

func (dt *DistributionSnapshot) GetP75() float64

@JsonProperty

func (*DistributionSnapshot) GetP90

func (dt *DistributionSnapshot) GetP90() float64

@JsonProperty

func (*DistributionSnapshot) GetP95

func (dt *DistributionSnapshot) GetP95() float64

@JsonProperty

func (*DistributionSnapshot) GetP99

func (dt *DistributionSnapshot) GetP99() float64

@JsonProperty

func (*DistributionSnapshot) GetTotal

func (dt *DistributionSnapshot) GetTotal() float64

@JsonProperty

func (*DistributionSnapshot) String

func (dt *DistributionSnapshot) String() string

@Override

type DistributionStat

type DistributionStat struct {
	// contains filtered or unexported fields
}

func NewDistributionStat

func NewDistributionStat() *DistributionStat

func (*DistributionStat) Add

func (dt *DistributionStat) Add(value int64)

func (*DistributionStat) GetAllTime

func (dt *DistributionStat) GetAllTime() *Distribution

@Managed @Nested

func (*DistributionStat) GetFifteenMinutes

func (dt *DistributionStat) GetFifteenMinutes() *Distribution

@Managed @Nested

func (*DistributionStat) GetFiveMinutes

func (dt *DistributionStat) GetFiveMinutes() *Distribution

@Managed @Nested

func (*DistributionStat) GetOneMinute

func (dt *DistributionStat) GetOneMinute() *Distribution

@Managed @Nested

func (*DistributionStat) Snapshot

func (*DistributionStat) String

func (dt *DistributionStat) String() string

type DistributionStatSnapshot

type DistributionStatSnapshot struct {
	// contains filtered or unexported fields
}

func NewDistributionStatSnapshot

func NewDistributionStatSnapshot(oneMinute *DistributionSnapshot, fiveMinute *DistributionSnapshot, fifteenMinute *DistributionSnapshot, allTime *DistributionSnapshot) *DistributionStatSnapshot

func (*DistributionStatSnapshot) GetAllTime

@JsonProperty

func (*DistributionStatSnapshot) GetFifteenMinutes

func (dt *DistributionStatSnapshot) GetFifteenMinutes() *DistributionSnapshot

@JsonProperty

func (*DistributionStatSnapshot) GetFiveMinutes

func (dt *DistributionStatSnapshot) GetFiveMinutes() *DistributionSnapshot

@JsonProperty

func (*DistributionStatSnapshot) GetOneMinute

func (dt *DistributionStatSnapshot) GetOneMinute() *DistributionSnapshot

@JsonProperty

func (*DistributionStatSnapshot) String

func (dt *DistributionStatSnapshot) String() string

@Override

type DoubleColumnReader

type DoubleColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewDoubleColumnReader

func NewDoubleColumnReader(kind block.Type, column *MothColumn, memoryContext memory.LocalMemoryContext) *DoubleColumnReader

func (*DoubleColumnReader) Close

func (dr *DoubleColumnReader) Close()

@Override

func (*DoubleColumnReader) GetRetainedSizeInBytes

func (dr *DoubleColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*DoubleColumnReader) PrepareNextRead

func (dr *DoubleColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*DoubleColumnReader) ReadBlock

func (dr *DoubleColumnReader) ReadBlock() block.Block

@Override

func (*DoubleColumnReader) StartRowGroup

func (dr *DoubleColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*DoubleColumnReader) StartStripe

func (dr *DoubleColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*DoubleColumnReader) String

func (dr *DoubleColumnReader) String() string

@Override

type DoubleColumnWriter

type DoubleColumnWriter struct {
	// 继承
	ColumnWriter
	// contains filtered or unexported fields
}

func NewDoubleColumnWriter

func NewDoubleColumnWriter(columnId metadata.MothColumnId, kind block.Type, compression metadata.CompressionKind, bufferSize int32, statisticsBuilderSupplier function.Supplier[*metadata.DoubleStatisticsBuilder]) *DoubleColumnWriter

func (*DoubleColumnWriter) BeginRowGroup

func (dr *DoubleColumnWriter) BeginRowGroup()

@Override

func (*DoubleColumnWriter) Close

func (dr *DoubleColumnWriter) Close()

@Override

func (*DoubleColumnWriter) FinishRowGroup

@Override

func (*DoubleColumnWriter) GetBloomFilters

func (dr *DoubleColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*DoubleColumnWriter) GetBufferedBytes

func (dr *DoubleColumnWriter) GetBufferedBytes() int64

@Override

func (*DoubleColumnWriter) GetColumnEncodings

func (dr *DoubleColumnWriter) GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding

@Override

func (*DoubleColumnWriter) GetColumnStripeStatistics

func (dr *DoubleColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*DoubleColumnWriter) GetDataStreams

func (dr *DoubleColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*DoubleColumnWriter) GetIndexStreams

func (dr *DoubleColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*DoubleColumnWriter) GetNestedColumnWriters

func (dr *DoubleColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

@Override

func (*DoubleColumnWriter) GetRetainedBytes

func (dr *DoubleColumnWriter) GetRetainedBytes() int64

@Override

func (*DoubleColumnWriter) Reset

func (dr *DoubleColumnWriter) Reset()

@Override

func (*DoubleColumnWriter) WriteBlock

func (dr *DoubleColumnWriter) WriteBlock(block block.Block)

@Override

type DoubleInputStream

type DoubleInputStream struct {
	// 继承
	ValueInputStream[*DoubleStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewDoubleInputStream

func NewDoubleInputStream(input *MothInputStream) *DoubleInputStream

func (*DoubleInputStream) Next

func (dm *DoubleInputStream) Next() float64

func (*DoubleInputStream) Next2

func (dm *DoubleInputStream) Next2(values []int64, items int32)

func (*DoubleInputStream) SeekToCheckpoint

func (dm *DoubleInputStream) SeekToCheckpoint(checkpoint StreamCheckpoint)

@Override

func (*DoubleInputStream) Skip

func (dm *DoubleInputStream) Skip(items int64)

@Override

type DoubleOutputStream

type DoubleOutputStream struct {
	// 继承
	ValueOutputStream[*DoubleStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewDoubleOutputStream

func NewDoubleOutputStream(compression metadata.CompressionKind, bufferSize int32) *DoubleOutputStream

func (*DoubleOutputStream) Close

func (dm *DoubleOutputStream) Close()

@Override

func (*DoubleOutputStream) GetBufferedBytes

func (dm *DoubleOutputStream) GetBufferedBytes() int64

@Override

func (*DoubleOutputStream) GetCheckpoints

func (dm *DoubleOutputStream) GetCheckpoints() *util.ArrayList[*DoubleStreamCheckpoint]

@Override

func (*DoubleOutputStream) GetRetainedBytes

func (dm *DoubleOutputStream) GetRetainedBytes() int64

@Override

func (*DoubleOutputStream) GetStreamDataOutput

func (dm *DoubleOutputStream) GetStreamDataOutput(columnId metadata.MothColumnId) *StreamDataOutput

@Override

func (*DoubleOutputStream) RecordCheckpoint

func (dm *DoubleOutputStream) RecordCheckpoint()

@Override

func (*DoubleOutputStream) Reset

func (dm *DoubleOutputStream) Reset()

@Override

func (*DoubleOutputStream) WriteDouble

func (dm *DoubleOutputStream) WriteDouble(value float64)

type DoubleStreamCheckpoint

type DoubleStreamCheckpoint struct {
	// 继承
	StreamCheckpoint
	// contains filtered or unexported fields
}

func NewDoubleStreamCheckpoint

func NewDoubleStreamCheckpoint(inputStreamCheckpoint int64) *DoubleStreamCheckpoint

func NewDoubleStreamCheckpoint2

func NewDoubleStreamCheckpoint2(compressed bool, positionsList *ColumnPositionsList) *DoubleStreamCheckpoint

func (*DoubleStreamCheckpoint) GetInputStreamCheckpoint

func (dt *DoubleStreamCheckpoint) GetInputStreamCheckpoint() int64

func (*DoubleStreamCheckpoint) String

func (bt *DoubleStreamCheckpoint) String() string

func (*DoubleStreamCheckpoint) ToPositionList

func (dt *DoubleStreamCheckpoint) ToPositionList(compressed bool) *util.ArrayList[int32]

type EncodingType

type EncodingType int8
	private int getOpCode()
	{
		return ordinal() << 6;
	}
}
const (
	SHORT_REPEAT EncodingType = iota
	DIRECT
	PATCHED_BASE
	DELTA
)

func (EncodingType) GetOpCode

func (e EncodingType) GetOpCode() int32

type FieldMapper

type FieldMapper interface {
	Get(fieldName string) *MothColumn
}

func Create

func Create(column *MothColumn) FieldMapper

type FieldMapperFactory

type FieldMapperFactory interface {
	Create(mothColumn *MothColumn) FieldMapper
}

func NewFieldMapperFactory

func NewFieldMapperFactory() FieldMapperFactory

type FieldMapperFactoryImpl

type FieldMapperFactoryImpl struct {
	// 继承
	FieldMapperFactory
}

func (*FieldMapperFactoryImpl) Create

func (f *FieldMapperFactoryImpl) Create(column *MothColumn) FieldMapper

type FileMothDataSource

type FileMothDataSource struct {
	// 继承
	AbstractMothDataSource
	// contains filtered or unexported fields
}

func NewFileMothDataSource

func NewFileMothDataSource(path string, options *MothReaderOptions) *FileMothDataSource

*os.File

func (*FileMothDataSource) Close

func (fe *FileMothDataSource) Close()

@Override

func (*FileMothDataSource) GetEstimatedSize

func (ae *FileMothDataSource) GetEstimatedSize() int64

@Override

func (*FileMothDataSource) GetId

@Override

func (*FileMothDataSource) GetReadBytes

func (ae *FileMothDataSource) GetReadBytes() int64

@Override

func (*FileMothDataSource) GetReadTimeNanos

func (ae *FileMothDataSource) GetReadTimeNanos() int64

@Override

func (*FileMothDataSource) GetRetainedSize

func (ae *FileMothDataSource) GetRetainedSize() int64

@Override

func (*FileMothDataSource) ReadFully

func (ae *FileMothDataSource) ReadFully(position int64, length int32) *slice.Slice

@Override

func (*FileMothDataSource) ReadFully2

func (ae *FileMothDataSource) ReadFully2(diskRanges map[StreamId]*DiskRange) map[StreamId]MothDataReader

@Override

func (*FileMothDataSource) ReadTail

func (ae *FileMothDataSource) ReadTail(length int32) *slice.Slice

@Override

func (*FileMothDataSource) String

func (ae *FileMothDataSource) String() string

@Override

type FixedBitSizes

type FixedBitSizes int8
const (
	ONE FixedBitSizes = iota
	TWO
	THREE
	FOUR
	FIVE
	SIX
	SEVEN
	EIGHT
	NINE
	TEN
	ELEVEN
	TWELVE
	THIRTEEN
	FOURTEEN
	FIFTEEN
	SIXTEEN
	SEVENTEEN
	EIGHTEEN
	NINETEEN
	TWENTY
	TWENTY_ONE
	TWENTY_TWO
	TWENTY_THREE
	TWENTY_FOUR
	TWENTY_SIX
	TWENTY_EIGHT
	THIRTY
	THIRTY_TWO
	FORTY
	FORTY_EIGHT
	FIFTY_SIX
	SIXTY_FOUR
)

type FixedBitSizes_V1

type FixedBitSizes_V1 int8
const (
	ONE_V1 FixedBitSizes_V1 = iota
	TWO_V1
	THREE_V1
	FOUR_V1
	FIVE_V1
	SIX_V1
	SEVEN_V1
	EIGHT_V1
	NINE_V1
	TEN_V1
	ELEVEN_V1
	TWELVE_V1

	THIRTEEN_V1
	FOURTEEN_V1
	FIFTEEN_V1
	SIXTEEN_V1
	SEVENTEEN_V1
	EIGHTEEN_V1
	NINETEEN_V1

	TWENTY_V1
	TWENTY_ONE_V1
	TWENTY_TWO_V1
	TWENTY_THREE_V1
	TWENTY_FOUR_V1
	TWENTY_SIX_V1

	TWENTY_EIGHT_V1
	THIRTY_V1
	THIRTY_TWO_V1
	FORTY_V1

	FORTY_EIGHT_V1
	FIFTY_SIX_V1
	SIXTY_FOUR_V1
)

enum FixedBitSizes_V1

{
	ONE, TWO, THREE, FOUR, FIVE, SIX, SEVEN, EIGHT, NINE, TEN, ELEVEN, TWELVE,
	THIRTEEN, FOURTEEN, FIFTEEN, SIXTEEN, SEVENTEEN, EIGHTEEN, NINETEEN,
	TWENTY, TWENTY_ONE, TWENTY_TWO, TWENTY_THREE, TWENTY_FOUR, TWENTY_SIX,
	TWENTY_EIGHT, THIRTY, THIRTY_TWO, FORTY, FORTY_EIGHT, FIFTY_SIX, SIXTY_FOUR
}

type FloatColumnReader

type FloatColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewFloatColumnReader

func NewFloatColumnReader(kind block.Type, column *MothColumn, memoryContext memory.LocalMemoryContext) *FloatColumnReader

func (*FloatColumnReader) Close

func (fr *FloatColumnReader) Close()

@Override

func (*FloatColumnReader) GetRetainedSizeInBytes

func (fr *FloatColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*FloatColumnReader) PrepareNextRead

func (fr *FloatColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*FloatColumnReader) ReadBlock

func (fr *FloatColumnReader) ReadBlock() block.Block

@Override

func (*FloatColumnReader) StartRowGroup

func (fr *FloatColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*FloatColumnReader) StartStripe

func (fr *FloatColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*FloatColumnReader) ToString

func (fr *FloatColumnReader) ToString() string

@Override

type FloatColumnWriter

type FloatColumnWriter struct {
	// 继承
	ColumnWriter
	// contains filtered or unexported fields
}

func NewFloatColumnWriter

func NewFloatColumnWriter(columnId metadata.MothColumnId, kind block.Type, compression metadata.CompressionKind, bufferSize int32, statisticsBuilderSupplier function.Supplier[*metadata.DoubleStatisticsBuilder]) *FloatColumnWriter

func (*FloatColumnWriter) BeginRowGroup

func (fr *FloatColumnWriter) BeginRowGroup()

@Override

func (*FloatColumnWriter) Close

func (fr *FloatColumnWriter) Close()

@Override

func (*FloatColumnWriter) FinishRowGroup

@Override

func (*FloatColumnWriter) GetBloomFilters

func (fr *FloatColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*FloatColumnWriter) GetBufferedBytes

func (fr *FloatColumnWriter) GetBufferedBytes() int64

@Override

func (*FloatColumnWriter) GetColumnEncodings

func (fr *FloatColumnWriter) GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding

@Override

func (*FloatColumnWriter) GetColumnStripeStatistics

func (fr *FloatColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*FloatColumnWriter) GetDataStreams

func (fr *FloatColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*FloatColumnWriter) GetIndexStreams

func (fr *FloatColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*FloatColumnWriter) GetNestedColumnWriters

func (fr *FloatColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

@Override

func (*FloatColumnWriter) GetRetainedBytes

func (fr *FloatColumnWriter) GetRetainedBytes() int64

@Override

func (*FloatColumnWriter) Reset

func (fr *FloatColumnWriter) Reset()

@Override

func (*FloatColumnWriter) WriteBlock

func (fr *FloatColumnWriter) WriteBlock(block block.Block)

@Override

type FloatInputStream

type FloatInputStream struct {
	// 继承
	ValueInputStream[*FloatStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewFloatInputStream

func NewFloatInputStream(input *MothInputStream) *FloatInputStream

func (*FloatInputStream) Next

func (fm *FloatInputStream) Next() float32

func (*FloatInputStream) Next2

func (fm *FloatInputStream) Next2(values []int32, items int32)

func (*FloatInputStream) SeekToCheckpoint

func (fm *FloatInputStream) SeekToCheckpoint(checkpoint StreamCheckpoint)

@Override

func (*FloatInputStream) Skip

func (fm *FloatInputStream) Skip(items int64)

@Override

type FloatOutputStream

type FloatOutputStream struct {
	//继承
	ValueOutputStream[*FloatStreamCheckpoint]
	// contains filtered or unexported fields
}

func NewFloatOutputStream

func NewFloatOutputStream(compression metadata.CompressionKind, bufferSize int32) *FloatOutputStream

func (*FloatOutputStream) Close

func (fm *FloatOutputStream) Close()

@Override

func (*FloatOutputStream) GetBufferedBytes

func (fm *FloatOutputStream) GetBufferedBytes() int64

@Override

func (*FloatOutputStream) GetCheckpoints

func (fm *FloatOutputStream) GetCheckpoints() *util.ArrayList[*FloatStreamCheckpoint]

@Override

func (*FloatOutputStream) GetRetainedBytes

func (fm *FloatOutputStream) GetRetainedBytes() int64

@Override

func (*FloatOutputStream) GetStreamDataOutput

func (fm *FloatOutputStream) GetStreamDataOutput(columnId metadata.MothColumnId) *StreamDataOutput

@Override

func (*FloatOutputStream) RecordCheckpoint

func (fm *FloatOutputStream) RecordCheckpoint()

@Override

func (*FloatOutputStream) Reset

func (fm *FloatOutputStream) Reset()

@Override

func (*FloatOutputStream) WriteFloat

func (fm *FloatOutputStream) WriteFloat(value float32)

type FloatStreamCheckpoint

type FloatStreamCheckpoint struct {
	// 继承
	StreamCheckpoint
	// contains filtered or unexported fields
}

func NewFloatStreamCheckpoint

func NewFloatStreamCheckpoint(inputStreamCheckpoint int64) *FloatStreamCheckpoint

func NewFloatStreamCheckpoint2

func NewFloatStreamCheckpoint2(compressed bool, positionsList *ColumnPositionsList) *FloatStreamCheckpoint

func (*FloatStreamCheckpoint) GetInputStreamCheckpoint

func (ft *FloatStreamCheckpoint) GetInputStreamCheckpoint() int64

func (*FloatStreamCheckpoint) String

func (bt *FloatStreamCheckpoint) String() string

func (*FloatStreamCheckpoint) ToPositionList

func (ft *FloatStreamCheckpoint) ToPositionList(compressed bool) *util.ArrayList[int32]

type FlushReason

type FlushReason int8
const (
	MAX_ROWS FlushReason = iota
	MAX_BYTES
	DICTIONARY_FULL
	CLOSED
)

type IValueInputStream

type IValueInputStream interface {
	Skip(items int64)

	String() string
	SeekToCheckpoint(checkpoint StreamCheckpoint)
}

func CreateValueStreams

func CreateValueStreams(streamId StreamId, chunkLoader MothChunkLoader, kind metadata.MothTypeKind, encoding metadata.ColumnEncodingKind) IValueInputStream

type InputStreamSource

type InputStreamSource interface {
	OpenStream() IValueInputStream
}

public interface InputStreamSource<S extends ValueInputStream<?>>

func GetInputStreamSource

func GetInputStreamSource[T IValueInputStream](is *InputStreamSources, column *MothColumn, streamKind metadata.StreamKind) InputStreamSource

type InputStreamSources

type InputStreamSources struct {
	// contains filtered or unexported fields
}

func NewInputStreamSources

func NewInputStreamSources(streamSources map[StreamId]InputStreamSource) *InputStreamSources

public InputStreamSources(Map<StreamId, InputStreamSource<?>> streamSources)

type Ints

type Ints struct {
	// contains filtered or unexported fields
}

func NewInts

func NewInts(data []int32, b block.Block) *Ints

func (Ints) Len

func (is Ints) Len() int

func (Ints) Less

func (is Ints) Less(i, j int) bool

func (Ints) Swap

func (is Ints) Swap(i, j int)

type LazyBufferLoader

type LazyBufferLoader struct {
	// contains filtered or unexported fields
}

func NewLazyBufferLoader

func NewLazyBufferLoader(diskRange *DiskRange, parent MothDataSource) *LazyBufferLoader

func (*LazyBufferLoader) LoadNestedDiskRangeBuffer

func (lr *LazyBufferLoader) LoadNestedDiskRangeBuffer(nestedDiskRange *DiskRange) *slice.Slice

type LinearProbeRangeFinder

type LinearProbeRangeFinder struct {
	// contains filtered or unexported fields
}

func CreateTinyStripesRangeFinder

func CreateTinyStripesRangeFinder(stripes *util.ArrayList[*metadata.StripeInformation], maxMergeDistance util.DataSize, tinyStripeThreshold util.DataSize) *LinearProbeRangeFinder

func NewLinearProbeRangeFinder

func NewLinearProbeRangeFinder(diskRanges *util.ArrayList[*DiskRange]) *LinearProbeRangeFinder

func (*LinearProbeRangeFinder) GetRangeFor

func (lr *LinearProbeRangeFinder) GetRangeFor(desiredOffset int64) *DiskRange

@Override

type ListColumnReader

type ListColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewListColumnReader

func NewListColumnReader(kind block.Type, column *MothColumn, memoryContext memory.AggregatedMemoryContext, blockFactory *MothBlockFactory, fieldMapperFactory FieldMapperFactory) *ListColumnReader

func (*ListColumnReader) Close

func (lr *ListColumnReader) Close()

@Override

func (*ListColumnReader) GetRetainedSizeInBytes

func (lr *ListColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*ListColumnReader) PrepareNextRead

func (lr *ListColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*ListColumnReader) ReadBlock

func (lr *ListColumnReader) ReadBlock() block.Block

@Override

func (*ListColumnReader) StartRowGroup

func (lr *ListColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*ListColumnReader) StartStripe

func (lr *ListColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*ListColumnReader) String

func (lr *ListColumnReader) String() string

@Override

type ListColumnWriter

type ListColumnWriter struct {
	// 继承
	ColumnWriter
	// contains filtered or unexported fields
}

func NewListColumnWriter

func NewListColumnWriter(columnId metadata.MothColumnId, compression metadata.CompressionKind, bufferSize int32, elementWriter ColumnWriter) *ListColumnWriter

func (*ListColumnWriter) BeginRowGroup

func (lr *ListColumnWriter) BeginRowGroup()

@Override

func (*ListColumnWriter) Close

func (lr *ListColumnWriter) Close()

@Override

func (*ListColumnWriter) FinishRowGroup

@Override

func (*ListColumnWriter) GetBloomFilters

func (lr *ListColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*ListColumnWriter) GetBufferedBytes

func (lr *ListColumnWriter) GetBufferedBytes() int64

@Override

func (*ListColumnWriter) GetColumnEncodings

func (lr *ListColumnWriter) GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding

@Override

func (*ListColumnWriter) GetColumnStripeStatistics

func (lr *ListColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*ListColumnWriter) GetDataStreams

func (lr *ListColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*ListColumnWriter) GetIndexStreams

func (lr *ListColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*ListColumnWriter) GetNestedColumnWriters

func (lr *ListColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

@Override

func (*ListColumnWriter) GetRetainedBytes

func (lr *ListColumnWriter) GetRetainedBytes() int64

@Override

func (*ListColumnWriter) Reset

func (lr *ListColumnWriter) Reset()

@Override

func (*ListColumnWriter) WriteBlock

func (lr *ListColumnWriter) WriteBlock(b block.Block)

@Override

type LongBitPacker

type LongBitPacker struct {
	// contains filtered or unexported fields
}

func NewLongBitPacker

func NewLongBitPacker() *LongBitPacker

func (*LongBitPacker) GetTmp

func (lr *LongBitPacker) GetTmp() []byte

func (*LongBitPacker) Unpack

func (lr *LongBitPacker) Unpack(buffer []int64, offset int32, len int32, bitSize int32, input mothio.InputStream)

type LongColumnReader

type LongColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewLongColumnReader

func NewLongColumnReader(kind block.Type, column *MothColumn, memoryContext memory.LocalMemoryContext) *LongColumnReader

func (*LongColumnReader) Close

func (lr *LongColumnReader) Close()

@Override

func (*LongColumnReader) GetRetainedSizeInBytes

func (lr *LongColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*LongColumnReader) PrepareNextRead

func (lr *LongColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*LongColumnReader) ReadBlock

func (lr *LongColumnReader) ReadBlock() block.Block

@Override

func (*LongColumnReader) StartRowGroup

func (lr *LongColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*LongColumnReader) StartStripe

func (lr *LongColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*LongColumnReader) ToString

func (lr *LongColumnReader) ToString() string

@Override

type LongColumnWriter

type LongColumnWriter struct {
	// 继承
	ColumnWriter
	// contains filtered or unexported fields
}

func NewLongColumnWriter

func NewLongColumnWriter(columnId metadata.MothColumnId, kind block.Type, compression metadata.CompressionKind, bufferSize int32, statisticsBuilderSupplier function.Supplier[metadata.LongValueStatisticsBuilder]) *LongColumnWriter

func (*LongColumnWriter) BeginRowGroup

func (lr *LongColumnWriter) BeginRowGroup()

@Override

func (*LongColumnWriter) Close

func (lr *LongColumnWriter) Close()

@Override

func (*LongColumnWriter) FinishRowGroup

@Override

func (*LongColumnWriter) GetBloomFilters

func (lr *LongColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*LongColumnWriter) GetBufferedBytes

func (lr *LongColumnWriter) GetBufferedBytes() int64

@Override

func (*LongColumnWriter) GetColumnEncodings

func (lr *LongColumnWriter) GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding

@Override

func (*LongColumnWriter) GetColumnStripeStatistics

func (lr *LongColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*LongColumnWriter) GetDataStreams

func (lr *LongColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*LongColumnWriter) GetIndexStreams

func (lr *LongColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*LongColumnWriter) GetNestedColumnWriters

func (lr *LongColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

@Override

func (*LongColumnWriter) GetRetainedBytes

func (lr *LongColumnWriter) GetRetainedBytes() int64

@Override

func (*LongColumnWriter) Reset

func (lr *LongColumnWriter) Reset()

@Override

func (*LongColumnWriter) String

func (lr *LongColumnWriter) String() string

@Override

func (*LongColumnWriter) WriteBlock

func (lr *LongColumnWriter) WriteBlock(block block.Block)

@Override

type LongInputStream

type LongInputStream interface {
	ValueInputStream[LongStreamCheckpoint]
	Next() int64
	Next2(values []int64, items int32)
	Next3(values []int32, items int32)
	Next4(values []int16, items int32)
	Sum(items int32) int64
}

type LongInputStreamV1

type LongInputStreamV1 struct {
	//继承
	LongInputStream
	// contains filtered or unexported fields
}

func NewLongInputStreamV1

func NewLongInputStreamV1(input *MothInputStream, signed bool) *LongInputStreamV1

func (*LongInputStreamV1) Next

func (l1 *LongInputStreamV1) Next() int64

@Override

func (*LongInputStreamV1) Next2

func (l1 *LongInputStreamV1) Next2(values []int64, items int32)

@Override

func (*LongInputStreamV1) Next3

func (l1 *LongInputStreamV1) Next3(values []int32, items int32)

@Override

func (*LongInputStreamV1) Next4

func (l1 *LongInputStreamV1) Next4(values []int16, items int32)

@Override

func (*LongInputStreamV1) SeekToCheckpoint

func (l1 *LongInputStreamV1) SeekToCheckpoint(cp StreamCheckpoint)

@Override

func (*LongInputStreamV1) Skip

func (l1 *LongInputStreamV1) Skip(items int64)

@Override

func (*LongInputStreamV1) String

func (l1 *LongInputStreamV1) String() string

@Override

type LongInputStreamV2

type LongInputStreamV2 struct {
	// 继承
	LongInputStream
	// contains filtered or unexported fields
}

func NewLongInputStreamV2

func NewLongInputStreamV2(input *MothInputStream, signed bool, skipCorrupt bool) *LongInputStreamV2

func (*LongInputStreamV2) Next

func (l2 *LongInputStreamV2) Next() int64

@Override

func (*LongInputStreamV2) Next2

func (l2 *LongInputStreamV2) Next2(values []int64, items int32)

@Override

func (*LongInputStreamV2) Next3

func (l2 *LongInputStreamV2) Next3(values []int32, items int32)

@Override

func (*LongInputStreamV2) Next4

func (l2 *LongInputStreamV2) Next4(values []int16, items int32)

@Override

func (*LongInputStreamV2) SeekToCheckpoint

func (l2 *LongInputStreamV2) SeekToCheckpoint(checkpoint StreamCheckpoint)

@Override

func (*LongInputStreamV2) Skip

func (l2 *LongInputStreamV2) Skip(items int64)

@Override

func (*LongInputStreamV2) String

func (l2 *LongInputStreamV2) String() string

type LongOutputStream

type LongOutputStream interface {
	// 继承
	ValueOutputStream[LongStreamCheckpoint]

	WriteLong(value int64)
}

*

*
*

func CreateLengthOutputStream

func CreateLengthOutputStream(compression metadata.CompressionKind, bufferSize int32) LongOutputStream

type LongOutputStreamV1

type LongOutputStreamV1 struct {

	// 继承
	LongOutputStream
	// contains filtered or unexported fields
}

func NewLongOutputStreamV1

func NewLongOutputStreamV1(compression metadata.CompressionKind, bufferSize int32, signed bool, streamKind metadata.StreamKind) *LongOutputStreamV1

func (*LongOutputStreamV1) Close

func (l1 *LongOutputStreamV1) Close()

@Override

func (*LongOutputStreamV1) GetBufferedBytes

func (l1 *LongOutputStreamV1) GetBufferedBytes() int64

@Override

func (*LongOutputStreamV1) GetCheckpoints

func (l1 *LongOutputStreamV1) GetCheckpoints() *util.ArrayList[LongStreamCheckpoint]

@Override

func (*LongOutputStreamV1) GetRetainedBytes

func (l1 *LongOutputStreamV1) GetRetainedBytes() int64

@Override

func (*LongOutputStreamV1) GetStreamDataOutput

func (l1 *LongOutputStreamV1) GetStreamDataOutput(columnId metadata.MothColumnId) *StreamDataOutput

@Override

func (*LongOutputStreamV1) RecordCheckpoint

func (l1 *LongOutputStreamV1) RecordCheckpoint()

@Override

func (*LongOutputStreamV1) Reset

func (l1 *LongOutputStreamV1) Reset()

@Override

func (*LongOutputStreamV1) WriteLong

func (l1 *LongOutputStreamV1) WriteLong(value int64)

@Override

type LongOutputStreamV2

type LongOutputStreamV2 struct {

	// 继承
	LongOutputStream
	// contains filtered or unexported fields
}

func NewLongOutputStreamV2

func NewLongOutputStreamV2(compression metadata.CompressionKind, bufferSize int32, signed bool, streamKind metadata.StreamKind) *LongOutputStreamV2

func (*LongOutputStreamV2) Close

func (l2 *LongOutputStreamV2) Close()

@Override

func (*LongOutputStreamV2) GetBufferedBytes

func (l2 *LongOutputStreamV2) GetBufferedBytes() int64

@Override

func (*LongOutputStreamV2) GetCheckpoints

func (l2 *LongOutputStreamV2) GetCheckpoints() *util.ArrayList[LongStreamCheckpoint]

@Override

func (*LongOutputStreamV2) GetRetainedBytes

func (l2 *LongOutputStreamV2) GetRetainedBytes() int64

@Override

func (*LongOutputStreamV2) GetStreamDataOutput

func (l2 *LongOutputStreamV2) GetStreamDataOutput(columnId metadata.MothColumnId) *StreamDataOutput

@Override

func (*LongOutputStreamV2) RecordCheckpoint

func (l2 *LongOutputStreamV2) RecordCheckpoint()

@Override

func (*LongOutputStreamV2) Reset

func (l2 *LongOutputStreamV2) Reset()

@Override

func (*LongOutputStreamV2) WriteLong

func (l2 *LongOutputStreamV2) WriteLong(value int64)

@Override

type LongStreamCheckpoint

type LongStreamCheckpoint interface {
	// 继承
	StreamCheckpoint

	ToPositionList(compressed bool) *util.ArrayList[int32]
}

type LongStreamV1Checkpoint

type LongStreamV1Checkpoint struct {
	//继承
	LongStreamCheckpoint
	// contains filtered or unexported fields
}

func NewLongStreamV1Checkpoint

func NewLongStreamV1Checkpoint(offset int32, inputStreamCheckpoint int64) *LongStreamV1Checkpoint

func NewLongStreamV1Checkpoint2

func NewLongStreamV1Checkpoint2(compressed bool, positionsList *ColumnPositionsList) *LongStreamV1Checkpoint

func (*LongStreamV1Checkpoint) GetInputStreamCheckpoint

func (lt *LongStreamV1Checkpoint) GetInputStreamCheckpoint() int64

func (*LongStreamV1Checkpoint) GetOffset

func (lt *LongStreamV1Checkpoint) GetOffset() int32

func (*LongStreamV1Checkpoint) String

func (bt *LongStreamV1Checkpoint) String() string

func (*LongStreamV1Checkpoint) ToPositionList

func (lt *LongStreamV1Checkpoint) ToPositionList(compressed bool) *util.ArrayList[int32]

@Override

type LongStreamV2Checkpoint

type LongStreamV2Checkpoint struct {
	//继承
	LongStreamCheckpoint
	// contains filtered or unexported fields
}

func NewLongStreamV2Checkpoint

func NewLongStreamV2Checkpoint(offset int32, inputStreamCheckpoint int64) *LongStreamV2Checkpoint

func NewLongStreamV2Checkpoint2

func NewLongStreamV2Checkpoint2(compressed bool, positionsList *ColumnPositionsList) *LongStreamV2Checkpoint

func (*LongStreamV2Checkpoint) GetInputStreamCheckpoint

func (lt *LongStreamV2Checkpoint) GetInputStreamCheckpoint() int64

func (*LongStreamV2Checkpoint) GetOffset

func (lt *LongStreamV2Checkpoint) GetOffset() int32

func (*LongStreamV2Checkpoint) String

func (bt *LongStreamV2Checkpoint) String() string

func (*LongStreamV2Checkpoint) ToPositionList

func (lt *LongStreamV2Checkpoint) ToPositionList(compressed bool) *util.ArrayList[int32]

@Override

type Lz4Compressor

type Lz4Compressor struct {
	// 继承
	Compressor
}

func (*Lz4Compressor) Compress

func (sr *Lz4Compressor) Compress(input []byte, inputOffset int32, inputLength int32, output []byte, outputOffset int32, maxOutputLength int32) int32

@Override

func (*Lz4Compressor) Decompress2

func (dr *Lz4Compressor) Decompress2(input *bytes.Buffer, output *bytes.Buffer)

@Override

func (*Lz4Compressor) MaxCompressedLength

func (sr *Lz4Compressor) MaxCompressedLength(uncompressedSize int32) int32

@Override

type MapColumnReader

type MapColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewMapColumnReader

func NewMapColumnReader(kind block.Type, column *MothColumn, memoryContext memory.AggregatedMemoryContext, blockFactory *MothBlockFactory, fieldMapperFactory FieldMapperFactory) *MapColumnReader

func (*MapColumnReader) Close

func (mr *MapColumnReader) Close()

@Override

func (*MapColumnReader) GetRetainedSizeInBytes

func (mr *MapColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*MapColumnReader) PrepareNextRead

func (mr *MapColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*MapColumnReader) ReadBlock

func (mr *MapColumnReader) ReadBlock() block.Block

@Override

func (*MapColumnReader) StartRowGroup

func (mr *MapColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*MapColumnReader) StartStripe

func (mr *MapColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*MapColumnReader) ToString

func (mr *MapColumnReader) ToString() string

@Override

type MapColumnWriter

type MapColumnWriter struct {
	// 继承
	ColumnWriter
	// contains filtered or unexported fields
}

func NewMapColumnWriter

func NewMapColumnWriter(columnId metadata.MothColumnId, compression metadata.CompressionKind, bufferSize int32, keyWriter ColumnWriter, valueWriter ColumnWriter) *MapColumnWriter

func (*MapColumnWriter) BeginRowGroup

func (mr *MapColumnWriter) BeginRowGroup()

@Override

func (*MapColumnWriter) Close

func (mr *MapColumnWriter) Close()

@Override

func (*MapColumnWriter) FinishRowGroup

@Override

func (*MapColumnWriter) GetBloomFilters

func (mr *MapColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*MapColumnWriter) GetBufferedBytes

func (mr *MapColumnWriter) GetBufferedBytes() int64

@Override

func (*MapColumnWriter) GetColumnEncodings

func (mr *MapColumnWriter) GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding

@Override

func (*MapColumnWriter) GetColumnStripeStatistics

func (mr *MapColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*MapColumnWriter) GetDataStreams

func (mr *MapColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*MapColumnWriter) GetIndexStreams

func (mr *MapColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*MapColumnWriter) GetNestedColumnWriters

func (mr *MapColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

@Override

func (*MapColumnWriter) GetRetainedBytes

func (mr *MapColumnWriter) GetRetainedBytes() int64

@Override

func (*MapColumnWriter) Reset

func (mr *MapColumnWriter) Reset()

@Override

func (*MapColumnWriter) WriteBlock

func (mr *MapColumnWriter) WriteBlock(b block.Block)

@Override

type MemoryMothDataReader

type MemoryMothDataReader struct {
	// 继承
	MothDataReader
	// contains filtered or unexported fields
}

func NewMemoryMothDataReader

func NewMemoryMothDataReader(mothDataSourceId *common.MothDataSourceId, data *slice.Slice, retainedSize int64) *MemoryMothDataReader

func (*MemoryMothDataReader) GetMaxBufferSize

func (mr *MemoryMothDataReader) GetMaxBufferSize() int32

@Override

func (*MemoryMothDataReader) GetMothDataSourceId

func (mr *MemoryMothDataReader) GetMothDataSourceId() *common.MothDataSourceId

@Override

func (*MemoryMothDataReader) GetRetainedSize

func (mr *MemoryMothDataReader) GetRetainedSize() int64

@Override

func (*MemoryMothDataReader) GetSize

func (mr *MemoryMothDataReader) GetSize() int32

@Override

func (*MemoryMothDataReader) SeekBuffer

func (mr *MemoryMothDataReader) SeekBuffer(newPosition int32) *slice.Slice

@Override

func (*MemoryMothDataReader) String

func (mr *MemoryMothDataReader) String() string

type MemoryMothDataSource

type MemoryMothDataSource struct {
	// 继承
	MothDataSource
	// contains filtered or unexported fields
}

func NewMemoryMothDataSource

func NewMemoryMothDataSource(id *common.MothDataSourceId, data *slice.Slice) *MemoryMothDataSource

func (*MemoryMothDataSource) Close

func (me *MemoryMothDataSource) Close()

func (*MemoryMothDataSource) GetEstimatedSize

func (me *MemoryMothDataSource) GetEstimatedSize() int64

@Override

func (*MemoryMothDataSource) GetId

@Override

func (*MemoryMothDataSource) GetReadBytes

func (me *MemoryMothDataSource) GetReadBytes() int64

@Override

func (*MemoryMothDataSource) GetReadTimeNanos

func (me *MemoryMothDataSource) GetReadTimeNanos() int64

@Override

func (*MemoryMothDataSource) GetRetainedSize

func (me *MemoryMothDataSource) GetRetainedSize() int64

@Override

func (*MemoryMothDataSource) ReadFully

func (me *MemoryMothDataSource) ReadFully(position int64, length int32) *slice.Slice

@Override

func (*MemoryMothDataSource) ReadFully2

func (me *MemoryMothDataSource) ReadFully2(diskRanges map[StreamId]*DiskRange) map[StreamId]MothDataReader

ReadFully2(diskRanges map[StreamId]*DiskRange) map[StreamId]MothDataReader @Override

func (*MemoryMothDataSource) ReadTail

func (me *MemoryMothDataSource) ReadTail(length int32) *slice.Slice

@Override

func (*MemoryMothDataSource) ToString

func (me *MemoryMothDataSource) ToString() string

@Override

type MergedMothDataReader

type MergedMothDataReader struct {
	// contains filtered or unexported fields
}

func NewMergedMothDataReader

func NewMergedMothDataReader(mothDataSourceId *common.MothDataSourceId, diskRange *DiskRange, LazyBufferLoader *LazyBufferLoader) *MergedMothDataReader

func (*MergedMothDataReader) GetMaxBufferSize

func (mr *MergedMothDataReader) GetMaxBufferSize() int32

@Override

func (*MergedMothDataReader) GetMothDataSourceId

func (mr *MergedMothDataReader) GetMothDataSourceId() *common.MothDataSourceId

@Override

func (*MergedMothDataReader) GetRetainedSize

func (mr *MergedMothDataReader) GetRetainedSize() int64

@Override

func (*MergedMothDataReader) GetSize

func (mr *MergedMothDataReader) GetSize() int32

@Override

func (*MergedMothDataReader) SeekBuffer

func (mr *MergedMothDataReader) SeekBuffer(newPosition int32) *slice.Slice

@Override

func (*MergedMothDataReader) String

func (mr *MergedMothDataReader) String() string

@Override

type MissingInputStreamSource

type MissingInputStreamSource struct {
	// 继承
	// InputStreamSource[S]
	InputStreamSource
}

func MissingStreamSource

func MissingStreamSource() *MissingInputStreamSource

public static <S extends ValueInputStream<?>> InputStreamSource<S> missingStreamSource(Class<S> streamType)

func (*MissingInputStreamSource) OpenStream

@Nullable @Override

type MothBlockFactory

type MothBlockFactory struct {
	// contains filtered or unexported fields
}

func NewMothBlockFactory

func NewMothBlockFactory(nestedLazy bool) *MothBlockFactory

func (*MothBlockFactory) CreateBlock

func (my *MothBlockFactory) CreateBlock(positionCount int32, reader MothBlockReader, nested bool) block.Block

func (*MothBlockFactory) NextPage

func (my *MothBlockFactory) NextPage()

type MothBlockLoader

type MothBlockLoader struct {
	// contains filtered or unexported fields
}

func NewMothBlockLoader

func NewMothBlockLoader(blockReader MothBlockReader, loadFully bool) *MothBlockLoader

func (*MothBlockLoader) Load

func (mr *MothBlockLoader) Load() block.Block

@Override

type MothBlockReader

type MothBlockReader interface {
	ReadBlock() block.Block
}

type MothChunkLoader

type MothChunkLoader interface {
	GetMothDataSourceId() *common.MothDataSourceId
	HasNextChunk() bool
	NextChunk() *slice.Slice
	GetLastCheckpoint() int64
	SeekToCheckpoint(checkpoint int64)
	String() string
}

func CreateChunkLoader

func CreateChunkLoader(mothDataSourceId *common.MothDataSourceId, chunk *slice.Slice, decompressor *optional.Optional[MothDecompressor], memoryContext memory.AggregatedMemoryContext) MothChunkLoader

func CreateChunkLoader2

func CreateChunkLoader2(dataReader MothDataReader, decompressor *optional.Optional[MothDecompressor], memoryContext memory.AggregatedMemoryContext) MothChunkLoader

type MothColumn

type MothColumn struct {
	// contains filtered or unexported fields
}

func NewMothColumn

func NewMothColumn(path string, columnId metadata.MothColumnId, columnName string, columnType metadata.MothTypeKind, mothDataSourceId *common.MothDataSourceId, nestedColumns *util.ArrayList[*MothColumn], attributes map[string]string) *MothColumn

func (*MothColumn) GetAttributes

func (mn *MothColumn) GetAttributes() map[string]string

func (*MothColumn) GetColumnId

func (mn *MothColumn) GetColumnId() metadata.MothColumnId

func (*MothColumn) GetColumnName

func (mn *MothColumn) GetColumnName() string

func (*MothColumn) GetColumnType

func (mn *MothColumn) GetColumnType() metadata.MothTypeKind

func (*MothColumn) GetMothDataSourceId

func (mn *MothColumn) GetMothDataSourceId() *common.MothDataSourceId

func (*MothColumn) GetNestedColumns

func (mn *MothColumn) GetNestedColumns() *util.ArrayList[*MothColumn]

func (*MothColumn) GetPath

func (mn *MothColumn) GetPath() string

func (*MothColumn) String

func (mn *MothColumn) String() string

@Override

type MothDataOutput

type MothDataOutput interface {
	Size() int64
	WriteData(sliceOutput slice.SliceOutput)
}

func CreateDataOutput

func CreateDataOutput(s *slice.Slice) MothDataOutput

type MothDataReader

type MothDataReader interface {
	GetMothDataSourceId() *common.MothDataSourceId
	GetRetainedSize() int64
	GetSize() int32
	GetMaxBufferSize() int32
	SeekBuffer(position int32) *slice.Slice

	// 返回当前类
	String() string
}

type MothDataSink

type MothDataSink interface {
	Size() int64
	GetRetainedSizeInBytes() int64
	Write(outputData *util.ArrayList[MothDataOutput])
	Close()
}

MothDataSink

type MothDataSource

type MothDataSource interface {
	GetId() *common.MothDataSourceId
	GetReadBytes() int64
	GetReadTimeNanos() int64
	GetEstimatedSize() int64
	GetRetainedSize() int64
	ReadTail(length int32) *slice.Slice
	ReadFully(position int64, length int32) *slice.Slice

	ReadFully2(diskRanges map[StreamId]*DiskRange) map[StreamId]MothDataReader
	Close()

	String() string
}

type MothDecompressor

type MothDecompressor interface {
	Decompress(input []byte, offset int32, length int32, output OutputBuffer) int32

	String() string
}

type MothInputStream

type MothInputStream struct {
	mothio.InputStream
	// contains filtered or unexported fields
}

public final class MothInputStream extends InputStream

func NewMothInputStream

func NewMothInputStream(chunkLoader MothChunkLoader) *MothInputStream

func (*MothInputStream) Available

func (mm *MothInputStream) Available() int32

@Override

func (*MothInputStream) Close

func (mm *MothInputStream) Close()

@Override

func (*MothInputStream) GetCheckpoint

func (mm *MothInputStream) GetCheckpoint() int64

func (*MothInputStream) GetMothDataSourceId

func (mm *MothInputStream) GetMothDataSourceId() *common.MothDataSourceId

func (*MothInputStream) GetReader

func (mm *MothInputStream) GetReader() io.Reader

func (*MothInputStream) MarkSupported

func (mm *MothInputStream) MarkSupported() bool

@Override

func (*MothInputStream) Read

func (mm *MothInputStream) Read(p []byte) (n int, err error)

func (*MothInputStream) ReadBS

func (mm *MothInputStream) ReadBS() (byte, error)

@Override

func (*MothInputStream) ReadBS2

func (mm *MothInputStream) ReadBS2(b []byte) (n int, err error)

func (*MothInputStream) ReadBS3

func (mm *MothInputStream) ReadBS3(b []byte, off int, length int) (n int, err error)

@Override

func (*MothInputStream) ReadFully

func (mm *MothInputStream) ReadFully(buffer []byte, offset int, length int)

func (*MothInputStream) ReadFully2

func (mm *MothInputStream) ReadFully2(buffer *slice.Slice, offset int, length int)

func (*MothInputStream) SeekToCheckpoint

func (mm *MothInputStream) SeekToCheckpoint(checkpoint int64)

func (*MothInputStream) Skip

func (mm *MothInputStream) Skip(n int64) int64

@Override

func (*MothInputStream) SkipFully

func (mm *MothInputStream) SkipFully(length int64)

func (*MothInputStream) String

func (mm *MothInputStream) String() string

@Override

type MothLz4Decompressor

type MothLz4Decompressor struct {
	// 继承
	MothDecompressor
	// contains filtered or unexported fields
}

func NewMothLz4Decompressor

func NewMothLz4Decompressor(mothDataSourceId *common.MothDataSourceId, maxBufferSize int32) *MothLz4Decompressor

func (*MothLz4Decompressor) Decompress

func (mr *MothLz4Decompressor) Decompress(input []byte, offset int32, length int32, output OutputBuffer) int32

@Override

func (*MothLz4Decompressor) String

func (mr *MothLz4Decompressor) String() string

@Override

type MothOutputBuffer

type MothOutputBuffer struct {
	// 继承
	slice.SliceOutput
	// contains filtered or unexported fields
}

func NewMothOutputBuffer

func NewMothOutputBuffer(compression metadata.CompressionKind, maxBufferSize int32) *MothOutputBuffer

func (*MothOutputBuffer) AppendByte

func (mr *MothOutputBuffer) AppendByte(value byte) slice.SliceOutput

@Override

func (*MothOutputBuffer) AppendBytes

func (mr *MothOutputBuffer) AppendBytes(source []byte, sourceIndex int32, length int32) slice.SliceOutput

@Override

func (*MothOutputBuffer) AppendBytes2

func (mr *MothOutputBuffer) AppendBytes2(source []byte) slice.SliceOutput

@Override

func (*MothOutputBuffer) AppendDouble

func (mr *MothOutputBuffer) AppendDouble(value float64) slice.SliceOutput

@Override

func (*MothOutputBuffer) AppendInt

func (mr *MothOutputBuffer) AppendInt(value int32) slice.SliceOutput

@Override

func (*MothOutputBuffer) AppendLong

func (mr *MothOutputBuffer) AppendLong(value int64) slice.SliceOutput

@Override

func (*MothOutputBuffer) AppendShort

func (mr *MothOutputBuffer) AppendShort(value int16) slice.SliceOutput

@Override

func (*MothOutputBuffer) AppendSlice

func (mr *MothOutputBuffer) AppendSlice(slice *slice.Slice) slice.SliceOutput

@Override

func (*MothOutputBuffer) Close

func (mr *MothOutputBuffer) Close() error

@Override

func (*MothOutputBuffer) EstimateOutputDataSize

func (mr *MothOutputBuffer) EstimateOutputDataSize() int64

func (*MothOutputBuffer) Flush

func (mr *MothOutputBuffer) Flush()

@Override

func (*MothOutputBuffer) GetCheckpoint

func (mr *MothOutputBuffer) GetCheckpoint() int64

func (*MothOutputBuffer) GetOutputDataSize

func (mr *MothOutputBuffer) GetOutputDataSize() int64

func (*MothOutputBuffer) GetRetainedSize

func (mr *MothOutputBuffer) GetRetainedSize() int64

@Override

func (*MothOutputBuffer) GetUnderlyingSlice

func (mr *MothOutputBuffer) GetUnderlyingSlice() *slice.Slice

@Override

func (*MothOutputBuffer) IsWritable

func (mr *MothOutputBuffer) IsWritable() bool

@Override

func (*MothOutputBuffer) Reset

func (mr *MothOutputBuffer) Reset()

@Override

func (*MothOutputBuffer) Reset2

func (mr *MothOutputBuffer) Reset2(position int32)

@Override

func (*MothOutputBuffer) Size

func (mr *MothOutputBuffer) Size() int32

@Override

func (*MothOutputBuffer) Slice

func (mr *MothOutputBuffer) Slice() *slice.Slice

@Override

func (*MothOutputBuffer) String

func (mr *MothOutputBuffer) String() string

@Override

func (*MothOutputBuffer) WritableBytes

func (mr *MothOutputBuffer) WritableBytes() int32

@Override

func (*MothOutputBuffer) Write

func (mr *MothOutputBuffer) Write(b byte)

func (*MothOutputBuffer) WriteBS

func (mr *MothOutputBuffer) WriteBS(source []byte) (n int, err error)

func (*MothOutputBuffer) WriteBS2

func (mr *MothOutputBuffer) WriteBS2(source []byte, sourceIndex int32, length int32) (n int, err error)

func (*MothOutputBuffer) WriteByte

func (mr *MothOutputBuffer) WriteByte(value byte) error

@Override

func (*MothOutputBuffer) WriteBytes

func (mr *MothOutputBuffer) WriteBytes(source []byte)

@Override

func (*MothOutputBuffer) WriteBytes2

func (mr *MothOutputBuffer) WriteBytes2(source []byte, sourceIndex int32, length int32)

@Override

func (*MothOutputBuffer) WriteDataTo

func (mr *MothOutputBuffer) WriteDataTo(outputStream slice.SliceOutput) int64

func (*MothOutputBuffer) WriteDouble

func (mr *MothOutputBuffer) WriteDouble(value float64)

@Override

func (*MothOutputBuffer) WriteFloat

func (mr *MothOutputBuffer) WriteFloat(value float32)

@Override

func (*MothOutputBuffer) WriteInputStream

func (mr *MothOutputBuffer) WriteInputStream(in mothio.InputStream, length int32)

@Override

func (*MothOutputBuffer) WriteInt

func (mr *MothOutputBuffer) WriteInt(value int32)

@Override

func (*MothOutputBuffer) WriteLong

func (mr *MothOutputBuffer) WriteLong(value int64)

@Override

func (*MothOutputBuffer) WriteShort

func (mr *MothOutputBuffer) WriteShort(value int16)

@Override

func (*MothOutputBuffer) WriteSlice

func (mr *MothOutputBuffer) WriteSlice(source *slice.Slice)

@Override

func (*MothOutputBuffer) WriteSlice2

func (mr *MothOutputBuffer) WriteSlice2(source *slice.Slice, sourceIndex int32, length int32)

@Override

func (*MothOutputBuffer) WriteZero

func (mr *MothOutputBuffer) WriteZero(length int32)

@Override

type MothPredicate

type MothPredicate interface {
	Matches(numberOfRows int64, allColumnStatistics *metadata.ColumnMetadata[*metadata.ColumnStatistics]) bool
}
var TRUE MothPredicate = &trueMothPredicate{}

type MothReader

type MothReader struct {
	// contains filtered or unexported fields
}

func NewMothReader

func NewMothReader(mothDataSource MothDataSource, options *MothReaderOptions, fileTail *slice.Slice) *MothReader

func (*MothReader) CreateRecordReader

func (mr *MothReader) CreateRecordReader(readColumns *util.ArrayList[*MothColumn], readTypes *util.ArrayList[block.Type], predicate MothPredicate, legacyFileTimeZone *time.Location, memoryUsage memory.AggregatedMemoryContext, initialBatchSize int32) *MothRecordReader

func (*MothReader) CreateRecordReader2

func (mr *MothReader) CreateRecordReader2(readColumns *util.ArrayList[*MothColumn], readTypes *util.ArrayList[block.Type], readLayouts util.List[ProjectedLayout], predicate MothPredicate, offset int64, length int64, legacyFileTimeZone *time.Location, memoryUsage memory.AggregatedMemoryContext, initialBatchSize int32, fieldMapperFactory FieldMapperFactory) *MothRecordReader

func (*MothReader) GetBufferSize

func (mr *MothReader) GetBufferSize() int32

func (*MothReader) GetColumnNames

func (mr *MothReader) GetColumnNames() *util.ArrayList[string]

func (*MothReader) GetCompressionKind

func (mr *MothReader) GetCompressionKind() metadata.CompressionKind

func (*MothReader) GetFooter

func (mr *MothReader) GetFooter() *metadata.Footer

func (*MothReader) GetMetadata

func (mr *MothReader) GetMetadata() *metadata.Metadata

func (*MothReader) GetRootColumn

func (mr *MothReader) GetRootColumn() *MothColumn

type MothReaderOptions

type MothReaderOptions struct {
	// contains filtered or unexported fields
}

func NewMothReaderOptions

func NewMothReaderOptions() *MothReaderOptions

func NewMothReaderOptions2

func NewMothReaderOptions2(bloomFiltersEnabled bool, maxMergeDistance util.DataSize, maxBufferSize util.DataSize, tinyStripeThreshold util.DataSize, streamBufferSize util.DataSize, maxBlockSize util.DataSize, lazyReadSmallRanges bool, nestedLazy bool) *MothReaderOptions

func (*MothReaderOptions) GetMaxBlockSize

func (ms *MothReaderOptions) GetMaxBlockSize() util.DataSize

func (*MothReaderOptions) GetMaxBufferSize

func (ms *MothReaderOptions) GetMaxBufferSize() util.DataSize

func (*MothReaderOptions) GetMaxMergeDistance

func (ms *MothReaderOptions) GetMaxMergeDistance() util.DataSize

func (*MothReaderOptions) GetStreamBufferSize

func (ms *MothReaderOptions) GetStreamBufferSize() util.DataSize

func (*MothReaderOptions) GetTinyStripeThreshold

func (ms *MothReaderOptions) GetTinyStripeThreshold() util.DataSize

func (*MothReaderOptions) IsBloomFiltersEnabled

func (ms *MothReaderOptions) IsBloomFiltersEnabled() bool

func (*MothReaderOptions) IsLazyReadSmallRanges

func (ms *MothReaderOptions) IsLazyReadSmallRanges() bool

func (*MothReaderOptions) IsNestedLazy

func (ms *MothReaderOptions) IsNestedLazy() bool

func (*MothReaderOptions) WithBloomFiltersEnabled

func (ms *MothReaderOptions) WithBloomFiltersEnabled(bloomFiltersEnabled bool) *MothReaderOptions

func (*MothReaderOptions) WithLazyReadSmallRanges

func (ms *MothReaderOptions) WithLazyReadSmallRanges(lazyReadSmallRanges bool) *MothReaderOptions

@Deprecated

func (*MothReaderOptions) WithMaxBufferSize

func (ms *MothReaderOptions) WithMaxBufferSize(maxBufferSize util.DataSize) *MothReaderOptions

func (*MothReaderOptions) WithMaxMergeDistance

func (ms *MothReaderOptions) WithMaxMergeDistance(maxMergeDistance util.DataSize) *MothReaderOptions

func (*MothReaderOptions) WithMaxReadBlockSize

func (ms *MothReaderOptions) WithMaxReadBlockSize(maxBlockSize util.DataSize) *MothReaderOptions

func (*MothReaderOptions) WithNestedLazy

func (ms *MothReaderOptions) WithNestedLazy(nestedLazy bool) *MothReaderOptions

@Deprecated

func (*MothReaderOptions) WithStreamBufferSize

func (ms *MothReaderOptions) WithStreamBufferSize(streamBufferSize util.DataSize) *MothReaderOptions

func (*MothReaderOptions) WithTinyStripeThreshold

func (ms *MothReaderOptions) WithTinyStripeThreshold(tinyStripeThreshold util.DataSize) *MothReaderOptions

type MothRecordReader

type MothRecordReader struct {
	// contains filtered or unexported fields
}

func NewMothRecordReader

func NewMothRecordReader(readColumns *util.ArrayList[*MothColumn], readTypes *util.ArrayList[block.Type], readLayouts util.List[ProjectedLayout], predicate MothPredicate, numberOfRows int64, fileStripes *util.ArrayList[*metadata.StripeInformation], fileStats *optional.Optional[*metadata.ColumnMetadata[*metadata.ColumnStatistics]], stripeStats *util.ArrayList[*optional.Optional[*metadata.StripeStatistics]], mothDataSource MothDataSource, splitOffset int64, splitLength int64, mothTypes *metadata.ColumnMetadata[*metadata.MothType], decompressor *optional.Optional[MothDecompressor], rowsInRowGroup *optional.OptionalInt, legacyFileTimeZone *time.Location, hiveWriterVersion metadata.HiveWriterVersion, metadataReader metadata.MetadataReader, options *MothReaderOptions, userMetadata map[string]*slice.Slice, memoryUsage memory.AggregatedMemoryContext, initialBatchSize int32, fieldMapperFactory FieldMapperFactory) *MothRecordReader

func (*MothRecordReader) Close

func (mr *MothRecordReader) Close()

@Override

func (*MothRecordReader) GetColumnTypes

func (mr *MothRecordReader) GetColumnTypes() *metadata.ColumnMetadata[*metadata.MothType]

func (*MothRecordReader) GetFilePosition

func (mr *MothRecordReader) GetFilePosition() int64

func (*MothRecordReader) GetFileRowCount

func (mr *MothRecordReader) GetFileRowCount() int64

func (*MothRecordReader) GetMaxCombinedBytesPerRow

func (mr *MothRecordReader) GetMaxCombinedBytesPerRow() int64

func (*MothRecordReader) GetReaderPosition

func (mr *MothRecordReader) GetReaderPosition() int64

func (*MothRecordReader) GetReaderRowCount

func (mr *MothRecordReader) GetReaderRowCount() int64

func (*MothRecordReader) GetSplitLength

func (mr *MothRecordReader) GetSplitLength() int64

func (*MothRecordReader) GetUserMetadata

func (mr *MothRecordReader) GetUserMetadata() map[string]*slice.Slice

func (*MothRecordReader) NextPage

func (mr *MothRecordReader) NextPage() *spi.Page

type MothSnappyDecompressor

type MothSnappyDecompressor struct {
	// 继承
	MothDecompressor
	// contains filtered or unexported fields
}

func NewMothSnappyDecompressor

func NewMothSnappyDecompressor(mothDataSourceId *common.MothDataSourceId, maxBufferSize int32) *MothSnappyDecompressor

func (*MothSnappyDecompressor) Decompress

func (mr *MothSnappyDecompressor) Decompress(input []byte, offset int32, length int32, output OutputBuffer) int32

@Override

func (*MothSnappyDecompressor) String

func (mr *MothSnappyDecompressor) String() string

@Override

type MothWriter

type MothWriter struct {
	// contains filtered or unexported fields
}

func NewMothWriter

func NewMothWriter(mothDataSink MothDataSink, columnNames *util.ArrayList[string], types *util.ArrayList[block.Type], mothTypes *metadata.ColumnMetadata[*metadata.MothType], compression metadata.CompressionKind, options *MothWriterOptions, userMetadata map[string]string, stats *MothWriterStats) *MothWriter

func (*MothWriter) Close

func (mr *MothWriter) Close()

@Override

func (*MothWriter) GetBufferedBytes

func (mr *MothWriter) GetBufferedBytes() int32

func (*MothWriter) GetFileRowCount

func (mr *MothWriter) GetFileRowCount() int64

func (*MothWriter) GetFileStats

func (*MothWriter) GetRetainedBytes

func (mr *MothWriter) GetRetainedBytes() int64

func (*MothWriter) GetStripeRowCount

func (mr *MothWriter) GetStripeRowCount() int32

func (*MothWriter) GetWrittenBytes

func (mr *MothWriter) GetWrittenBytes() int64

func (*MothWriter) UpdateUserMetadata

func (mr *MothWriter) UpdateUserMetadata(updatedProperties map[string]string)

func (*MothWriter) Write

func (mr *MothWriter) Write(page *spi.Page)

type MothWriterFlushStats

type MothWriterFlushStats struct {
	// contains filtered or unexported fields
}

func NewMothWriterFlushStats

func NewMothWriterFlushStats(name string) *MothWriterFlushStats

func (*MothWriterFlushStats) GetDictionaryBytes

func (ms *MothWriterFlushStats) GetDictionaryBytes() *DistributionStat

@Managed @Nested

func (*MothWriterFlushStats) GetName

func (ms *MothWriterFlushStats) GetName() string

func (*MothWriterFlushStats) GetStripeBytes

func (ms *MothWriterFlushStats) GetStripeBytes() *DistributionStat

@Managed @Nested

func (*MothWriterFlushStats) GetStripeRows

func (ms *MothWriterFlushStats) GetStripeRows() *DistributionStat

@Managed @Nested

func (*MothWriterFlushStats) RecordStripeWritten

func (ms *MothWriterFlushStats) RecordStripeWritten(stripeBytes int64, stripeRows int32, dictionaryBytes int32)

func (*MothWriterFlushStats) String

func (ms *MothWriterFlushStats) String() string

@Override

type MothWriterOptions

type MothWriterOptions struct {
	// contains filtered or unexported fields
}

func NewMothWriterOptions

func NewMothWriterOptions() *MothWriterOptions

func NewMothWriterOptions2

func NewMothWriterOptions2(writerIdentification metadata.WriterIdentification, stripeMinSize util.DataSize, stripeMaxSize util.DataSize, stripeMaxRowCount int32, rowGroupMaxRowCount int32, dictionaryMaxMemory util.DataSize, maxStringStatisticsLimit util.DataSize, maxCompressionBufferSize util.DataSize, bloomFilterColumns util.SetInterface[string], bloomFilterFpp float64) *MothWriterOptions

func (*MothWriterOptions) GetBloomFilterFpp

func (ms *MothWriterOptions) GetBloomFilterFpp() float64

func (*MothWriterOptions) GetDictionaryMaxMemory

func (ms *MothWriterOptions) GetDictionaryMaxMemory() util.DataSize

func (*MothWriterOptions) GetMaxCompressionBufferSize

func (ms *MothWriterOptions) GetMaxCompressionBufferSize() util.DataSize

func (*MothWriterOptions) GetMaxStringStatisticsLimit

func (ms *MothWriterOptions) GetMaxStringStatisticsLimit() util.DataSize

func (*MothWriterOptions) GetRowGroupMaxRowCount

func (ms *MothWriterOptions) GetRowGroupMaxRowCount() int32

func (*MothWriterOptions) GetStripeMaxRowCount

func (ms *MothWriterOptions) GetStripeMaxRowCount() int32

func (*MothWriterOptions) GetStripeMaxSize

func (ms *MothWriterOptions) GetStripeMaxSize() util.DataSize

func (*MothWriterOptions) GetStripeMinSize

func (ms *MothWriterOptions) GetStripeMinSize() util.DataSize

func (*MothWriterOptions) GetWriterIdentification

func (ms *MothWriterOptions) GetWriterIdentification() metadata.WriterIdentification

func (*MothWriterOptions) IsBloomFilterColumn

func (ms *MothWriterOptions) IsBloomFilterColumn(columnName string) bool

func (*MothWriterOptions) String

func (ms *MothWriterOptions) String() string

@Override

func (*MothWriterOptions) WithBloomFilterColumns

func (ms *MothWriterOptions) WithBloomFilterColumns(bloomFilterColumns util.SetInterface[string]) *MothWriterOptions

func (*MothWriterOptions) WithBloomFilterFpp

func (ms *MothWriterOptions) WithBloomFilterFpp(bloomFilterFpp float64) *MothWriterOptions

func (*MothWriterOptions) WithDictionaryMaxMemory

func (ms *MothWriterOptions) WithDictionaryMaxMemory(dictionaryMaxMemory util.DataSize) *MothWriterOptions

func (*MothWriterOptions) WithMaxCompressionBufferSize

func (ms *MothWriterOptions) WithMaxCompressionBufferSize(maxCompressionBufferSize util.DataSize) *MothWriterOptions

func (*MothWriterOptions) WithMaxStringStatisticsLimit

func (ms *MothWriterOptions) WithMaxStringStatisticsLimit(maxStringStatisticsLimit util.DataSize) *MothWriterOptions

func (*MothWriterOptions) WithRowGroupMaxRowCount

func (ms *MothWriterOptions) WithRowGroupMaxRowCount(rowGroupMaxRowCount int32) *MothWriterOptions

func (*MothWriterOptions) WithStripeMaxRowCount

func (ms *MothWriterOptions) WithStripeMaxRowCount(stripeMaxRowCount int32) *MothWriterOptions

func (*MothWriterOptions) WithStripeMaxSize

func (ms *MothWriterOptions) WithStripeMaxSize(stripeMaxSize util.DataSize) *MothWriterOptions

func (*MothWriterOptions) WithStripeMinSize

func (ms *MothWriterOptions) WithStripeMinSize(stripeMinSize util.DataSize) *MothWriterOptions

func (*MothWriterOptions) WithWriterIdentification

func (ms *MothWriterOptions) WithWriterIdentification(writerIdentification metadata.WriterIdentification) *MothWriterOptions

type MothWriterStats

type MothWriterStats struct {
	// contains filtered or unexported fields
}

func NewMothWriterStats

func NewMothWriterStats() *MothWriterStats

func (*MothWriterStats) GetAllFlush

func (ms *MothWriterStats) GetAllFlush() *MothWriterFlushStats

@Managed @Nested

func (*MothWriterStats) GetClosedFlush

func (ms *MothWriterStats) GetClosedFlush() *MothWriterFlushStats

@Managed @Nested

func (*MothWriterStats) GetDictionaryFullFlush

func (ms *MothWriterStats) GetDictionaryFullFlush() *MothWriterFlushStats

@Managed @Nested

func (*MothWriterStats) GetMaxBytesFlush

func (ms *MothWriterStats) GetMaxBytesFlush() *MothWriterFlushStats

@Managed @Nested

func (*MothWriterStats) GetMaxRowsFlush

func (ms *MothWriterStats) GetMaxRowsFlush() *MothWriterFlushStats

@Managed @Nested

func (*MothWriterStats) GetWriterSizeInBytes

func (ms *MothWriterStats) GetWriterSizeInBytes() int64

@Managed

func (*MothWriterStats) RecordStripeWritten

func (ms *MothWriterStats) RecordStripeWritten(flushReason FlushReason, stripeBytes int64, stripeRows int32, dictionaryBytes int32)

func (*MothWriterStats) String

func (ms *MothWriterStats) String() string

@Override

func (*MothWriterStats) UpdateSizeInBytes

func (ms *MothWriterStats) UpdateSizeInBytes(deltaInBytes int64)

type MothZlibDecompressor

type MothZlibDecompressor struct {
	// 继承
	MothDecompressor
	// contains filtered or unexported fields
}

func NewMothZlibDecompressor

func NewMothZlibDecompressor(mothDataSourceId *common.MothDataSourceId, maxBufferSize int32) *MothZlibDecompressor

func (*MothZlibDecompressor) Decompress

func (mr *MothZlibDecompressor) Decompress(input []byte, offset int32, length int32, output OutputBuffer) int32

@Override

func (*MothZlibDecompressor) String

func (mr *MothZlibDecompressor) String() string

@Override

type MothZstdDecompressor

type MothZstdDecompressor struct {
	// 继承
	MothDecompressor
	// contains filtered or unexported fields
}

func NewMothZstdDecompressor

func NewMothZstdDecompressor(mothDataSourceId *common.MothDataSourceId, maxBufferSize int32) *MothZstdDecompressor

func (*MothZstdDecompressor) Decompress

func (mr *MothZstdDecompressor) Decompress(input []byte, offset int32, length int32, output OutputBuffer) int32

@Override

func (*MothZstdDecompressor) String

func (mr *MothZstdDecompressor) String() string

@Override

type NameBasedFieldMapper

type NameBasedFieldMapper struct {
	// 继承
	FieldMapper
	// contains filtered or unexported fields
}

func NewNameBasedFieldMapper

func NewNameBasedFieldMapper(nestedColumns map[string]*MothColumn) *NameBasedFieldMapper

func (*NameBasedFieldMapper) Get

func (nr *NameBasedFieldMapper) Get(fieldName string) *MothColumn

@Override

type NameBasedProjectedLayout

type NameBasedProjectedLayout struct {
	// 继承
	ProjectedLayout
	// contains filtered or unexported fields
}

func NewNameBasedProjectedLayout

func NewNameBasedProjectedLayout(fieldLayouts *optional.Optional[map[string]ProjectedLayout]) *NameBasedProjectedLayout

func (*NameBasedProjectedLayout) GetFieldLayout

func (nt *NameBasedProjectedLayout) GetFieldLayout(mothColumn *MothColumn) ProjectedLayout

@Override

type NoOpTicker

type NoOpTicker struct {
	// 继承
	Ticker
}

func (*NoOpTicker) Read

func (tr *NoOpTicker) Read() int64

type OutputBuffer

type OutputBuffer interface {
	Initialize(size int32) []byte
	Grow(size int32) []byte
}

func NewOutputBuffer

func NewOutputBuffer(cr *CompressedMothChunkLoader) OutputBuffer

type OutputBufferImpl

type OutputBufferImpl struct {
	// 继承
	OutputBuffer
	// contains filtered or unexported fields
}

func (*OutputBufferImpl) Grow

func (ol *OutputBufferImpl) Grow(size int32) []byte

@Override

func (*OutputBufferImpl) Initialize

func (ol *OutputBufferImpl) Initialize(size int32) []byte

@Override

type OutputStreamMothDataSink

type OutputStreamMothDataSink struct {
	// 继承
	MothDataSink
	// 继承
	io.Closer
	// contains filtered or unexported fields
}

func NewOutputStreamMothDataSink

func NewOutputStreamMothDataSink(outputStream mothio.OutputStream) *OutputStreamMothDataSink

func (*OutputStreamMothDataSink) Close

func (ok *OutputStreamMothDataSink) Close()

@Override

func (*OutputStreamMothDataSink) GetRetainedSizeInBytes

func (ok *OutputStreamMothDataSink) GetRetainedSizeInBytes() int64

@Override

func (*OutputStreamMothDataSink) Size

func (ok *OutputStreamMothDataSink) Size() int64

@Override

func (*OutputStreamMothDataSink) Write

func (ok *OutputStreamMothDataSink) Write(outputData *util.ArrayList[MothDataOutput])

@Override

type PresentOutputStream

type PresentOutputStream struct {
	// contains filtered or unexported fields
}

func NewPresentOutputStream

func NewPresentOutputStream(compression metadata.CompressionKind, bufferSize int32) *PresentOutputStream

func (*PresentOutputStream) Close

func (pm *PresentOutputStream) Close()

func (*PresentOutputStream) GetBufferedBytes

func (pm *PresentOutputStream) GetBufferedBytes() int64

func (*PresentOutputStream) GetCheckpoints

func (*PresentOutputStream) GetRetainedBytes

func (pm *PresentOutputStream) GetRetainedBytes() int64

func (*PresentOutputStream) GetStreamDataOutput

func (pm *PresentOutputStream) GetStreamDataOutput(columnId metadata.MothColumnId) *optional.Optional[*StreamDataOutput]

func (*PresentOutputStream) RecordCheckpoint

func (pm *PresentOutputStream) RecordCheckpoint()

func (*PresentOutputStream) Reset

func (pm *PresentOutputStream) Reset()

func (*PresentOutputStream) WriteBoolean

func (pm *PresentOutputStream) WriteBoolean(value bool)

type ProjectedLayout

type ProjectedLayout interface {
	GetFieldLayout(mothColumn *MothColumn) ProjectedLayout
}

func CreateProjectedLayout

func CreateProjectedLayout(root *MothColumn, dereferences *util.ArrayList[*util.ArrayList[string]]) ProjectedLayout

func FullyProjectedLayout

func FullyProjectedLayout() ProjectedLayout

type RegionFinder

type RegionFinder interface {
	GetRangeFor(desiredOffset int64) *DiskRange
}

type RowGroup

type RowGroup struct {
	// contains filtered or unexported fields
}

func NewRowGroup

func NewRowGroup(groupId int32, rowOffset int64, rowCount int64, minAverageRowBytes int64, streamSources *InputStreamSources) *RowGroup

func (*RowGroup) Cmp

func (rp *RowGroup) Cmp(o *RowGroup) int

func (*RowGroup) GetGroupId

func (rp *RowGroup) GetGroupId() int32

func (*RowGroup) GetMinAverageRowBytes

func (rp *RowGroup) GetMinAverageRowBytes() int64

func (*RowGroup) GetRowCount

func (rp *RowGroup) GetRowCount() int64

func (*RowGroup) GetRowOffset

func (rp *RowGroup) GetRowOffset() int64

func (*RowGroup) GetStreamSources

func (rp *RowGroup) GetStreamSources() *InputStreamSources

type SerializationUtils

type SerializationUtils struct {
	// contains filtered or unexported fields
}

func NewSerializationUtils

func NewSerializationUtils() *SerializationUtils

type SliceColumnReader

type SliceColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewSliceColumnReader

func NewSliceColumnReader(kind block.Type, column *MothColumn, memoryContext memory.AggregatedMemoryContext) *SliceColumnReader

func (*SliceColumnReader) Close

func (sr *SliceColumnReader) Close()

@Override

func (*SliceColumnReader) GetRetainedSizeInBytes

func (sr *SliceColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*SliceColumnReader) PrepareNextRead

func (sr *SliceColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*SliceColumnReader) ReadBlock

func (sr *SliceColumnReader) ReadBlock() block.Block

@Override

func (*SliceColumnReader) StartRowGroup

func (sr *SliceColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*SliceColumnReader) StartStripe

func (sr *SliceColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*SliceColumnReader) ToString

func (sr *SliceColumnReader) ToString() string

@Override

type SliceDictionaryColumnReader

type SliceDictionaryColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewSliceDictionaryColumnReader

func NewSliceDictionaryColumnReader(column *MothColumn, memoryContext memory.LocalMemoryContext, maxCodePointCount int32, isCharType bool) *SliceDictionaryColumnReader

func (*SliceDictionaryColumnReader) Close

func (sr *SliceDictionaryColumnReader) Close()

@Override

func (*SliceDictionaryColumnReader) GetRetainedSizeInBytes

func (sr *SliceDictionaryColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*SliceDictionaryColumnReader) PrepareNextRead

func (sr *SliceDictionaryColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*SliceDictionaryColumnReader) ReadBlock

func (sr *SliceDictionaryColumnReader) ReadBlock() block.Block

@Override

func (*SliceDictionaryColumnReader) StartRowGroup

func (sr *SliceDictionaryColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*SliceDictionaryColumnReader) StartStripe

func (sr *SliceDictionaryColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*SliceDictionaryColumnReader) String

func (sr *SliceDictionaryColumnReader) String() string

@Override

type SliceDictionaryColumnWriter

type SliceDictionaryColumnWriter struct {
	// 继承
	ColumnWriter

	// 继承
	DictionaryColumn
	// contains filtered or unexported fields
}

func NewSliceDictionaryColumnWriter

func NewSliceDictionaryColumnWriter(columnId metadata.MothColumnId, kind block.Type, compression metadata.CompressionKind, bufferSize int32, statisticsBuilderSupplier function.Supplier[metadata.SliceColumnStatisticsBuilder]) *SliceDictionaryColumnWriter

func (*SliceDictionaryColumnWriter) BeginRowGroup

func (sr *SliceDictionaryColumnWriter) BeginRowGroup()

@Override

func (*SliceDictionaryColumnWriter) Close

func (sr *SliceDictionaryColumnWriter) Close()

@Override

func (*SliceDictionaryColumnWriter) FinishRowGroup

@Override

func (*SliceDictionaryColumnWriter) GetBloomFilters

@Override

func (*SliceDictionaryColumnWriter) GetBufferedBytes

func (sr *SliceDictionaryColumnWriter) GetBufferedBytes() int64

@Override

func (*SliceDictionaryColumnWriter) GetColumnEncodings

@Override

func (*SliceDictionaryColumnWriter) GetColumnStripeStatistics

func (sr *SliceDictionaryColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*SliceDictionaryColumnWriter) GetDataStreams

@Override

func (*SliceDictionaryColumnWriter) GetDictionaryBytes

func (sr *SliceDictionaryColumnWriter) GetDictionaryBytes() int32

@Override

func (*SliceDictionaryColumnWriter) GetDictionaryEntries

func (sr *SliceDictionaryColumnWriter) GetDictionaryEntries() int32

@Override

func (*SliceDictionaryColumnWriter) GetIndexBytes

func (sr *SliceDictionaryColumnWriter) GetIndexBytes() int32

@Override

func (*SliceDictionaryColumnWriter) GetIndexStreams

@Override

func (*SliceDictionaryColumnWriter) GetNestedColumnWriters

func (mr *SliceDictionaryColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

func (*SliceDictionaryColumnWriter) GetNonNullValueCount

func (sr *SliceDictionaryColumnWriter) GetNonNullValueCount() int64

@Override

func (*SliceDictionaryColumnWriter) GetRawBytes

func (sr *SliceDictionaryColumnWriter) GetRawBytes() int64

@Override

func (*SliceDictionaryColumnWriter) GetRetainedBytes

func (sr *SliceDictionaryColumnWriter) GetRetainedBytes() int64

@Override

func (*SliceDictionaryColumnWriter) GetValueCount

func (sr *SliceDictionaryColumnWriter) GetValueCount() int64

@Override

func (*SliceDictionaryColumnWriter) Reset

func (sr *SliceDictionaryColumnWriter) Reset()

@Override

func (*SliceDictionaryColumnWriter) TryConvertToDirect

func (sr *SliceDictionaryColumnWriter) TryConvertToDirect(maxDirectBytes int32) *optional.OptionalInt

@Override

func (*SliceDictionaryColumnWriter) WriteBlock

func (sr *SliceDictionaryColumnWriter) WriteBlock(block block.Block)

@Override

type SliceDirectColumnReader

type SliceDirectColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewSliceDirectColumnReader

func NewSliceDirectColumnReader(column *MothColumn, maxCodePointCount int32, isCharType bool) *SliceDirectColumnReader

func (*SliceDirectColumnReader) Close

func (sr *SliceDirectColumnReader) Close()

@Override

func (*SliceDirectColumnReader) GetRetainedSizeInBytes

func (sr *SliceDirectColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*SliceDirectColumnReader) PrepareNextRead

func (sr *SliceDirectColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*SliceDirectColumnReader) ReadBlock

func (sr *SliceDirectColumnReader) ReadBlock() block.Block

@Override

func (*SliceDirectColumnReader) StartRowGroup

func (sr *SliceDirectColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*SliceDirectColumnReader) StartStripe

func (sr *SliceDirectColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*SliceDirectColumnReader) ToString

func (sr *SliceDirectColumnReader) ToString() string

@Override

type SliceDirectColumnWriter

type SliceDirectColumnWriter struct {
	// 继承
	ColumnWriter
	// contains filtered or unexported fields
}

func NewSliceDirectColumnWriter

func NewSliceDirectColumnWriter(columnId metadata.MothColumnId, kind block.Type, compression metadata.CompressionKind, bufferSize int32, statisticsBuilderSupplier function.Supplier[metadata.SliceColumnStatisticsBuilder]) *SliceDirectColumnWriter

func (*SliceDirectColumnWriter) BeginRowGroup

func (sr *SliceDirectColumnWriter) BeginRowGroup()

@Override

func (*SliceDirectColumnWriter) Close

func (sr *SliceDirectColumnWriter) Close()

@Override

func (*SliceDirectColumnWriter) FinishRowGroup

@Override

func (*SliceDirectColumnWriter) GetBloomFilters

func (sr *SliceDirectColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*SliceDirectColumnWriter) GetBufferedBytes

func (sr *SliceDirectColumnWriter) GetBufferedBytes() int64

@Override

func (*SliceDirectColumnWriter) GetColumnEncodings

@Override

func (*SliceDirectColumnWriter) GetColumnStripeStatistics

func (sr *SliceDirectColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*SliceDirectColumnWriter) GetDataStreams

func (sr *SliceDirectColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*SliceDirectColumnWriter) GetIndexStreams

func (sr *SliceDirectColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*SliceDirectColumnWriter) GetNestedColumnWriters

func (sr *SliceDirectColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

func (*SliceDirectColumnWriter) GetRetainedBytes

func (sr *SliceDirectColumnWriter) GetRetainedBytes() int64

@Override

func (*SliceDirectColumnWriter) Reset

func (sr *SliceDirectColumnWriter) Reset()

@Override

func (*SliceDirectColumnWriter) WriteBlock

func (sr *SliceDirectColumnWriter) WriteBlock(block block.Block)

@Override

type SnappyCompressor

type SnappyCompressor struct {
	// 继承
	Compressor
}

func (*SnappyCompressor) Compress

func (sr *SnappyCompressor) Compress(input []byte, inputOffset int32, inputLength int32, output []byte, outputOffset int32, maxOutputLength int32) int32

@Override

func (*SnappyCompressor) Decompress2

func (dr *SnappyCompressor) Decompress2(input *bytes.Buffer, output *bytes.Buffer)

@Override

func (*SnappyCompressor) MaxCompressedLength

func (sr *SnappyCompressor) MaxCompressedLength(uncompressedSize int32) int32

@Override

type StreamCheckpoint

type StreamCheckpoint interface {
	String() string
}

func GetDictionaryStreamCheckpoint

func GetDictionaryStreamCheckpoint(streamId StreamId, columnType metadata.MothTypeKind, columnEncoding metadata.ColumnEncodingKind) StreamCheckpoint

type StreamDataOutput

type StreamDataOutput struct {
	// 继承
	MothDataOutput
	// contains filtered or unexported fields
}

func NewStreamDataOutput

func NewStreamDataOutput(s *slice.Slice, stream *metadata.Stream) *StreamDataOutput

func NewStreamDataOutput2

func NewStreamDataOutput2(writer func(slice.SliceOutput) int64, stream *metadata.Stream) *StreamDataOutput

func (*StreamDataOutput) CompareTo

func (st *StreamDataOutput) CompareTo(otherStream *StreamDataOutput) int

@Override

func (*StreamDataOutput) GetStream

func (st *StreamDataOutput) GetStream() *metadata.Stream

func (*StreamDataOutput) Size

func (st *StreamDataOutput) Size() int64

@Override

func (*StreamDataOutput) WriteData

func (st *StreamDataOutput) WriteData(sliceOutput slice.SliceOutput)

@Override

type StreamDataOutputCmp

type StreamDataOutputCmp struct {
}

继承 util.Compare[*StreamDataOutput]

func NewStreamDataOutputCmp

func NewStreamDataOutputCmp() *StreamDataOutputCmp

func (StreamDataOutputCmp) Cmp

type StreamId

type StreamId struct {
	// contains filtered or unexported fields
}

func NewSId

func NewSId(stream *metadata.Stream) StreamId

func NewStreamId

func NewStreamId(columnId metadata.MothColumnId, streamKind metadata.StreamKind) StreamId

func (StreamId) CompareTo

func (sd StreamId) CompareTo(o StreamId) int

func (StreamId) GetColumnId

func (sd StreamId) GetColumnId() metadata.MothColumnId

func (StreamId) GetStreamKind

func (sd StreamId) GetStreamKind() metadata.StreamKind

func (StreamId) String

func (sd StreamId) String() string

type Stripe

type Stripe struct {
	// contains filtered or unexported fields
}

func NewStripe

func NewStripe(rowCount int64, fileTimeZone *time.Location, columnEncodings *metadata.ColumnMetadata[*metadata.ColumnEncoding], rowGroups *util.ArrayList[*RowGroup], dictionaryStreamSources *InputStreamSources) *Stripe

func (*Stripe) GetColumnEncodings

func (se *Stripe) GetColumnEncodings() *metadata.ColumnMetadata[*metadata.ColumnEncoding]

func (*Stripe) GetDictionaryStreamSources

func (se *Stripe) GetDictionaryStreamSources() *InputStreamSources

func (*Stripe) GetFileTimeZone

func (se *Stripe) GetFileTimeZone() *time.Location

func (*Stripe) GetRowCount

func (se *Stripe) GetRowCount() int64

func (*Stripe) GetRowGroups

func (se *Stripe) GetRowGroups() *util.ArrayList[*RowGroup]

func (*Stripe) ToString

func (se *Stripe) ToString() string

@Override

type StripeInfo

type StripeInfo struct {
	// contains filtered or unexported fields
}

func (*StripeInfo) GetStats

func (*StripeInfo) GetStripe

func (so *StripeInfo) GetStripe() *metadata.StripeInformation

type StripeInfoCmp

type StripeInfoCmp struct {
	util.Compare[*StripeInfo]
}

func (*StripeInfoCmp) Cmp

func (sp *StripeInfoCmp) Cmp(i, j *StripeInfo) int

type StripeReader

type StripeReader struct {
	// contains filtered or unexported fields
}

func NewStripeReader

func NewStripeReader(mothDataSource MothDataSource, legacyFileTimeZone *time.Location, decompressor *optional.Optional[MothDecompressor], types *metadata.ColumnMetadata[*metadata.MothType], readColumns util.SetInterface[*MothColumn], rowsInRowGroup *optional.OptionalInt, predicate MothPredicate, hiveWriterVersion metadata.HiveWriterVersion, metadataReader metadata.MetadataReader) *StripeReader

func (*StripeReader) ReadStripe

func (sr *StripeReader) ReadStripe(stripe *metadata.StripeInformation, memoryUsage memory.AggregatedMemoryContext) *Stripe

type StructColumnReader

type StructColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewStructColumnReader

func NewStructColumnReader(kind block.Type, column *MothColumn, readLayout ProjectedLayout, memoryContext memory.AggregatedMemoryContext, blockFactory *MothBlockFactory, fieldMapperFactory FieldMapperFactory) *StructColumnReader

func (*StructColumnReader) Close

func (sr *StructColumnReader) Close()

@Override

func (*StructColumnReader) GetRetainedSizeInBytes

func (sr *StructColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*StructColumnReader) PrepareNextRead

func (sr *StructColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*StructColumnReader) ReadBlock

func (sr *StructColumnReader) ReadBlock() block.Block

@Override

func (*StructColumnReader) StartRowGroup

func (sr *StructColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*StructColumnReader) StartStripe

func (sr *StructColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*StructColumnReader) ToString

func (sr *StructColumnReader) ToString() string

@Override

type StructColumnWriter

type StructColumnWriter struct {
	//继承
	ColumnWriter
	// contains filtered or unexported fields
}

func NewStructColumnWriter

func NewStructColumnWriter(columnId metadata.MothColumnId, compression metadata.CompressionKind, bufferSize int32, structFields *util.ArrayList[ColumnWriter]) *StructColumnWriter

func (*StructColumnWriter) BeginRowGroup

func (sr *StructColumnWriter) BeginRowGroup()

@Override

func (*StructColumnWriter) Close

func (sr *StructColumnWriter) Close()

@Override

func (*StructColumnWriter) FinishRowGroup

@Override

func (*StructColumnWriter) GetBloomFilters

func (sr *StructColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*StructColumnWriter) GetBufferedBytes

func (sr *StructColumnWriter) GetBufferedBytes() int64

@Override

func (*StructColumnWriter) GetColumnEncodings

func (sr *StructColumnWriter) GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding

@Override

func (*StructColumnWriter) GetColumnStripeStatistics

func (sr *StructColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*StructColumnWriter) GetDataStreams

func (sr *StructColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*StructColumnWriter) GetIndexStreams

func (sr *StructColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*StructColumnWriter) GetNestedColumnWriters

func (sr *StructColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

@Override

func (*StructColumnWriter) GetRetainedBytes

func (sr *StructColumnWriter) GetRetainedBytes() int64

@Override

func (*StructColumnWriter) Reset

func (sr *StructColumnWriter) Reset()

@Override

func (*StructColumnWriter) WriteBlock

func (sr *StructColumnWriter) WriteBlock(b block.Block)

@Override

type SystemTicker

type SystemTicker struct {
	// 继承
	Ticker
}

func (*SystemTicker) Read

func (tr *SystemTicker) Read() int64

type TDigest

type TDigest struct {
	// contains filtered or unexported fields
}

func CopyOf

func CopyOf(other *TDigest) *TDigest

func Deserialize

func Deserialize(serialized *slice.Slice) *TDigest

func NewTDigest

func NewTDigest() *TDigest

func NewTDigest2

func NewTDigest2(compression float64) *TDigest

func NewTDigest3

func NewTDigest3(compression float64, min float64, max float64, totalWeight float64, centroidCount int32, means []float64, weights []float64, needsMerge bool, backwards bool) *TDigest

func (*TDigest) Add

func (tt *TDigest) Add(value float64)

func (*TDigest) Add2

func (tt *TDigest) Add2(value float64, weight float64)

func (*TDigest) EstimatedInMemorySizeInBytes

func (tt *TDigest) EstimatedInMemorySizeInBytes() int32

func (*TDigest) GetCount

func (tt *TDigest) GetCount() float64

func (*TDigest) GetMax

func (tt *TDigest) GetMax() float64

func (*TDigest) GetMin

func (tt *TDigest) GetMin() float64

func (*TDigest) MergeWith

func (tt *TDigest) MergeWith(other *TDigest)

func (*TDigest) Serialize

func (tt *TDigest) Serialize() *slice.Slice

func (*TDigest) SerializedSizeInBytes

func (tt *TDigest) SerializedSizeInBytes() int32

func (*TDigest) ValueAt

func (tt *TDigest) ValueAt(quantile float64) float64

func (*TDigest) ValuesAt

func (tt *TDigest) ValuesAt(quantiles *util.ArrayList[float64]) util.List[float64]

type Ticker

type Ticker interface {
	Read() int64
}
var NO_TICKER Ticker = new(NoOpTicker)
var SYSTEM_TICKER Ticker = new(SystemTicker)

func GetNoicker

func GetNoicker() Ticker

func GetSystemTicker

func GetSystemTicker() Ticker

type TimeColumnReader

type TimeColumnReader struct {
	//继承
	LongColumnReader
}

func NewTimeColumnReader

func NewTimeColumnReader(kind block.Type, column *MothColumn, memoryContext memory.LocalMemoryContext) *TimeColumnReader

func (*TimeColumnReader) Close

func (tr *TimeColumnReader) Close()

@Override

func (*TimeColumnReader) GetRetainedSizeInBytes

func (tr *TimeColumnReader) GetRetainedSizeInBytes() int64

func (*TimeColumnReader) PrepareNextRead

func (tr *TimeColumnReader) PrepareNextRead(batchSize int32)

func (*TimeColumnReader) ReadBlock

func (tr *TimeColumnReader) ReadBlock() block.Block

继承ColumnReader

func (*TimeColumnReader) StartRowGroup

func (tr *TimeColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

func (*TimeColumnReader) StartStripe

func (tr *TimeColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

type TimeColumnWriter

type TimeColumnWriter struct {
	// 继承
	LongColumnWriter
}

func NewTimeColumnWriter

func NewTimeColumnWriter(columnId metadata.MothColumnId, kind block.Type, compression metadata.CompressionKind, bufferSize int32, statisticsBuilderSupplier function.Supplier[metadata.LongValueStatisticsBuilder]) *TimeColumnWriter

type TimestampColumnReader

type TimestampColumnReader struct {
	// 继承
	ColumnReader
	// contains filtered or unexported fields
}

func NewTimestampColumnReader

func NewTimestampColumnReader(kind block.Type, column *MothColumn, memoryContext memory.LocalMemoryContext) *TimestampColumnReader

func (*TimestampColumnReader) Close

func (tr *TimestampColumnReader) Close()

@Override

func (*TimestampColumnReader) GetRetainedSizeInBytes

func (tr *TimestampColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*TimestampColumnReader) PrepareNextRead

func (tr *TimestampColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*TimestampColumnReader) ReadBlock

func (tr *TimestampColumnReader) ReadBlock() block.Block

@Override

func (*TimestampColumnReader) StartRowGroup

func (tr *TimestampColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*TimestampColumnReader) StartStripe

func (tr *TimestampColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*TimestampColumnReader) ToString

func (tr *TimestampColumnReader) ToString() string

@Override

type TimestampColumnWriter

type TimestampColumnWriter struct {
	//继承
	ColumnWriter
	// contains filtered or unexported fields
}

The MOTH encoding erroneously uses normal integer division to compute seconds, rather than floor modulus, which produces the wrong result for negative values (those that are before the epoch). Readers must correct for this. It also makes it impossible to represent values less than one second before the epoch, which must also be handled in MothWriteValidation.

The sub-second value (nanoseconds) typically has a large number of trailing zeroes, as many systems only record millisecond or microsecond precision. To optimize storage, if the value has at least two trailing zeros, the trailing decimal zero digits are removed, and the last three bits record how many zeros were removed, minus one:

# Trailing 0s   Last 3 Bits   Example nanos       Example encoding
      0            0b000        123456789     (123456789 << 3) | 0b000
      1            0b000        123456780     (123456780 << 3) | 0b000
      2            0b001        123456700       (1234567 << 3) | 0b001
      3            0b010        123456000        (123456 << 3) | 0b010
      4            0b011        123450000         (12345 << 3) | 0b011
      5            0b100        123400000          (1234 << 3) | 0b100
      6            0b101        123000000           (123 << 3) | 0b101
      7            0b110        120000000            (12 << 3) | 0b110
      8            0b111        100000000             (1 << 3) | 0b111

func NewTimestampColumnWriter

func NewTimestampColumnWriter(columnId metadata.MothColumnId, kind block.Type, compression metadata.CompressionKind, bufferSize int32, statisticsBuilderSupplier function.Supplier[*metadata.TimestampStatisticsBuilder]) *TimestampColumnWriter

func (*TimestampColumnWriter) BeginRowGroup

func (tr *TimestampColumnWriter) BeginRowGroup()

@Override

func (*TimestampColumnWriter) Close

func (tr *TimestampColumnWriter) Close()

@Override

func (*TimestampColumnWriter) FinishRowGroup

@Override

func (*TimestampColumnWriter) GetBloomFilters

func (tr *TimestampColumnWriter) GetBloomFilters(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*TimestampColumnWriter) GetBufferedBytes

func (tr *TimestampColumnWriter) GetBufferedBytes() int64

@Override

func (*TimestampColumnWriter) GetColumnEncodings

func (tr *TimestampColumnWriter) GetColumnEncodings() map[metadata.MothColumnId]*metadata.ColumnEncoding

@Override

func (*TimestampColumnWriter) GetColumnStripeStatistics

func (tr *TimestampColumnWriter) GetColumnStripeStatistics() map[metadata.MothColumnId]*metadata.ColumnStatistics

@Override

func (*TimestampColumnWriter) GetDataStreams

func (tr *TimestampColumnWriter) GetDataStreams() *util.ArrayList[*StreamDataOutput]

@Override

func (*TimestampColumnWriter) GetIndexStreams

func (tr *TimestampColumnWriter) GetIndexStreams(metadataWriter *CompressedMetadataWriter) *util.ArrayList[*StreamDataOutput]

@Override

func (*TimestampColumnWriter) GetNestedColumnWriters

func (tr *TimestampColumnWriter) GetNestedColumnWriters() *util.ArrayList[ColumnWriter]

@Override

func (*TimestampColumnWriter) GetRetainedBytes

func (tr *TimestampColumnWriter) GetRetainedBytes() int64

@Override

func (*TimestampColumnWriter) Reset

func (tr *TimestampColumnWriter) Reset()

@Override

func (*TimestampColumnWriter) WriteBlock

func (tr *TimestampColumnWriter) WriteBlock(block block.Block)

@Override

type TimestampKind

type TimestampKind int8
const (
	TIMESTAMP_MILLIS TimestampKind = iota
	TIMESTAMP_MICROS
	TIMESTAMP_NANOS
	INSTANT_MILLIS
	INSTANT_MICROS
	INSTANT_NANOS
	UNKONW
)

type UncompressedMothChunkLoader

type UncompressedMothChunkLoader struct {
	// contains filtered or unexported fields
}

func NewUncompressedMothChunkLoader

func NewUncompressedMothChunkLoader(dataReader MothDataReader, memoryContext memory.AggregatedMemoryContext) *UncompressedMothChunkLoader

func (*UncompressedMothChunkLoader) GetLastCheckpoint

func (ur *UncompressedMothChunkLoader) GetLastCheckpoint() int64

@Override

func (*UncompressedMothChunkLoader) GetMothDataSourceId

func (ur *UncompressedMothChunkLoader) GetMothDataSourceId() *common.MothDataSourceId

@Override

func (*UncompressedMothChunkLoader) HasNextChunk

func (ur *UncompressedMothChunkLoader) HasNextChunk() bool

@Override

func (*UncompressedMothChunkLoader) NextChunk

func (ur *UncompressedMothChunkLoader) NextChunk() *slice.Slice

@Override

func (*UncompressedMothChunkLoader) SeekToCheckpoint

func (ur *UncompressedMothChunkLoader) SeekToCheckpoint(checkpoint int64)

@Override

func (*UncompressedMothChunkLoader) String

func (ur *UncompressedMothChunkLoader) String() string

@Override

type UnionColumnReader

type UnionColumnReader struct {
	// contains filtered or unexported fields
}

func NewUnionColumnReader

func NewUnionColumnReader(kind block.Type, column *MothColumn, memoryContext memory.AggregatedMemoryContext, blockFactory *MothBlockFactory, fieldMapperFactory FieldMapperFactory) *UnionColumnReader

func (*UnionColumnReader) Close

func (ur *UnionColumnReader) Close()

@Override

func (*UnionColumnReader) GetRetainedSizeInBytes

func (ur *UnionColumnReader) GetRetainedSizeInBytes() int64

@Override

func (*UnionColumnReader) PrepareNextRead

func (ur *UnionColumnReader) PrepareNextRead(batchSize int32)

@Override

func (*UnionColumnReader) ReadBlock

func (ur *UnionColumnReader) ReadBlock() block.Block

@Override

func (*UnionColumnReader) StartRowGroup

func (ur *UnionColumnReader) StartRowGroup(dataStreamSources *InputStreamSources)

@Override

func (*UnionColumnReader) StartStripe

func (ur *UnionColumnReader) StartStripe(fileTimeZone *time.Location, dictionaryStreamSources *InputStreamSources, encoding *metadata.ColumnMetadata[*metadata.ColumnEncoding])

@Override

func (*UnionColumnReader) ToString

func (ur *UnionColumnReader) ToString() string

@Override

type UnpackLazyBlockLoader

type UnpackLazyBlockLoader struct {
	// contains filtered or unexported fields
}

func NewUnpackLazyBlockLoader

func NewUnpackLazyBlockLoader(denseBlock block.Block, kind block.Type, valueIsNonNull []bool) *UnpackLazyBlockLoader

func (*UnpackLazyBlockLoader) Load

func (ur *UnpackLazyBlockLoader) Load() block.Block

@Override

type ValueInputStream

type ValueInputStream[T StreamCheckpoint] interface {
	// 继承
	IValueInputStream

	Skip(items int64)

	String() string
}

public interface ValueInputStream<C extends StreamCheckpoint> checkpoint.StreamCheckpoint

type ValueInputStreamSource

type ValueInputStreamSource[S IValueInputStream] struct {
	// 继承
	InputStreamSource
	// contains filtered or unexported fields
}

func NewValueInputStreamSource

func NewValueInputStreamSource[S IValueInputStream](stream S) *ValueInputStreamSource[S]

func (*ValueInputStreamSource[S]) OpenStream

func (ve *ValueInputStreamSource[S]) OpenStream() S

@Nullable @Override

type ValueOutputStream

type ValueOutputStream[T StreamCheckpoint] interface {
	RecordCheckpoint()
	Close()
	GetCheckpoints() *util.ArrayList[T]
	GetStreamDataOutput(columnId metadata.MothColumnId) *StreamDataOutput

	/**
	 * This method returns the size of the flushed data plus any unflushed data.
	 * If the output is compressed, flush data size is the size after compression.
	 */
	GetBufferedBytes() int64
	GetRetainedBytes() int64
	Reset()
}

public interface ValueOutputStream<C extends StreamCheckpoint>

Source Files

Directories

Path Synopsis

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL