package memory
Import Path
github.com/apache/arrow-go/v18/arrow/memory (on go.dev )
Dependency Relation
imports 10 packages , and imported by 22 packages
Code Examples
_memoryPerf
package main
import (
"fmt"
"github.com/apache/arrow-go/v18/arrow/array"
"github.com/apache/arrow-go/v18/arrow/memory"
)
func main() {
// Create a memory allocator
pool := memory.NewGoAllocator()
// Create a large Arrow array
fmt.Println("Creating a large Arrow Int64 array...")
const N = 10_000_000
builder := array.NewInt64Builder(pool)
defer builder.Release()
for i := 0; i < N; i++ {
builder.Append(int64(i))
}
arr := builder.NewInt64Array()
defer arr.Release()
fmt.Printf("Built array of %d elements\n", N)
// Batch processing
fmt.Println("\nBatch processing large data in chunks...")
batchSize := 1_000_000
for batch := 0; batch < N; batch += batchSize {
end := batch + batchSize
if end > N {
end = N
}
b := array.NewInt64Builder(pool)
for i := batch; i < end; i++ {
b.Append(int64(i))
}
chunk := b.NewInt64Array()
// Simulate processing
_ = chunk.Value(0)
chunk.Release()
b.Release()
}
fmt.Printf("Processed %d elements in batches of %d\n", N, batchSize)
}
Package-Level Type Names (total 6)
/* sort by: alphabet | popularity */
type Allocator (interface)
Methods (total 3 )
( Allocator) Allocate (size int ) []byte
( Allocator) Free (b []byte )
( Allocator) Reallocate (size int , b []byte ) []byte
Implemented By (at least 2 )
*CheckedAllocator
*GoAllocator
As Outputs Of (at least 4 )
func github.com/apache/arrow-go/v18/arrow/compute/exec.GetAllocator (ctx context .Context ) Allocator
func github.com/apache/arrow-go/v18/arrow/compute/internal/kernels.HashState .Allocator () Allocator
func github.com/apache/arrow-go/v18/parquet.(*ReaderProperties ).Allocator () Allocator
func github.com/apache/arrow-go/v18/parquet.(*WriterProperties ).Allocator () Allocator
As Inputs Of (at least 159 )
func NewBufferWithAllocator (data []byte , mem Allocator ) *Buffer
func NewCheckedAllocator (mem Allocator ) *CheckedAllocator
func NewResizableBuffer (mem Allocator ) *Buffer
func github.com/apache/arrow-go/v18/arrow/array.ChunkedFromJSON (mem Allocator , dt arrow .DataType , chunkStrs []string , opts ...array .FromJSONOption ) (*arrow .Chunked , error )
func github.com/apache/arrow-go/v18/arrow/array.Concatenate (arrs []arrow .Array , mem Allocator ) (result arrow .Array , err error )
func github.com/apache/arrow-go/v18/arrow/array.DictArrayFromJSON (mem Allocator , dt *arrow .DictionaryType , indicesJSON, dictJSON string ) (arrow .Array , error )
func github.com/apache/arrow-go/v18/arrow/array.FromJSON (mem Allocator , dt arrow .DataType , r io .Reader , opts ...array .FromJSONOption ) (arr arrow .Array , offset int64 , err error )
func github.com/apache/arrow-go/v18/arrow/array.GetDictArrayData (mem Allocator , valueType arrow .DataType , memoTable hashing .MemoTable , startOffset int ) (*array .Data , error )
func github.com/apache/arrow-go/v18/arrow/array.MakeArrayOfNull (mem Allocator , dt arrow .DataType , length int ) arrow .Array
func github.com/apache/arrow-go/v18/arrow/array.NewBinaryBuilder (mem Allocator , dtype arrow .BinaryDataType ) *array .BinaryBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewBinaryDictionaryUnifier (alloc Allocator ) array .DictionaryUnifier
func github.com/apache/arrow-go/v18/arrow/array.NewBinaryViewBuilder (mem Allocator ) *array .BinaryViewBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewBooleanBuilder (mem Allocator ) *array .BooleanBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewBuilder (mem Allocator , dtype arrow .DataType ) array .Builder
func github.com/apache/arrow-go/v18/arrow/array.NewDate32Builder (mem Allocator ) *array .Date32Builder
func github.com/apache/arrow-go/v18/arrow/array.NewDate64Builder (mem Allocator ) *array .Date64Builder
func github.com/apache/arrow-go/v18/arrow/array.NewDayTimeIntervalBuilder (mem Allocator ) *array .DayTimeIntervalBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewDecimal128Builder (mem Allocator , dtype *arrow .Decimal128Type ) *array .Decimal128Builder
func github.com/apache/arrow-go/v18/arrow/array.NewDecimal256Builder (mem Allocator , dtype *arrow .Decimal256Type ) *array .Decimal256Builder
func github.com/apache/arrow-go/v18/arrow/array.NewDecimal32Builder (mem Allocator , dtype *arrow .Decimal32Type ) *array .Decimal32Builder
func github.com/apache/arrow-go/v18/arrow/array.NewDecimal64Builder (mem Allocator , dtype *arrow .Decimal64Type ) *array .Decimal64Builder
func github.com/apache/arrow-go/v18/arrow/array.NewDenseUnionBuilder (mem Allocator , typ *arrow .DenseUnionType ) *array .DenseUnionBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewDenseUnionBuilderWithBuilders (mem Allocator , typ *arrow .DenseUnionType , children []array .Builder ) *array .DenseUnionBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewDictionaryBuilder (mem Allocator , dt *arrow .DictionaryType ) array .DictionaryBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewDictionaryBuilderWithDict (mem Allocator , dt *arrow .DictionaryType , init arrow .Array ) array .DictionaryBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewDictionaryUnifier (alloc Allocator , valueType arrow .DataType ) (array .DictionaryUnifier , error )
func github.com/apache/arrow-go/v18/arrow/array.NewDurationBuilder (mem Allocator , dtype *arrow .DurationType ) *array .DurationBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewEmptyDenseUnionBuilder (mem Allocator ) *array .DenseUnionBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewEmptySparseUnionBuilder (mem Allocator ) *array .SparseUnionBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewExtensionBuilder (mem Allocator , dt arrow .ExtensionType ) *array .ExtensionBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewFixedSizeBinaryBuilder (mem Allocator , dtype *arrow .FixedSizeBinaryType ) *array .FixedSizeBinaryBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewFixedSizeListBuilder (mem Allocator , n int32 , etype arrow .DataType ) *array .FixedSizeListBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewFixedSizeListBuilderWithField (mem Allocator , n int32 , field arrow .Field ) *array .FixedSizeListBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewFloat16Builder (mem Allocator ) *array .Float16Builder
func github.com/apache/arrow-go/v18/arrow/array.NewFloat32Builder (mem Allocator ) *array .Float32Builder
func github.com/apache/arrow-go/v18/arrow/array.NewFloat64Builder (mem Allocator ) *array .Float64Builder
func github.com/apache/arrow-go/v18/arrow/array.NewInt16Builder (mem Allocator ) *array .Int16Builder
func github.com/apache/arrow-go/v18/arrow/array.NewInt32Builder (mem Allocator ) *array .Int32Builder
func github.com/apache/arrow-go/v18/arrow/array.NewInt64Builder (mem Allocator ) *array .Int64Builder
func github.com/apache/arrow-go/v18/arrow/array.NewInt8Builder (mem Allocator ) *array .Int8Builder
func github.com/apache/arrow-go/v18/arrow/array.NewLargeListBuilder (mem Allocator , etype arrow .DataType ) *array .LargeListBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewLargeListBuilderWithField (mem Allocator , field arrow .Field ) *array .LargeListBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewLargeListViewBuilder (mem Allocator , etype arrow .DataType ) *array .LargeListViewBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewLargeListViewBuilderWithField (mem Allocator , field arrow .Field ) *array .LargeListViewBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewLargeStringBuilder (mem Allocator ) *array .LargeStringBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewListBuilder (mem Allocator , etype arrow .DataType ) *array .ListBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewListBuilderWithField (mem Allocator , field arrow .Field ) *array .ListBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewListViewBuilder (mem Allocator , etype arrow .DataType ) *array .ListViewBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewListViewBuilderWithField (mem Allocator , field arrow .Field ) *array .ListViewBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewMapBuilder (mem Allocator , keytype, itemtype arrow .DataType , keysSorted bool ) *array .MapBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewMapBuilderWithType (mem Allocator , dt *arrow .MapType ) *array .MapBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewMonthDayNanoIntervalBuilder (mem Allocator ) *array .MonthDayNanoIntervalBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewMonthIntervalBuilder (mem Allocator ) *array .MonthIntervalBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewNullBuilder (mem Allocator ) *array .NullBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewRecordBuilder (mem Allocator , schema *arrow .Schema ) *array .RecordBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewRunEndEncodedBuilder (mem Allocator , runEnds, encoded arrow .DataType ) *array .RunEndEncodedBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewSparseUnionBuilder (mem Allocator , typ *arrow .SparseUnionType ) *array .SparseUnionBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewSparseUnionBuilderWithBuilders (mem Allocator , typ *arrow .SparseUnionType , children []array .Builder ) *array .SparseUnionBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewStringBuilder (mem Allocator ) *array .StringBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewStringViewBuilder (mem Allocator ) *array .StringViewBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewStructBuilder (mem Allocator , dtype *arrow .StructType ) *array .StructBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewTime32Builder (mem Allocator , dtype *arrow .Time32Type ) *array .Time32Builder
func github.com/apache/arrow-go/v18/arrow/array.NewTime64Builder (mem Allocator , dtype *arrow .Time64Type ) *array .Time64Builder
func github.com/apache/arrow-go/v18/arrow/array.NewTimestampBuilder (mem Allocator , dtype *arrow .TimestampType ) *array .TimestampBuilder
func github.com/apache/arrow-go/v18/arrow/array.NewUint16Builder (mem Allocator ) *array .Uint16Builder
func github.com/apache/arrow-go/v18/arrow/array.NewUint32Builder (mem Allocator ) *array .Uint32Builder
func github.com/apache/arrow-go/v18/arrow/array.NewUint64Builder (mem Allocator ) *array .Uint64Builder
func github.com/apache/arrow-go/v18/arrow/array.NewUint8Builder (mem Allocator ) *array .Uint8Builder
func github.com/apache/arrow-go/v18/arrow/array.RecordFromJSON (mem Allocator , schema *arrow .Schema , r io .Reader , opts ...array .FromJSONOption ) (arrow .RecordBatch , int64 , error )
func github.com/apache/arrow-go/v18/arrow/array.TableFromJSON (mem Allocator , sc *arrow .Schema , recJSON []string , opt ...array .FromJSONOption ) (arrow .Table , error )
func github.com/apache/arrow-go/v18/arrow/array.TransposeDictIndices (mem Allocator , data arrow .ArrayData , inType, outType arrow .DataType , dict arrow .ArrayData , transposeMap []int32 ) (arrow .ArrayData , error )
func github.com/apache/arrow-go/v18/arrow/array.UnifyChunkedDicts (alloc Allocator , chnkd *arrow .Chunked ) (*arrow .Chunked , error )
func github.com/apache/arrow-go/v18/arrow/array.UnifyTableDicts (alloc Allocator , table arrow .Table ) (arrow .Table , error )
func github.com/apache/arrow-go/v18/arrow/array.WithAllocator (mem Allocator ) array .Option
func github.com/apache/arrow-go/v18/arrow/array.CustomExtensionBuilder .NewBuilder (Allocator ) array .Builder
func github.com/apache/arrow-go/v18/arrow/array.(*RunEndEncoded ).LogicalRunEndsArray (mem Allocator ) arrow .Array
func github.com/apache/arrow-go/v18/arrow/array.(*SparseUnion ).GetFlattenedField (mem Allocator , index int ) (arrow .Array , error )
func github.com/apache/arrow-go/v18/arrow/bitutil.BitmapAndAlloc (mem Allocator , left, right []byte , lOffset, rOffset int64 , length, outOffset int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/bitutil.BitmapAndNotAlloc (mem Allocator , left, right []byte , lOffset, rOffset int64 , length, outOffset int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/bitutil.BitmapOpAlloc (mem Allocator , op bitutil .bitOp , left, right []byte , lOffset, rOffset int64 , length int64 , outOffset int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/bitutil.BitmapOrAlloc (mem Allocator , left, right []byte , lOffset, rOffset int64 , length, outOffset int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/bitutil.BitmapXorAlloc (mem Allocator , left, right []byte , lOffset, rOffset int64 , length, outOffset int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/compute.DeserializeExpr (mem Allocator , buf *Buffer ) (compute .Expression , error )
func github.com/apache/arrow-go/v18/arrow/compute.SerializeExpr (expr compute .Expression , mem Allocator ) (*Buffer , error )
func github.com/apache/arrow-go/v18/arrow/compute.SerializeOptions (opts compute .FunctionOptions , mem Allocator ) (*Buffer , error )
func github.com/apache/arrow-go/v18/arrow/compute/exec.ArrayFromSlice [T](mem Allocator , data []T) arrow .Array
func github.com/apache/arrow-go/v18/arrow/compute/exec.ArrayFromSliceWithValid [T](mem Allocator , data []T, valid []bool ) arrow .Array
func github.com/apache/arrow-go/v18/arrow/compute/exec.WithAllocator (ctx context .Context , mem Allocator ) context .Context
func github.com/apache/arrow-go/v18/arrow/compute/internal/kernels.CreateSetLookupState (opts kernels .SetLookupOptions , alloc Allocator ) (exec .KernelState , error )
func github.com/apache/arrow-go/v18/arrow/compute/internal/kernels.GetTakeIndices (mem Allocator , filter *exec .ArraySpan , nullSelect kernels .NullSelectionBehavior ) (arrow .ArrayData , error )
func github.com/apache/arrow-go/v18/arrow/extensions.NewBool8Builder (mem Allocator ) *extensions .Bool8Builder
func github.com/apache/arrow-go/v18/arrow/extensions.NewUUIDBuilder (mem Allocator ) *extensions .UUIDBuilder
func github.com/apache/arrow-go/v18/arrow/extensions.NewVariantBuilder (mem Allocator , dt *extensions .VariantType ) *extensions .VariantBuilder
func github.com/apache/arrow-go/v18/arrow/extensions.(*Bool8Type ).NewBuilder (mem Allocator ) array .Builder
func github.com/apache/arrow-go/v18/arrow/extensions.(*UUIDType ).NewBuilder (mem Allocator ) array .Builder
func github.com/apache/arrow-go/v18/arrow/extensions.(*VariantType ).NewBuilder (mem Allocator ) array .Builder
func github.com/apache/arrow-go/v18/arrow/internal/dictutils.ResolveDictionaries (memo *dictutils .Memo , cols []arrow .ArrayData , parentPos dictutils .FieldPos , mem Allocator ) error
func github.com/apache/arrow-go/v18/arrow/internal/dictutils.ResolveFieldDict (memo *dictutils .Memo , data arrow .ArrayData , pos dictutils .FieldPos , mem Allocator ) error
func github.com/apache/arrow-go/v18/arrow/internal/dictutils.(*Memo ).Dict (id int64 , mem Allocator ) (arrow .ArrayData , error )
func github.com/apache/arrow-go/v18/arrow/ipc.GetSchemaPayload (schema *arrow .Schema , mem Allocator ) ipc .Payload
func github.com/apache/arrow-go/v18/arrow/ipc.WithAllocator (mem Allocator ) ipc .Option
func github.com/apache/arrow-go/v18/arrow/scalar.MakeArrayFromScalar (sc scalar .Scalar , length int , mem Allocator ) (arrow .Array , error )
func github.com/apache/arrow-go/v18/arrow/scalar.MakeArrayOfNull (dt arrow .DataType , length int , mem Allocator ) arrow .Array
func github.com/apache/arrow-go/v18/arrow/scalar.ToScalar (val interface{}, mem Allocator ) (scalar .Scalar , error )
func github.com/apache/arrow-go/v18/arrow/util.ProtobufMessageFieldReflection .AppendValueOrNull (b array .Builder , mem Allocator ) error
func github.com/apache/arrow-go/v18/arrow/util.ProtobufMessageReflection .Record (mem Allocator ) arrow .RecordBatch
func github.com/apache/arrow-go/v18/parquet.NewReaderProperties (alloc Allocator ) *parquet .ReaderProperties
func github.com/apache/arrow-go/v18/parquet.WithAllocator (mem Allocator ) parquet .WriterProperty
func github.com/polarsignals/frostdb.NewGenericTable [T](db *frostdb .DB , name string , mem Allocator , options ...frostdb .TableOption ) (*frostdb .GenericTable [T], error )
func github.com/polarsignals/frostdb.(*Table ).Iterator (ctx context .Context , tx uint64 , pool Allocator , callbacks []logicalplan .Callback , options ...logicalplan .Option ) error
func github.com/polarsignals/frostdb.(*Table ).SchemaIterator (ctx context .Context , tx uint64 , pool Allocator , callbacks []logicalplan .Callback , options ...logicalplan .Option ) error
func github.com/polarsignals/frostdb/internal/records.NewBuild [T](mem Allocator ) *records .Build [T]
func github.com/polarsignals/frostdb/pqarrow.NewParquetConverter (pool Allocator , iterOpts logicalplan .IterOptions ) *pqarrow .ParquetConverter
func github.com/polarsignals/frostdb/pqarrow/arrowutils.MakeNullArray (mem Allocator , dt arrow .DataType , length int ) arrow .Array
func github.com/polarsignals/frostdb/pqarrow/arrowutils.MergeRecords (mem Allocator , records []arrow .Record , orderByCols []arrowutils .SortingColumn , limit uint64 ) (arrow .Record , error )
func github.com/polarsignals/frostdb/pqarrow/arrowutils.(*ArrayConcatenator ).NewArray (mem Allocator ) (arrow .Array , error )
func github.com/polarsignals/frostdb/pqarrow/builder.NewBuilder (mem Allocator , t arrow .DataType ) builder .ColumnBuilder
func github.com/polarsignals/frostdb/pqarrow/builder.NewListBuilder (mem Allocator , etype arrow .DataType ) *builder .ListBuilder
func github.com/polarsignals/frostdb/pqarrow/builder.NewRecordBuilder (mem Allocator , schema *arrow .Schema ) *builder .RecordBuilder
func github.com/polarsignals/frostdb/query/logicalplan.TableReader .Iterator (ctx context .Context , tx uint64 , pool Allocator , callbacks []logicalplan .Callback , options ...logicalplan .Option ) error
func github.com/polarsignals/frostdb/query/logicalplan.TableReader .SchemaIterator (ctx context .Context , tx uint64 , pool Allocator , callbacks []logicalplan .Callback , options ...logicalplan .Option ) error
func github.com/polarsignals/frostdb/query/physicalplan.AddFloat64s (mem Allocator , left, right *array .Float64 ) *array .Float64
func github.com/polarsignals/frostdb/query/physicalplan.AddInt32s (mem Allocator , left, right *array .Int32 ) *array .Int32
func github.com/polarsignals/frostdb/query/physicalplan.AddInt64s (mem Allocator , left, right *array .Int64 ) *array .Int64
func github.com/polarsignals/frostdb/query/physicalplan.AddUint64s (mem Allocator , left, right *array .Uint64 ) *array .Uint64
func github.com/polarsignals/frostdb/query/physicalplan.Aggregate (pool Allocator , tracer trace .Tracer , agg *logicalplan .Aggregation , final bool , ordered bool , seed maphash .Seed ) (physicalplan .PhysicalPlan , error )
func github.com/polarsignals/frostdb/query/physicalplan.AndArrays (pool Allocator , arrs []arrow .Array ) arrow .Array
func github.com/polarsignals/frostdb/query/physicalplan.Build (ctx context .Context , pool Allocator , tracer trace .Tracer , s *dynparquet .Schema , plan *logicalplan .LogicalPlan , options ...physicalplan .Option ) (*physicalplan .OutputPlan , error )
func github.com/polarsignals/frostdb/query/physicalplan.Distinct (pool Allocator , tracer trace .Tracer , columns []logicalplan .Expr ) *physicalplan .Distinction
func github.com/polarsignals/frostdb/query/physicalplan.DivFloat64s (mem Allocator , left, right *array .Float64 ) *array .Float64
func github.com/polarsignals/frostdb/query/physicalplan.DivInt32s (mem Allocator , left, right *array .Int32 ) *array .Int32
func github.com/polarsignals/frostdb/query/physicalplan.DivInt64s (mem Allocator , left, right *array .Int64 ) *array .Int64
func github.com/polarsignals/frostdb/query/physicalplan.DivUint64s (mem Allocator , left, right *array .Uint64 ) *array .Uint64
func github.com/polarsignals/frostdb/query/physicalplan.Filter (pool Allocator , tracer trace .Tracer , filterExpr logicalplan .Expr ) (*physicalplan .PredicateFilter , error )
func github.com/polarsignals/frostdb/query/physicalplan.Limit (pool Allocator , tracer trace .Tracer , expr logicalplan .Expr ) (*physicalplan .Limiter , error )
func github.com/polarsignals/frostdb/query/physicalplan.MulFloat64s (mem Allocator , left, right *array .Float64 ) *array .Float64
func github.com/polarsignals/frostdb/query/physicalplan.MulInt32s (mem Allocator , left, right *array .Int32 ) *array .Int32
func github.com/polarsignals/frostdb/query/physicalplan.MulInt64s (mem Allocator , left, right *array .Int64 ) *array .Int64
func github.com/polarsignals/frostdb/query/physicalplan.MulUint64s (mem Allocator , left, right *array .Uint64 ) *array .Uint64
func github.com/polarsignals/frostdb/query/physicalplan.NewHashAggregate (pool Allocator , tracer trace .Tracer , aggregations []physicalplan .Aggregation , groupByColumnMatchers []logicalplan .Expr , seed maphash .Seed , finalStage bool ) *physicalplan .HashAggregate
func github.com/polarsignals/frostdb/query/physicalplan.NewOrderedAggregate (pool Allocator , tracer trace .Tracer , aggregation physicalplan .Aggregation , groupByColumnMatchers []logicalplan .Expr , finalStage bool ) *physicalplan .OrderedAggregate
func github.com/polarsignals/frostdb/query/physicalplan.NewOrderedSynchronizer (pool Allocator , inputs int , orderByExprs []logicalplan .Expr ) *physicalplan .OrderedSynchronizer
func github.com/polarsignals/frostdb/query/physicalplan.NewReservoirSampler (size, limit int64 , allocator Allocator ) *physicalplan .ReservoirSampler
func github.com/polarsignals/frostdb/query/physicalplan.Project (mem Allocator , tracer trace .Tracer , exprs []logicalplan .Expr ) (*physicalplan .Projection , error )
func github.com/polarsignals/frostdb/query/physicalplan.SubFloat64s (mem Allocator , left, right *array .Float64 ) *array .Float64
func github.com/polarsignals/frostdb/query/physicalplan.SubInt32s (mem Allocator , left, right *array .Int32 ) *array .Int32
func github.com/polarsignals/frostdb/query/physicalplan.SubInt64s (mem Allocator , left, right *array .Int64 ) *array .Int64
func github.com/polarsignals/frostdb/query/physicalplan.SubUint64s (mem Allocator , left, right *array .Uint64 ) *array .Uint64
func github.com/polarsignals/frostdb/query/physicalplan.AggregationFunction .Aggregate (pool Allocator , arrs []arrow .Array ) (arrow .Array , error )
func github.com/polarsignals/frostdb/query/physicalplan.(*AndAggregation ).Aggregate (pool Allocator , arrs []arrow .Array ) (arrow .Array , error )
func github.com/polarsignals/frostdb/query/physicalplan.(*CountAggregation ).Aggregate (pool Allocator , arrs []arrow .Array ) (arrow .Array , error )
func github.com/polarsignals/frostdb/query/physicalplan.(*MaxAggregation ).Aggregate (pool Allocator , arrs []arrow .Array ) (arrow .Array , error )
func github.com/polarsignals/frostdb/query/physicalplan.(*MinAggregation ).Aggregate (pool Allocator , arrs []arrow .Array ) (arrow .Array , error )
func github.com/polarsignals/frostdb/query/physicalplan.(*OutputPlan ).Execute (ctx context .Context , pool Allocator , callback func(ctx context .Context , r arrow .Record ) error ) error
func github.com/polarsignals/frostdb/query/physicalplan.ScanPhysicalPlan .Execute (ctx context .Context , pool Allocator ) error
func github.com/polarsignals/frostdb/query/physicalplan.(*SchemaScan ).Execute (ctx context .Context , pool Allocator ) error
func github.com/polarsignals/frostdb/query/physicalplan.(*SumAggregation ).Aggregate (pool Allocator , arrs []arrow .Array ) (arrow .Array , error )
func github.com/polarsignals/frostdb/query/physicalplan.(*TableScan ).Execute (ctx context .Context , pool Allocator ) error
func github.com/polarsignals/frostdb/query/physicalplan.(*UniqueAggregation ).Aggregate (pool Allocator , arrs []arrow .Array ) (arrow .Array , error )
As Types Of (only one )
var DefaultAllocator
type Buffer (struct)
Buffer is a wrapper type for a buffer of bytes.
Methods (total 12 )
(*Buffer) Buf () []byte
Buf returns the slice of memory allocated by the Buffer, which is adjusted by calling Reserve.
(*Buffer) Bytes () []byte
Bytes returns a slice of size Len, which is adjusted by calling Resize.
(*Buffer) Cap () int
Cap returns the capacity of the buffer.
(*Buffer) Len () int
Len returns the length of the buffer.
(*Buffer) Mutable () bool
Mutable returns a bool indicating whether the buffer is mutable or not.
(*Buffer) Parent () *Buffer
Parent returns either nil or a pointer to the parent buffer if this buffer
was sliced from another.
(*Buffer) Release ()
Release decreases the reference count by 1.
When the reference count goes to zero, the memory is freed.
(*Buffer) Reserve (capacity int )
Reserve reserves the provided amount of capacity for the buffer.
(*Buffer) Reset (buf []byte )
Reset resets the buffer for reuse.
(*Buffer) Resize (newSize int )
Resize resizes the buffer to the target size.
(*Buffer) ResizeNoShrink (newSize int )
ResizeNoShrink resizes the buffer to the target size, but will not
shrink it.
(*Buffer) Retain ()
Retain increases the reference count by 1.
Implements (at least 2 )
*Buffer : github.com/apache/arrow-go/v18/arrow/scalar.Releasable
*Buffer : github.com/apache/arrow-go/v18/internal/hashing.ByteSlice
As Outputs Of (at least 23 )
func NewBufferBytes (data []byte ) *Buffer
func NewBufferWithAllocator (data []byte , mem Allocator ) *Buffer
func NewResizableBuffer (mem Allocator ) *Buffer
func SliceBuffer (buf *Buffer , offset, length int ) *Buffer
func (*Buffer).Parent () *Buffer
func github.com/apache/arrow-go/v18/arrow.ArrayData .Buffers () []*Buffer
func github.com/apache/arrow-go/v18/arrow/array.(*Data ).Buffers () []*Buffer
func github.com/apache/arrow-go/v18/arrow/array.(*DenseUnion ).ValueOffsets () *Buffer
func github.com/apache/arrow-go/v18/arrow/array.DictionaryUnifier .UnifyAndTranspose (dict arrow .Array ) (transposed *Buffer , err error )
func github.com/apache/arrow-go/v18/arrow/array.Union .TypeCodes () *Buffer
func github.com/apache/arrow-go/v18/arrow/bitutil.BitmapAndAlloc (mem Allocator , left, right []byte , lOffset, rOffset int64 , length, outOffset int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/bitutil.BitmapAndNotAlloc (mem Allocator , left, right []byte , lOffset, rOffset int64 , length, outOffset int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/bitutil.BitmapOpAlloc (mem Allocator , op bitutil .bitOp , left, right []byte , lOffset, rOffset int64 , length int64 , outOffset int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/bitutil.BitmapOrAlloc (mem Allocator , left, right []byte , lOffset, rOffset int64 , length, outOffset int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/bitutil.BitmapXorAlloc (mem Allocator , left, right []byte , lOffset, rOffset int64 , length, outOffset int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/compute.SerializeExpr (expr compute .Expression , mem Allocator ) (*Buffer , error )
func github.com/apache/arrow-go/v18/arrow/compute.SerializeOptions (opts compute .FunctionOptions , mem Allocator ) (*Buffer , error )
func github.com/apache/arrow-go/v18/arrow/compute/exec.(*ArraySpan ).GetBuffer (idx int ) *Buffer
func github.com/apache/arrow-go/v18/arrow/compute/exec.(*KernelCtx ).Allocate (bufsize int ) *Buffer
func github.com/apache/arrow-go/v18/arrow/compute/exec.(*KernelCtx ).AllocateBitmap (nbits int64 ) *Buffer
func github.com/apache/arrow-go/v18/arrow/ipc.(*Payload ).Meta () *Buffer
func github.com/apache/arrow-go/v18/arrow/scalar.(*Binary ).Buffer () *Buffer
func github.com/apache/arrow-go/v18/arrow/scalar.BinaryScalar .Buffer () *Buffer
As Inputs Of (at least 23 )
func ReleaseBuffers (buffers []*Buffer )
func SliceBuffer (buf *Buffer , offset, length int ) *Buffer
func github.com/apache/arrow-go/v18/arrow.ArrayData .Reset (newtype arrow .DataType , newlength int , newbuffers []*Buffer , newchildren []arrow .ArrayData , newnulls int , newoffset int )
func github.com/apache/arrow-go/v18/arrow.(*ViewHeader ).Equals (buffers []*Buffer , other *arrow .ViewHeader , otherBuffers []*Buffer ) bool
func github.com/apache/arrow-go/v18/arrow.(*ViewHeader ).Equals (buffers []*Buffer , other *arrow .ViewHeader , otherBuffers []*Buffer ) bool
func github.com/apache/arrow-go/v18/arrow/array.NewBoolean (length int , data *Buffer , nullBitmap *Buffer , nulls int ) *array .Boolean
func github.com/apache/arrow-go/v18/arrow/array.NewBoolean (length int , data *Buffer , nullBitmap *Buffer , nulls int ) *array .Boolean
func github.com/apache/arrow-go/v18/arrow/array.NewData (dtype arrow .DataType , length int , buffers []*Buffer , childData []arrow .ArrayData , nulls, offset int ) *array .Data
func github.com/apache/arrow-go/v18/arrow/array.NewDataWithDictionary (dtype arrow .DataType , length int , buffers []*Buffer , nulls, offset int , dict *array .Data ) *array .Data
func github.com/apache/arrow-go/v18/arrow/array.NewDenseUnion (dt *arrow .DenseUnionType , length int , children []arrow .Array , typeIDs, valueOffsets *Buffer , offset int ) *array .DenseUnion
func github.com/apache/arrow-go/v18/arrow/array.NewSparseUnion (dt *arrow .SparseUnionType , length int , children []arrow .Array , typeIDs *Buffer , offset int ) *array .SparseUnion
func github.com/apache/arrow-go/v18/arrow/array.NewStructArrayWithFieldsAndNulls (cols []arrow .Array , fields []arrow .Field , nullBitmap *Buffer , nullCount int , offset int ) (*array .Struct , error )
func github.com/apache/arrow-go/v18/arrow/array.NewStructArrayWithNulls (cols []arrow .Array , names []string , nullBitmap *Buffer , nullCount int , offset int ) (*array .Struct , error )
func github.com/apache/arrow-go/v18/arrow/array.(*Data ).Reset (dtype arrow .DataType , length int , buffers []*Buffer , childData []arrow .ArrayData , nulls, offset int )
func github.com/apache/arrow-go/v18/arrow/compute.DeserializeExpr (mem Allocator , buf *Buffer ) (compute .Expression , error )
func github.com/apache/arrow-go/v18/arrow/compute/exec.(*BufferSpan ).SetBuffer (buf *Buffer )
func github.com/apache/arrow-go/v18/arrow/compute/exec.(*BufferSpan ).WrapBuffer (buf *Buffer )
func github.com/apache/arrow-go/v18/arrow/ipc.NewMessage (meta, body *Buffer ) *ipc .Message
func github.com/apache/arrow-go/v18/arrow/scalar.NewBinaryScalar (val *Buffer , typ arrow .DataType ) *scalar .Binary
func github.com/apache/arrow-go/v18/arrow/scalar.NewFixedSizeBinaryScalar (val *Buffer , typ arrow .DataType ) *scalar .FixedSizeBinary
func github.com/apache/arrow-go/v18/arrow/scalar.NewLargeBinaryScalar (val *Buffer ) *scalar .LargeBinary
func github.com/apache/arrow-go/v18/arrow/scalar.NewLargeStringScalarFromBuffer (val *Buffer ) *scalar .LargeString
func github.com/apache/arrow-go/v18/arrow/scalar.NewStringScalarFromBuffer (val *Buffer ) *scalar .String
Package-Level Functions (total 9)
Package-Level Variables (only one)
The pages are generated with Golds v0.8.2 . (GOOS=linux GOARCH=amd64)
Golds is a Go 101 project developed by Tapir Liu .
PR and bug reports are welcome and can be submitted to the issue list .
Please follow @zigo_101 (reachable from the left QR code) to get the latest news of Golds .