PostgreSQL format codes
const ( TextFormatCode = 0 BinaryFormatCode = 1 )
var ( // ErrNoRows occurs when rows are expected but none are returned. ErrNoRows = errors.New("no rows in result set") // ErrTooManyRows occurs when more rows than expected are returned. ErrTooManyRows = errors.New("too many rows in result set") )
var ErrTxClosed = errors.New("tx is closed")
ErrTxCommitRollback occurs when an error has occurred in a transaction and Commit() is called. PostgreSQL accepts COMMIT on aborted transactions, but it is treated as ROLLBACK.
var ErrTxCommitRollback = errors.New("commit unexpectedly resulted in rollback")
func AppendRows[T any, S ~[]T](slice S, rows Rows, fn RowToFunc[T]) (S, error)
AppendRows iterates through rows, calling fn for each row, and appending the results into a slice of T.
func BeginFunc( ctx context.Context, db interface { Begin(ctx context.Context) (Tx, error) }, fn func(Tx) error, ) (err error)
BeginFunc calls Begin on db and then calls fn. If fn does not return an error then it calls Commit on db. If fn returns an error it calls Rollback on db. The context will be used when executing the transaction control statements (BEGIN, ROLLBACK, and COMMIT) but does not otherwise affect the execution of fn.
func BeginTxFunc( ctx context.Context, db interface { BeginTx(ctx context.Context, txOptions TxOptions) (Tx, error) }, txOptions TxOptions, fn func(Tx) error, ) (err error)
BeginTxFunc calls BeginTx on db and then calls fn. If fn does not return an error then it calls Commit on db. If fn returns an error it calls Rollback on db. The context will be used when executing the transaction control statements (BEGIN, ROLLBACK, and COMMIT) but does not otherwise affect the execution of fn.
func CollectExactlyOneRow[T any](rows Rows, fn RowToFunc[T]) (T, error)
CollectExactlyOneRow calls fn for the first row in rows and returns the result.
func CollectOneRow[T any](rows Rows, fn RowToFunc[T]) (T, error)
CollectOneRow calls fn for the first row in rows and returns the result. If no rows are found returns an error where errors.Is(ErrNoRows) is true. CollectOneRow is to CollectRows as QueryRow is to Query.
func CollectRows[T any](rows Rows, fn RowToFunc[T]) ([]T, error)
CollectRows iterates through rows, calling fn for each row, and collecting the results into a slice of T.
▹ Example
func ForEachRow(rows Rows, scans []any, fn func() error) (pgconn.CommandTag, error)
ForEachRow iterates through rows. For each row it scans into the elements of scans and calls fn. If any row fails to scan or fn returns an error the query will be aborted and the error will be returned. Rows will be closed when ForEachRow returns.
▹ Example
func RowTo[T any](row CollectableRow) (T, error)
RowTo returns a T scanned from row.
▹ Example
func RowToAddrOf[T any](row CollectableRow) (*T, error)
RowTo returns a the address of a T scanned from row.
▹ Example
func RowToAddrOfStructByName[T any](row CollectableRow) (*T, error)
RowToAddrOfStructByName returns the address of a T scanned from row. T must be a struct. T must have the same number of named public fields as row has fields. The row and T fields will be matched by name. The match is case-insensitive. The database column name can be overridden with a "db" struct tag. If the "db" struct tag is "-" then the field will be ignored.
func RowToAddrOfStructByNameLax[T any](row CollectableRow) (*T, error)
RowToAddrOfStructByNameLax returns the address of a T scanned from row. T must be a struct. T must have greater than or equal number of named public fields as row has fields. The row and T fields will be matched by name. The match is case-insensitive. The database column name can be overridden with a "db" struct tag. If the "db" struct tag is "-" then the field will be ignored.
func RowToAddrOfStructByPos[T any](row CollectableRow) (*T, error)
RowToAddrOfStructByPos returns the address of a T scanned from row. T must be a struct. T must have the same number a public fields as row has fields. The row and T fields will be matched by position. If the "db" struct tag is "-" then the field will be ignored.
func RowToMap(row CollectableRow) (map[string]any, error)
RowToMap returns a map scanned from row.
func RowToStructByName[T any](row CollectableRow) (T, error)
RowToStructByName returns a T scanned from row. T must be a struct. T must have the same number of named public fields as row has fields. The row and T fields will be matched by name. The match is case-insensitive. The database column name can be overridden with a "db" struct tag. If the "db" struct tag is "-" then the field will be ignored.
▹ Example
func RowToStructByNameLax[T any](row CollectableRow) (T, error)
RowToStructByNameLax returns a T scanned from row. T must be a struct. T must have greater than or equal number of named public fields as row has fields. The row and T fields will be matched by name. The match is case-insensitive. The database column name can be overridden with a "db" struct tag. If the "db" struct tag is "-" then the field will be ignored.
▹ Example
func RowToStructByPos[T any](row CollectableRow) (T, error)
RowToStructByPos returns a T scanned from row. T must be a struct. T must have the same number a public fields as row has fields. The row and T fields will be matched by position. If the "db" struct tag is "-" then the field will be ignored.
▹ Example
func ScanRow(typeMap *pgtype.Map, fieldDescriptions []pgconn.FieldDescription, values [][]byte, dest ...any) error
ScanRow decodes raw row data into dest. It can be used to scan rows read from the lower level pgconn interface.
typeMap - OID to Go type mapping. fieldDescriptions - OID and format of values values - the raw data as returned from the PostgreSQL server dest - the destination that values will be decoded into
Batch queries are a way of bundling multiple queries together to avoid unnecessary network round trips. A Batch must only be sent once.
type Batch struct { QueuedQueries []*QueuedQuery }
func (b *Batch) Len() int
Len returns number of queries that have been queued so far.
func (b *Batch) Queue(query string, arguments ...any) *QueuedQuery
Queue queues a query to batch b. query can be an SQL query or the name of a prepared statement. The only pgx option argument that is supported is QueryRewriter. Queries are executed using the connection's DefaultQueryExecMode.
type BatchResults interface { // Exec reads the results from the next query in the batch as if the query has been sent with Conn.Exec. Prefer // calling Exec on the QueuedQuery. Exec() (pgconn.CommandTag, error) // Query reads the results from the next query in the batch as if the query has been sent with Conn.Query. Prefer // calling Query on the QueuedQuery. Query() (Rows, error) // QueryRow reads the results from the next query in the batch as if the query has been sent with Conn.QueryRow. // Prefer calling QueryRow on the QueuedQuery. QueryRow() Row // Close closes the batch operation. All unread results are read and any callback functions registered with // QueuedQuery.Query, QueuedQuery.QueryRow, or QueuedQuery.Exec will be called. If a callback function returns an // error or the batch encounters an error subsequent callback functions will not be called. // // Close must be called before the underlying connection can be used again. Any error that occurred during a batch // operation may have made it impossible to resyncronize the connection with the server. In this case the underlying // connection will have been closed. // // Close is safe to call multiple times. If it returns an error subsequent calls will return the same error. Callback // functions will not be rerun. Close() error }
BatchTracer traces SendBatch.
type BatchTracer interface { // TraceBatchStart is called at the beginning of SendBatch calls. The returned context is used for the // rest of the call and will be passed to TraceBatchQuery and TraceBatchEnd. TraceBatchStart(ctx context.Context, conn *Conn, data TraceBatchStartData) context.Context TraceBatchQuery(ctx context.Context, conn *Conn, data TraceBatchQueryData) TraceBatchEnd(ctx context.Context, conn *Conn, data TraceBatchEndData) }
CollectableRow is the subset of Rows methods that a RowToFunc is allowed to call.
type CollectableRow interface { FieldDescriptions() []pgconn.FieldDescription Scan(dest ...any) error Values() ([]any, error) RawValues() [][]byte }
Conn is a PostgreSQL connection handle. It is not safe for concurrent usage. Use a connection pool to manage access to multiple database connections from multiple goroutines.
type Conn struct {
// contains filtered or unexported fields
}
func Connect(ctx context.Context, connString string) (*Conn, error)
Connect establishes a connection with a PostgreSQL server with a connection string. See pgconn.Connect for details.
func ConnectConfig(ctx context.Context, connConfig *ConnConfig) (*Conn, error)
ConnectConfig establishes a connection with a PostgreSQL server with a configuration struct. connConfig must have been created by ParseConfig.
func ConnectWithOptions(ctx context.Context, connString string, options ParseConfigOptions) (*Conn, error)
ConnectWithOptions behaves exactly like Connect with the addition of options. At the present options is only used to provide a GetSSLPassword function.
func (c *Conn) Begin(ctx context.Context) (Tx, error)
Begin starts a transaction. Unlike database/sql, the context only affects the begin command. i.e. there is no auto-rollback on context cancellation.
func (c *Conn) BeginTx(ctx context.Context, txOptions TxOptions) (Tx, error)
BeginTx starts a transaction with txOptions determining the transaction mode. Unlike database/sql, the context only affects the begin command. i.e. there is no auto-rollback on context cancellation.
func (c *Conn) Close(ctx context.Context) error
Close closes a connection. It is safe to call Close on an already closed connection.
func (c *Conn) Config() *ConnConfig
Config returns a copy of config that was used to establish this connection.
func (c *Conn) CopyFrom(ctx context.Context, tableName Identifier, columnNames []string, rowSrc CopyFromSource) (int64, error)
CopyFrom uses the PostgreSQL copy protocol to perform bulk data insertion. It returns the number of rows copied and an error.
CopyFrom requires all values use the binary format. A pgtype.Type that supports the binary format must be registered for the type of each column. Almost all types implemented by pgx support the binary format.
Even though enum types appear to be strings they still must be registered to use with CopyFrom. This can be done with Conn.LoadType and pgtype.Map.RegisterType.
func (c *Conn) Deallocate(ctx context.Context, name string) error
Deallocate releases a prepared statement. Calling Deallocate on a non-existent prepared statement will succeed.
func (c *Conn) DeallocateAll(ctx context.Context) error
DeallocateAll releases all previously prepared statements from the server and client, where it also resets the statement and description cache.
func (c *Conn) Exec(ctx context.Context, sql string, arguments ...any) (pgconn.CommandTag, error)
Exec executes sql. sql can be either a prepared statement name or an SQL string. arguments should be referenced positionally from the sql string as $1, $2, etc.
func (c *Conn) IsClosed() bool
IsClosed reports if the connection has been closed.
func (c *Conn) LoadType(ctx context.Context, typeName string) (*pgtype.Type, error)
LoadType inspects the database for typeName and produces a pgtype.Type suitable for registration. typeName must be the name of a type where the underlying type(s) is already understood by pgx. It is for derived types. In particular, typeName must be one of the following:
func (c *Conn) PgConn() *pgconn.PgConn
PgConn returns the underlying *pgconn.PgConn. This is an escape hatch method that allows lower level access to the PostgreSQL connection than pgx exposes.
It is strongly recommended that the connection be idle (no in-progress queries) before the underlying *pgconn.PgConn is used and the connection must be returned to the same state before any *pgx.Conn methods are again used.
func (c *Conn) Ping(ctx context.Context) error
Ping delegates to the underlying *pgconn.PgConn.Ping.
func (c *Conn) Prepare(ctx context.Context, name, sql string) (sd *pgconn.StatementDescription, err error)
Prepare creates a prepared statement with name and sql. sql can contain placeholders for bound parameters. These placeholders are referenced positionally as $1, $2, etc. name can be used instead of sql with Query, QueryRow, and Exec to execute the statement. It can also be used with Batch.Queue.
The underlying PostgreSQL identifier for the prepared statement will be name if name != sql or a digest of sql if name == sql.
Prepare is idempotent; i.e. it is safe to call Prepare multiple times with the same name and sql arguments. This allows a code path to Prepare and Query/Exec without concern for if the statement has already been prepared.
func (c *Conn) Query(ctx context.Context, sql string, args ...any) (Rows, error)
Query sends a query to the server and returns a Rows to read the results. Only errors encountered sending the query and initializing Rows will be returned. Err() on the returned Rows must be checked after the Rows is closed to determine if the query executed successfully.
The returned Rows must be closed before the connection can be used again. It is safe to attempt to read from the returned Rows even if an error is returned. The error will be the available in rows.Err() after rows are closed. It is allowed to ignore the error returned from Query and handle it in Rows.
It is possible for a call of FieldDescriptions on the returned Rows to return nil even if the Query call did not return an error.
It is possible for a query to return one or more rows before encountering an error. In most cases the rows should be collected before processing rather than processed while receiving each row. This avoids the possibility of the application processing rows from a query that the server rejected. The CollectRows function is useful here.
An implementor of QueryRewriter may be passed as the first element of args. It can rewrite the sql and change or replace args. For example, NamedArgs is QueryRewriter that implements named arguments.
For extra control over how the query is executed, the types QueryExecMode, QueryResultFormats, and QueryResultFormatsByOID may be used as the first args to control exactly how the query is executed. This is rarely needed. See the documentation for those types for details.
▹ Example
func (c *Conn) QueryRow(ctx context.Context, sql string, args ...any) Row
QueryRow is a convenience wrapper over Query. Any error that occurs while querying is deferred until calling Scan on the returned Row. That Row will error with ErrNoRows if no rows are returned.
func (c *Conn) SendBatch(ctx context.Context, b *Batch) (br BatchResults)
SendBatch sends all queued queries to the server at once. All queries are run in an implicit transaction unless explicit transaction control statements are executed. The returned BatchResults must be closed before the connection is used again.
▹ Example
func (c *Conn) TypeMap() *pgtype.Map
TypeMap returns the connection info used for this connection.
func (c *Conn) WaitForNotification(ctx context.Context) (*pgconn.Notification, error)
WaitForNotification waits for a PostgreSQL notification. It wraps the underlying pgconn notification system in a slightly more convenient form.
ConnConfig contains all the options used to establish a connection. It must be created by ParseConfig and then it can be modified. A manually initialized ConnConfig will cause ConnectConfig to panic.
type ConnConfig struct { pgconn.Config Tracer QueryTracer // StatementCacheCapacity is maximum size of the statement cache used when executing a query with "cache_statement" // query exec mode. StatementCacheCapacity int // DescriptionCacheCapacity is the maximum size of the description cache used when executing a query with // "cache_describe" query exec mode. DescriptionCacheCapacity int // DefaultQueryExecMode controls the default mode for executing queries. By default pgx uses the extended protocol // and automatically prepares and caches prepared statements. However, this may be incompatible with proxies such as // PGBouncer. In this case it may be preferable to use QueryExecModeExec or QueryExecModeSimpleProtocol. The same // functionality can be controlled on a per query basis by passing a QueryExecMode as the first query argument. DefaultQueryExecMode QueryExecMode // contains filtered or unexported fields }
func ParseConfig(connString string) (*ConnConfig, error)
ParseConfig creates a ConnConfig from a connection string. ParseConfig handles all options that pgconn.ParseConfig does. In addition, it accepts the following options:
default_query_exec_mode. Possible values: "cache_statement", "cache_describe", "describe_exec", "exec", and "simple_protocol". See QueryExecMode constant documentation for the meaning of these values. Default: "cache_statement".
statement_cache_capacity. The maximum size of the statement cache used when executing a query with "cache_statement" query exec mode. Default: 512.
description_cache_capacity. The maximum size of the description cache used when executing a query with "cache_describe" query exec mode. Default: 512.
func ParseConfigWithOptions(connString string, options ParseConfigOptions) (*ConnConfig, error)
ParseConfigWithOptions behaves exactly as ParseConfig does with the addition of options. At the present options is only used to provide a GetSSLPassword function.
func (cc *ConnConfig) ConnString() string
ConnString returns the connection string as parsed by pgx.ParseConfig into pgx.ConnConfig.
func (cc *ConnConfig) Copy() *ConnConfig
Copy returns a deep copy of the config that is safe to use and modify. The only exception is the tls.Config: according to the tls.Config docs it must not be modified after creation.
ConnectTracer traces Connect and ConnectConfig.
type ConnectTracer interface { // TraceConnectStart is called at the beginning of Connect and ConnectConfig calls. The returned context is used for // the rest of the call and will be passed to TraceConnectEnd. TraceConnectStart(ctx context.Context, data TraceConnectStartData) context.Context TraceConnectEnd(ctx context.Context, data TraceConnectEndData) }
CopyFromSource is the interface used by *Conn.CopyFrom as the source for copy data.
type CopyFromSource interface { // Next returns true if there is another row and makes the next row data // available to Values(). When there are no more rows available or an error // has occurred it returns false. Next() bool // Values returns the values for the current row. Values() ([]any, error) // Err returns any error that has been encountered by the CopyFromSource. If // this is not nil *Conn.CopyFrom will abort the copy. Err() error }
func CopyFromFunc(nxtf func() (row []any, err error)) CopyFromSource
CopyFromFunc returns a CopyFromSource interface that relies on nxtf for values. nxtf returns rows until it either signals an 'end of data' by returning row=nil and err=nil, or it returns an error. If nxtf returns an error, the copy is aborted.
func CopyFromRows(rows [][]any) CopyFromSource
CopyFromRows returns a CopyFromSource interface over the provided rows slice making it usable by *Conn.CopyFrom.
func CopyFromSlice(length int, next func(int) ([]any, error)) CopyFromSource
CopyFromSlice returns a CopyFromSource interface over a dynamic func making it usable by *Conn.CopyFrom.
CopyFromTracer traces CopyFrom.
type CopyFromTracer interface { // TraceCopyFromStart is called at the beginning of CopyFrom calls. The returned context is used for the // rest of the call and will be passed to TraceCopyFromEnd. TraceCopyFromStart(ctx context.Context, conn *Conn, data TraceCopyFromStartData) context.Context TraceCopyFromEnd(ctx context.Context, conn *Conn, data TraceCopyFromEndData) }
ExtendedQueryBuilder is used to choose the parameter formats, to format the parameters and to choose the result formats for an extended query.
type ExtendedQueryBuilder struct { ParamValues [][]byte ParamFormats []int16 ResultFormats []int16 // contains filtered or unexported fields }
func (eqb *ExtendedQueryBuilder) Build(m *pgtype.Map, sd *pgconn.StatementDescription, args []any) error
Build sets ParamValues, ParamFormats, and ResultFormats for use with *PgConn.ExecParams or *PgConn.ExecPrepared. If sd is nil then QueryExecModeExec behavior will be used.
Identifier a PostgreSQL identifier or name. Identifiers can be composed of multiple parts such as ["schema", "table"] or ["table", "column"].
type Identifier []string
func (ident Identifier) Sanitize() string
Sanitize returns a sanitized string safe for SQL interpolation.
A LargeObject is a large object stored on the server. It is only valid within the transaction that it was initialized in. It uses the context it was initialized with for all operations. It implements these interfaces:
io.Writer io.Reader io.Seeker io.Closer
type LargeObject struct {
// contains filtered or unexported fields
}
func (o *LargeObject) Close() error
Close the large object descriptor.
func (o *LargeObject) Read(p []byte) (int, error)
Read reads up to len(p) bytes into p returning the number of bytes read.
func (o *LargeObject) Seek(offset int64, whence int) (n int64, err error)
Seek moves the current location pointer to the new location specified by offset.
func (o *LargeObject) Tell() (n int64, err error)
Tell returns the current read or write location of the large object descriptor.
func (o *LargeObject) Truncate(size int64) (err error)
Truncate the large object to size.
func (o *LargeObject) Write(p []byte) (int, error)
Write writes p to the large object and returns the number of bytes written and an error if not all of p was written.
type LargeObjectMode int32
const ( LargeObjectModeWrite LargeObjectMode = 0x20000 LargeObjectModeRead LargeObjectMode = 0x40000 )
LargeObjects is a structure used to access the large objects API. It is only valid within the transaction where it was created.
For more details see: http://www.postgresql.org/docs/current/static/largeobjects.html
type LargeObjects struct {
// contains filtered or unexported fields
}
func (o *LargeObjects) Create(ctx context.Context, oid uint32) (uint32, error)
Create creates a new large object. If oid is zero, the server assigns an unused OID.
func (o *LargeObjects) Open(ctx context.Context, oid uint32, mode LargeObjectMode) (*LargeObject, error)
Open opens an existing large object with the given mode. ctx will also be used for all operations on the opened large object.
func (o *LargeObjects) Unlink(ctx context.Context, oid uint32) error
Unlink removes a large object from the database.
NamedArgs can be used as the first argument to a query method. It will replace every '@' named placeholder with a '$' ordinal placeholder and construct the appropriate arguments.
For example, the following two queries are equivalent:
conn.Query(ctx, "select * from widgets where foo = @foo and bar = @bar", pgx.NamedArgs{"foo": 1, "bar": 2}) conn.Query(ctx, "select * from widgets where foo = $1 and bar = $2", 1, 2)
Named placeholders are case sensitive and must start with a letter or underscore. Subsequent characters can be letters, numbers, or underscores.
type NamedArgs map[string]any
func (na NamedArgs) RewriteQuery(ctx context.Context, conn *Conn, sql string, args []any) (newSQL string, newArgs []any, err error)
RewriteQuery implements the QueryRewriter interface.
ParseConfigOptions contains options that control how a config is built such as getsslpassword.
type ParseConfigOptions struct { pgconn.ParseConfigOptions }
PrepareTracer traces Prepare.
type PrepareTracer interface { // TracePrepareStart is called at the beginning of Prepare calls. The returned context is used for the // rest of the call and will be passed to TracePrepareEnd. TracePrepareStart(ctx context.Context, conn *Conn, data TracePrepareStartData) context.Context TracePrepareEnd(ctx context.Context, conn *Conn, data TracePrepareEndData) }
type QueryExecMode int32
const ( // Automatically prepare and cache statements. This uses the extended protocol. Queries are executed in a single round // trip after the statement is cached. This is the default. If the database schema is modified or the search_path is // changed after a statement is cached then the first execution of a previously cached query may fail. e.g. If the // number of columns returned by a "SELECT *" changes or the type of a column is changed. QueryExecModeCacheStatement QueryExecMode // Cache statement descriptions (i.e. argument and result types) and assume they do not change. This uses the extended // protocol. Queries are executed in a single round trip after the description is cached. If the database schema is // modified or the search_path is changed after a statement is cached then the first execution of a previously cached // query may fail. e.g. If the number of columns returned by a "SELECT *" changes or the type of a column is changed. QueryExecModeCacheDescribe // Get the statement description on every execution. This uses the extended protocol. Queries require two round trips // to execute. It does not use named prepared statements. But it does use the unnamed prepared statement to get the // statement description on the first round trip and then uses it to execute the query on the second round trip. This // may cause problems with connection poolers that switch the underlying connection between round trips. It is safe // even when the the database schema is modified concurrently. QueryExecModeDescribeExec // Assume the PostgreSQL query parameter types based on the Go type of the arguments. This uses the extended protocol // with text formatted parameters and results. Queries are executed in a single round trip. Type mappings can be // registered with pgtype.Map.RegisterDefaultPgType. Queries will be rejected that have arguments that are // unregistered or ambiguous. e.g. A map[string]string may have the PostgreSQL type json or hstore. Modes that know // the PostgreSQL type can use a map[string]string directly as an argument. This mode cannot. QueryExecModeExec // Use the simple protocol. Assume the PostgreSQL query parameter types based on the Go type of the arguments. // Queries are executed in a single round trip. Type mappings can be registered with // pgtype.Map.RegisterDefaultPgType. Queries will be rejected that have arguments that are unregistered or ambiguous. // e.g. A map[string]string may have the PostgreSQL type json or hstore. Modes that know the PostgreSQL type can use // a map[string]string directly as an argument. This mode cannot. // // QueryExecModeSimpleProtocol should have the user application visible behavior as QueryExecModeExec with minor // exceptions such as behavior when multiple result returning queries are erroneously sent in a single string. // // QueryExecModeSimpleProtocol uses client side parameter interpolation. All values are quoted and escaped. Prefer // QueryExecModeExec over QueryExecModeSimpleProtocol whenever possible. In general QueryExecModeSimpleProtocol // should only be used if connecting to a proxy server, connection pool server, or non-PostgreSQL server that does // not support the extended protocol. QueryExecModeSimpleProtocol )
func (m QueryExecMode) String() string
QueryResultFormats controls the result format (text=0, binary=1) of a query by result column position.
type QueryResultFormats []int16
QueryResultFormatsByOID controls the result format (text=0, binary=1) of a query by the result column OID.
type QueryResultFormatsByOID map[uint32]int16
QueryRewriter rewrites a query when used as the first arguments to a query method.
type QueryRewriter interface { RewriteQuery(ctx context.Context, conn *Conn, sql string, args []any) (newSQL string, newArgs []any, err error) }
QueryTracer traces Query, QueryRow, and Exec.
type QueryTracer interface { // TraceQueryStart is called at the beginning of Query, QueryRow, and Exec calls. The returned context is used for the // rest of the call and will be passed to TraceQueryEnd. TraceQueryStart(ctx context.Context, conn *Conn, data TraceQueryStartData) context.Context TraceQueryEnd(ctx context.Context, conn *Conn, data TraceQueryEndData) }
QueuedQuery is a query that has been queued for execution via a Batch.
type QueuedQuery struct { SQL string Arguments []any // contains filtered or unexported fields }
func (qq *QueuedQuery) Exec(fn func(ct pgconn.CommandTag) error)
Exec sets fn to be called when the response to qq is received.
func (qq *QueuedQuery) Query(fn func(rows Rows) error)
Query sets fn to be called when the response to qq is received.
func (qq *QueuedQuery) QueryRow(fn func(row Row) error)
Query sets fn to be called when the response to qq is received.
Row is a convenience wrapper over Rows that is returned by QueryRow.
Row is an interface instead of a struct to allow tests to mock QueryRow. However, adding a method to an interface is technically a breaking change. Because of this the Row interface is partially excluded from semantic version requirements. Methods will not be removed or changed, but new methods may be added.
type Row interface { // Scan works the same as Rows. with the following exceptions. If no // rows were found it returns ErrNoRows. If multiple rows are returned it // ignores all but the first. Scan(dest ...any) error }
RowScanner scans an entire row at a time into the RowScanner.
type RowScanner interface { // ScanRows scans the row. ScanRow(rows Rows) error }
RowToFunc is a function that scans or otherwise converts row to a T.
type RowToFunc[T any] func(row CollectableRow) (T, error)
Rows is the result set returned from *Conn.Query. Rows must be closed before the *Conn can be used again. Rows are closed by explicitly calling Close(), calling Next() until it returns false, or when a fatal error occurs.
Once a Rows is closed the only methods that may be called are Close(), Err(), and CommandTag().
Rows is an interface instead of a struct to allow tests to mock Query. However, adding a method to an interface is technically a breaking change. Because of this the Rows interface is partially excluded from semantic version requirements. Methods will not be removed or changed, but new methods may be added.
type Rows interface { // Close closes the rows, making the connection ready for use again. It is safe // to call Close after rows is already closed. Close() // Err returns any error that occurred while reading. Err must only be called after the Rows is closed (either by // calling Close or by Next returning false). If it is called early it may return nil even if there was an error // executing the query. Err() error // CommandTag returns the command tag from this query. It is only available after Rows is closed. CommandTag() pgconn.CommandTag // FieldDescriptions returns the field descriptions of the columns. It may return nil. In particular this can occur // when there was an error executing the query. FieldDescriptions() []pgconn.FieldDescription // Next prepares the next row for reading. It returns true if there is another // row and false if no more rows are available or a fatal error has occurred. // It automatically closes rows when all rows are read. // // Callers should check rows.Err() after rows.Next() returns false to detect // whether result-set reading ended prematurely due to an error. See // Conn.Query for details. // // For simpler error handling, consider using the higher-level pgx v5 // CollectRows() and ForEachRow() helpers instead. Next() bool // Scan reads the values from the current row into dest values positionally. // dest can include pointers to core types, values implementing the Scanner // interface, and nil. nil will skip the value entirely. It is an error to // call Scan without first calling Next() and checking that it returned true. Scan(dest ...any) error // Values returns the decoded row values. As with Scan(), it is an error to // call Values without first calling Next() and checking that it returned // true. Values() ([]any, error) // RawValues returns the unparsed bytes of the row values. The returned data is only valid until the next Next // call or the Rows is closed. RawValues() [][]byte // Conn returns the underlying *Conn on which the query was executed. This may return nil if Rows did not come from a // *Conn (e.g. if it was created by RowsFromResultReader) Conn() *Conn }
func RowsFromResultReader(typeMap *pgtype.Map, resultReader *pgconn.ResultReader) Rows
RowsFromResultReader returns a Rows that will read from values resultReader and decode with typeMap. It can be used to read from the lower level pgconn interface.
type ScanArgError struct { ColumnIndex int Err error }
func (e ScanArgError) Error() string
func (e ScanArgError) Unwrap() error
type TraceBatchEndData struct { Err error }
type TraceBatchQueryData struct { SQL string Args []any CommandTag pgconn.CommandTag Err error }
type TraceBatchStartData struct { Batch *Batch }
type TraceConnectEndData struct { Conn *Conn Err error }
type TraceConnectStartData struct { ConnConfig *ConnConfig }
type TraceCopyFromEndData struct { CommandTag pgconn.CommandTag Err error }
type TraceCopyFromStartData struct { TableName Identifier ColumnNames []string }
type TracePrepareEndData struct { AlreadyPrepared bool Err error }
type TracePrepareStartData struct { Name string SQL string }
type TraceQueryEndData struct { CommandTag pgconn.CommandTag Err error }
type TraceQueryStartData struct { SQL string Args []any }
Tx represents a database transaction.
Tx is an interface instead of a struct to enable connection pools to be implemented without relying on internal pgx state, to support pseudo-nested transactions with savepoints, and to allow tests to mock transactions. However, adding a method to an interface is technically a breaking change. If new methods are added to Conn it may be desirable to add them to Tx as well. Because of this the Tx interface is partially excluded from semantic version requirements. Methods will not be removed or changed, but new methods may be added.
type Tx interface { // Begin starts a pseudo nested transaction. Begin(ctx context.Context) (Tx, error) // Commit commits the transaction if this is a real transaction or releases the savepoint if this is a pseudo nested // transaction. Commit will return an error where errors.Is(ErrTxClosed) is true if the Tx is already closed, but is // otherwise safe to call multiple times. If the commit fails with a rollback status (e.g. the transaction was already // in a broken state) then an error where errors.Is(ErrTxCommitRollback) is true will be returned. Commit(ctx context.Context) error // Rollback rolls back the transaction if this is a real transaction or rolls back to the savepoint if this is a // pseudo nested transaction. Rollback will return an error where errors.Is(ErrTxClosed) is true if the Tx is already // closed, but is otherwise safe to call multiple times. Hence, a defer tx.Rollback() is safe even if tx.Commit() will // be called first in a non-error condition. Any other failure of a real transaction will result in the connection // being closed. Rollback(ctx context.Context) error CopyFrom(ctx context.Context, tableName Identifier, columnNames []string, rowSrc CopyFromSource) (int64, error) SendBatch(ctx context.Context, b *Batch) BatchResults LargeObjects() LargeObjects Prepare(ctx context.Context, name, sql string) (*pgconn.StatementDescription, error) Exec(ctx context.Context, sql string, arguments ...any) (commandTag pgconn.CommandTag, err error) Query(ctx context.Context, sql string, args ...any) (Rows, error) QueryRow(ctx context.Context, sql string, args ...any) Row // Conn returns the underlying *Conn that on which this transaction is executing. Conn() *Conn }
TxAccessMode is the transaction access mode (read write or read only)
type TxAccessMode string
Transaction access modes
const ( ReadWrite TxAccessMode = "read write" ReadOnly TxAccessMode = "read only" )
TxDeferrableMode is the transaction deferrable mode (deferrable or not deferrable)
type TxDeferrableMode string
Transaction deferrable modes
const ( Deferrable TxDeferrableMode = "deferrable" NotDeferrable TxDeferrableMode = "not deferrable" )
TxIsoLevel is the transaction isolation level (serializable, repeatable read, read committed or read uncommitted)
type TxIsoLevel string
Transaction isolation levels
const ( Serializable TxIsoLevel = "serializable" RepeatableRead TxIsoLevel = "repeatable read" ReadCommitted TxIsoLevel = "read committed" ReadUncommitted TxIsoLevel = "read uncommitted" )
TxOptions are transaction modes within a transaction block
type TxOptions struct { IsoLevel TxIsoLevel AccessMode TxAccessMode DeferrableMode TxDeferrableMode // BeginQuery is the SQL query that will be executed to begin the transaction. This allows using non-standard syntax // such as BEGIN PRIORITY HIGH with CockroachDB. If set this will override the other settings. BeginQuery string }
Name | Synopsis |
---|---|
.. | |
examples | |
chat | |
todo | |
url_shortener | |
log | |
testingadapter | Package testingadapter provides a logger that writes to a test or benchmark log. |
pgconn | Package pgconn is a low-level PostgreSQL database driver. |
pgproto3 | Package pgproto3 is an encoder and decoder of the PostgreSQL wire protocol version 3. |
example | |
pgfortune | |
pgtype | Package pgtype converts between Go and PostgreSQL values. |
zeronull | Package zeronull contains types that automatically convert between database NULLs and Go zero values. |
pgxpool | Package pgxpool is a concurrency-safe connection pool for pgx. |
pgxtest | Package pgxtest provides utilities for testing pgx and packages that integrate with pgx. |
stdlib | Package stdlib is the compatibility layer from pgx to database/sql. |
testsetup | |
tracelog | Package tracelog provides a tracer that acts as a traditional logger. |