Documentation
¶
Index ¶
- func AddReplacementScan(db Database, callbackPtr unsafe.Pointer, extraData unsafe.Pointer, ...)
- func AppenderError(appender Appender) string
- func BindAddResultColumn(info BindInfo, name string, logicalType LogicalType)
- func BindGetExtraInfo(info BindInfo) unsafe.Pointer
- func BindSetBindData(info BindInfo, bindDataPtr unsafe.Pointer, callbackPtr unsafe.Pointer)
- func BindSetCardinality(info BindInfo, cardinality IdxT, exact bool)
- func BindSetError(info BindInfo, err string)
- func Close(db *Database)
- func ColumnName(res *Result, col IdxT) string
- func ConfigCount() uint64
- func ConnectionGetArrowOptions(conn Connection, outOptions *ArrowOptions)
- func ConnectionGetClientContext(conn Connection, outCtx *ClientContext)
- func DataChunkReset(chunk DataChunk)
- func DataChunkSetSize(chunk DataChunk, size IdxT)
- func DateMembers(date *Date) int32
- func DateStructMembers(date *DateStruct) (int32, int8, int8)
- func DecimalScale(logicalType LogicalType) uint8
- func DecimalToDouble(d Decimal) float64
- func DecimalWidth(logicalType LogicalType) uint8
- func DestroyArrow(arrow *Arrow)
- func DestroyArrowConvertedSchema(schema *ArrowConvertedSchema)
- func DestroyArrowOptions(options *ArrowOptions)
- func DestroyBigNum(i *BigNum)
- func DestroyBit(b *Bit)
- func DestroyBlob(b *Blob)
- func DestroyClientContext(ctx *ClientContext)
- func DestroyConfig(config *Config)
- func DestroyDataChunk(chunk *DataChunk)
- func DestroyErrorData(errorData *ErrorData)
- func DestroyExpression(expr *Expression)
- func DestroyExtracted(extractedStmts *ExtractedStatements)
- func DestroyInstanceCache(cache *InstanceCache)
- func DestroyLogicalType(logicalType *LogicalType)
- func DestroyPending(pendingRes *PendingResult)
- func DestroyPrepare(preparedStmt *PreparedStatement)
- func DestroyResult(res *Result)
- func DestroyScalarFunction(f *ScalarFunction)
- func DestroyScalarFunctionSet(set *ScalarFunctionSet)
- func DestroySelectionVector(sel *SelectionVector)
- func DestroyTableFunction(f *TableFunction)
- func DestroyValue(v *Value)
- func DestroyVector(vec *Vector)
- func Disconnect(conn *Connection)
- func EnumDictionarySize(logicalType LogicalType) uint32
- func EnumDictionaryValue(logicalType LogicalType, index IdxT) string
- func ErrorDataHasError(errorData ErrorData) bool
- func ErrorDataMessage(errorData ErrorData) string
- func ExpressionIsFoldable(expr Expression) bool
- func ExtractStatementsError(extractedStmts ExtractedStatements) string
- func Free(ptr unsafe.Pointer)
- func FunctionGetBindData(info FunctionInfo) unsafe.Pointer
- func FunctionGetExtraInfo(info FunctionInfo) unsafe.Pointer
- func FunctionGetInitData(info FunctionInfo) unsafe.Pointer
- func FunctionGetLocalInitData(info FunctionInfo) unsafe.Pointer
- func FunctionSetError(info FunctionInfo, err string)
- func GetAllocationCount(k string) (int, bool)
- func GetAllocationCounts() string
- func GetBool(v Value) bool
- func GetDouble(v Value) float64
- func GetEnumValue(v Value) uint64
- func GetFloat(v Value) float32
- func GetInt16(v Value) int16
- func GetInt32(v Value) int32
- func GetInt64(v Value) int64
- func GetInt8(v Value) int8
- func GetUInt16(v Value) uint16
- func GetUInt32(v Value) uint32
- func GetUInt64(v Value) uint64
- func GetUInt8(v Value) uint8
- func GetVarchar(v Value) string
- func HugeIntMembers(hi *HugeInt) (uint64, int64)
- func HugeIntToDouble(hi HugeInt) float64
- func InitGetBindData(info InitInfo) unsafe.Pointer
- func InitGetExtraInfo(info InitInfo) unsafe.Pointer
- func InitSetError(info InitInfo, err string)
- func InitSetInitData(info InitInfo, initDataPtr unsafe.Pointer, callbackPtr unsafe.Pointer)
- func InitSetMaxThreads(info InitInfo, max IdxT)
- func Interrupt(conn Connection)
- func IntervalMembers(i *Interval) (int32, int32, int64)
- func IsFiniteDate(date Date) bool
- func IsFiniteTimestamp(ts Timestamp) bool
- func IsFiniteTimestampMS(ts TimestampMS) bool
- func IsFiniteTimestampNS(ts TimestampNS) bool
- func IsFiniteTimestampS(ts TimestampS) bool
- func IsNullValue(v Value) bool
- func LibraryVersion() string
- func ListEntryMembers(entry *ListEntry) (uint64, uint64)
- func LogicalTypeGetAlias(logicalType LogicalType) string
- func LogicalTypeSetAlias(logicalType LogicalType, alias string)
- func ParameterName(preparedStmt PreparedStatement, index IdxT) string
- func PendingError(pendingRes PendingResult) string
- func PendingExecutionIsFinished(state PendingState) bool
- func PrepareError(preparedStmt PreparedStatement) string
- func PreparedStatementColumnName(preparedStmt PreparedStatement, index IdxT) string
- func QueryArrowError(arrow Arrow) string
- func QueryProgressTypeMembers(q *QueryProgressType) (float64, uint64, uint64)
- func ReplacementScanAddParameter(info ReplacementScanInfo, v Value)
- func ReplacementScanSetError(info ReplacementScanInfo, err string)
- func ReplacementScanSetFunctionName(info ReplacementScanInfo, name string)
- func ResultError(res *Result) string
- func ScalarFunctionAddParameter(f ScalarFunction, logicalType LogicalType)
- func ScalarFunctionBindGetExtraInfo(info BindInfo) unsafe.Pointer
- func ScalarFunctionBindSetError(info BindInfo, err string)
- func ScalarFunctionGetBindData(info FunctionInfo) unsafe.Pointer
- func ScalarFunctionGetClientContext(info BindInfo, outCtx *ClientContext)
- func ScalarFunctionGetExtraInfo(info FunctionInfo) unsafe.Pointer
- func ScalarFunctionSetBind(f ScalarFunction, callbackPtr unsafe.Pointer)
- func ScalarFunctionSetBindData(info BindInfo, bindDataPtr unsafe.Pointer, callbackPtr unsafe.Pointer)
- func ScalarFunctionSetBindDataCopy(info BindInfo, callbackPtr unsafe.Pointer)
- func ScalarFunctionSetError(info FunctionInfo, err string)
- func ScalarFunctionSetExtraInfo(f ScalarFunction, extraInfoPtr unsafe.Pointer, callbackPtr unsafe.Pointer)
- func ScalarFunctionSetFunction(f ScalarFunction, callbackPtr unsafe.Pointer)
- func ScalarFunctionSetName(f ScalarFunction, name string)
- func ScalarFunctionSetReturnType(f ScalarFunction, logicalType LogicalType)
- func ScalarFunctionSetSpecialHandling(f ScalarFunction)
- func ScalarFunctionSetVarargs(f ScalarFunction, logicalType LogicalType)
- func ScalarFunctionSetVolatile(f ScalarFunction)
- func SliceVector(vec Vector, sel SelectionVector, len IdxT)
- func StringIsInlined(strT StringT) bool
- func StringTData(strT *StringT) string
- func StringTLength(strT StringT) uint32
- func StructTypeChildName(logicalType LogicalType, index IdxT) string
- func TableDescriptionDestroy(desc *TableDescription)
- func TableDescriptionError(desc TableDescription) string
- func TableDescriptionGetColumnName(desc TableDescription, index IdxT) string
- func TableFunctionAddNamedParameter(f TableFunction, name string, logicalType LogicalType)
- func TableFunctionAddParameter(f TableFunction, logicalType LogicalType)
- func TableFunctionGetClientContext(info BindInfo, outCtx *ClientContext)
- func TableFunctionSetBind(f TableFunction, callbackPtr unsafe.Pointer)
- func TableFunctionSetExtraInfo(f TableFunction, extraInfoPtr unsafe.Pointer, callbackPtr unsafe.Pointer)
- func TableFunctionSetFunction(f TableFunction, callbackPtr unsafe.Pointer)
- func TableFunctionSetInit(f TableFunction, callbackPtr unsafe.Pointer)
- func TableFunctionSetLocalInit(f TableFunction, callbackPtr unsafe.Pointer)
- func TableFunctionSetName(f TableFunction, name string)
- func TableFunctionSupportsProjectionPushdown(f TableFunction, pushdown bool)
- func TimeMembers(ti *Time) int64
- func TimeNSMembers(ti *TimeNS) int64
- func TimeStructMembers(ti *TimeStruct) (int8, int8, int8, int32)
- func TimeTZMembers(ti *TimeTZ) uint64
- func TimestampMSMembers(ts *TimestampMS) int64
- func TimestampMembers(ts *Timestamp) int64
- func TimestampNSMembers(ts *TimestampNS) int64
- func TimestampSMembers(ts *TimestampS) int64
- func TimestampStructMembers(ts *TimestampStruct) (DateStruct, TimeStruct)
- func UHugeIntMembers(hi *UHugeInt) (uint64, uint64)
- func UHugeIntToDouble(hi UHugeInt) float64
- func UnionTypeMemberName(logicalType LogicalType, index IdxT) string
- func ValidityMaskValueIsValid(maskPtr unsafe.Pointer, index IdxT) bool
- func ValidityRowIsValid(maskPtr unsafe.Pointer, row IdxT) bool
- func ValiditySetRowInvalid(maskPtr unsafe.Pointer, row IdxT)
- func ValiditySetRowValid(maskPtr unsafe.Pointer, row IdxT)
- func ValiditySetRowValidity(maskPtr unsafe.Pointer, row IdxT, valid bool)
- func ValueInt64(res *Result, col IdxT, row IdxT) int64
- func ValueToString(val Value) string
- func VectorAssignStringElement(vec Vector, index IdxT, str string)
- func VectorAssignStringElementLen(vec Vector, index IdxT, blob []byte)
- func VectorCopySel(src Vector, dst Vector, sel SelectionVector, count IdxT, srcOffset IdxT, ...)
- func VectorEnsureValidityWritable(vec Vector)
- func VectorGetData(vec Vector) unsafe.Pointer
- func VectorGetValidity(vec Vector) unsafe.Pointer
- func VectorReferenceValue(vec Vector, v Value)
- func VectorReferenceVector(toVec Vector, fromVec Vector)
- func VerifyAllocationCounters()
- type Appender
- type Arrow
- type ArrowArray
- type ArrowConvertedSchema
- type ArrowOptions
- type ArrowSchema
- type ArrowStream
- type BigNum
- type BindInfo
- type Bit
- type Blob
- type CastMode
- type ClientContext
- type Column
- type Config
- type Connection
- type CreateTypeInfo
- type DataChunk
- type Database
- type Date
- type DateStruct
- type Decimal
- type ErrorData
- type ErrorType
- type Expression
- type ExtractedStatements
- type FunctionInfo
- type HugeInt
- type IdxT
- func AppenderColumnCount(appender Appender) IdxT
- func ArrayTypeArraySize(logicalType LogicalType) IdxT
- func ArrowRowCount(arrow Arrow) IdxT
- func BindGetParameterCount(info BindInfo) IdxT
- func ClientContextGetConnectionId(ctx ClientContext) IdxT
- func ColumnCount(res *Result) IdxT
- func DataChunkGetColumnCount(chunk DataChunk) IdxT
- func DataChunkGetSize(chunk DataChunk) IdxT
- func ExtractStatements(conn Connection, query string, outExtractedStmts *ExtractedStatements) IdxT
- func GetListSize(v Value) IdxT
- func GetMapSize(v Value) IdxT
- func InitGetColumnCount(info InitInfo) IdxT
- func InitGetColumnIndex(info InitInfo, index IdxT) IdxT
- func ListVectorGetSize(vec Vector) IdxT
- func NParams(preparedStmt PreparedStatement) IdxT
- func PreparedStatementColumnCount(preparedStmt PreparedStatement) IdxT
- func ProfilingInfoGetChildCount(info ProfilingInfo) IdxT
- func ResultChunkCount(res Result) IdxT
- func RowsChanged(res *Result) IdxT
- func ScalarFunctionBindGetArgumentCount(info BindInfo) IdxT
- func StructTypeChildCount(logicalType LogicalType) IdxT
- func UnionTypeMemberCount(logicalType LogicalType) IdxT
- func VectorSize() IdxT
- type InitInfo
- type InstanceCache
- type Interval
- type ListEntry
- type LogicalType
- func AppenderColumnType(appender Appender, index IdxT) LogicalType
- func ArrayTypeChildType(logicalType LogicalType) LogicalType
- func ColumnLogicalType(res *Result, col IdxT) LogicalType
- func CreateArrayType(child LogicalType, size IdxT) LogicalType
- func CreateDecimalType(width uint8, scale uint8) LogicalType
- func CreateEnumType(names []string) LogicalType
- func CreateListType(child LogicalType) LogicalType
- func CreateLogicalType(t Type) LogicalType
- func CreateMapType(key LogicalType, value LogicalType) LogicalType
- func CreateStructType(types []LogicalType, names []string) LogicalType
- func CreateUnionType(types []LogicalType, names []string) LogicalType
- func ExpressionReturnType(expr Expression) LogicalType
- func GetValueType(v Value) LogicalType
- func ListTypeChildType(logicalType LogicalType) LogicalType
- func MapTypeKeyType(logicalType LogicalType) LogicalType
- func MapTypeValueType(logicalType LogicalType) LogicalType
- func ParamLogicalType(preparedStmt PreparedStatement, index IdxT) LogicalType
- func PreparedStatementColumnLogicalType(preparedStmt PreparedStatement, index IdxT) LogicalType
- func StructTypeChildType(logicalType LogicalType, index IdxT) LogicalType
- func UnionTypeMemberType(logicalType LogicalType, index IdxT) LogicalType
- func VectorGetColumnType(vec Vector) LogicalType
- type PendingResult
- type PendingState
- type PreparedStatement
- type ProfilingInfo
- type QueryProgressType
- type ReplacementScanInfo
- type Result
- type ResultType
- type ScalarFunction
- type ScalarFunctionSet
- type SelT
- type SelectionVector
- type State
- func AddScalarFunctionToSet(set ScalarFunctionSet, f ScalarFunction) State
- func AppendDataChunk(appender Appender, chunk DataChunk) State
- func AppendDefaultToChunk(appender Appender, chunk DataChunk, col IdxT, row IdxT) State
- func AppenderAddColumn(appender Appender, name string) State
- func AppenderClearColumns(appender Appender) State
- func AppenderClose(appender Appender) State
- func AppenderCreate(conn Connection, schema string, table string, outAppender *Appender) State
- func AppenderCreateExt(conn Connection, catalog string, schema string, table string, ...) State
- func AppenderCreateQuery(conn Connection, query string, types []LogicalType, tableName string, ...) State
- func AppenderDestroy(appender *Appender) State
- func AppenderFlush(appender Appender) State
- func ArrowScan(conn Connection, table string, stream ArrowStream) State
- func BindBlob(preparedStmt PreparedStatement, index IdxT, v []byte) State
- func BindBoolean(preparedStmt PreparedStatement, index IdxT, v bool) State
- func BindDate(preparedStmt PreparedStatement, index IdxT, v Date) State
- func BindDecimal(preparedStmt PreparedStatement, index IdxT, v Decimal) State
- func BindDouble(preparedStmt PreparedStatement, index IdxT, v float64) State
- func BindFloat(preparedStmt PreparedStatement, index IdxT, v float32) State
- func BindHugeInt(preparedStmt PreparedStatement, index IdxT, v HugeInt) State
- func BindInt16(preparedStmt PreparedStatement, index IdxT, v int16) State
- func BindInt32(preparedStmt PreparedStatement, index IdxT, v int32) State
- func BindInt64(preparedStmt PreparedStatement, index IdxT, v int64) State
- func BindInt8(preparedStmt PreparedStatement, index IdxT, v int8) State
- func BindInterval(preparedStmt PreparedStatement, index IdxT, v Interval) State
- func BindNull(preparedStmt PreparedStatement, index IdxT) State
- func BindParameterIndex(preparedStmt PreparedStatement, outIndex *IdxT, name string) State
- func BindTime(preparedStmt PreparedStatement, index IdxT, v Time) State
- func BindTimestamp(preparedStmt PreparedStatement, index IdxT, v Timestamp) State
- func BindTimestampTZ(preparedStmt PreparedStatement, index IdxT, v Timestamp) State
- func BindUHugeInt(preparedStmt PreparedStatement, index IdxT, v UHugeInt) State
- func BindUInt16(preparedStmt PreparedStatement, index IdxT, v uint16) State
- func BindUInt32(preparedStmt PreparedStatement, index IdxT, v uint32) State
- func BindUInt64(preparedStmt PreparedStatement, index IdxT, v uint64) State
- func BindUInt8(preparedStmt PreparedStatement, index IdxT, v uint8) State
- func BindValue(preparedStmt PreparedStatement, index IdxT, v Value) State
- func BindVarchar(preparedStmt PreparedStatement, index IdxT, v string) State
- func BindVarcharLength(preparedStmt PreparedStatement, index IdxT, v string, length IdxT) State
- func ClearBindings(preparedStmt PreparedStatement) State
- func ColumnHasDefault(desc TableDescription, index IdxT, outBool *bool) State
- func Connect(db Database, outConn *Connection) State
- func CreateConfig(outConfig *Config) State
- func ExecutePending(res PendingResult, outRes *Result) State
- func ExecutePrepared(preparedStmt PreparedStatement, outRes *Result) State
- func ExecutePreparedArrow(preparedStmt PreparedStatement, outArrow *Arrow) State
- func GetConfigFlag(index uint64, outName *string, outDescription *string) State
- func GetOrCreateFromCache(cache InstanceCache, path string, outDb *Database, config Config, ...) State
- func ListVectorReserve(vec Vector, capacity IdxT) State
- func ListVectorSetSize(vec Vector, size IdxT) State
- func Open(path string, outDb *Database) State
- func OpenExt(path string, outDb *Database, config Config, errMsg *string) State
- func PendingPrepared(preparedStmt PreparedStatement, outPendingRes *PendingResult) State
- func Prepare(conn Connection, query string, outPreparedStmt *PreparedStatement) State
- func PrepareExtractedStatement(conn Connection, extractedStmts ExtractedStatements, index IdxT, ...) State
- func Query(conn Connection, query string, outRes *Result) State
- func QueryArrowArray(arrow Arrow, outArray *ArrowArray) State
- func QueryArrowSchema(arrow Arrow, outSchema *ArrowSchema) State
- func RegisterLogicalType(conn Connection, logicalType LogicalType, info CreateTypeInfo) State
- func RegisterScalarFunction(conn Connection, f ScalarFunction) State
- func RegisterScalarFunctionSet(conn Connection, f ScalarFunctionSet) State
- func RegisterTableFunction(conn Connection, f TableFunction) State
- func SetConfig(config Config, name string, option string) State
- func TableDescriptionCreate(conn Connection, schema string, table string, outDesc *TableDescription) State
- func TableDescriptionCreateExt(conn Connection, catalog string, schema string, table string, ...) State
- type StatementType
- type StringT
- type TableDescription
- type TableFunction
- type Time
- type TimeNS
- type TimeStruct
- type TimeTZ
- type TimeTZStruct
- type Timestamp
- type TimestampMS
- type TimestampNS
- type TimestampS
- type TimestampStruct
- type Type
- func ColumnType(res *Result, col IdxT) Type
- func DecimalInternalType(logicalType LogicalType) Type
- func EnumInternalType(logicalType LogicalType) Type
- func GetTypeId(logicalType LogicalType) Type
- func ParamType(preparedStmt PreparedStatement, index IdxT) Type
- func PreparedStatementColumnType(preparedStmt PreparedStatement, index IdxT) Type
- type UHugeInt
- type Value
- func BindGetNamedParameter(info BindInfo, name string) Value
- func BindGetParameter(info BindInfo, index IdxT) Value
- func CreateArrayValue(logicalType LogicalType, values []Value) Value
- func CreateBigNum(val BigNum) Value
- func CreateBit(val Bit) Value
- func CreateBlob(val []byte) Value
- func CreateBool(val bool) Value
- func CreateDate(val Date) Value
- func CreateDecimal(val Decimal) Value
- func CreateDouble(val float64) Value
- func CreateEnumValue(logicalType LogicalType, val uint64) Value
- func CreateFloat(val float32) Value
- func CreateHugeInt(val HugeInt) Value
- func CreateInt16(val int16) Value
- func CreateInt32(val int32) Value
- func CreateInt64(val int64) Value
- func CreateInt8(val int8) Value
- func CreateInterval(val Interval) Value
- func CreateListValue(logicalType LogicalType, values []Value) Value
- func CreateMapValue(logicalType LogicalType, keys []Value, values []Value) Value
- func CreateNullValue() Value
- func CreateStructValue(logicalType LogicalType, values []Value) Value
- func CreateTime(val Time) Value
- func CreateTimeNS(val TimeNS) Value
- func CreateTimeTZValue(timeTZ TimeTZ) Value
- func CreateTimestamp(val Timestamp) Value
- func CreateTimestampMS(val TimestampMS) Value
- func CreateTimestampNS(val TimestampNS) Value
- func CreateTimestampS(val TimestampS) Value
- func CreateTimestampTZ(val Timestamp) Value
- func CreateUHugeInt(val UHugeInt) Value
- func CreateUInt16(val uint16) Value
- func CreateUInt32(val uint32) Value
- func CreateUInt64(val uint64) Value
- func CreateUInt8(val uint8) Value
- func CreateUUID(val UHugeInt) Value
- func CreateUnionValue(logicalType LogicalType, tag IdxT, value Value) Value
- func CreateVarchar(str string) Value
- func CreateVarcharLength(str string, length IdxT) Value
- func GetListChild(val Value, index IdxT) Value
- func GetMapKey(v Value, index IdxT) Value
- func GetMapValue(v Value, index IdxT) Value
- func GetStructChild(val Value, index IdxT) Value
- func GetTableNames(conn Connection, query string, qualified bool) Value
- func ProfilingInfoGetMetrics(info ProfilingInfo) Value
- func ProfilingInfoGetValue(info ProfilingInfo, key string) Value
- type Vector
Constants ¶
This section is empty.
Variables ¶
This section is empty.
Functions ¶
func AddReplacementScan ¶
func AppenderError ¶
func BindAddResultColumn ¶
func BindAddResultColumn(info BindInfo, name string, logicalType LogicalType)
func BindGetExtraInfo ¶
func BindSetBindData ¶
func BindSetCardinality ¶
func BindSetError ¶
func ColumnName ¶
func ConfigCount ¶
func ConfigCount() uint64
func ConnectionGetArrowOptions ¶ added in v0.1.19
func ConnectionGetArrowOptions(conn Connection, outOptions *ArrowOptions)
ConnectionGetArrowOptions wraps duckdb_connection_get_arrow_options. outOptions must be destroyed with DestroyArrowOptions.
func ConnectionGetClientContext ¶
func ConnectionGetClientContext(conn Connection, outCtx *ClientContext)
ConnectionGetClientContext wraps duckdb_connection_get_client_context. outCtx must be destroyed with DestroyClientContext.
func DataChunkReset ¶
func DataChunkReset(chunk DataChunk)
func DataChunkSetSize ¶
func DateMembers ¶
DateMembers returns the days of a duckdb_date.
func DateStructMembers ¶
func DateStructMembers(date *DateStruct) (int32, int8, int8)
DateStructMembers returns the year, month, and day of a duckdb_date.
func DecimalScale ¶
func DecimalScale(logicalType LogicalType) uint8
func DecimalToDouble ¶
func DecimalWidth ¶
func DecimalWidth(logicalType LogicalType) uint8
func DestroyArrowConvertedSchema ¶ added in v0.1.19
func DestroyArrowConvertedSchema(schema *ArrowConvertedSchema)
DestroyArrowConvertedSchema wraps duckdb_destroy_arrow_converted_schema.
func DestroyArrowOptions ¶ added in v0.1.19
func DestroyArrowOptions(options *ArrowOptions)
DestroyArrowOptions wraps duckdb_destroy_arrow_options.
func DestroyBigNum ¶ added in v0.1.19
func DestroyBigNum(i *BigNum)
DestroyBigNum destroys the data field of duckdb_bignum.
func DestroyClientContext ¶
func DestroyClientContext(ctx *ClientContext)
DestroyClientContext wraps duckdb_destroy_client_context.
func DestroyDataChunk ¶
func DestroyDataChunk(chunk *DataChunk)
DestroyDataChunk wraps duckdb_destroy_data_chunk.
func DestroyErrorData ¶ added in v0.1.19
func DestroyErrorData(errorData *ErrorData)
DestroyErrorData wraps duckdb_destroy_error_data.
func DestroyExpression ¶ added in v0.1.19
func DestroyExpression(expr *Expression)
DestroyExpression wraps duckdb_destroy_expression.
func DestroyExtracted ¶
func DestroyExtracted(extractedStmts *ExtractedStatements)
DestroyExtracted wraps duckdb_destroy_extracted.
func DestroyInstanceCache ¶
func DestroyInstanceCache(cache *InstanceCache)
DestroyInstanceCache wraps duckdb_destroy_instance_cache.
func DestroyLogicalType ¶
func DestroyLogicalType(logicalType *LogicalType)
DestroyLogicalType wraps duckdb_destroy_logical_type.
func DestroyPending ¶
func DestroyPending(pendingRes *PendingResult)
DestroyPending wraps duckdb_destroy_pending.
func DestroyPrepare ¶
func DestroyPrepare(preparedStmt *PreparedStatement)
DestroyPrepare wraps duckdb_destroy_prepare.
func DestroyScalarFunction ¶
func DestroyScalarFunction(f *ScalarFunction)
DestroyScalarFunction wraps duckdb_destroy_scalar_function.
func DestroyScalarFunctionSet ¶
func DestroyScalarFunctionSet(set *ScalarFunctionSet)
DestroyScalarFunctionSet wraps duckdb_destroy_scalar_function_set.
func DestroySelectionVector ¶
func DestroySelectionVector(sel *SelectionVector)
DestroySelectionVector wraps duckdb_destroy_selection_vector.
func DestroyTableFunction ¶
func DestroyTableFunction(f *TableFunction)
DestroyTableFunction wraps duckdb_destroy_table_function.
func EnumDictionarySize ¶
func EnumDictionarySize(logicalType LogicalType) uint32
func EnumDictionaryValue ¶
func EnumDictionaryValue(logicalType LogicalType, index IdxT) string
func ErrorDataHasError ¶ added in v0.1.19
func ErrorDataMessage ¶ added in v0.1.19
func ExpressionIsFoldable ¶ added in v0.1.19
func ExpressionIsFoldable(expr Expression) bool
func ExtractStatementsError ¶
func ExtractStatementsError(extractedStmts ExtractedStatements) string
func FunctionGetBindData ¶
func FunctionGetBindData(info FunctionInfo) unsafe.Pointer
func FunctionGetExtraInfo ¶
func FunctionGetExtraInfo(info FunctionInfo) unsafe.Pointer
func FunctionGetInitData ¶
func FunctionGetInitData(info FunctionInfo) unsafe.Pointer
func FunctionGetLocalInitData ¶
func FunctionGetLocalInitData(info FunctionInfo) unsafe.Pointer
func FunctionSetError ¶
func FunctionSetError(info FunctionInfo, err string)
func GetAllocationCount ¶
GetAllocationCount returns the value of an allocation count, and true, if it exists, otherwise zero, and false.
func GetAllocationCounts ¶
func GetAllocationCounts() string
GetAllocationCounts returns the value of each non-zero allocation count.
func GetEnumValue ¶
func GetVarchar ¶
func HugeIntMembers ¶
HugeIntMembers returns the lower and upper of a duckdb_hugeint.
func HugeIntToDouble ¶
func InitGetBindData ¶
func InitGetExtraInfo ¶
func InitSetError ¶
func InitSetInitData ¶
func InitSetMaxThreads ¶
func Interrupt ¶
func Interrupt(conn Connection)
func IntervalMembers ¶
IntervalMembers returns the months, days, and micros of a duckdb_interval.
func IsFiniteDate ¶
func IsFiniteTimestamp ¶
func IsFiniteTimestampMS ¶
func IsFiniteTimestampMS(ts TimestampMS) bool
func IsFiniteTimestampNS ¶
func IsFiniteTimestampNS(ts TimestampNS) bool
func IsFiniteTimestampS ¶
func IsFiniteTimestampS(ts TimestampS) bool
func IsNullValue ¶
func LibraryVersion ¶
func LibraryVersion() string
func ListEntryMembers ¶
ListEntryMembers returns the offset and length of a duckdb_list_entry.
func LogicalTypeGetAlias ¶
func LogicalTypeGetAlias(logicalType LogicalType) string
func LogicalTypeSetAlias ¶
func LogicalTypeSetAlias(logicalType LogicalType, alias string)
func ParameterName ¶
func ParameterName(preparedStmt PreparedStatement, index IdxT) string
func PendingError ¶
func PendingError(pendingRes PendingResult) string
func PendingExecutionIsFinished ¶
func PendingExecutionIsFinished(state PendingState) bool
func PrepareError ¶
func PrepareError(preparedStmt PreparedStatement) string
func PreparedStatementColumnName ¶ added in v0.1.19
func PreparedStatementColumnName(preparedStmt PreparedStatement, index IdxT) string
func QueryArrowError ¶
func QueryProgressTypeMembers ¶
func QueryProgressTypeMembers(q *QueryProgressType) (float64, uint64, uint64)
QueryProgressTypeMembers returns the percentage, rows_processed, and total_rows_to_process of a duckdb_query_progress_type.
func ReplacementScanAddParameter ¶
func ReplacementScanAddParameter(info ReplacementScanInfo, v Value)
func ReplacementScanSetError ¶
func ReplacementScanSetError(info ReplacementScanInfo, err string)
func ReplacementScanSetFunctionName ¶
func ReplacementScanSetFunctionName(info ReplacementScanInfo, name string)
func ResultError ¶
func ScalarFunctionAddParameter ¶
func ScalarFunctionAddParameter(f ScalarFunction, logicalType LogicalType)
func ScalarFunctionBindGetExtraInfo ¶ added in v0.1.19
func ScalarFunctionGetBindData ¶
func ScalarFunctionGetBindData(info FunctionInfo) unsafe.Pointer
func ScalarFunctionGetClientContext ¶
func ScalarFunctionGetClientContext(info BindInfo, outCtx *ClientContext)
ScalarFunctionGetClientContext wraps duckdb_scalar_function_get_client_context. outCtx must be destroyed with DestroyClientContext.
func ScalarFunctionGetExtraInfo ¶
func ScalarFunctionGetExtraInfo(info FunctionInfo) unsafe.Pointer
func ScalarFunctionSetBind ¶
func ScalarFunctionSetBind(f ScalarFunction, callbackPtr unsafe.Pointer)
func ScalarFunctionSetBindDataCopy ¶ added in v0.1.19
func ScalarFunctionSetError ¶
func ScalarFunctionSetError(info FunctionInfo, err string)
func ScalarFunctionSetExtraInfo ¶
func ScalarFunctionSetExtraInfo(f ScalarFunction, extraInfoPtr unsafe.Pointer, callbackPtr unsafe.Pointer)
func ScalarFunctionSetFunction ¶
func ScalarFunctionSetFunction(f ScalarFunction, callbackPtr unsafe.Pointer)
func ScalarFunctionSetName ¶
func ScalarFunctionSetName(f ScalarFunction, name string)
func ScalarFunctionSetReturnType ¶
func ScalarFunctionSetReturnType(f ScalarFunction, logicalType LogicalType)
func ScalarFunctionSetSpecialHandling ¶
func ScalarFunctionSetSpecialHandling(f ScalarFunction)
func ScalarFunctionSetVarargs ¶
func ScalarFunctionSetVarargs(f ScalarFunction, logicalType LogicalType)
func ScalarFunctionSetVolatile ¶
func ScalarFunctionSetVolatile(f ScalarFunction)
func SliceVector ¶
func SliceVector(vec Vector, sel SelectionVector, len IdxT)
func StringIsInlined ¶
func StringTData ¶
func StringTLength ¶
func StructTypeChildName ¶
func StructTypeChildName(logicalType LogicalType, index IdxT) string
func TableDescriptionDestroy ¶
func TableDescriptionDestroy(desc *TableDescription)
TableDescriptionDestroy wraps duckdb_table_description_destroy.
func TableDescriptionError ¶
func TableDescriptionError(desc TableDescription) string
func TableDescriptionGetColumnName ¶
func TableDescriptionGetColumnName(desc TableDescription, index IdxT) string
func TableFunctionAddNamedParameter ¶
func TableFunctionAddNamedParameter(f TableFunction, name string, logicalType LogicalType)
func TableFunctionAddParameter ¶
func TableFunctionAddParameter(f TableFunction, logicalType LogicalType)
func TableFunctionGetClientContext ¶ added in v0.1.19
func TableFunctionGetClientContext(info BindInfo, outCtx *ClientContext)
TableFunctionGetClientContext wraps duckdb_table_function_get_client_context. outCtx must be destroyed with DestroyClientContext.
func TableFunctionSetBind ¶
func TableFunctionSetBind(f TableFunction, callbackPtr unsafe.Pointer)
func TableFunctionSetExtraInfo ¶
func TableFunctionSetExtraInfo(f TableFunction, extraInfoPtr unsafe.Pointer, callbackPtr unsafe.Pointer)
func TableFunctionSetFunction ¶
func TableFunctionSetFunction(f TableFunction, callbackPtr unsafe.Pointer)
func TableFunctionSetInit ¶
func TableFunctionSetInit(f TableFunction, callbackPtr unsafe.Pointer)
func TableFunctionSetLocalInit ¶
func TableFunctionSetLocalInit(f TableFunction, callbackPtr unsafe.Pointer)
func TableFunctionSetName ¶
func TableFunctionSetName(f TableFunction, name string)
func TableFunctionSupportsProjectionPushdown ¶
func TableFunctionSupportsProjectionPushdown(f TableFunction, pushdown bool)
func TimeMembers ¶
TimeMembers returns the micros of a duckdb_time.
func TimeNSMembers ¶ added in v0.1.19
TimeNSMembers returns the nanos of a duckdb_time_ns.
func TimeStructMembers ¶
func TimeStructMembers(ti *TimeStruct) (int8, int8, int8, int32)
TimeStructMembers returns the hour, min, sec, and micros of a duckdb_time_struct.
func TimeTZMembers ¶
TimeTZMembers returns the bits of a duckdb_time_tz.
func TimestampMSMembers ¶
func TimestampMSMembers(ts *TimestampMS) int64
TimestampMSMembers returns the millis of a duckdb_timestamp_ms.
func TimestampMembers ¶
TimestampMembers returns the micros of a duckdb_timestamp.
func TimestampNSMembers ¶
func TimestampNSMembers(ts *TimestampNS) int64
TimestampNSMembers returns the nanos of a duckdb_timestamp_ns.
func TimestampSMembers ¶
func TimestampSMembers(ts *TimestampS) int64
TimestampSMembers returns the seconds of a duckdb_timestamp_s.
func TimestampStructMembers ¶
func TimestampStructMembers(ts *TimestampStruct) (DateStruct, TimeStruct)
TimestampStructMembers returns the date and time of a duckdb_timestamp_struct.
func UHugeIntMembers ¶
UHugeIntMembers returns the lower and upper of a duckdb_uhugeint.
func UHugeIntToDouble ¶
func UnionTypeMemberName ¶
func UnionTypeMemberName(logicalType LogicalType, index IdxT) string
func ValiditySetRowInvalid ¶
func ValiditySetRowValid ¶
func ValiditySetRowValidity ¶
func ValueToString ¶
func VectorCopySel ¶ added in v0.1.19
func VectorEnsureValidityWritable ¶
func VectorEnsureValidityWritable(vec Vector)
func VectorGetData ¶
func VectorGetValidity ¶
func VectorReferenceValue ¶
func VectorReferenceVector ¶
func VerifyAllocationCounters ¶
func VerifyAllocationCounters()
VerifyAllocationCounters verifies all allocation counters. This includes the instance cache, which should be kept alive as long as the application is kept alive, causing this verification to fail. If you're using the instance cache, use VerifyAllocationCounter instead.
Types ¶
type ArrowArray ¶
ArrowArray wraps *duckdb_arrow_array.
type ArrowConvertedSchema ¶ added in v0.1.19
ArrowConvertedSchema wraps *duckdb_arrow_converted_schema.
type ArrowOptions ¶ added in v0.1.19
ArrowOptions wraps *duckdb_arrow_options.
func ResultGetArrowOptions ¶ added in v0.1.19
func ResultGetArrowOptions(res *Result) ArrowOptions
ResultGetArrowOptions wraps duckdb_result_get_arrow_options. The return value must be destroyed with DestroyArrowOptions.
type ArrowSchema ¶
ArrowSchema wraps *duckdb_arrow_schema.
type ArrowStream ¶
ArrowStream wraps *duckdb_arrow_stream.
type BigNum ¶ added in v0.1.19
type BigNum = C.duckdb_bignum
BigNum does not export New and Members. Use the respective BigNum functions to access / write to this type. This type must be destroyed with DestroyBigNum.
type Bit ¶
type Bit = C.duckdb_bit
Bit does not export New and Members. Use the respective Bit functions to access / write to this type. This type must be destroyed with DestroyBit.
type Blob ¶
type Blob = C.duckdb_blob
Blob does not export New and Members. Use the respective Blob functions to access / write to this type. This type must be destroyed with DestroyBlob.
type CastMode ¶
type CastMode = C.duckdb_cast_mode
CastMode wraps duckdb_cast_mode.
const ( CastModeNormal CastMode = C.DUCKDB_CAST_NORMAL CastModeTry CastMode = C.DUCKDB_CAST_TRY )
type ClientContext ¶
ClientContext wraps *duckdb_client_context.
type Column ¶
type Column struct {
// contains filtered or unexported fields
}
Column wraps duckdb_column. NOTE: Same limitations as Result.
type Connection ¶
Connection wraps *duckdb_connection.
type CreateTypeInfo ¶
CreateTypeInfo wraps *duckdb_create_type_info.
type DataChunk ¶
DataChunk wraps *duckdb_data_chunk.
func CreateDataChunk ¶
func CreateDataChunk(types []LogicalType) DataChunk
CreateDataChunk wraps duckdb_create_data_chunk. The return value must be destroyed with DestroyDataChunk.
func ResultGetChunk ¶
ResultGetChunk wraps duckdb_result_get_chunk. The return value must be destroyed with DestroyDataChunk.
type DateStruct ¶
type DateStruct = C.duckdb_date_struct
func FromDate ¶
func FromDate(date Date) DateStruct
func NewDateStruct ¶
func NewDateStruct(year int32, month int8, day int8) DateStruct
NewDateStruct sets the members of a duckdb_date_struct.
type ErrorData ¶ added in v0.1.19
ErrorData wraps *duckdb_error_data.
func AppenderErrorData ¶ added in v0.1.19
AppenderErrorData wraps duckdb_appender_error_data. The return value must be destroyed with DestroyErrorData.
func CreateErrorData ¶ added in v0.1.19
CreateErrorData wraps duckdb_create_error_data. The return value must be destroyed with DestroyErrorData.
func ExpressionFold ¶ added in v0.1.19
func ExpressionFold(ctx ClientContext, expr Expression, outValue *Value) ErrorData
ExpressionFold wraps duckdb_expression_fold. outValue must be destroyed with DestroyValue. The return value must be destroyed with DestroyErrorData.
type ErrorType ¶
type ErrorType = C.duckdb_error_type
ErrorType wraps duckdb_error_type.
const ( ErrorTypeInvalid ErrorType = C.DUCKDB_ERROR_INVALID ErrorTypeOutOfRange ErrorType = C.DUCKDB_ERROR_OUT_OF_RANGE ErrorTypeConversion ErrorType = C.DUCKDB_ERROR_CONVERSION ErrorTypeUnknownType ErrorType = C.DUCKDB_ERROR_UNKNOWN_TYPE ErrorTypeDecimal ErrorType = C.DUCKDB_ERROR_DECIMAL ErrorTypeMismatchType ErrorType = C.DUCKDB_ERROR_MISMATCH_TYPE ErrorTypeDivideByZero ErrorType = C.DUCKDB_ERROR_DIVIDE_BY_ZERO ErrorTypeObjectSize ErrorType = C.DUCKDB_ERROR_OBJECT_SIZE ErrorTypeInvalidType ErrorType = C.DUCKDB_ERROR_INVALID_TYPE ErrorTypeSerialization ErrorType = C.DUCKDB_ERROR_SERIALIZATION ErrorTypeTransaction ErrorType = C.DUCKDB_ERROR_TRANSACTION ErrorTypeNotImplemented ErrorType = C.DUCKDB_ERROR_NOT_IMPLEMENTED ErrorTypeExpression ErrorType = C.DUCKDB_ERROR_EXPRESSION ErrorTypeCatalog ErrorType = C.DUCKDB_ERROR_CATALOG ErrorTypeParser ErrorType = C.DUCKDB_ERROR_PARSER ErrorTypePlanner ErrorType = C.DUCKDB_ERROR_PLANNER ErrorTypeScheduler ErrorType = C.DUCKDB_ERROR_SCHEDULER ErrorTypeExecutor ErrorType = C.DUCKDB_ERROR_EXECUTOR ErrorTypeConstraint ErrorType = C.DUCKDB_ERROR_CONSTRAINT ErrorTypeIndex ErrorType = C.DUCKDB_ERROR_INDEX ErrorTypeStat ErrorType = C.DUCKDB_ERROR_STAT ErrorTypeConnection ErrorType = C.DUCKDB_ERROR_CONNECTION ErrorTypeSyntax ErrorType = C.DUCKDB_ERROR_SYNTAX ErrorTypeSettings ErrorType = C.DUCKDB_ERROR_SETTINGS ErrorTypeBinder ErrorType = C.DUCKDB_ERROR_BINDER ErrorTypeNetwork ErrorType = C.DUCKDB_ERROR_NETWORK ErrorTypeOptimizer ErrorType = C.DUCKDB_ERROR_OPTIMIZER ErrorTypeNullPointer ErrorType = C.DUCKDB_ERROR_NULL_POINTER ErrorTypeErrorIO ErrorType = C.DUCKDB_ERROR_IO ErrorTypeInterrupt ErrorType = C.DUCKDB_ERROR_INTERRUPT ErrorTypeFatal ErrorType = C.DUCKDB_ERROR_FATAL ErrorTypeInternal ErrorType = C.DUCKDB_ERROR_INTERNAL ErrorTypeInvalidInput ErrorType = C.DUCKDB_ERROR_INVALID_INPUT ErrorTypeOutOfMemory ErrorType = C.DUCKDB_ERROR_OUT_OF_MEMORY ErrorTypePermission ErrorType = C.DUCKDB_ERROR_PERMISSION ErrorTypeParameterNotResolved ErrorType = C.DUCKDB_ERROR_PARAMETER_NOT_RESOLVED ErrorTypeParameterNotAllowed ErrorType = C.DUCKDB_ERROR_PARAMETER_NOT_ALLOWED ErrorTypeDependency ErrorType = C.DUCKDB_ERROR_DEPENDENCY ErrorTypeHTTP ErrorType = C.DUCKDB_ERROR_HTTP ErrorTypeMissingExtension ErrorType = C.DUCKDB_ERROR_MISSING_EXTENSION ErrorTypeAutoload ErrorType = C.DUCKDB_ERROR_AUTOLOAD ErrorTypeSequence ErrorType = C.DUCKDB_ERROR_SEQUENCE ErrorTypeInvalidConfiguration ErrorType = C.DUCKDB_INVALID_CONFIGURATION )
func ErrorDataErrorType ¶ added in v0.1.19
func ResultErrorType ¶
type Expression ¶ added in v0.1.19
Expression wraps *duckdb_expression.
func ScalarFunctionBindGetArgument ¶ added in v0.1.19
func ScalarFunctionBindGetArgument(info BindInfo, index IdxT) Expression
ScalarFunctionBindGetArgument wraps duckdb_scalar_function_bind_get_argument. The return value must be destroyed with DestroyExpression.
type ExtractedStatements ¶
ExtractedStatements wraps *duckdb_extracted_statements.
type FunctionInfo ¶
FunctionInfo wraps *duckdb_function_info.
type HugeInt ¶
type HugeInt = C.duckdb_hugeint
func DecimalMembers ¶
DecimalMembers returns the width, scale, and value of a duckdb_decimal.
func DoubleToHugeInt ¶
func GetHugeInt ¶
func NewHugeInt ¶
NewHugeInt sets the members of a duckdb_hugeint.
type IdxT ¶
func AppenderColumnCount ¶
func ArrayTypeArraySize ¶
func ArrayTypeArraySize(logicalType LogicalType) IdxT
func ArrowRowCount ¶
func BindGetParameterCount ¶
func ClientContextGetConnectionId ¶
func ClientContextGetConnectionId(ctx ClientContext) IdxT
func ColumnCount ¶
func DataChunkGetSize ¶
func ExtractStatements ¶
func ExtractStatements(conn Connection, query string, outExtractedStmts *ExtractedStatements) IdxT
ExtractStatements wraps duckdb_extract_statements. outExtractedStmts must be destroyed with DestroyExtracted.
func GetListSize ¶
func GetMapSize ¶
func InitGetColumnCount ¶
func InitGetColumnIndex ¶
func ListVectorGetSize ¶
func NParams ¶
func NParams(preparedStmt PreparedStatement) IdxT
func PreparedStatementColumnCount ¶ added in v0.1.19
func PreparedStatementColumnCount(preparedStmt PreparedStatement) IdxT
func ProfilingInfoGetChildCount ¶
func ProfilingInfoGetChildCount(info ProfilingInfo) IdxT
func ResultChunkCount ¶
func RowsChanged ¶
func ScalarFunctionBindGetArgumentCount ¶ added in v0.1.19
func StructTypeChildCount ¶
func StructTypeChildCount(logicalType LogicalType) IdxT
func UnionTypeMemberCount ¶
func UnionTypeMemberCount(logicalType LogicalType) IdxT
func VectorSize ¶
func VectorSize() IdxT
type InstanceCache ¶
InstanceCache wraps *duckdb_instance_cache.
func CreateInstanceCache ¶
func CreateInstanceCache() InstanceCache
CreateInstanceCache wraps duckdb_create_instance_cache. The return value must be destroyed with DestroyInstanceCache.
type ListEntry ¶
type ListEntry = C.duckdb_list_entry
func NewListEntry ¶
NewListEntry sets the members of a duckdb_list_entry.
type LogicalType ¶
LogicalType wraps *duckdb_logical_type.
func AppenderColumnType ¶
func AppenderColumnType(appender Appender, index IdxT) LogicalType
AppenderColumnType wraps duckdb_appender_column_type. The return value must be destroyed with DestroyLogicalType.
func ArrayTypeChildType ¶
func ArrayTypeChildType(logicalType LogicalType) LogicalType
ArrayTypeChildType wraps duckdb_array_type_child_type. The return value must be destroyed with DestroyLogicalType.
func ColumnLogicalType ¶
func ColumnLogicalType(res *Result, col IdxT) LogicalType
ColumnLogicalType wraps duckdb_column_logical_type. The return value must be destroyed with DestroyLogicalType.
func CreateArrayType ¶
func CreateArrayType(child LogicalType, size IdxT) LogicalType
CreateArrayType wraps duckdb_create_array_type. The return value must be destroyed with DestroyLogicalType.
func CreateDecimalType ¶
func CreateDecimalType(width uint8, scale uint8) LogicalType
CreateDecimalType wraps duckdb_create_decimal_type. The return value must be destroyed with DestroyLogicalType.
func CreateEnumType ¶
func CreateEnumType(names []string) LogicalType
CreateEnumType wraps duckdb_create_enum_type. The return value must be destroyed with DestroyLogicalType.
func CreateListType ¶
func CreateListType(child LogicalType) LogicalType
CreateListType wraps duckdb_create_list_type. The return value must be destroyed with DestroyLogicalType.
func CreateLogicalType ¶
func CreateLogicalType(t Type) LogicalType
CreateLogicalType wraps duckdb_create_logical_type. The return value must be destroyed with DestroyLogicalType.
func CreateMapType ¶
func CreateMapType(key LogicalType, value LogicalType) LogicalType
CreateMapType wraps duckdb_create_map_type. The return value must be destroyed with DestroyLogicalType.
func CreateStructType ¶
func CreateStructType(types []LogicalType, names []string) LogicalType
CreateStructType wraps duckdb_create_struct_type. The return value must be destroyed with DestroyLogicalType.
func CreateUnionType ¶
func CreateUnionType(types []LogicalType, names []string) LogicalType
CreateUnionType wraps duckdb_create_union_type. The return value must be destroyed with DestroyLogicalType.
func ExpressionReturnType ¶ added in v0.1.19
func ExpressionReturnType(expr Expression) LogicalType
ExpressionReturnType wraps duckdb_expression_return_type. The return value must be destroyed with DestroyLogicalType.
func GetValueType ¶
func GetValueType(v Value) LogicalType
GetValueType wraps duckdb_get_value_type. The return value must be destroyed with DestroyLogicalType.
func ListTypeChildType ¶
func ListTypeChildType(logicalType LogicalType) LogicalType
ListTypeChildType wraps duckdb_list_type_child_type. The return value must be destroyed with DestroyLogicalType.
func MapTypeKeyType ¶
func MapTypeKeyType(logicalType LogicalType) LogicalType
MapTypeKeyType wraps duckdb_map_type_key_type. The return value must be destroyed with DestroyLogicalType.
func MapTypeValueType ¶
func MapTypeValueType(logicalType LogicalType) LogicalType
MapTypeValueType wraps duckdb_map_type_value_type. The return value must be destroyed with DestroyLogicalType.
func ParamLogicalType ¶
func ParamLogicalType(preparedStmt PreparedStatement, index IdxT) LogicalType
ParamLogicalType wraps duckdb_param_logical_type. The return value must be destroyed with DestroyLogicalType.
func PreparedStatementColumnLogicalType ¶ added in v0.1.19
func PreparedStatementColumnLogicalType(preparedStmt PreparedStatement, index IdxT) LogicalType
PreparedStatementColumnLogicalType wraps duckdb_prepared_statement_column_logical_type. The return value must be destroyed with DestroyLogicalType.
func StructTypeChildType ¶
func StructTypeChildType(logicalType LogicalType, index IdxT) LogicalType
StructTypeChildType wraps duckdb_struct_type_child_type. The return value must be destroyed with DestroyLogicalType.
func UnionTypeMemberType ¶
func UnionTypeMemberType(logicalType LogicalType, index IdxT) LogicalType
UnionTypeMemberType wraps duckdb_union_type_member_type. The return value must be destroyed with DestroyLogicalType.
func VectorGetColumnType ¶
func VectorGetColumnType(vec Vector) LogicalType
VectorGetColumnType wraps duckdb_vector_get_column_type. The return value must be destroyed with DestroyLogicalType.
type PendingResult ¶
PendingResult wraps *duckdb_pending_result.
type PendingState ¶
type PendingState = C.duckdb_pending_state
PendingState wraps duckdb_pending_state.
const ( PendingStateResultReady PendingState = C.DUCKDB_PENDING_RESULT_READY PendingStateResultNotReady PendingState = C.DUCKDB_PENDING_RESULT_NOT_READY PendingStateError PendingState = C.DUCKDB_PENDING_ERROR PendingStateNoTasksAvailable PendingState = C.DUCKDB_PENDING_NO_TASKS_AVAILABLE )
func PendingExecuteCheckState ¶
func PendingExecuteCheckState(pendingRes PendingResult) PendingState
func PendingExecuteTask ¶
func PendingExecuteTask(pendingRes PendingResult) PendingState
type PreparedStatement ¶
PreparedStatement wraps *duckdb_prepared_statement.
type ProfilingInfo ¶
ProfilingInfo wraps *duckdb_profiling_info.
func GetProfilingInfo ¶
func GetProfilingInfo(conn Connection) ProfilingInfo
func ProfilingInfoGetChild ¶
func ProfilingInfoGetChild(info ProfilingInfo, index IdxT) ProfilingInfo
type QueryProgressType ¶
type QueryProgressType = C.duckdb_query_progress_type
func NewQueryProgressType ¶
func NewQueryProgressType(percentage float64, rowsProcessed uint64, totalRowsToProcess uint64) QueryProgressType
NewQueryProgressType sets the members of a duckdb_query_progress_type.
func QueryProgress ¶
func QueryProgress(conn Connection) QueryProgressType
type ReplacementScanInfo ¶
ReplacementScanInfo wraps *duckdb_replacement_scan.
type Result ¶
type Result struct {
// contains filtered or unexported fields
}
Result wraps duckdb_result. NOTE: Using 'type Result = C.duckdb_result' causes a somewhat mysterious 'runtime error: cgo argument has Go pointer to unpinned Go pointer'. See https://github.com/golang/go/issues/28606#issuecomment-2184269962. When using a type alias, duckdb_result itself contains a Go unsafe.Pointer for its 'void *internal_data' field.
type ResultType ¶
type ResultType = C.duckdb_result_type
ResultType wraps duckdb_result_type.
const ( ResultTypeInvalid ResultType = C.DUCKDB_RESULT_TYPE_INVALID ResultTypeChangedRows ResultType = C.DUCKDB_RESULT_TYPE_CHANGED_ROWS ResultTypeNothing ResultType = C.DUCKDB_RESULT_TYPE_NOTHING ResultTypeQueryResult ResultType = C.DUCKDB_RESULT_TYPE_QUERY_RESULT )
func ResultReturnType ¶
func ResultReturnType(res Result) ResultType
type ScalarFunction ¶
ScalarFunction wraps *duckdb_scalar_function.
func CreateScalarFunction ¶
func CreateScalarFunction() ScalarFunction
CreateScalarFunction wraps duckdb_create_scalar_function. The return value must be destroyed with DestroyScalarFunction.
type ScalarFunctionSet ¶
ScalarFunctionSet wraps *duckdb_scalar_function_set.
func CreateScalarFunctionSet ¶
func CreateScalarFunctionSet(name string) ScalarFunctionSet
CreateScalarFunctionSet wraps duckdb_create_scalar_function_set. The return value must be destroyed with DestroyScalarFunctionSet.
type SelT ¶
func SelectionVectorGetDataPtr ¶
func SelectionVectorGetDataPtr(sel SelectionVector) *SelT
type SelectionVector ¶
SelectionVector wraps *duckdb_selection_vector.
func CreateSelectionVector ¶
func CreateSelectionVector(size IdxT) SelectionVector
CreateSelectionVector wraps duckdb_create_selection_vector. The return value must be destroyed with DestroySelectionVector.
type State ¶
type State = C.duckdb_state
State wraps duckdb_state.
const ( StateSuccess State = C.DuckDBSuccess StateError State = C.DuckDBError )
func AddScalarFunctionToSet ¶
func AddScalarFunctionToSet(set ScalarFunctionSet, f ScalarFunction) State
func AppendDataChunk ¶
func AppendDefaultToChunk ¶
func AppenderAddColumn ¶
func AppenderClearColumns ¶
func AppenderClose ¶
func AppenderCreate ¶
func AppenderCreate(conn Connection, schema string, table string, outAppender *Appender) State
AppenderCreate wraps duckdb_appender_create. outAppender must be destroyed with AppenderDestroy.
func AppenderCreateExt ¶
func AppenderCreateExt(conn Connection, catalog string, schema string, table string, outAppender *Appender) State
AppenderCreateExt wraps duckdb_appender_create_ext. outAppender must be destroyed with AppenderDestroy.
func AppenderCreateQuery ¶ added in v0.1.19
func AppenderCreateQuery(conn Connection, query string, types []LogicalType, tableName string, columnNames []string, outAppender *Appender) State
AppenderCreateQuery wraps duckdb_appender_create_query. outAppender must be destroyed with AppenderDestroy.
func AppenderDestroy ¶
AppenderDestroy wraps duckdb_appender_destroy.
func AppenderFlush ¶
func ArrowScan ¶
func ArrowScan(conn Connection, table string, stream ArrowStream) State
func BindBoolean ¶
func BindBoolean(preparedStmt PreparedStatement, index IdxT, v bool) State
func BindDecimal ¶
func BindDecimal(preparedStmt PreparedStatement, index IdxT, v Decimal) State
func BindDouble ¶
func BindDouble(preparedStmt PreparedStatement, index IdxT, v float64) State
func BindHugeInt ¶
func BindHugeInt(preparedStmt PreparedStatement, index IdxT, v HugeInt) State
func BindInterval ¶
func BindInterval(preparedStmt PreparedStatement, index IdxT, v Interval) State
func BindNull ¶
func BindNull(preparedStmt PreparedStatement, index IdxT) State
func BindParameterIndex ¶
func BindParameterIndex(preparedStmt PreparedStatement, outIndex *IdxT, name string) State
func BindTimestamp ¶
func BindTimestamp(preparedStmt PreparedStatement, index IdxT, v Timestamp) State
func BindTimestampTZ ¶
func BindTimestampTZ(preparedStmt PreparedStatement, index IdxT, v Timestamp) State
func BindUHugeInt ¶
func BindUHugeInt(preparedStmt PreparedStatement, index IdxT, v UHugeInt) State
func BindUInt16 ¶
func BindUInt16(preparedStmt PreparedStatement, index IdxT, v uint16) State
func BindUInt32 ¶
func BindUInt32(preparedStmt PreparedStatement, index IdxT, v uint32) State
func BindUInt64 ¶
func BindUInt64(preparedStmt PreparedStatement, index IdxT, v uint64) State
func BindVarchar ¶
func BindVarchar(preparedStmt PreparedStatement, index IdxT, v string) State
func BindVarcharLength ¶
func BindVarcharLength(preparedStmt PreparedStatement, index IdxT, v string, length IdxT) State
func ClearBindings ¶
func ClearBindings(preparedStmt PreparedStatement) State
func ColumnHasDefault ¶
func ColumnHasDefault(desc TableDescription, index IdxT, outBool *bool) State
func Connect ¶
func Connect(db Database, outConn *Connection) State
Connect wraps duckdb_connect. outConn must be disconnected with Disconnect.
func CreateConfig ¶
CreateConfig wraps duckdb_create_config. outConfig must be destroyed with DestroyConfig.
func ExecutePending ¶
func ExecutePending(res PendingResult, outRes *Result) State
ExecutePending wraps duckdb_execute_pending. outRes must be destroyed with DestroyResult.
func ExecutePrepared ¶
func ExecutePrepared(preparedStmt PreparedStatement, outRes *Result) State
ExecutePrepared wraps duckdb_execute_prepared. outRes must be destroyed with DestroyResult.
func ExecutePreparedArrow ¶
func ExecutePreparedArrow(preparedStmt PreparedStatement, outArrow *Arrow) State
ExecutePreparedArrow wraps duckdb_execute_prepared_arrow. outArrow must be destroyed with DestroyArrow.
func GetConfigFlag ¶
func GetOrCreateFromCache ¶
func GetOrCreateFromCache(cache InstanceCache, path string, outDb *Database, config Config, errMsg *string) State
GetOrCreateFromCache wraps duckdb_get_or_create_from_cache. outDb must be closed with Close.
func ListVectorReserve ¶
func ListVectorSetSize ¶
func PendingPrepared ¶
func PendingPrepared(preparedStmt PreparedStatement, outPendingRes *PendingResult) State
PendingPrepared wraps duckdb_pending_prepared. outPendingRes must be destroyed with DestroyPending.
func Prepare ¶
func Prepare(conn Connection, query string, outPreparedStmt *PreparedStatement) State
Prepare wraps duckdb_prepare. outPreparedStmt must be destroyed with DestroyPrepare.
func PrepareExtractedStatement ¶
func PrepareExtractedStatement(conn Connection, extractedStmts ExtractedStatements, index IdxT, outPreparedStmt *PreparedStatement) State
PrepareExtractedStatement wraps duckdb_prepare_extracted_statement. outPreparedStmt must be destroyed with DestroyPrepare.
func Query ¶
func Query(conn Connection, query string, outRes *Result) State
Query wraps duckdb_query. outRes must be destroyed with DestroyResult.
func QueryArrowArray ¶
func QueryArrowArray(arrow Arrow, outArray *ArrowArray) State
func QueryArrowSchema ¶
func QueryArrowSchema(arrow Arrow, outSchema *ArrowSchema) State
func RegisterLogicalType ¶
func RegisterLogicalType(conn Connection, logicalType LogicalType, info CreateTypeInfo) State
func RegisterScalarFunction ¶
func RegisterScalarFunction(conn Connection, f ScalarFunction) State
func RegisterScalarFunctionSet ¶
func RegisterScalarFunctionSet(conn Connection, f ScalarFunctionSet) State
func RegisterTableFunction ¶
func RegisterTableFunction(conn Connection, f TableFunction) State
func TableDescriptionCreate ¶
func TableDescriptionCreate(conn Connection, schema string, table string, outDesc *TableDescription) State
TableDescriptionCreate wraps duckdb_table_description_create. outDesc must be destroyed with TableDescriptionDestroy.
func TableDescriptionCreateExt ¶
func TableDescriptionCreateExt(conn Connection, catalog string, schema string, table string, outDesc *TableDescription) State
TableDescriptionCreateExt wraps duckdb_table_description_create_ext. outDesc must be destroyed with TableDescriptionDestroy.
type StatementType ¶
type StatementType = C.duckdb_statement_type
StatementType wraps duckdb_statement_type.
const ( StatementTypeInvalid StatementType = C.DUCKDB_STATEMENT_TYPE_INVALID StatementTypeSelect StatementType = C.DUCKDB_STATEMENT_TYPE_SELECT StatementTypeInsert StatementType = C.DUCKDB_STATEMENT_TYPE_INSERT StatementTypeUpdate StatementType = C.DUCKDB_STATEMENT_TYPE_UPDATE StatementTypeExplain StatementType = C.DUCKDB_STATEMENT_TYPE_EXPLAIN StatementTypeDelete StatementType = C.DUCKDB_STATEMENT_TYPE_DELETE StatementTypePrepare StatementType = C.DUCKDB_STATEMENT_TYPE_PREPARE StatementTypeCreate StatementType = C.DUCKDB_STATEMENT_TYPE_CREATE StatementTypeExecute StatementType = C.DUCKDB_STATEMENT_TYPE_EXECUTE StatementTypeAlter StatementType = C.DUCKDB_STATEMENT_TYPE_ALTER StatementTypeTransaction StatementType = C.DUCKDB_STATEMENT_TYPE_TRANSACTION StatementTypeCopy StatementType = C.DUCKDB_STATEMENT_TYPE_COPY StatementTypeAnalyze StatementType = C.DUCKDB_STATEMENT_TYPE_ANALYZE StatementTypeVariableSet StatementType = C.DUCKDB_STATEMENT_TYPE_VARIABLE_SET StatementTypeCreateFunc StatementType = C.DUCKDB_STATEMENT_TYPE_CREATE_FUNC StatementTypeDrop StatementType = C.DUCKDB_STATEMENT_TYPE_DROP StatementTypeExport StatementType = C.DUCKDB_STATEMENT_TYPE_EXPORT StatementTypePragma StatementType = C.DUCKDB_STATEMENT_TYPE_PRAGMA StatementTypeVacuum StatementType = C.DUCKDB_STATEMENT_TYPE_VACUUM StatementTypeCall StatementType = C.DUCKDB_STATEMENT_TYPE_CALL StatementTypeSet StatementType = C.DUCKDB_STATEMENT_TYPE_SET StatementTypeLoad StatementType = C.DUCKDB_STATEMENT_TYPE_LOAD StatementTypeRelation StatementType = C.DUCKDB_STATEMENT_TYPE_RELATION StatementTypeExtension StatementType = C.DUCKDB_STATEMENT_TYPE_EXTENSION StatementTypeLogicalPlan StatementType = C.DUCKDB_STATEMENT_TYPE_LOGICAL_PLAN StatementTypeAttach StatementType = C.DUCKDB_STATEMENT_TYPE_ATTACH StatementTypeDetach StatementType = C.DUCKDB_STATEMENT_TYPE_DETACH StatementTypeMulti StatementType = C.DUCKDB_STATEMENT_TYPE_MULTI )
func PreparedStatementType ¶
func PreparedStatementType(preparedStmt PreparedStatement) StatementType
func ResultStatementType ¶
func ResultStatementType(res Result) StatementType
type StringT ¶
type StringT = C.duckdb_string_t
StringT does not export New and Members. Use the respective StringT functions to access / write to this type.
type TableDescription ¶
TableDescription wraps *duckdb_table_description.
type TableFunction ¶
TableFunction wraps *duckdb_table_function.
func CreateTableFunction ¶
func CreateTableFunction() TableFunction
CreateTableFunction wraps duckdb_create_table_function. The return value must be destroyed with DestroyTableFunction.
type TimeNS ¶ added in v0.1.19
type TimeNS = C.duckdb_time_ns
type TimeStruct ¶
type TimeStruct = C.duckdb_time_struct
func FromTime ¶
func FromTime(ti Time) TimeStruct
func NewTimeStruct ¶
func NewTimeStruct(hour int8, min int8, sec int8, micros int32) TimeStruct
NewTimeStruct sets the members of a duckdb_time_struct.
func TimeTZStructMembers ¶
func TimeTZStructMembers(ti *TimeTZStruct) (TimeStruct, int32)
TimeTZStructMembers returns the time and offset of a duckdb_time_tz_struct.
type TimeTZStruct ¶
type TimeTZStruct = C.duckdb_time_tz_struct
func FromTimeTZ ¶
func FromTimeTZ(ti TimeTZ) TimeTZStruct
func NewTimeTZStruct ¶
func NewTimeTZStruct(ti TimeStruct, offset int32) TimeTZStruct
NewTimeTZStruct sets the members of a duckdb_time_tz_struct.
type Timestamp ¶
type Timestamp = C.duckdb_timestamp
func GetTimestamp ¶
func GetTimestampTZ ¶
func NewTimestamp ¶
NewTimestamp sets the members of a duckdb_timestamp.
func ToTimestamp ¶
func ToTimestamp(ts TimestampStruct) Timestamp
type TimestampMS ¶
type TimestampMS = C.duckdb_timestamp_ms
func GetTimestampMS ¶
func GetTimestampMS(v Value) TimestampMS
func NewTimestampMS ¶
func NewTimestampMS(millis int64) TimestampMS
NewTimestampMS sets the members of a duckdb_timestamp_ms.
type TimestampNS ¶
type TimestampNS = C.duckdb_timestamp_ns
func GetTimestampNS ¶
func GetTimestampNS(v Value) TimestampNS
func NewTimestampNS ¶
func NewTimestampNS(nanos int64) TimestampNS
NewTimestampNS sets the members of a duckdb_timestamp_ns.
type TimestampS ¶
type TimestampS = C.duckdb_timestamp_s
func GetTimestampS ¶
func GetTimestampS(v Value) TimestampS
func NewTimestampS ¶
func NewTimestampS(seconds int64) TimestampS
NewTimestampS sets the members of a duckdb_timestamp_s.
type TimestampStruct ¶
type TimestampStruct = C.duckdb_timestamp_struct
func FromTimestamp ¶
func FromTimestamp(ts Timestamp) TimestampStruct
func NewTimestampStruct ¶
func NewTimestampStruct(date DateStruct, ti TimeStruct) TimestampStruct
NewTimestampStruct sets the members of a duckdb_timestamp_struct.
type Type ¶
type Type = C.duckdb_type
Type wraps duckdb_type.
const ( TypeInvalid Type = C.DUCKDB_TYPE_INVALID TypeBoolean Type = C.DUCKDB_TYPE_BOOLEAN TypeTinyInt Type = C.DUCKDB_TYPE_TINYINT TypeSmallInt Type = C.DUCKDB_TYPE_SMALLINT TypeInteger Type = C.DUCKDB_TYPE_INTEGER TypeBigInt Type = C.DUCKDB_TYPE_BIGINT TypeUTinyInt Type = C.DUCKDB_TYPE_UTINYINT TypeUSmallInt Type = C.DUCKDB_TYPE_USMALLINT TypeUInteger Type = C.DUCKDB_TYPE_UINTEGER TypeUBigInt Type = C.DUCKDB_TYPE_UBIGINT TypeFloat Type = C.DUCKDB_TYPE_FLOAT TypeDouble Type = C.DUCKDB_TYPE_DOUBLE TypeTimestamp Type = C.DUCKDB_TYPE_TIMESTAMP TypeDate Type = C.DUCKDB_TYPE_DATE TypeTime Type = C.DUCKDB_TYPE_TIME TypeInterval Type = C.DUCKDB_TYPE_INTERVAL TypeHugeInt Type = C.DUCKDB_TYPE_HUGEINT TypeUHugeInt Type = C.DUCKDB_TYPE_UHUGEINT TypeVarchar Type = C.DUCKDB_TYPE_VARCHAR TypeBlob Type = C.DUCKDB_TYPE_BLOB TypeDecimal Type = C.DUCKDB_TYPE_DECIMAL TypeTimestampS Type = C.DUCKDB_TYPE_TIMESTAMP_S TypeTimestampMS Type = C.DUCKDB_TYPE_TIMESTAMP_MS TypeTimestampNS Type = C.DUCKDB_TYPE_TIMESTAMP_NS TypeEnum Type = C.DUCKDB_TYPE_ENUM TypeList Type = C.DUCKDB_TYPE_LIST TypeStruct Type = C.DUCKDB_TYPE_STRUCT TypeMap Type = C.DUCKDB_TYPE_MAP TypeArray Type = C.DUCKDB_TYPE_ARRAY TypeUUID Type = C.DUCKDB_TYPE_UUID TypeUnion Type = C.DUCKDB_TYPE_UNION TypeBit Type = C.DUCKDB_TYPE_BIT TypeTimeTZ Type = C.DUCKDB_TYPE_TIME_TZ TypeTimestampTZ Type = C.DUCKDB_TYPE_TIMESTAMP_TZ TypeAny Type = C.DUCKDB_TYPE_ANY TypeBigNum Type = C.DUCKDB_TYPE_BIGNUM TypeSQLNull Type = C.DUCKDB_TYPE_SQLNULL TypeStringLiteral Type = C.DUCKDB_TYPE_STRING_LITERAL TypeIntegerLiteral Type = C.DUCKDB_TYPE_INTEGER_LITERAL TypeTimeNS Type = C.DUCKDB_TYPE_TIME_NS )
func ColumnType ¶
func DecimalInternalType ¶
func DecimalInternalType(logicalType LogicalType) Type
func EnumInternalType ¶
func EnumInternalType(logicalType LogicalType) Type
func GetTypeId ¶
func GetTypeId(logicalType LogicalType) Type
func ParamType ¶
func ParamType(preparedStmt PreparedStatement, index IdxT) Type
func PreparedStatementColumnType ¶ added in v0.1.19
func PreparedStatementColumnType(preparedStmt PreparedStatement, index IdxT) Type
type UHugeInt ¶
type UHugeInt = C.duckdb_uhugeint
func DoubleToUHugeInt ¶
func GetUHugeInt ¶
func NewUHugeInt ¶
NewUHugeInt sets the members of a duckdb_uhugeint.
type Value ¶
Value wraps *duckdb_value.
func BindGetNamedParameter ¶
BindGetNamedParameter wraps duckdb_bind_get_named_parameter. The return value must be destroyed with DestroyValue.
func BindGetParameter ¶
BindGetParameter wraps duckdb_bind_get_parameter. The return value must be destroyed with DestroyValue.
func CreateArrayValue ¶
func CreateArrayValue(logicalType LogicalType, values []Value) Value
CreateArrayValue wraps duckdb_create_array_value. The return value must be destroyed with DestroyValue.
func CreateBigNum ¶ added in v0.1.19
CreateBigNum wraps duckdb_create_bignum. The return value must be destroyed with DestroyValue.
func CreateBit ¶
CreateBit wraps duckdb_create_bit. The return value must be destroyed with DestroyValue.
func CreateBlob ¶
CreateBlob wraps duckdb_create_blob. The return value must be destroyed with DestroyValue.
func CreateBool ¶
CreateBool wraps duckdb_create_bool. The return value must be destroyed with DestroyValue.
func CreateDate ¶
CreateDate wraps duckdb_create_date. The return value must be destroyed with DestroyValue.
func CreateDecimal ¶
CreateDecimal wraps duckdb_create_decimal. The return value must be destroyed with DestroyValue.
func CreateDouble ¶
CreateDouble wraps duckdb_create_double. The return value must be destroyed with DestroyValue.
func CreateEnumValue ¶
func CreateEnumValue(logicalType LogicalType, val uint64) Value
CreateEnumValue wraps duckdb_create_enum_value. The return value must be destroyed with DestroyValue.
func CreateFloat ¶
CreateFloat wraps duckdb_create_float. The return value must be destroyed with DestroyValue.
func CreateHugeInt ¶
CreateHugeInt wraps duckdb_create_hugeint. The return value must be destroyed with DestroyValue.
func CreateInt16 ¶
CreateInt16 wraps duckdb_create_int16. The return value must be destroyed with DestroyValue.
func CreateInt32 ¶
CreateInt32 wraps duckdb_create_int32. The return value must be destroyed with DestroyValue.
func CreateInt64 ¶
CreateInt64 wraps duckdb_create_int64. The return value must be destroyed with DestroyValue.
func CreateInt8 ¶
CreateInt8 wraps duckdb_create_int8. The return value must be destroyed with DestroyValue.
func CreateInterval ¶
CreateInterval wraps duckdb_create_interval. The return value must be destroyed with DestroyValue.
func CreateListValue ¶
func CreateListValue(logicalType LogicalType, values []Value) Value
CreateListValue wraps duckdb_create_list_value. The return value must be destroyed with DestroyValue.
func CreateMapValue ¶
func CreateMapValue(logicalType LogicalType, keys []Value, values []Value) Value
CreateMapValue wraps duckdb_create_map_value. The return value must be destroyed with DestroyValue.
func CreateNullValue ¶
func CreateNullValue() Value
CreateNullValue wraps duckdb_create_null_value. The return value must be destroyed with DestroyValue.
func CreateStructValue ¶
func CreateStructValue(logicalType LogicalType, values []Value) Value
CreateStructValue wraps duckdb_create_struct_value. The return value must be destroyed with DestroyValue.
func CreateTime ¶
CreateTime wraps duckdb_create_time. The return value must be destroyed with DestroyValue.
func CreateTimeNS ¶ added in v0.1.19
CreateTimeNS wraps duckdb_create_time_ns. The return value must be destroyed with DestroyValue.
func CreateTimeTZValue ¶
CreateTimeTZValue wraps duckdb_create_time_tz_value. The return value must be destroyed with DestroyValue.
func CreateTimestamp ¶
CreateTimestamp wraps duckdb_create_timestamp. The return value must be destroyed with DestroyValue.
func CreateTimestampMS ¶
func CreateTimestampMS(val TimestampMS) Value
CreateTimestampMS wraps duckdb_create_timestamp_ms. The return value must be destroyed with DestroyValue.
func CreateTimestampNS ¶
func CreateTimestampNS(val TimestampNS) Value
CreateTimestampNS wraps duckdb_create_timestamp_ns. The return value must be destroyed with DestroyValue.
func CreateTimestampS ¶
func CreateTimestampS(val TimestampS) Value
CreateTimestampS wraps duckdb_create_timestamp_s. The return value must be destroyed with DestroyValue.
func CreateTimestampTZ ¶
CreateTimestampTZ wraps duckdb_create_timestamp_tz. The return value must be destroyed with DestroyValue.
func CreateUHugeInt ¶
CreateUHugeInt wraps duckdb_create_uhugeint. The return value must be destroyed with DestroyValue.
func CreateUInt16 ¶
CreateUInt16 wraps duckdb_create_uint16. The return value must be destroyed with DestroyValue.
func CreateUInt32 ¶
CreateUInt32 wraps duckdb_create_uint32. The return value must be destroyed with DestroyValue.
func CreateUInt64 ¶
CreateUInt64 wraps duckdb_create_uint64. The return value must be destroyed with DestroyValue.
func CreateUInt8 ¶
CreateUInt8 wraps duckdb_create_uint8. The return value must be destroyed with DestroyValue.
func CreateUUID ¶
CreateUUID wraps duckdb_create_uuid. The return value must be destroyed with DestroyValue.
func CreateUnionValue ¶
func CreateUnionValue(logicalType LogicalType, tag IdxT, value Value) Value
CreateUnionValue wraps duckdb_create_union_value. The return value must be destroyed with DestroyValue.
func CreateVarchar ¶
CreateVarchar wraps duckdb_create_varchar. The return value must be destroyed with DestroyValue.
func CreateVarcharLength ¶
CreateVarcharLength wraps duckdb_create_varchar_length. The return value must be destroyed with DestroyValue.
func GetListChild ¶
GetListChild wraps duckdb_get_list_child. The return value must be destroyed with DestroyValue.
func GetMapKey ¶
GetMapKey wraps duckdb_get_map_key. The return value must be destroyed with DestroyValue.
func GetMapValue ¶
GetMapValue wraps duckdb_get_map_value. The return value must be destroyed with DestroyValue.
func GetStructChild ¶
GetStructChild wraps duckdb_get_struct_child. The return value must be destroyed with DestroyValue.
func GetTableNames ¶
func GetTableNames(conn Connection, query string, qualified bool) Value
GetTableNames wraps duckdb_get_table_names. The return value must be destroyed with DestroyValue.
func ProfilingInfoGetMetrics ¶
func ProfilingInfoGetMetrics(info ProfilingInfo) Value
ProfilingInfoGetMetrics wraps duckdb_profiling_info_get_metrics. The return value must be destroyed with DestroyValue.
func ProfilingInfoGetValue ¶
func ProfilingInfoGetValue(info ProfilingInfo, key string) Value
ProfilingInfoGetValue wraps duckdb_profiling_info_get_value. The return value must be destroyed with DestroyValue.
type Vector ¶
Vector wraps *duckdb_vector.
func ArrayVectorGetChild ¶
func CreateVector ¶
func CreateVector(logicalType LogicalType, capacity IdxT) Vector
CreateVector wraps duckdb_create_vector. The return value must be destroyed with DestroyVector.
func DataChunkGetVector ¶
func ListVectorGetChild ¶
func StructVectorGetChild ¶
Directories
¶
Path | Synopsis |
---|---|
darwin-amd64
module
|
|
darwin-arm64
module
|
|
darwin_amd64
module
|
|
darwin_arm64
module
|
|
linux-amd64
module
|
|
linux-arm64
module
|
|
linux_amd64
module
|
|
linux_arm64
module
|
|
windows-amd64
module
|
|
windows_amd64
module
|