package io

Import Path
	io (on go.dev)

Dependency Relation
	imports 2 packages, and imported by 401 packages

Involved Source Files Package io provides basic interfaces to I/O primitives. Its primary job is to wrap existing implementations of such primitives, such as those in package os, into shared public interfaces that abstract the functionality, plus some other related primitives. Because these interfaces and primitives wrap lower-level operations with various implementations, unless otherwise informed clients should not assume they are safe for parallel execution. multi.go pipe.go
Code Examples package main import ( "io" "log" "os" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") if _, err := io.Copy(os.Stdout, r); err != nil { log.Fatal(err) } } package main import ( "io" "log" "os" "strings" ) func main() { r1 := strings.NewReader("first reader\n") r2 := strings.NewReader("second reader\n") buf := make([]byte, 8) // buf is used here... if _, err := io.CopyBuffer(os.Stdout, r1, buf); err != nil { log.Fatal(err) } // ... reused here also. No need to allocate an extra buffer. if _, err := io.CopyBuffer(os.Stdout, r2, buf); err != nil { log.Fatal(err) } } package main import ( "io" "log" "os" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read") if _, err := io.CopyN(os.Stdout, r, 4); err != nil { log.Fatal(err) } } package main import ( "io" "log" "os" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") lr := io.LimitReader(r, 4) if _, err := io.Copy(os.Stdout, lr); err != nil { log.Fatal(err) } } package main import ( "io" "log" "os" "strings" ) func main() { r1 := strings.NewReader("first reader ") r2 := strings.NewReader("second reader ") r3 := strings.NewReader("third reader\n") r := io.MultiReader(r1, r2, r3) if _, err := io.Copy(os.Stdout, r); err != nil { log.Fatal(err) } } package main import ( "fmt" "io" "log" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") var buf1, buf2 strings.Builder w := io.MultiWriter(&buf1, &buf2) if _, err := io.Copy(w, r); err != nil { log.Fatal(err) } fmt.Print(buf1.String()) fmt.Print(buf2.String()) } package main import ( "fmt" "io" "log" "os" ) func main() { r, w := io.Pipe() go func() { fmt.Fprint(w, "some io.Reader stream to be read\n") w.Close() }() if _, err := io.Copy(os.Stdout, r); err != nil { log.Fatal(err) } } package main import ( "fmt" "io" "log" "strings" ) func main() { r := strings.NewReader("Go is a general-purpose language designed with systems programming in mind.") b, err := io.ReadAll(r) if err != nil { log.Fatal(err) } fmt.Printf("%s", b) } package main import ( "fmt" "io" "log" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") buf := make([]byte, 14) if _, err := io.ReadAtLeast(r, buf, 4); err != nil { log.Fatal(err) } fmt.Printf("%s\n", buf) // buffer smaller than minimal read size. shortBuf := make([]byte, 3) if _, err := io.ReadAtLeast(r, shortBuf, 4); err != nil { fmt.Println("error:", err) } // minimal read size bigger than io.Reader stream longBuf := make([]byte, 64) if _, err := io.ReadAtLeast(r, longBuf, 64); err != nil { fmt.Println("error:", err) } } package main import ( "fmt" "io" "log" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") buf := make([]byte, 4) if _, err := io.ReadFull(r, buf); err != nil { log.Fatal(err) } fmt.Printf("%s\n", buf) // minimal read size bigger than io.Reader stream longBuf := make([]byte, 64) if _, err := io.ReadFull(r, longBuf); err != nil { fmt.Println("error:", err) } } package main import ( "io" "log" "os" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") s := io.NewSectionReader(r, 5, 17) if _, err := io.Copy(os.Stdout, s); err != nil { log.Fatal(err) } } package main import ( "fmt" "io" "log" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") s := io.NewSectionReader(r, 5, 17) buf := make([]byte, 9) if _, err := s.Read(buf); err != nil { log.Fatal(err) } fmt.Printf("%s\n", buf) } package main import ( "fmt" "io" "log" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") s := io.NewSectionReader(r, 5, 17) buf := make([]byte, 6) if _, err := s.ReadAt(buf, 10); err != nil { log.Fatal(err) } fmt.Printf("%s\n", buf) } package main import ( "io" "log" "os" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") s := io.NewSectionReader(r, 5, 17) if _, err := s.Seek(10, io.SeekStart); err != nil { log.Fatal(err) } if _, err := io.Copy(os.Stdout, s); err != nil { log.Fatal(err) } } package main import ( "fmt" "io" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") s := io.NewSectionReader(r, 5, 17) fmt.Println(s.Size()) } package main import ( "io" "log" "os" "strings" ) func main() { r := strings.NewReader("some io.Reader stream to be read\n") r.Seek(5, io.SeekStart) // move to the 5th char from the start if _, err := io.Copy(os.Stdout, r); err != nil { log.Fatal(err) } r.Seek(-5, io.SeekEnd) if _, err := io.Copy(os.Stdout, r); err != nil { log.Fatal(err) } } package main import ( "io" "log" "os" "strings" ) func main() { var r io.Reader = strings.NewReader("some io.Reader stream to be read\n") r = io.TeeReader(r, os.Stdout) // Everything read from r will be copied to stdout. if _, err := io.ReadAll(r); err != nil { log.Fatal(err) } } package main import ( "io" "log" "os" ) func main() { if _, err := io.WriteString(os.Stdout, "Hello World"); err != nil { log.Fatal(err) } }
Package-Level Type Names (total 27)
/* sort by: | */
ByteReader is the interface that wraps the ReadByte method. ReadByte reads and returns the next byte from the input or any error encountered. If ReadByte returns an error, no input byte was consumed, and the returned byte value is undefined. ReadByte provides an efficient interface for byte-at-time processing. A [Reader] that does not implement ByteReader can be wrapped using bufio.NewReader to add this method. ( ByteReader) ReadByte() (byte, error) ByteScanner (interface) *bufio.Reader bufio.ReadWriter *bytes.Buffer *bytes.Reader compress/flate.Reader (interface) *github.com/apache/thrift/lib/go/thrift.RichTransport *github.com/apache/thrift/lib/go/thrift.StreamTransport github.com/apache/thrift/lib/go/thrift.TBufferedTransport *github.com/apache/thrift/lib/go/thrift.TFramedTransport *github.com/apache/thrift/lib/go/thrift.THttpClient github.com/apache/thrift/lib/go/thrift.TMemoryBuffer github.com/apache/thrift/lib/go/thrift.TRichTransport (interface) *github.com/golang/snappy.Reader github.com/klauspost/compress/flate.Reader (interface) *github.com/klauspost/compress/internal/snapref.Reader *github.com/klauspost/compress/s2.Reader github.com/klauspost/compress/s2.ReadSeeker *github.com/libp2p/go-buffer-pool.Buffer *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/util.DelimitedReader github.com/quic-go/quic-go/quicvarint.Reader (interface) google.golang.org/grpc/mem.Reader (interface) google.golang.org/protobuf/encoding/protodelim.Reader (interface) *strings.Reader func encoding/binary.ReadUvarint(r ByteReader) (uint64, error) func encoding/binary.ReadVarint(r ByteReader) (int64, error) func github.com/go-sourcemap/sourcemap/internal/base64vlq.NewDecoder(r ByteReader) base64vlq.Decoder func github.com/multiformats/go-varint.ReadUvarint(r ByteReader) (uint64, error) func github.com/quic-go/quic-go/quicvarint.Read(r ByteReader) (uint64, error) func github.com/tetratelabs/wazero/internal/leb128.DecodeInt32(r ByteReader) (ret int32, bytesRead uint64, err error) func github.com/tetratelabs/wazero/internal/leb128.DecodeInt33AsInt64(r ByteReader) (ret int64, bytesRead uint64, err error) func github.com/tetratelabs/wazero/internal/leb128.DecodeInt64(r ByteReader) (ret int64, bytesRead uint64, err error) func github.com/tetratelabs/wazero/internal/leb128.DecodeUint32(r ByteReader) (ret uint32, bytesRead uint64, err error)
ByteScanner is the interface that adds the UnreadByte method to the basic ReadByte method. UnreadByte causes the next call to ReadByte to return the last byte read. If the last operation was not a successful call to ReadByte, UnreadByte may return an error, unread the last byte read (or the byte prior to the last-unread byte), or (in implementations that support the [Seeker] interface) seek to one byte before the current offset. ( ByteScanner) ReadByte() (byte, error) ( ByteScanner) UnreadByte() error *bufio.Reader bufio.ReadWriter *bytes.Buffer *bytes.Reader github.com/apache/thrift/lib/go/thrift.TBufferedTransport github.com/apache/thrift/lib/go/thrift.TMemoryBuffer *strings.Reader ByteScanner : ByteReader
ByteWriter is the interface that wraps the WriteByte method. ( ByteWriter) WriteByte(c byte) error bufio.ReadWriter *bufio.Writer *bytes.Buffer *github.com/apache/thrift/lib/go/thrift.RichTransport *github.com/apache/thrift/lib/go/thrift.StreamTransport github.com/apache/thrift/lib/go/thrift.TBufferedTransport *github.com/apache/thrift/lib/go/thrift.TFramedTransport *github.com/apache/thrift/lib/go/thrift.THttpClient github.com/apache/thrift/lib/go/thrift.TMemoryBuffer github.com/apache/thrift/lib/go/thrift.TRichTransport (interface) *github.com/libp2p/go-buffer-pool.Buffer *github.com/libp2p/go-buffer-pool.Writer github.com/quic-go/quic-go/quicvarint.Writer (interface) github.com/redis/go-redis/v9/internal/proto.Writer github.com/yuin/goldmark/util.BufWriter (interface) *github.com/yuin/goldmark/util.CopyOnWriteBuffer *go.uber.org/zap/buffer.Buffer *gorm.io/gorm.Statement gorm.io/gorm/clause.Builder (interface) gorm.io/gorm/clause.Writer (interface) *hash/maphash.Hash *log/slog/internal/buffer.Buffer mvdan.cc/sh/v3/syntax.Printer net/http/internal.FlushAfterChunkWriter *strings.Builder func github.com/go-sourcemap/sourcemap/internal/base64vlq.NewEncoder(w ByteWriter) *base64vlq.Encoder
Closer is the interface that wraps the basic Close method. The behavior of Close after the first call is undefined. Specific implementations may document their own behavior. ( Closer) Close() error *PipeReader *PipeWriter ReadCloser (interface) ReadSeekCloser (interface) ReadWriteCloser (interface) WriteCloser (interface) io/fs.File (interface) io/fs.ReadDirFile (interface) *compress/flate.Writer *compress/gzip.Reader *compress/gzip.Writer *compress/zlib.Writer crypto/cipher.StreamWriter *crypto/tls.Conn *crypto/tls.QUICConn *database/sql.Conn *database/sql.DB *database/sql.Rows *database/sql.Stmt database/sql/driver.Conn (interface) database/sql/driver.Rows (interface) database/sql/driver.RowsColumnTypeDatabaseTypeName (interface) database/sql/driver.RowsColumnTypeLength (interface) database/sql/driver.RowsColumnTypeNullable (interface) database/sql/driver.RowsColumnTypePrecisionScale (interface) database/sql/driver.RowsColumnTypeScanType (interface) database/sql/driver.RowsNextResultSet (interface) database/sql/driver.Stmt (interface) *encoding/xml.Encoder *github.com/andybalholm/brotli.Writer *github.com/andybalholm/brotli/matchfinder.Writer *github.com/apache/arrow-go/v18/arrow/ipc.FileReader *github.com/apache/arrow-go/v18/arrow/ipc.FileWriter github.com/apache/arrow-go/v18/arrow/ipc.PayloadWriter (interface) *github.com/apache/arrow-go/v18/arrow/ipc.Writer github.com/apache/thrift/lib/go/thrift.RichTransport *github.com/apache/thrift/lib/go/thrift.StreamTransport *github.com/apache/thrift/lib/go/thrift.TBufferedTransport *github.com/apache/thrift/lib/go/thrift.TFramedTransport *github.com/apache/thrift/lib/go/thrift.THeaderTransport *github.com/apache/thrift/lib/go/thrift.THttpClient *github.com/apache/thrift/lib/go/thrift.TMemoryBuffer *github.com/apache/thrift/lib/go/thrift.TransformReader *github.com/apache/thrift/lib/go/thrift.TransformWriter *github.com/apache/thrift/lib/go/thrift.TServerSocket github.com/apache/thrift/lib/go/thrift.TServerTransport (interface) *github.com/apache/thrift/lib/go/thrift.TSocket *github.com/apache/thrift/lib/go/thrift.TSSLServerSocket *github.com/apache/thrift/lib/go/thrift.TSSLSocket github.com/apache/thrift/lib/go/thrift.TTransport (interface) *github.com/apache/thrift/lib/go/thrift.TZlibTransport *github.com/cenkalti/rpc2.Client github.com/cenkalti/rpc2.Codec (interface) *github.com/chromedp/chromedp.Conn github.com/chromedp/chromedp.Transport (interface) github.com/coreos/etcd/pkg/fileutil.LockedFile *github.com/fsnotify/fsnotify.Watcher github.com/gdamore/tcell/v2.Tty (interface) *github.com/gliderlabs/ssh.Server github.com/gliderlabs/ssh.Session (interface) *github.com/golang/snappy.Writer *github.com/gorilla/websocket.Conn *github.com/hamba/avro/v2/ocf.Encoder *github.com/hibiken/asynq.Client *github.com/hibiken/asynq.Inspector github.com/hibiken/asynq/internal/base.Broker (interface) *github.com/hibiken/asynq/internal/rdb.RDB *github.com/huin/goupnp/httpu.HTTPUClient *github.com/ipfs/go-log/v2.PipeReader *github.com/klauspost/compress/flate.Writer *github.com/klauspost/compress/gzip.Reader *github.com/klauspost/compress/gzip.Writer *github.com/klauspost/compress/internal/snapref.Writer *github.com/klauspost/compress/s2.Writer *github.com/klauspost/compress/zstd.Encoder *github.com/koron/go-ssdp.Advertiser *github.com/koron/go-ssdp.Monitor *github.com/koron/go-ssdp/internal/multicast.Conn *github.com/libp2p/go-buffer-pool.Writer github.com/libp2p/go-libp2p/core/connmgr.ConnManager (interface) github.com/libp2p/go-libp2p/core/connmgr.Decayer (interface) github.com/libp2p/go-libp2p/core/connmgr.DecayingTag (interface) github.com/libp2p/go-libp2p/core/connmgr.NullConnMgr github.com/libp2p/go-libp2p/core/event.Emitter (interface) github.com/libp2p/go-libp2p/core/event.Subscription (interface) github.com/libp2p/go-libp2p/core/host.Host (interface) github.com/libp2p/go-libp2p/core/network.Conn (interface) github.com/libp2p/go-libp2p/core/network.MuxedConn (interface) github.com/libp2p/go-libp2p/core/network.MuxedStream (interface) github.com/libp2p/go-libp2p/core/network.Network (interface) *github.com/libp2p/go-libp2p/core/network.NullResourceManager github.com/libp2p/go-libp2p/core/network.ResourceManager (interface) github.com/libp2p/go-libp2p/core/network.Stream (interface) github.com/libp2p/go-libp2p/core/peerstore.Peerstore (interface) github.com/libp2p/go-libp2p/core/sec.SecureConn (interface) github.com/libp2p/go-libp2p/core/sec/insecure.Conn github.com/libp2p/go-libp2p/core/transport.CapableConn (interface) github.com/libp2p/go-libp2p/core/transport.GatedMaListener (interface) github.com/libp2p/go-libp2p/core/transport.Listener (interface) github.com/libp2p/go-libp2p/core/transport.TransportNetwork (interface) *github.com/libp2p/go-libp2p/p2p/host/autonat.AmbientAutoNAT github.com/libp2p/go-libp2p/p2p/host/autonat.AutoNAT (interface) *github.com/libp2p/go-libp2p/p2p/host/autonat.StaticAutoNAT *github.com/libp2p/go-libp2p/p2p/host/autorelay.AutoRelay *github.com/libp2p/go-libp2p/p2p/host/basic.BasicHost github.com/libp2p/go-libp2p/p2p/host/basic.NATManager (interface) *github.com/libp2p/go-libp2p/p2p/host/blank.BlankHost *github.com/libp2p/go-libp2p/p2p/host/pstoremanager.PeerstoreManager *github.com/libp2p/go-libp2p/p2p/host/relaysvc.RelayManager *github.com/libp2p/go-libp2p/p2p/host/routed.RoutedHost *github.com/libp2p/go-libp2p/p2p/net/connmgr.BasicConnMgr *github.com/libp2p/go-libp2p/p2p/net/nat.NAT *github.com/libp2p/go-libp2p/p2p/net/swarm.Conn *github.com/libp2p/go-libp2p/p2p/net/swarm.Stream *github.com/libp2p/go-libp2p/p2p/net/swarm.Swarm *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.Client *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.Conn *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.Listener *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/relay.Relay *github.com/libp2p/go-libp2p/p2p/protocol/holepunch.Service github.com/libp2p/go-libp2p/p2p/protocol/identify.IDService (interface) *github.com/libp2p/go-libp2p/p2p/protocol/identify.ObservedAddrManager *github.com/libp2p/go-libp2p/p2p/transport/quicreuse.ConnManager github.com/libp2p/go-libp2p/p2p/transport/quicreuse.Listener (interface) github.com/libp2p/go-libp2p/p2p/transport/quicreuse.QUICListener (interface) github.com/libp2p/go-libp2p/p2p/transport/quicreuse.QUICTransport (interface) github.com/libp2p/go-libp2p/p2p/transport/quicreuse.RefCountedQUICTransport (interface) github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface (interface) *github.com/libp2p/go-libp2p/p2p/transport/webrtc/udpmux.UDPMux *github.com/libp2p/go-libp2p/p2p/transport/websocket.Conn *github.com/libp2p/go-libp2p-pubsub.Topic github.com/libp2p/go-msgio.ReadCloser (interface) github.com/libp2p/go-msgio.ReadWriteCloser (interface) github.com/libp2p/go-msgio.WriteCloser (interface) github.com/libp2p/go-msgio/pbio.ReadCloser (interface) github.com/libp2p/go-msgio/pbio.WriteCloser (interface) github.com/libp2p/go-msgio/protoio.ReadCloser (interface) github.com/libp2p/go-msgio/protoio.WriteCloser (interface) *github.com/libp2p/go-yamux/v5.Session *github.com/libp2p/go-yamux/v5.Stream github.com/marten-seemann/tcp.Conn github.com/miekg/dns.Conn github.com/miekg/dns.ResponseWriter (interface) github.com/miekg/dns.Transfer github.com/multiformats/go-multiaddr/net.Conn (interface) github.com/multiformats/go-multiaddr/net.Listener (interface) github.com/multiformats/go-multiaddr/net.PacketConn (interface) github.com/multiformats/go-multistream.LazyConn (interface) github.com/nats-io/nats.go.ObjectResult (interface) *github.com/ncruces/go-sqlite3.Backup *github.com/ncruces/go-sqlite3.Blob *github.com/ncruces/go-sqlite3.Conn *github.com/ncruces/go-sqlite3.Stmt *github.com/ncruces/go-sqlite3.Value github.com/ncruces/go-sqlite3/driver.Conn (interface) github.com/ncruces/go-sqlite3/vfs.File (interface) github.com/ncruces/go-sqlite3/vfs.FileBatchAtomicWrite (interface) github.com/ncruces/go-sqlite3/vfs.FileBusyHandler (interface) github.com/ncruces/go-sqlite3/vfs.FileCheckpoint (interface) github.com/ncruces/go-sqlite3/vfs.FileChunkSize (interface) github.com/ncruces/go-sqlite3/vfs.FileCommitPhaseTwo (interface) github.com/ncruces/go-sqlite3/vfs.FileHasMoved (interface) github.com/ncruces/go-sqlite3/vfs.FileLockState (interface) github.com/ncruces/go-sqlite3/vfs.FileOverwrite (interface) github.com/ncruces/go-sqlite3/vfs.FilePersistWAL (interface) github.com/ncruces/go-sqlite3/vfs.FilePowersafeOverwrite (interface) github.com/ncruces/go-sqlite3/vfs.FilePragma (interface) github.com/ncruces/go-sqlite3/vfs.FileSharedMemory (interface) github.com/ncruces/go-sqlite3/vfs.FileSizeHint (interface) github.com/ncruces/go-sqlite3/vfs.FileSync (interface) github.com/ncruces/go-sqlite3/vfs.FileUnwrap (interface) github.com/ncruces/go-sqlite3/vfs.SharedMemory (interface) *github.com/pancsta/asyncmachine-go/pkg/x/history/frostdb.Memory *github.com/parquet-go/parquet-go.GenericReader[...] *github.com/parquet-go/parquet-go.GenericWriter[...] github.com/parquet-go/parquet-go.Pages (interface) *github.com/parquet-go/parquet-go.Reader github.com/parquet-go/parquet-go.Rows (interface) *github.com/parquet-go/parquet-go.SortingWriter[...] *github.com/parquet-go/parquet-go.Writer github.com/parquet-go/parquet-go/compress.Reader (interface) github.com/parquet-go/parquet-go/compress.Writer (interface) *github.com/pierrec/lz4/v4.CompressingReader *github.com/pierrec/lz4/v4.Writer *github.com/pion/datachannel.DataChannel github.com/pion/datachannel.ReadWriteCloser (interface) github.com/pion/datachannel.ReadWriteCloserDeadliner (interface) *github.com/pion/dtls/v2.Conn *github.com/pion/dtls/v3.Conn *github.com/pion/dtls/v3/internal/net.PacketBuffer *github.com/pion/dtls/v3/internal/net/udp.PacketConn github.com/pion/dtls/v3/pkg/net.PacketListener (interface) *github.com/pion/ice/v4.Agent *github.com/pion/ice/v4.Conn *github.com/pion/ice/v4.MultiTCPMuxDefault *github.com/pion/ice/v4.MultiUDPMuxDefault github.com/pion/ice/v4.TCPMux (interface) *github.com/pion/ice/v4.TCPMuxDefault github.com/pion/ice/v4.UDPMux (interface) *github.com/pion/ice/v4.UDPMuxDefault github.com/pion/ice/v4.UniversalUDPMux (interface) github.com/pion/ice/v4.UniversalUDPMuxDefault *github.com/pion/ice/v4/internal/fakenet.MockPacketConn github.com/pion/ice/v4/internal/fakenet.PacketConn *github.com/pion/interceptor.Chain github.com/pion/interceptor.Interceptor (interface) *github.com/pion/interceptor.NoOp *github.com/pion/interceptor/pkg/flexfec.FecInterceptor *github.com/pion/interceptor/pkg/nack.GeneratorInterceptor *github.com/pion/interceptor/pkg/nack.ResponderInterceptor *github.com/pion/interceptor/pkg/report.ReceiverInterceptor *github.com/pion/interceptor/pkg/report.SenderInterceptor *github.com/pion/interceptor/pkg/rfc8888.SenderInterceptor *github.com/pion/interceptor/pkg/twcc.HeaderExtensionInterceptor *github.com/pion/interceptor/pkg/twcc.SenderInterceptor *github.com/pion/mdns/v2.Conn *github.com/pion/sctp.Association *github.com/pion/sctp.Stream *github.com/pion/srtp/v3.ReadStreamSRTCP *github.com/pion/srtp/v3.ReadStreamSRTP *github.com/pion/srtp/v3.SessionSRTCP *github.com/pion/srtp/v3.SessionSRTP *github.com/pion/stun.Agent *github.com/pion/stun.Client github.com/pion/stun.ClientAgent (interface) github.com/pion/stun.Collector (interface) github.com/pion/stun.Connection (interface) *github.com/pion/stun/v3.Agent *github.com/pion/stun/v3.Client github.com/pion/stun/v3.ClientAgent (interface) github.com/pion/stun/v3.Collector (interface) github.com/pion/stun/v3.Connection (interface) github.com/pion/transport/v2.TCPConn (interface) github.com/pion/transport/v2.TCPListener (interface) github.com/pion/transport/v2.UDPConn (interface) github.com/pion/transport/v2/connctx.ConnCtx (interface) *github.com/pion/transport/v2/packetio.Buffer *github.com/pion/transport/v2/udp.BatchConn github.com/pion/transport/v2/udp.BatchPacketConn (interface) *github.com/pion/transport/v2/udp.Conn github.com/pion/transport/v3.TCPConn (interface) github.com/pion/transport/v3.TCPListener (interface) github.com/pion/transport/v3.UDPConn (interface) github.com/pion/transport/v3/netctx.Conn (interface) github.com/pion/transport/v3/netctx.PacketConn (interface) *github.com/pion/transport/v3/packetio.Buffer *github.com/pion/transport/v3/vnet.TokenBucketFilter *github.com/pion/transport/v3/vnet.UDPConn *github.com/pion/transport/v3/vnet.UDPProxy *github.com/pion/turn/v4.Server *github.com/pion/turn/v4.STUNConn *github.com/pion/turn/v4/internal/allocation.Allocation *github.com/pion/turn/v4/internal/allocation.Manager *github.com/pion/turn/v4/internal/client.TCPAllocation github.com/pion/turn/v4/internal/client.TCPConn *github.com/pion/turn/v4/internal/client.UDPConn *github.com/pion/webrtc/v4.DataChannel *github.com/pion/webrtc/v4.ICEGatherer *github.com/pion/webrtc/v4.PeerConnection *github.com/pion/webrtc/v4/internal/mux.Endpoint *github.com/pion/webrtc/v4/internal/mux.Mux github.com/pion/webrtc/v4/pkg/media.Writer (interface) *github.com/polarsignals/frostdb.ColumnStore github.com/polarsignals/frostdb.DefaultObjstoreBucket github.com/polarsignals/frostdb.ParquetWriter (interface) github.com/polarsignals/frostdb.WAL (interface) github.com/polarsignals/frostdb/dynparquet.DynamicRowReader (interface) github.com/polarsignals/frostdb/dynparquet.ParquetWriter (interface) github.com/polarsignals/frostdb/dynparquet.PooledWriter *github.com/polarsignals/frostdb/index.LSM github.com/polarsignals/frostdb/storage.Bucket (interface) github.com/polarsignals/frostdb/storage.BucketReaderAt github.com/polarsignals/frostdb/storage.FileReaderAt *github.com/polarsignals/frostdb/storage.Iceberg *github.com/polarsignals/frostdb/wal.FileWAL *github.com/polarsignals/frostdb/wal.NopWAL github.com/polarsignals/wal.LogStore (interface) *github.com/polarsignals/wal.WAL *github.com/polarsignals/wal/fs.File *github.com/polarsignals/wal/metadb.BoltMetaDB *github.com/polarsignals/wal/segment.Reader *github.com/polarsignals/wal/segment.Writer github.com/polarsignals/wal/types.MetaStore (interface) github.com/polarsignals/wal/types.ReadableFile (interface) github.com/polarsignals/wal/types.SegmentReader (interface) github.com/polarsignals/wal/types.SegmentWriter (interface) github.com/polarsignals/wal/types.WritableFile (interface) github.com/prometheus/common/expfmt.Closer (interface) *github.com/quic-go/qpack.Decoder *github.com/quic-go/qpack.Encoder *github.com/quic-go/quic-go.EarlyListener *github.com/quic-go/quic-go.Listener github.com/quic-go/quic-go.OOBCapablePacketConn (interface) *github.com/quic-go/quic-go.Path github.com/quic-go/quic-go.SendStream (interface) github.com/quic-go/quic-go.Stream (interface) *github.com/quic-go/quic-go.Transport github.com/quic-go/quic-go/http3.QUICEarlyListener (interface) github.com/quic-go/quic-go/http3.RequestStream (interface) *github.com/quic-go/quic-go/http3.Server github.com/quic-go/quic-go/http3.Stream (interface) *github.com/quic-go/quic-go/http3.Transport github.com/quic-go/quic-go/internal/handshake.CryptoSetup (interface) *github.com/quic-go/webtransport-go.Dialer github.com/quic-go/webtransport-go.SendStream (interface) *github.com/quic-go/webtransport-go.Server github.com/quic-go/webtransport-go.Stream (interface) github.com/redis/go-redis/v9.Client *github.com/redis/go-redis/v9.ClusterClient *github.com/redis/go-redis/v9.Conn *github.com/redis/go-redis/v9.PubSub *github.com/redis/go-redis/v9.Ring github.com/redis/go-redis/v9.SentinelClient github.com/redis/go-redis/v9.UniversalClient (interface) *github.com/redis/go-redis/v9/internal/pool.Conn *github.com/redis/go-redis/v9/internal/pool.ConnPool github.com/redis/go-redis/v9/internal/pool.Pooler (interface) *github.com/redis/go-redis/v9/internal/pool.SingleConnPool *github.com/redis/go-redis/v9/internal/pool.StickyConnPool github.com/soheilhy/cmux.MuxConn *github.com/tetratelabs/wazero/internal/sys.FSContext github.com/tetratelabs/wazero/internal/wasm.Engine (interface) github.com/thanos-io/objstore.Bucket (interface) *github.com/thanos-io/objstore.InMemBucket github.com/thanos-io/objstore.InstrumentedBucket (interface) *github.com/thanos-io/objstore.PrefixedBucket *go.etcd.io/bbolt.DB go.uber.org/zap.Sink (interface) golang.org/x/crypto/ssh.Channel (interface) golang.org/x/crypto/ssh.Client golang.org/x/crypto/ssh.Conn (interface) golang.org/x/crypto/ssh.ServerConn *golang.org/x/crypto/ssh.Session golang.org/x/image/font.Face (interface) *golang.org/x/image/font/opentype.Face *golang.org/x/net/http2.ClientConn *golang.org/x/net/http2/hpack.Decoder golang.org/x/net/internal/socks.Conn *golang.org/x/net/ipv4.PacketConn *golang.org/x/net/ipv4.RawConn *golang.org/x/net/ipv6.PacketConn *golang.org/x/text/transform.Writer *google.golang.org/grpc.ClientConn google.golang.org/grpc/internal/binarylog.Sink (interface) google.golang.org/grpc/mem.Reader (interface) *gopkg.in/yaml.v3.Encoder gorm.io/gorm.Rows (interface) *gorm.io/gorm/internal/stmt_store.Stmt *internal/poll.FD *log/syslog.Writer mime/multipart.File (interface) *mime/multipart.Part *mime/multipart.Writer *mime/quotedprintable.Writer net.Conn (interface) *net.IPConn net.Listener (interface) net.PacketConn (interface) *net.TCPConn *net.TCPListener *net.UDPConn *net.UnixConn *net.UnixListener net/http.File (interface) *net/http.Server *net/http/httputil.ClientConn *net/http/httputil.ServerConn *net/rpc.Client net/rpc.ClientCodec (interface) net/rpc.ServerCodec (interface) *net/textproto.Conn *os.File *os.Root *vendor/golang.org/x/net/http2/hpack.Decoder *vendor/golang.org/x/text/transform.Writer Closer : github.com/prometheus/common/expfmt.Closer func github.com/quic-go/quic-go/internal/utils.NewBufferedWriteCloser(writer *bufio.Writer, closer Closer) WriteCloser func go.uber.org/multierr.Close(closer Closer) multierr.Invoker
A LimitedReader reads from R but limits the amount of data returned to just N bytes. Each call to Read updates N to reflect the new amount remaining. Read returns EOF when N <= 0 or when the underlying R returns EOF. // max bytes remaining // underlying reader (*LimitedReader) Read(p []byte) (n int, err error) *LimitedReader : Reader
An OffsetWriter maps writes at offset base to offset base+off in the underlying writer. (*OffsetWriter) Seek(offset int64, whence int) (int64, error) (*OffsetWriter) Write(p []byte) (n int, err error) (*OffsetWriter) WriteAt(p []byte, off int64) (n int, err error) *OffsetWriter : Seeker *OffsetWriter : Writer *OffsetWriter : WriterAt *OffsetWriter : WriteSeeker *OffsetWriter : github.com/miekg/dns.Writer *OffsetWriter : internal/bisect.Writer func NewOffsetWriter(w WriterAt, off int64) *OffsetWriter
A PipeReader is the read half of a pipe. Close closes the reader; subsequent writes to the write half of the pipe will return the error [ErrClosedPipe]. CloseWithError closes the reader; subsequent writes to the write half of the pipe will return the error err. CloseWithError never overwrites the previous error if it exists and always returns nil. Read implements the standard Read interface: it reads data from the pipe, blocking until a writer arrives or the write end is closed. If the write end is closed with an error, that error is returned as err; otherwise err is EOF. *PipeReader : Closer *PipeReader : ReadCloser *PipeReader : Reader *PipeReader : github.com/prometheus/common/expfmt.Closer func Pipe() (*PipeReader, *PipeWriter)
A PipeWriter is the write half of a pipe. Close closes the writer; subsequent reads from the read half of the pipe will return no bytes and EOF. CloseWithError closes the writer; subsequent reads from the read half of the pipe will return no bytes and the error err, or EOF if err is nil. CloseWithError never overwrites the previous error if it exists and always returns nil. Write implements the standard Write interface: it writes data to the pipe, blocking until one or more readers have consumed all the data or the read end is closed. If the read end is closed with an error, that err is returned as err; otherwise err is [ErrClosedPipe]. *PipeWriter : Closer *PipeWriter : WriteCloser *PipeWriter : Writer *PipeWriter : github.com/miekg/dns.Writer *PipeWriter : github.com/prometheus/common/expfmt.Closer *PipeWriter : internal/bisect.Writer func Pipe() (*PipeReader, *PipeWriter)
ReadCloser is the interface that groups the basic Read and Close methods. ( ReadCloser) Close() error ( ReadCloser) Read(p []byte) (n int, err error) *PipeReader ReadSeekCloser (interface) ReadWriteCloser (interface) io/fs.File (interface) io/fs.ReadDirFile (interface) *compress/gzip.Reader *crypto/tls.Conn github.com/apache/thrift/lib/go/thrift.RichTransport *github.com/apache/thrift/lib/go/thrift.StreamTransport *github.com/apache/thrift/lib/go/thrift.TBufferedTransport *github.com/apache/thrift/lib/go/thrift.TFramedTransport *github.com/apache/thrift/lib/go/thrift.THeaderTransport *github.com/apache/thrift/lib/go/thrift.THttpClient *github.com/apache/thrift/lib/go/thrift.TMemoryBuffer *github.com/apache/thrift/lib/go/thrift.TransformReader *github.com/apache/thrift/lib/go/thrift.TSocket *github.com/apache/thrift/lib/go/thrift.TSSLSocket github.com/apache/thrift/lib/go/thrift.TTransport (interface) *github.com/apache/thrift/lib/go/thrift.TZlibTransport github.com/coreos/etcd/pkg/fileutil.LockedFile github.com/gdamore/tcell/v2.Tty (interface) github.com/gliderlabs/ssh.Session (interface) *github.com/ipfs/go-log/v2.PipeReader *github.com/klauspost/compress/gzip.Reader github.com/libp2p/go-libp2p/core/network.MuxedStream (interface) github.com/libp2p/go-libp2p/core/network.Stream (interface) github.com/libp2p/go-libp2p/core/sec.SecureConn (interface) github.com/libp2p/go-libp2p/core/sec/insecure.Conn *github.com/libp2p/go-libp2p/p2p/net/swarm.Stream *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.Conn github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface (interface) *github.com/libp2p/go-libp2p/p2p/transport/websocket.Conn github.com/libp2p/go-msgio.ReadCloser (interface) github.com/libp2p/go-msgio.ReadWriteCloser (interface) *github.com/libp2p/go-yamux/v5.Stream github.com/marten-seemann/tcp.Conn *github.com/miekg/dns.Conn github.com/miekg/dns.Transfer github.com/multiformats/go-multiaddr/net.Conn (interface) github.com/multiformats/go-multistream.LazyConn (interface) github.com/nats-io/nats.go.ObjectResult (interface) *github.com/ncruces/go-sqlite3.Blob github.com/parquet-go/parquet-go/compress.Reader (interface) *github.com/pierrec/lz4/v4.CompressingReader *github.com/pion/datachannel.DataChannel github.com/pion/datachannel.ReadWriteCloser (interface) github.com/pion/datachannel.ReadWriteCloserDeadliner (interface) *github.com/pion/dtls/v2.Conn *github.com/pion/dtls/v3.Conn *github.com/pion/ice/v4.Conn github.com/pion/ice/v4/internal/fakenet.PacketConn *github.com/pion/sctp.Stream *github.com/pion/srtp/v3.ReadStreamSRTCP *github.com/pion/srtp/v3.ReadStreamSRTP github.com/pion/stun.Connection (interface) github.com/pion/stun/v3.Connection (interface) github.com/pion/transport/v2.TCPConn (interface) github.com/pion/transport/v2.UDPConn (interface) *github.com/pion/transport/v2/packetio.Buffer *github.com/pion/transport/v2/udp.Conn github.com/pion/transport/v3.TCPConn (interface) github.com/pion/transport/v3.UDPConn (interface) *github.com/pion/transport/v3/packetio.Buffer *github.com/pion/transport/v3/vnet.UDPConn github.com/pion/turn/v4/internal/client.TCPConn *github.com/pion/webrtc/v4/internal/mux.Endpoint *github.com/polarsignals/wal/fs.File github.com/quic-go/quic-go.Stream (interface) github.com/quic-go/quic-go/http3.RequestStream (interface) github.com/quic-go/quic-go/http3.Stream (interface) github.com/quic-go/webtransport-go.Stream (interface) *github.com/soheilhy/cmux.MuxConn golang.org/x/crypto/ssh.Channel (interface) golang.org/x/net/internal/socks.Conn *golang.org/x/net/ipv4.RawConn google.golang.org/grpc/mem.Reader (interface) *internal/poll.FD mime/multipart.File (interface) *mime/multipart.Part net.Conn (interface) *net.IPConn *net.TCPConn *net.UDPConn *net.UnixConn net/http.File (interface) *os.File ReadCloser : Closer ReadCloser : Reader ReadCloser : github.com/prometheus/common/expfmt.Closer func NopCloser(r Reader) ReadCloser func io/ioutil.NopCloser(r Reader) ReadCloser func compress/flate.NewReader(r Reader) ReadCloser func compress/flate.NewReaderDict(r Reader, dict []byte) ReadCloser func compress/zlib.NewReader(r Reader) (ReadCloser, error) func compress/zlib.NewReaderDict(r Reader, dict []byte) (ReadCloser, error) func github.com/apache/arrow-go/v18/parquet/compress.StreamingCodec.NewReader(Reader) ReadCloser func github.com/google/go-github/v66/github.(*RepositoriesService).DownloadContents(ctx context.Context, owner, repo, filepath string, opts *github.RepositoryContentGetOptions) (ReadCloser, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DownloadContentsWithMeta(ctx context.Context, owner, repo, filepath string, opts *github.RepositoryContentGetOptions) (ReadCloser, *github.RepositoryContent, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DownloadReleaseAsset(ctx context.Context, owner, repo string, id int64, followRedirectsClient *http.Client) (rc ReadCloser, redirectURL string, err error) func github.com/klauspost/compress/flate.NewReader(r Reader) ReadCloser func github.com/klauspost/compress/flate.NewReaderDict(r Reader, dict []byte) ReadCloser func github.com/klauspost/compress/flate.NewReaderOpts(r Reader, opts ...flate.ReaderOpt) ReadCloser func github.com/klauspost/compress/zstd.(*Decoder).IOReadCloser() ReadCloser func github.com/mailru/easyjson/buffer.(*Buffer).ReadCloser() ReadCloser func github.com/mailru/easyjson/jwriter.(*Writer).ReadCloser() (ReadCloser, error) func github.com/pierrec/lz4/v4.(*CompressingReader).Source() ReadCloser func github.com/polarsignals/frostdb/storage.Bucket.Get(ctx context.Context, name string) (ReadCloser, error) func github.com/polarsignals/frostdb/storage.Bucket.GetRange(ctx context.Context, name string, off, length int64) (ReadCloser, error) func github.com/tetratelabs/wazero/internal/filecache.Cache.Get(key filecache.Key) (content ReadCloser, ok bool, err error) func github.com/thanos-io/objstore.NopCloserWithSize(r Reader) ReadCloser func github.com/thanos-io/objstore.Bucket.Get(ctx context.Context, name string) (ReadCloser, error) func github.com/thanos-io/objstore.Bucket.GetRange(ctx context.Context, name string, off, length int64) (ReadCloser, error) func github.com/thanos-io/objstore.BucketReader.Get(ctx context.Context, name string) (ReadCloser, error) func github.com/thanos-io/objstore.BucketReader.GetRange(ctx context.Context, name string, off, length int64) (ReadCloser, error) func github.com/thanos-io/objstore.(*InMemBucket).Get(_ context.Context, name string) (ReadCloser, error) func github.com/thanos-io/objstore.(*InMemBucket).GetRange(_ context.Context, name string, off, length int64) (ReadCloser, error) func github.com/thanos-io/objstore.InstrumentedBucket.Get(ctx context.Context, name string) (ReadCloser, error) func github.com/thanos-io/objstore.InstrumentedBucket.GetRange(ctx context.Context, name string, off, length int64) (ReadCloser, error) func github.com/thanos-io/objstore.InstrumentedBucketReader.Get(ctx context.Context, name string) (ReadCloser, error) func github.com/thanos-io/objstore.InstrumentedBucketReader.GetRange(ctx context.Context, name string, off, length int64) (ReadCloser, error) func github.com/thanos-io/objstore.(*PrefixedBucket).Get(ctx context.Context, name string) (ReadCloser, error) func github.com/thanos-io/objstore.(*PrefixedBucket).GetRange(ctx context.Context, name string, off int64, length int64) (ReadCloser, error) func net/http.MaxBytesReader(w http.ResponseWriter, r ReadCloser, n int64) ReadCloser func os/exec.(*Cmd).StderrPipe() (ReadCloser, error) func os/exec.(*Cmd).StdoutPipe() (ReadCloser, error) func github.com/efficientgo/core/logerrcapture.ExhaustClose(logger logerrcapture.Logger, r ReadCloser, format string, a ...interface{}) func github.com/pierrec/lz4/v4.NewCompressingReader(src ReadCloser) *lz4.CompressingReader func github.com/pierrec/lz4/v4.(*CompressingReader).Reset(src ReadCloser) func net/http.MaxBytesReader(w http.ResponseWriter, r ReadCloser, n int64) ReadCloser var github.com/reeflective/readline/internal/core.Stdin
Reader is the interface that wraps the basic Read method. Read reads up to len(p) bytes into p. It returns the number of bytes read (0 <= n <= len(p)) and any error encountered. Even if Read returns n < len(p), it may use all of p as scratch space during the call. If some data is available but not len(p) bytes, Read conventionally returns what is available instead of waiting for more. When Read encounters an error or end-of-file condition after successfully reading n > 0 bytes, it returns the number of bytes read. It may return the (non-nil) error from the same call or return the error (and n == 0) from a subsequent call. An instance of this general case is that a Reader returning a non-zero number of bytes at the end of the input stream may return either err == EOF or err == nil. The next Read should return 0, EOF. Callers should always process the n > 0 bytes returned before considering the error err. Doing so correctly handles I/O errors that happen after reading some bytes and also both of the allowed EOF behaviors. If len(p) == 0, Read should always return n == 0. It may return a non-nil error if some error condition is known, such as EOF. Implementations of Read are discouraged from returning a zero byte count with a nil error, except when len(p) == 0. Callers should treat a return of 0 and nil as indicating that nothing happened; in particular it does not indicate EOF. Implementations must not retain p. ( Reader) Read(p []byte) (n int, err error) *LimitedReader *PipeReader ReadCloser (interface) ReadSeekCloser (interface) ReadSeeker (interface) ReadWriteCloser (interface) ReadWriter (interface) ReadWriteSeeker (interface) *SectionReader io/fs.File (interface) io/fs.ReadDirFile (interface) *bufio.Reader bufio.ReadWriter *bytes.Buffer *bytes.Reader compress/flate.Reader (interface) *compress/gzip.Reader crypto/cipher.StreamReader *crypto/internal/fips140/sha3.SHAKE *crypto/sha3.SHAKE *crypto/tls.Conn fmt.ScanState (interface) *github.com/andybalholm/brotli.Reader github.com/apache/arrow-go/v18/arrow/ipc.ReadAtSeeker (interface) github.com/apache/arrow-go/v18/internal/utils.Reader (interface) github.com/apache/arrow-go/v18/parquet.BufferedReader (interface) github.com/apache/thrift/lib/go/thrift.RichTransport *github.com/apache/thrift/lib/go/thrift.StreamTransport *github.com/apache/thrift/lib/go/thrift.TBufferedTransport *github.com/apache/thrift/lib/go/thrift.TFramedTransport *github.com/apache/thrift/lib/go/thrift.THeaderTransport *github.com/apache/thrift/lib/go/thrift.THttpClient github.com/apache/thrift/lib/go/thrift.TMemoryBuffer github.com/apache/thrift/lib/go/thrift.TRichTransport (interface) github.com/apache/thrift/lib/go/thrift.TransformReader *github.com/apache/thrift/lib/go/thrift.TSocket *github.com/apache/thrift/lib/go/thrift.TSSLSocket github.com/apache/thrift/lib/go/thrift.TTransport (interface) *github.com/apache/thrift/lib/go/thrift.TZlibTransport github.com/coder/websocket/internal/util.ReaderFunc github.com/coreos/etcd/pkg/fileutil.LockedFile github.com/gdamore/tcell/v2.Tty (interface) github.com/gliderlabs/ssh.Session (interface) *github.com/gobwas/ws/wsutil.CipherReader *github.com/gobwas/ws/wsutil.Reader *github.com/gobwas/ws/wsutil.UTF8Reader *github.com/golang/snappy.Reader *github.com/hamba/avro/v2/internal/bytesx.ResetReader *github.com/ipfs/go-log/v2.PipeReader github.com/klauspost/compress/flate.Reader (interface) *github.com/klauspost/compress/gzip.Reader *github.com/klauspost/compress/internal/snapref.Reader *github.com/klauspost/compress/s2.Reader github.com/klauspost/compress/s2.ReadSeeker *github.com/klauspost/compress/zstd.Decoder *github.com/libp2p/go-buffer-pool.Buffer github.com/libp2p/go-libp2p/core/network.MuxedStream (interface) github.com/libp2p/go-libp2p/core/network.Stream (interface) github.com/libp2p/go-libp2p/core/sec.SecureConn (interface) github.com/libp2p/go-libp2p/core/sec/insecure.Conn *github.com/libp2p/go-libp2p/p2p/net/swarm.Stream *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.Conn github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface (interface) *github.com/libp2p/go-libp2p/p2p/transport/websocket.Conn github.com/libp2p/go-msgio.ReadCloser (interface) github.com/libp2p/go-msgio.Reader (interface) github.com/libp2p/go-msgio.ReadWriteCloser (interface) github.com/libp2p/go-msgio.ReadWriter (interface) *github.com/libp2p/go-yamux/v5.Stream github.com/marten-seemann/tcp.Conn *github.com/miekg/dns.Conn github.com/miekg/dns.Transfer github.com/multiformats/go-multiaddr/net.Conn (interface) github.com/multiformats/go-multihash.Reader (interface) github.com/multiformats/go-multistream.LazyConn (interface) github.com/nats-io/nats.go.ObjectResult (interface) *github.com/ncruces/go-sqlite3.Blob github.com/oklog/ulid/v2.LockedMonotonicReader github.com/oklog/ulid/v2.MonotonicEntropy github.com/oklog/ulid/v2.MonotonicReader (interface) github.com/parquet-go/parquet-go/compress.Reader (interface) *github.com/pierrec/lz4/v4.CompressingReader *github.com/pierrec/lz4/v4.Reader *github.com/pion/datachannel.DataChannel github.com/pion/datachannel.ReadWriteCloser (interface) github.com/pion/datachannel.ReadWriteCloserDeadliner (interface) *github.com/pion/dtls/v2.Conn *github.com/pion/dtls/v3.Conn *github.com/pion/ice/v4.Conn github.com/pion/ice/v4/internal/fakenet.PacketConn *github.com/pion/sctp.Stream *github.com/pion/srtp/v3.ReadStreamSRTCP *github.com/pion/srtp/v3.ReadStreamSRTP github.com/pion/stun.Connection (interface) github.com/pion/stun/v3.Connection (interface) github.com/pion/transport/v2.TCPConn (interface) github.com/pion/transport/v2.UDPConn (interface) *github.com/pion/transport/v2/packetio.Buffer *github.com/pion/transport/v2/udp.Conn github.com/pion/transport/v3.TCPConn (interface) github.com/pion/transport/v3.UDPConn (interface) *github.com/pion/transport/v3/packetio.Buffer *github.com/pion/transport/v3/vnet.UDPConn github.com/pion/turn/v4/internal/client.TCPConn *github.com/pion/webrtc/v4/internal/mux.Endpoint *github.com/polarsignals/wal/fs.File github.com/quic-go/quic-go.ReceiveStream (interface) github.com/quic-go/quic-go.Stream (interface) github.com/quic-go/quic-go/http3.RequestStream (interface) github.com/quic-go/quic-go/http3.Stream (interface) github.com/quic-go/quic-go/quicvarint.Reader (interface) github.com/quic-go/webtransport-go.ReceiveStream (interface) github.com/quic-go/webtransport-go.Stream (interface) *github.com/RoaringBitmap/roaring/internal.ByteBuffer *github.com/RoaringBitmap/roaring/internal.ByteInputAdapter *github.com/soheilhy/cmux.MuxConn golang.org/x/crypto/blake2b.XOF (interface) golang.org/x/crypto/blake2s.XOF (interface) golang.org/x/crypto/sha3.ShakeHash (interface) golang.org/x/crypto/ssh.Channel (interface) golang.org/x/net/internal/socks.Conn golang.org/x/net/ipv4.RawConn *golang.org/x/text/transform.Reader google.golang.org/grpc/mem.Reader (interface) google.golang.org/protobuf/encoding/protodelim.Reader (interface) hash.XOF (interface) *internal/poll.FD *lukechampine.com/blake3.OutputReader *math/rand.Rand *math/rand/v2.ChaCha8 mime/multipart.File (interface) *mime/multipart.Part *mime/quotedprintable.Reader *net.Buffers net.Conn (interface) *net.IPConn *net.TCPConn *net.UDPConn *net.UnixConn net/http.File (interface) *os.File *strings.Reader *vendor/golang.org/x/text/transform.Reader func LimitReader(r Reader, n int64) Reader func MultiReader(readers ...Reader) Reader func TeeReader(r Reader, w Writer) Reader func encoding/base32.NewDecoder(enc *base32.Encoding, r Reader) Reader func encoding/base64.NewDecoder(enc *base64.Encoding, r Reader) Reader func encoding/hex.NewDecoder(r Reader) Reader func encoding/json.(*Decoder).Buffered() Reader func github.com/coder/websocket.(*Conn).Reader(ctx context.Context) (websocket.MessageType, Reader, error) func github.com/gobwas/ws/wsutil.NextReader(r Reader, s ws.State) (ws.Header, Reader, error) func github.com/goccy/go-json.(*Decoder).Buffered() Reader func github.com/goccy/go-json/internal/decoder.(*Stream).Buffered() Reader func github.com/gorilla/websocket.JoinMessages(c *websocket.Conn, term string) Reader func github.com/gorilla/websocket.(*Conn).NextReader() (messageType int, r Reader, err error) func github.com/json-iterator/go.(*Decoder).Buffered() Reader func github.com/libp2p/go-msgio.LimitedReader(r Reader) (Reader, error) func github.com/multiformats/go-base32.NewDecoder(enc *base32.Encoding, r Reader) Reader func github.com/oklog/ulid.Monotonic(entropy Reader, inc uint64) Reader func github.com/oklog/ulid/v2.DefaultEntropy() Reader func github.com/parquet-go/parquet-go/encoding/thrift.Reader.Reader() Reader func github.com/parquet-go/parquet-go/internal/debug.Reader(reader Reader, prefix string) Reader func github.com/quic-go/quic-go/http3.ParseCapsule(r quicvarint.Reader) (http3.CapsuleType, Reader, error) func github.com/spf13/cobra.(*Command).InOrStdin() Reader func github.com/tetratelabs/wazero/internal/platform.NewFakeRandSource() Reader func github.com/tetratelabs/wazero/internal/sys.(*Context).RandSource() Reader func github.com/vmihailenco/msgpack/v5.(*Decoder).Buffered() Reader func golang.org/x/crypto/hkdf.Expand(hash func() hash.Hash, pseudorandomKey, info []byte) Reader func golang.org/x/crypto/hkdf.New(hash func() hash.Hash, secret, salt, info []byte) Reader func golang.org/x/crypto/ssh.(*Session).StderrPipe() (Reader, error) func golang.org/x/crypto/ssh.(*Session).StdoutPipe() (Reader, error) func golang.org/x/text/encoding.(*Decoder).Reader(r Reader) Reader func golang.org/x/text/unicode/norm.Form.Reader(r Reader) Reader func google.golang.org/grpc/encoding.Compressor.Decompress(r Reader) (Reader, error) func net/http/httputil.NewChunkedReader(r Reader) Reader func net/http/internal.NewChunkedReader(r Reader) Reader func net/textproto.(*Reader).DotReader() Reader func vendor/golang.org/x/text/unicode/norm.Form.Reader(r Reader) Reader func Copy(dst Writer, src Reader) (written int64, err error) func CopyBuffer(dst Writer, src Reader, buf []byte) (written int64, err error) func CopyN(dst Writer, src Reader, n int64) (written int64, err error) func LimitReader(r Reader, n int64) Reader func MultiReader(readers ...Reader) Reader func NopCloser(r Reader) ReadCloser func ReadAll(r Reader) ([]byte, error) func ReadAtLeast(r Reader, buf []byte, min int) (n int, err error) func ReadFull(r Reader, buf []byte) (n int, err error) func TeeReader(r Reader, w Writer) Reader func ReaderFrom.ReadFrom(r Reader) (n int64, err error) func io/ioutil.NopCloser(r Reader) ReadCloser func io/ioutil.ReadAll(r Reader) ([]byte, error) func bufio.NewReader(rd Reader) *bufio.Reader func bufio.NewReaderSize(rd Reader, size int) *bufio.Reader func bufio.NewScanner(r Reader) *bufio.Scanner func bufio.(*Reader).Reset(r Reader) func bufio.(*Writer).ReadFrom(r Reader) (n int64, err error) func bytes.(*Buffer).ReadFrom(r Reader) (n int64, err error) func compress/flate.NewReader(r Reader) ReadCloser func compress/flate.NewReaderDict(r Reader, dict []byte) ReadCloser func compress/flate.Resetter.Reset(r Reader, dict []byte) error func compress/gzip.NewReader(r Reader) (*gzip.Reader, error) func compress/gzip.(*Reader).Reset(r Reader) error func compress/zlib.NewReader(r Reader) (ReadCloser, error) func compress/zlib.NewReaderDict(r Reader, dict []byte) (ReadCloser, error) func compress/zlib.Resetter.Reset(r Reader, dict []byte) error func crypto.SignMessage(signer crypto.Signer, rand Reader, msg []byte, opts crypto.SignerOpts) (signature []byte, err error) func crypto.Decrypter.Decrypt(rand Reader, msg []byte, opts crypto.DecrypterOpts) (plaintext []byte, err error) func crypto.MessageSigner.Sign(rand Reader, digest []byte, opts crypto.SignerOpts) (signature []byte, err error) func crypto.MessageSigner.SignMessage(rand Reader, msg []byte, opts crypto.SignerOpts) (signature []byte, err error) func crypto.Signer.Sign(rand Reader, digest []byte, opts crypto.SignerOpts) (signature []byte, err error) func crypto/dsa.GenerateKey(priv *dsa.PrivateKey, rand Reader) error func crypto/dsa.GenerateParameters(params *dsa.Parameters, rand Reader, sizes dsa.ParameterSizes) error func crypto/dsa.Sign(rand Reader, priv *dsa.PrivateKey, hash []byte) (r, s *big.Int, err error) func crypto/ecdh.Curve.GenerateKey(rand Reader) (*ecdh.PrivateKey, error) func crypto/ecdsa.GenerateKey(c elliptic.Curve, rand Reader) (*ecdsa.PrivateKey, error) func crypto/ecdsa.Sign(rand Reader, priv *ecdsa.PrivateKey, hash []byte) (r, s *big.Int, err error) func crypto/ecdsa.SignASN1(rand Reader, priv *ecdsa.PrivateKey, hash []byte) ([]byte, error) func crypto/ecdsa.(*PrivateKey).Sign(rand Reader, digest []byte, opts crypto.SignerOpts) ([]byte, error) func crypto/ed25519.GenerateKey(rand Reader) (ed25519.PublicKey, ed25519.PrivateKey, error) func crypto/ed25519.PrivateKey.Sign(rand Reader, message []byte, opts crypto.SignerOpts) (signature []byte, err error) func crypto/elliptic.GenerateKey(curve elliptic.Curve, rand Reader) (priv []byte, x, y *big.Int, err error) func crypto/internal/fips140/drbg.ReadWithReader(r Reader, b []byte) error func crypto/internal/fips140/drbg.ReadWithReaderDeterministic(r Reader, b []byte) error func crypto/internal/fips140/ecdh.GenerateKey[P](c *ecdh.Curve[P], rand Reader) (*ecdh.PrivateKey, error) func crypto/internal/fips140/ecdsa.GenerateKey[P](c *ecdsa.Curve[P], rand Reader) (*ecdsa.PrivateKey, error) func crypto/internal/fips140/ecdsa.Sign[P, H](c *ecdsa.Curve[P], h func() H, priv *ecdsa.PrivateKey, rand Reader, hash []byte) (*ecdsa.Signature, error) func crypto/internal/fips140/rsa.EncryptOAEP(hash, mgfHash hash.Hash, random Reader, pub *rsa.PublicKey, msg []byte, label []byte) ([]byte, error) func crypto/internal/fips140/rsa.GenerateKey(rand Reader, bits int) (*rsa.PrivateKey, error) func crypto/internal/fips140/rsa.SignPSS(rand Reader, priv *rsa.PrivateKey, hash hash.Hash, hashed []byte, saltLength int) ([]byte, error) func crypto/internal/fips140only.ApprovedRandomReader(r Reader) bool func crypto/internal/randutil.MaybeReadByte(r Reader) func crypto/rand.Int(rand Reader, max *big.Int) (n *big.Int, err error) func crypto/rand.Prime(rand Reader, bits int) (*big.Int, error) func crypto/rsa.DecryptOAEP(hash hash.Hash, random Reader, priv *rsa.PrivateKey, ciphertext []byte, label []byte) ([]byte, error) func crypto/rsa.DecryptPKCS1v15(random Reader, priv *rsa.PrivateKey, ciphertext []byte) ([]byte, error) func crypto/rsa.DecryptPKCS1v15SessionKey(random Reader, priv *rsa.PrivateKey, ciphertext []byte, key []byte) error func crypto/rsa.EncryptOAEP(hash hash.Hash, random Reader, pub *rsa.PublicKey, msg []byte, label []byte) ([]byte, error) func crypto/rsa.EncryptPKCS1v15(random Reader, pub *rsa.PublicKey, msg []byte) ([]byte, error) func crypto/rsa.GenerateKey(random Reader, bits int) (*rsa.PrivateKey, error) func crypto/rsa.GenerateMultiPrimeKey(random Reader, nprimes int, bits int) (*rsa.PrivateKey, error) func crypto/rsa.SignPKCS1v15(random Reader, priv *rsa.PrivateKey, hash crypto.Hash, hashed []byte) ([]byte, error) func crypto/rsa.SignPSS(rand Reader, priv *rsa.PrivateKey, hash crypto.Hash, digest []byte, opts *rsa.PSSOptions) ([]byte, error) func crypto/rsa.(*PrivateKey).Decrypt(rand Reader, ciphertext []byte, opts crypto.DecrypterOpts) (plaintext []byte, err error) func crypto/rsa.(*PrivateKey).Sign(rand Reader, digest []byte, opts crypto.SignerOpts) ([]byte, error) func crypto/x509.CreateCertificate(rand Reader, template, parent *x509.Certificate, pub, priv any) ([]byte, error) func crypto/x509.CreateCertificateRequest(rand Reader, template *x509.CertificateRequest, priv any) (csr []byte, err error) func crypto/x509.CreateRevocationList(rand Reader, template *x509.RevocationList, issuer *x509.Certificate, priv crypto.Signer) ([]byte, error) func crypto/x509.EncryptPEMBlock(rand Reader, blockType string, data, password []byte, alg x509.PEMCipher) (*pem.Block, error) func crypto/x509.(*Certificate).CreateCRL(rand Reader, priv any, revokedCerts []pkix.RevokedCertificate, now, expiry time.Time) (crlBytes []byte, err error) func encoding/base32.NewDecoder(enc *base32.Encoding, r Reader) Reader func encoding/base64.NewDecoder(enc *base64.Encoding, r Reader) Reader func encoding/binary.Read(r Reader, order binary.ByteOrder, data any) error func encoding/csv.NewReader(r Reader) *csv.Reader func encoding/gob.NewDecoder(r Reader) *gob.Decoder func encoding/hex.NewDecoder(r Reader) Reader func encoding/json.NewDecoder(r Reader) *json.Decoder func encoding/xml.NewDecoder(r Reader) *xml.Decoder func fmt.Fscan(r Reader, a ...any) (n int, err error) func fmt.Fscanf(r Reader, format string, a ...any) (n int, err error) func fmt.Fscanln(r Reader, a ...any) (n int, err error) func github.com/alecthomas/chroma/v2.MustNewXMLStyle(r Reader) *chroma.Style func github.com/alecthomas/chroma/v2.NewXMLStyle(r Reader) (*chroma.Style, error) func github.com/andybalholm/brotli.NewReader(src Reader) *brotli.Reader func github.com/andybalholm/brotli.(*Reader).Reset(src Reader) error func github.com/anmitsu/go-shlex.NewLexer(r Reader, posix, whitespacesplit bool) *shlex.Lexer func github.com/apache/arrow-go/v18/arrow/array.FromJSON(mem memory.Allocator, dt arrow.DataType, r Reader, opts ...array.FromJSONOption) (arr arrow.Array, offset int64, err error) func github.com/apache/arrow-go/v18/arrow/array.NewJSONReader(r Reader, schema *arrow.Schema, opts ...array.Option) *array.JSONReader func github.com/apache/arrow-go/v18/arrow/array.RecordFromJSON(mem memory.Allocator, schema *arrow.Schema, r Reader, opts ...array.FromJSONOption) (arrow.RecordBatch, int64, error) func github.com/apache/arrow-go/v18/arrow/ipc.NewMessageReader(r Reader, opts ...ipc.Option) ipc.MessageReader func github.com/apache/arrow-go/v18/arrow/ipc.NewReader(r Reader, opts ...ipc.Option) (*ipc.Reader, error) func github.com/apache/arrow-go/v18/internal/json.NewDecoder(r Reader) *json.Decoder func github.com/apache/arrow-go/v18/parquet/compress.StreamingCodec.NewReader(Reader) ReadCloser func github.com/apache/thrift/lib/go/thrift.NewStreamTransport(r Reader, w Writer) *thrift.StreamTransport func github.com/apache/thrift/lib/go/thrift.NewStreamTransportFactory(reader Reader, writer Writer, isReadWriter bool) *thrift.StreamTransportFactory func github.com/apache/thrift/lib/go/thrift.NewStreamTransportR(r Reader) *thrift.StreamTransport func github.com/apache/thrift/lib/go/thrift.NewTransformReaderWithCapacity(baseReader Reader, capacity int) *thrift.TransformReader func github.com/bits-and-blooms/bitset.(*BitSet).ReadFrom(stream Reader) (int64, error) func github.com/decred/dcrd/dcrec/secp256k1/v4.GeneratePrivateKeyFromRand(rand Reader) (*secp256k1.PrivateKey, error) func github.com/flynn/noise.CipherSuite.GenerateKeypair(random Reader) (noise.DHKey, error) func github.com/flynn/noise.DHFunc.GenerateKeypair(random Reader) (noise.DHKey, error) func github.com/francoispqt/gojay.BorrowDecoder(r Reader) *gojay.Decoder func github.com/francoispqt/gojay.NewDecoder(r Reader) *gojay.Decoder func github.com/gliderlabs/ssh.Signer.Sign(rand Reader, data []byte) (*ssh.Signature, error) func github.com/go-logfmt/logfmt.NewDecoder(r Reader) *logfmt.Decoder func github.com/go-logfmt/logfmt.NewDecoderSize(r Reader, size int) *logfmt.Decoder func github.com/gobwas/pool/pbufio.GetReader(w Reader, size int) *bufio.Reader func github.com/gobwas/pool/pbufio.(*ReaderPool).Get(r Reader, size int) *bufio.Reader func github.com/gobwas/ws.MustReadFrame(r Reader) ws.Frame func github.com/gobwas/ws.ReadFrame(r Reader) (f ws.Frame, err error) func github.com/gobwas/ws.ReadHeader(r Reader) (h ws.Header, err error) func github.com/gobwas/ws/wsutil.NewCipherReader(r Reader, mask [4]byte) *wsutil.CipherReader func github.com/gobwas/ws/wsutil.NewClientSideReader(r Reader) *wsutil.Reader func github.com/gobwas/ws/wsutil.NewReader(r Reader, s ws.State) *wsutil.Reader func github.com/gobwas/ws/wsutil.NewServerSideReader(r Reader) *wsutil.Reader func github.com/gobwas/ws/wsutil.NewUTF8Reader(r Reader) *wsutil.UTF8Reader func github.com/gobwas/ws/wsutil.NextReader(r Reader, s ws.State) (ws.Header, Reader, error) func github.com/gobwas/ws/wsutil.ReadClientMessage(r Reader, m []wsutil.Message) ([]wsutil.Message, error) func github.com/gobwas/ws/wsutil.ReadMessage(r Reader, s ws.State, m []wsutil.Message) ([]wsutil.Message, error) func github.com/gobwas/ws/wsutil.ReadServerMessage(r Reader, m []wsutil.Message) ([]wsutil.Message, error) func github.com/gobwas/ws/wsutil.(*CipherReader).Reset(r Reader, mask [4]byte) func github.com/gobwas/ws/wsutil.(*UTF8Reader).Reset(r Reader) func github.com/gobwas/ws/wsutil.(*Writer).ReadFrom(src Reader) (n int64, err error) func github.com/goccy/go-json.NewDecoder(r Reader) *json.Decoder func github.com/goccy/go-json/internal/decoder.NewStream(r Reader) *decoder.Stream func github.com/golang/snappy.NewReader(r Reader) *snappy.Reader func github.com/golang/snappy.(*Reader).Reset(reader Reader) func github.com/google/go-github/v66/github.ValidatePayloadFromBody(contentType string, readable Reader, signature string, secretToken []byte) (payload []byte, err error) func github.com/google/go-github/v66/github.(*Client).NewFormRequest(urlStr string, body Reader, opts ...github.RequestOption) (*http.Request, error) func github.com/google/go-github/v66/github.(*Client).NewUploadRequest(urlStr string, reader Reader, size int64, mediaType string, opts ...github.RequestOption) (*http.Request, error) func github.com/google/go-github/v66/github.MessageSigner.Sign(w Writer, r Reader) error func github.com/google/go-github/v66/github.MessageSignerFunc.Sign(w Writer, r Reader) error func github.com/google/pprof/profile.Parse(r Reader) (*profile.Profile, error) func github.com/google/pprof/profile.ParseProcMaps(rd Reader) ([]*profile.Mapping, error) func github.com/google/pprof/profile.(*Profile).ParseMemoryMap(rd Reader) error func github.com/google/uuid.NewRandomFromReader(r Reader) (uuid.UUID, error) func github.com/google/uuid.NewV7FromReader(r Reader) (uuid.UUID, error) func github.com/google/uuid.SetRand(r Reader) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.FieldMaskFromRequestBody(r Reader, msg proto.Message) (*field_mask.FieldMask, error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.(*JSONBuiltin).NewDecoder(r Reader) runtime.Decoder func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.(*JSONPb).NewDecoder(r Reader) runtime.Decoder func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.Marshaler.NewDecoder(r Reader) runtime.Decoder func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.(*ProtoMarshaller).NewDecoder(reader Reader) runtime.Decoder func github.com/grpc-ecosystem/grpc-gateway/v2/utilities.IOReaderFactory(r Reader) (func() Reader, error) func github.com/hamba/avro/v2.NewDecoder(s string, r Reader) (*avro.Decoder, error) func github.com/hamba/avro/v2.NewDecoderForSchema(schema avro.Schema, reader Reader) *avro.Decoder func github.com/hamba/avro/v2.NewReader(r Reader, bufSize int, opts ...avro.ReaderFunc) *avro.Reader func github.com/hamba/avro/v2.API.NewDecoder(schema avro.Schema, r Reader) *avro.Decoder func github.com/hamba/avro/v2/ocf.NewDecoder(r Reader, opts ...ocf.DecoderFunc) (*ocf.Decoder, error) func github.com/ipfs/go-cid.CidFromReader(r Reader) (int, cid.Cid, error) func github.com/joho/godotenv.Parse(r Reader) (map[string]string, error) func github.com/json-iterator/go.NewDecoder(reader Reader) *jsoniter.Decoder func github.com/json-iterator/go.Parse(cfg jsoniter.API, reader Reader, bufSize int) *jsoniter.Iterator func github.com/json-iterator/go.API.NewDecoder(reader Reader) *jsoniter.Decoder func github.com/json-iterator/go.(*Iterator).Reset(reader Reader) *jsoniter.Iterator func github.com/klauspost/compress/flate.NewReader(r Reader) ReadCloser func github.com/klauspost/compress/flate.NewReaderDict(r Reader, dict []byte) ReadCloser func github.com/klauspost/compress/flate.NewReaderOpts(r Reader, opts ...flate.ReaderOpt) ReadCloser func github.com/klauspost/compress/flate.Resetter.Reset(r Reader, dict []byte) error func github.com/klauspost/compress/gzip.NewReader(r Reader) (*gzip.Reader, error) func github.com/klauspost/compress/gzip.(*Reader).Reset(r Reader) error func github.com/klauspost/compress/internal/snapref.NewReader(r Reader) *snapref.Reader func github.com/klauspost/compress/internal/snapref.(*Reader).Reset(reader Reader) func github.com/klauspost/compress/s2.IndexStream(r Reader) ([]byte, error) func github.com/klauspost/compress/s2.NewReader(r Reader, opts ...s2.ReaderOption) *s2.Reader func github.com/klauspost/compress/s2.WriterPaddingSrc(reader Reader) s2.WriterOption func github.com/klauspost/compress/s2.(*Reader).Reset(reader Reader) func github.com/klauspost/compress/s2.(*Writer).ReadFrom(r Reader) (n int64, err error) func github.com/klauspost/compress/snappy.NewReader(r Reader) *snappy.Reader func github.com/klauspost/compress/zstd.NewReader(r Reader, opts ...zstd.DOption) (*zstd.Decoder, error) func github.com/klauspost/compress/zstd.(*Decoder).Reset(r Reader) error func github.com/klauspost/compress/zstd.(*Encoder).ReadFrom(r Reader) (n int64, err error) func github.com/klauspost/compress/zstd.(*SnappyConverter).Convert(in Reader, w Writer) (int64, error) func github.com/libp2p/go-buffer-pool.(*Buffer).ReadFrom(r Reader) (int64, error) func github.com/libp2p/go-libp2p/core/crypto.GenerateECDSAKeyPair(src Reader) (crypto.PrivKey, crypto.PubKey, error) func github.com/libp2p/go-libp2p/core/crypto.GenerateECDSAKeyPairWithCurve(curve elliptic.Curve, src Reader) (crypto.PrivKey, crypto.PubKey, error) func github.com/libp2p/go-libp2p/core/crypto.GenerateEd25519Key(src Reader) (crypto.PrivKey, crypto.PubKey, error) func github.com/libp2p/go-libp2p/core/crypto.GenerateKeyPairWithReader(typ, bits int, src Reader) (crypto.PrivKey, crypto.PubKey, error) func github.com/libp2p/go-libp2p/core/crypto.GenerateRSAKeyPair(bits int, src Reader) (crypto.PrivKey, crypto.PubKey, error) func github.com/libp2p/go-libp2p/core/crypto.GenerateSecp256k1Key(_ Reader) (crypto.PrivKey, crypto.PubKey, error) func github.com/libp2p/go-libp2p/core/pnet.DecodeV1PSK(in Reader) (pnet.PSK, error) func github.com/libp2p/go-libp2p/p2p/host/resource-manager.NewDefaultLimiterFromJSON(in Reader) (rcmgr.Limiter, error) func github.com/libp2p/go-libp2p/p2p/host/resource-manager.NewLimiterFromJSON(in Reader, defaults rcmgr.ConcreteLimitConfig) (rcmgr.Limiter, error) func github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/util.NewDelimitedReader(r Reader, maxSize int) *util.DelimitedReader func github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface.ReadFrom(r Reader) (n int64, err error) func github.com/libp2p/go-msgio.LimitedReader(r Reader) (Reader, error) func github.com/libp2p/go-msgio.NewReader(r Reader) msgio.ReadCloser func github.com/libp2p/go-msgio.NewReaderSize(r Reader, maxMessageSize int) msgio.ReadCloser func github.com/libp2p/go-msgio.NewReaderSizeWithPool(r Reader, maxMessageSize int, p *pool.BufferPool) msgio.ReadCloser func github.com/libp2p/go-msgio.NewReaderWithPool(r Reader, p *pool.BufferPool) msgio.ReadCloser func github.com/libp2p/go-msgio.NewVarintReader(r Reader) msgio.ReadCloser func github.com/libp2p/go-msgio.NewVarintReaderSize(r Reader, maxMessageSize int) msgio.ReadCloser func github.com/libp2p/go-msgio.NewVarintReaderSizeWithPool(r Reader, maxMessageSize int, p *pool.BufferPool) msgio.ReadCloser func github.com/libp2p/go-msgio.NewVarintReaderWithPool(r Reader, p *pool.BufferPool) msgio.ReadCloser func github.com/libp2p/go-msgio.ReadLen(r Reader, buf []byte) (int, error) func github.com/libp2p/go-msgio/pbio.NewDelimitedReader(r Reader, maxSize int) pbio.ReadCloser func github.com/libp2p/go-msgio/protoio.NewDelimitedReader(r Reader, maxSize int) protoio.ReadCloser func github.com/mailru/easyjson.UnmarshalFromReader(r Reader, v easyjson.Unmarshaler) error func github.com/miekg/dns.ClientConfigFromReader(resolvconf Reader) (*dns.ClientConfig, error) func github.com/miekg/dns.NewZoneParser(r Reader, origin, file string) *dns.ZoneParser func github.com/miekg/dns.ReadRR(r Reader, file string) (dns.RR, error) func github.com/miekg/dns.(*DNSKEY).ReadPrivateKey(q Reader, file string) (crypto.PrivateKey, error) func github.com/multiformats/go-base32.NewDecoder(enc *base32.Encoding, r Reader) Reader func github.com/multiformats/go-multihash.NewReader(r Reader) multihash.Reader func github.com/multiformats/go-multihash.SumStream(r Reader, code uint64, length int) (multihash.Multihash, error) func github.com/multiformats/go-multistream.ReadNextToken[T](r Reader) (T, error) func github.com/multiformats/go-multistream.ReadNextTokenBytes(r Reader) ([]byte, error) func github.com/nats-io/nats.go.ObjectStore.Put(obj *nats.ObjectMeta, reader Reader, opts ...nats.ObjectOpt) (*nats.ObjectInfo, error) func github.com/nats-io/nkeys.CreateCurveKeysWithRand(rr Reader) (nkeys.KeyPair, error) func github.com/nats-io/nkeys.CreatePairWithRand(prefix nkeys.PrefixByte, rr Reader) (nkeys.KeyPair, error) func github.com/nats-io/nkeys.KeyPair.SealWithRand(input []byte, recipient string, rr Reader) ([]byte, error) func github.com/ncruces/go-sqlite3.(*Blob).ReadFrom(r Reader) (n int64, err error) func github.com/oklog/ulid.Monotonic(entropy Reader, inc uint64) Reader func github.com/oklog/ulid.MustNew(ms uint64, entropy Reader) ulid.ULID func github.com/oklog/ulid.New(ms uint64, entropy Reader) (id ulid.ULID, err error) func github.com/oklog/ulid/v2.Monotonic(entropy Reader, inc uint64) *ulid.MonotonicEntropy func github.com/oklog/ulid/v2.MustNew(ms uint64, entropy Reader) ulid.ULID func github.com/oklog/ulid/v2.New(ms uint64, entropy Reader) (id ulid.ULID, err error) func github.com/parquet-go/parquet-go/compress.Reader.Reset(Reader) error func github.com/parquet-go/parquet-go/encoding/thrift.(*BinaryProtocol).NewReader(r Reader) thrift.Reader func github.com/parquet-go/parquet-go/encoding/thrift.(*CompactProtocol).NewReader(r Reader) thrift.Reader func github.com/parquet-go/parquet-go/encoding/thrift.Protocol.NewReader(r Reader) thrift.Reader func github.com/parquet-go/parquet-go/internal/debug.Reader(reader Reader, prefix string) Reader func github.com/pierrec/lz4/v4.NewReader(r Reader) *lz4.Reader func github.com/pierrec/lz4/v4.(*Reader).Reset(reader Reader) func github.com/pierrec/lz4/v4.(*Writer).ReadFrom(r Reader) (n int64, err error) func github.com/pierrec/lz4/v4/internal/lz4stream.(*Frame).CloseR(src Reader) (err error) func github.com/pierrec/lz4/v4/internal/lz4stream.(*Frame).InitR(src Reader, num int) (chan []byte, error) func github.com/pierrec/lz4/v4/internal/lz4stream.(*Frame).ParseHeaders(src Reader) error func github.com/pierrec/lz4/v4/internal/lz4stream.(*FrameDataBlock).Read(f *lz4stream.Frame, src Reader, cum uint32) (uint32, error) func github.com/pion/stun.(*Message).ReadFrom(r Reader) (int64, error) func github.com/pion/stun/v3.(*Message).ReadFrom(r Reader) (int64, error) func github.com/pion/transport/v2.TCPConn.ReadFrom(r Reader) (int64, error) func github.com/pion/transport/v3.TCPConn.ReadFrom(r Reader) (int64, error) func github.com/polarsignals/frostdb.StoreSnapshot(ctx context.Context, tx uint64, db *frostdb.DB, snapshot Reader) error func github.com/polarsignals/frostdb.DataSink.Upload(ctx context.Context, name string, r Reader) error func github.com/polarsignals/frostdb.DataSinkSource.Upload(ctx context.Context, name string, r Reader) error func github.com/polarsignals/frostdb/storage.Bucket.Upload(ctx context.Context, name string, r Reader) error func github.com/polarsignals/frostdb/storage.(*Iceberg).Upload(ctx context.Context, name string, r Reader) error func github.com/polarsignals/iceberg-go.ReadManifestList(in Reader) ([]iceberg.ManifestFile, error) func github.com/polarsignals/iceberg-go/table.ParseMetadata(r Reader) (table.Metadata, error) func github.com/polarsignals/iceberg-go/table.SnapshotWriter.Append(ctx context.Context, r Reader) error func github.com/prometheus/common/expfmt.NewDecoder(r Reader, format expfmt.Format) expfmt.Decoder func github.com/prometheus/common/expfmt.(*TextParser).TextToMetricFamilies(in Reader) (map[string]*dto.MetricFamily, error) func github.com/PuerkitoBio/goquery.NewDocumentFromReader(r Reader) (*goquery.Document, error) func github.com/quic-go/quic-go/internal/protocol.ReadConnectionID(r Reader, l int) (protocol.ConnectionID, error) func github.com/quic-go/quic-go/quicvarint.NewReader(r Reader) quicvarint.Reader func github.com/redis/go-redis/v9/internal/proto.NewReader(rd Reader) *proto.Reader func github.com/redis/go-redis/v9/internal/proto.(*Reader).Reset(rd Reader) func github.com/reeflective/readline/inputrc.Parse(r Reader, h inputrc.Handler, opts ...inputrc.Option) error func github.com/reeflective/readline/inputrc.(*Parser).Parse(stream Reader, handler inputrc.Handler) error func github.com/RoaringBitmap/roaring.(*Bitmap).ReadFrom(reader Reader, cookieHeader ...byte) (p int64, err error) func github.com/RoaringBitmap/roaring/internal.NewByteInputFromReader(reader Reader) internal.ByteInput func github.com/RoaringBitmap/roaring/internal.(*ByteInputAdapter).Reset(stream Reader) func github.com/shirou/gopsutil/v3/internal/common.Read(r Reader, order common.ByteOrder, data interface{}) error func github.com/spf13/cobra.(*Command).SetIn(newIn Reader) func github.com/tetratelabs/wazero.ModuleConfig.WithRandSource(Reader) wazero.ModuleConfig func github.com/tetratelabs/wazero.ModuleConfig.WithStdin(Reader) wazero.ModuleConfig func github.com/tetratelabs/wazero/internal/filecache.Cache.Add(key filecache.Key, content Reader) (err error) func github.com/tetratelabs/wazero/internal/sys.NewContext(max uint32, args, environ [][]byte, stdin Reader, stdout, stderr Writer, randSource Reader, walltime sys.Walltime, walltimeResolution sys.ClockResolution, nanotime sys.Nanotime, nanotimeResolution sys.ClockResolution, nanosleep sys.Nanosleep, osyield sys.Osyield, fs []experimentalsys.FS, guestPaths []string, tcpListeners []*net.TCPListener) (sysCtx *sys.Context, err error) func github.com/tetratelabs/wazero/internal/sys.NewContext(max uint32, args, environ [][]byte, stdin Reader, stdout, stderr Writer, randSource Reader, walltime sys.Walltime, walltimeResolution sys.ClockResolution, nanotime sys.Nanotime, nanotimeResolution sys.ClockResolution, nanosleep sys.Nanosleep, osyield sys.Osyield, fs []experimentalsys.FS, guestPaths []string, tcpListeners []*net.TCPListener) (sysCtx *sys.Context, err error) func github.com/tetratelabs/wazero/internal/sys.(*Context).InitFSContext(stdin Reader, stdout, stderr Writer, fs []sys.FS, guestPaths []string, tcpListeners []*net.TCPListener) (err error) func github.com/thanos-io/objstore.NopCloserWithSize(r Reader) ReadCloser func github.com/thanos-io/objstore.TryToGetSize(r Reader) (int64, error) func github.com/thanos-io/objstore.Bucket.Upload(ctx context.Context, name string, r Reader) error func github.com/thanos-io/objstore.(*InMemBucket).Upload(_ context.Context, name string, r Reader) error func github.com/thanos-io/objstore.InstrumentedBucket.Upload(ctx context.Context, name string, r Reader) error func github.com/thanos-io/objstore.(*PrefixedBucket).Upload(ctx context.Context, name string, r Reader) error func github.com/vmihailenco/msgpack/v5.NewDecoder(r Reader) *msgpack.Decoder func github.com/vmihailenco/msgpack/v5.(*Decoder).Reset(r Reader) func github.com/vmihailenco/msgpack/v5.(*Decoder).ResetDict(r Reader, dict []string) func github.com/vmihailenco/msgpack/v5.(*Decoder).ResetReader(r Reader) func golang.org/x/crypto/nacl/box.GenerateKey(rand Reader) (publicKey, privateKey *[32]byte, err error) func golang.org/x/crypto/nacl/box.SealAnonymous(out, message []byte, recipient *[32]byte, rand Reader) ([]byte, error) func golang.org/x/crypto/ssh.AlgorithmSigner.Sign(rand Reader, data []byte) (*ssh.Signature, error) func golang.org/x/crypto/ssh.AlgorithmSigner.SignWithAlgorithm(rand Reader, data []byte, algorithm string) (*ssh.Signature, error) func golang.org/x/crypto/ssh.(*Certificate).SignCert(rand Reader, authority ssh.Signer) error func golang.org/x/crypto/ssh.MultiAlgorithmSigner.Sign(rand Reader, data []byte) (*ssh.Signature, error) func golang.org/x/crypto/ssh.MultiAlgorithmSigner.SignWithAlgorithm(rand Reader, data []byte, algorithm string) (*ssh.Signature, error) func golang.org/x/crypto/ssh.Signer.Sign(rand Reader, data []byte) (*ssh.Signature, error) func golang.org/x/net/html.NewTokenizer(r Reader) *html.Tokenizer func golang.org/x/net/html.NewTokenizerFragment(r Reader, contextTag string) *html.Tokenizer func golang.org/x/net/html.Parse(r Reader) (*html.Node, error) func golang.org/x/net/html.ParseFragment(r Reader, context *html.Node) ([]*html.Node, error) func golang.org/x/net/html.ParseFragmentWithOptions(r Reader, context *html.Node, opts ...html.ParseOption) ([]*html.Node, error) func golang.org/x/net/html.ParseWithOptions(r Reader, opts ...html.ParseOption) (*html.Node, error) func golang.org/x/net/http2.NewFramer(w Writer, r Reader) *http2.Framer func golang.org/x/net/http2.ReadFrameHeader(r Reader) (http2.FrameHeader, error) func golang.org/x/text/encoding.(*Decoder).Reader(r Reader) Reader func golang.org/x/text/transform.NewReader(r Reader, t transform.Transformer) *transform.Reader func golang.org/x/text/unicode/norm.Form.Reader(r Reader) Reader func google.golang.org/grpc.Decompressor.Do(r Reader) ([]byte, error) func google.golang.org/grpc/encoding.Compressor.Decompress(r Reader) (Reader, error) func google.golang.org/grpc/mem.ReadAll(r Reader, pool mem.BufferPool) (mem.BufferSlice, error) func gopkg.in/yaml.v3.NewDecoder(r Reader) *yaml.Decoder func image.Decode(r Reader) (image.Image, string, error) func image.DecodeConfig(r Reader) (image.Config, string, error) func internal/profile.Parse(r Reader) (*profile.Profile, error) func internal/saferio.ReadData(r Reader, n uint64) ([]byte, error) func lukechampine.com/blake3.BaoDecode(dst Writer, data, outboard Reader, root [32]byte) (bool, error) func lukechampine.com/blake3.BaoEncode(dst WriterAt, data Reader, dataLen int64, outboard bool) ([32]byte, error) func lukechampine.com/blake3/bao.Decode(dst Writer, data, outboard Reader, group int, root [32]byte) (bool, error) func lukechampine.com/blake3/bao.DecodeSlice(dst Writer, data Reader, group int, offset, length uint64, root [32]byte) (bool, error) func lukechampine.com/blake3/bao.Encode(dst WriterAt, data Reader, dataLen int64, group int, outboard bool) ([32]byte, error) func lukechampine.com/blake3/bao.ExtractSlice(dst Writer, data, outboard Reader, group int, offset uint64, length uint64) error func mime/multipart.NewReader(r Reader, boundary string) *multipart.Reader func mime/quotedprintable.NewReader(r Reader) *quotedprintable.Reader func mvdan.cc/sh/v3/syntax.(*Parser).Arithmetic(r Reader) (syntax.ArithmExpr, error) func mvdan.cc/sh/v3/syntax.(*Parser).Document(r Reader) (*syntax.Word, error) func mvdan.cc/sh/v3/syntax.(*Parser).Interactive(r Reader, fn func([]*syntax.Stmt) bool) error func mvdan.cc/sh/v3/syntax.(*Parser).Parse(r Reader, name string) (*syntax.File, error) func mvdan.cc/sh/v3/syntax.(*Parser).Stmts(r Reader, fn func(*syntax.Stmt) bool) error func mvdan.cc/sh/v3/syntax.(*Parser).Words(r Reader, fn func(*syntax.Word) bool) error func net.(*TCPConn).ReadFrom(r Reader) (int64, error) func net/http.NewRequest(method, url string, body Reader) (*http.Request, error) func net/http.NewRequestWithContext(ctx context.Context, method, url string, body Reader) (*http.Request, error) func net/http.Post(url, contentType string, body Reader) (resp *http.Response, err error) func net/http.(*Client).Post(url, contentType string, body Reader) (resp *http.Response, err error) func net/http/httptest.NewRequest(method, target string, body Reader) *http.Request func net/http/httptest.NewRequestWithContext(ctx context.Context, method, target string, body Reader) *http.Request func net/http/httputil.NewChunkedReader(r Reader) Reader func net/http/internal.NewChunkedReader(r Reader) Reader func net/mail.ReadMessage(r Reader) (msg *mail.Message, err error) func os.(*File).ReadFrom(r Reader) (n int64, err error) func oss.terrastruct.com/d2/d2compiler.Compile(p string, r Reader, opts *d2compiler.CompileOptions) (*d2graph.Graph, *d2target.Config, error) func oss.terrastruct.com/d2/d2parser.Parse(path string, r Reader, opts *d2parser.ParseOptions) (*d2ast.Map, error) func vendor/golang.org/x/text/transform.NewReader(r Reader, t transform.Transformer) *transform.Reader func vendor/golang.org/x/text/unicode/norm.Form.Reader(r Reader) Reader var crypto/rand.Reader
ReaderAt is the interface that wraps the basic ReadAt method. ReadAt reads len(p) bytes into p starting at offset off in the underlying input source. It returns the number of bytes read (0 <= n <= len(p)) and any error encountered. When ReadAt returns n < len(p), it returns a non-nil error explaining why more bytes were not returned. In this respect, ReadAt is stricter than Read. Even if ReadAt returns n < len(p), it may use all of p as scratch space during the call. If some data is available but not len(p) bytes, ReadAt blocks until either all the data is available or an error occurs. In this respect ReadAt is different from Read. If the n = len(p) bytes returned by ReadAt are at the end of the input source, ReadAt may return either err == EOF or err == nil. If ReadAt is reading from an input source with a seek offset, ReadAt should not affect nor be affected by the underlying seek offset. Clients of ReadAt can execute parallel ReadAt calls on the same input source. Implementations must not retain p. ( ReaderAt) ReadAt(p []byte, off int64) (n int, err error) *SectionReader *bytes.Reader github.com/apache/arrow-go/v18/arrow/ipc.ReadAtSeeker (interface) github.com/apache/arrow-go/v18/internal/utils.Reader (interface) github.com/apache/arrow-go/v18/parquet.ReaderAtSeeker (interface) github.com/coreos/etcd/pkg/fileutil.LockedFile *github.com/klauspost/compress/s2.ReadSeeker github.com/ncruces/go-sqlite3/vfs.File (interface) github.com/ncruces/go-sqlite3/vfs.FileBatchAtomicWrite (interface) github.com/ncruces/go-sqlite3/vfs.FileBusyHandler (interface) github.com/ncruces/go-sqlite3/vfs.FileCheckpoint (interface) github.com/ncruces/go-sqlite3/vfs.FileChunkSize (interface) github.com/ncruces/go-sqlite3/vfs.FileCommitPhaseTwo (interface) github.com/ncruces/go-sqlite3/vfs.FileHasMoved (interface) github.com/ncruces/go-sqlite3/vfs.FileLockState (interface) github.com/ncruces/go-sqlite3/vfs.FileOverwrite (interface) github.com/ncruces/go-sqlite3/vfs.FilePersistWAL (interface) github.com/ncruces/go-sqlite3/vfs.FilePowersafeOverwrite (interface) github.com/ncruces/go-sqlite3/vfs.FilePragma (interface) github.com/ncruces/go-sqlite3/vfs.FileSharedMemory (interface) github.com/ncruces/go-sqlite3/vfs.FileSizeHint (interface) github.com/ncruces/go-sqlite3/vfs.FileSync (interface) github.com/ncruces/go-sqlite3/vfs.FileUnwrap (interface) github.com/parquet-go/parquet-go.BloomFilter (interface) *github.com/parquet-go/parquet-go.File *github.com/polarsignals/frostdb/storage.FileReaderAt *github.com/polarsignals/wal/fs.File github.com/polarsignals/wal/types.ReadableFile (interface) github.com/polarsignals/wal/types.WritableFile (interface) mime/multipart.File (interface) *os.File *strings.Reader func (*SectionReader).Outer() (r ReaderAt, off int64, n int64) func github.com/parquet-go/parquet-go/internal/debug.ReaderAt(reader ReaderAt, prefix string) ReaderAt func github.com/polarsignals/frostdb/storage.Bucket.GetReaderAt(ctx context.Context, name string) (ReaderAt, error) func github.com/polarsignals/frostdb/storage.(*BucketReaderAt).GetReaderAt(ctx context.Context, name string) (ReaderAt, error) func NewSectionReader(r ReaderAt, off int64, n int64) *SectionReader func github.com/apache/arrow-go/v18/parquet.(*ReaderProperties).GetStream(source ReaderAt, start, nbytes int64) (parquet.BufferedReader, error) func github.com/parquet-go/parquet-go.NewGenericReader[T](input ReaderAt, options ...parquet.ReaderOption) *parquet.GenericReader[T] func github.com/parquet-go/parquet-go.NewReader(input ReaderAt, options ...parquet.ReaderOption) *parquet.Reader func github.com/parquet-go/parquet-go.OpenFile(r ReaderAt, size int64, options ...parquet.FileOption) (*parquet.File, error) func github.com/parquet-go/parquet-go.Read[T](r ReaderAt, size int64, options ...parquet.ReaderOption) (rows []T, err error) func github.com/parquet-go/parquet-go/bloom.CheckSplitBlock(r ReaderAt, n int64, x uint64) (bool, error) func github.com/parquet-go/parquet-go/internal/debug.ReaderAt(reader ReaderAt, prefix string) ReaderAt func github.com/polarsignals/frostdb.LoadSnapshot(ctx context.Context, db *frostdb.DB, tx uint64, r ReaderAt, size int64, dir string, truncateWAL bool) (uint64, error) func github.com/polarsignals/iceberg-go.DataFileFromParquet(path string, size int64, schema *iceberg.Schema, r ReaderAt) (iceberg.DataFile, *iceberg.Schema, error) func github.com/polarsignals/iceberg-go.ManifestEntryV1FromParquet(path string, size int64, schema *iceberg.Schema, r ReaderAt) (iceberg.ManifestEntry, *iceberg.Schema, error) func golang.org/x/image/font/opentype.ParseCollectionReaderAt(src ReaderAt) (*opentype.Collection, error) func golang.org/x/image/font/opentype.ParseReaderAt(src ReaderAt) (*opentype.Font, error) func golang.org/x/image/font/sfnt.ParseCollectionReaderAt(src ReaderAt) (*sfnt.Collection, error) func golang.org/x/image/font/sfnt.ParseReaderAt(src ReaderAt) (*sfnt.Font, error) func internal/saferio.ReadDataAt(r ReaderAt, n uint64, off int64) ([]byte, error)
ReaderFrom is the interface that wraps the ReadFrom method. ReadFrom reads data from r until EOF or error. The return value n is the number of bytes read. Any error except EOF encountered during the read is also returned. The [Copy] function uses [ReaderFrom] if available. ( ReaderFrom) ReadFrom(r Reader) (n int64, err error) bufio.ReadWriter *bufio.Writer *bytes.Buffer github.com/apache/thrift/lib/go/thrift.TBufferedTransport github.com/apache/thrift/lib/go/thrift.TMemoryBuffer *github.com/bits-and-blooms/bitset.BitSet github.com/coreos/etcd/pkg/fileutil.LockedFile *github.com/gobwas/ws/wsutil.Writer *github.com/klauspost/compress/s2.Writer *github.com/klauspost/compress/zstd.Encoder *github.com/libp2p/go-buffer-pool.Buffer github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface (interface) *github.com/ncruces/go-sqlite3.Blob *github.com/pierrec/lz4/v4.Writer *github.com/pion/stun.Message *github.com/pion/stun/v3.Message github.com/pion/transport/v2.TCPConn (interface) github.com/pion/transport/v3.TCPConn (interface) github.com/pion/turn/v4/internal/client.TCPConn *github.com/polarsignals/wal/fs.File *net.TCPConn net/http/internal.FlushAfterChunkWriter *os.File
ReadSeekCloser is the interface that groups the basic Read, Seek and Close methods. ( ReadSeekCloser) Close() error ( ReadSeekCloser) Read(p []byte) (n int, err error) ( ReadSeekCloser) Seek(offset int64, whence int) (int64, error) github.com/coreos/etcd/pkg/fileutil.LockedFile *github.com/ncruces/go-sqlite3.Blob *github.com/polarsignals/wal/fs.File *internal/poll.FD mime/multipart.File (interface) net/http.File (interface) *os.File ReadSeekCloser : Closer ReadSeekCloser : ReadCloser ReadSeekCloser : Reader ReadSeekCloser : ReadSeeker ReadSeekCloser : Seeker ReadSeekCloser : github.com/prometheus/common/expfmt.Closer
ReadSeeker is the interface that groups the basic Read and Seek methods. ( ReadSeeker) Read(p []byte) (n int, err error) ( ReadSeeker) Seek(offset int64, whence int) (int64, error) ReadSeekCloser (interface) ReadWriteSeeker (interface) *SectionReader *bytes.Reader github.com/apache/arrow-go/v18/arrow/ipc.ReadAtSeeker (interface) github.com/apache/arrow-go/v18/internal/utils.Reader (interface) github.com/coreos/etcd/pkg/fileutil.LockedFile *github.com/klauspost/compress/s2.ReadSeeker *github.com/ncruces/go-sqlite3.Blob *github.com/polarsignals/wal/fs.File *internal/poll.FD *lukechampine.com/blake3.OutputReader mime/multipart.File (interface) net/http.File (interface) *os.File *strings.Reader ReadSeeker : Reader ReadSeeker : Seeker func github.com/klauspost/compress/s2.(*Index).LoadStream(rs ReadSeeker) error func net/http.ServeContent(w http.ResponseWriter, req *http.Request, name string, modtime time.Time, content ReadSeeker)
ReadWriteCloser is the interface that groups the basic Read, Write and Close methods. ( ReadWriteCloser) Close() error ( ReadWriteCloser) Read(p []byte) (n int, err error) ( ReadWriteCloser) Write([]byte) (int, error) *crypto/tls.Conn github.com/apache/thrift/lib/go/thrift.RichTransport *github.com/apache/thrift/lib/go/thrift.StreamTransport *github.com/apache/thrift/lib/go/thrift.TBufferedTransport *github.com/apache/thrift/lib/go/thrift.TFramedTransport *github.com/apache/thrift/lib/go/thrift.THeaderTransport *github.com/apache/thrift/lib/go/thrift.THttpClient *github.com/apache/thrift/lib/go/thrift.TMemoryBuffer *github.com/apache/thrift/lib/go/thrift.TSocket *github.com/apache/thrift/lib/go/thrift.TSSLSocket github.com/apache/thrift/lib/go/thrift.TTransport (interface) *github.com/apache/thrift/lib/go/thrift.TZlibTransport github.com/coreos/etcd/pkg/fileutil.LockedFile github.com/gdamore/tcell/v2.Tty (interface) github.com/gliderlabs/ssh.Session (interface) github.com/libp2p/go-libp2p/core/network.MuxedStream (interface) github.com/libp2p/go-libp2p/core/network.Stream (interface) github.com/libp2p/go-libp2p/core/sec.SecureConn (interface) github.com/libp2p/go-libp2p/core/sec/insecure.Conn *github.com/libp2p/go-libp2p/p2p/net/swarm.Stream *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.Conn github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface (interface) *github.com/libp2p/go-libp2p/p2p/transport/websocket.Conn github.com/libp2p/go-msgio.ReadWriteCloser (interface) *github.com/libp2p/go-yamux/v5.Stream github.com/marten-seemann/tcp.Conn *github.com/miekg/dns.Conn github.com/miekg/dns.Transfer github.com/multiformats/go-multiaddr/net.Conn (interface) github.com/multiformats/go-multistream.LazyConn (interface) *github.com/ncruces/go-sqlite3.Blob *github.com/pion/datachannel.DataChannel github.com/pion/datachannel.ReadWriteCloser (interface) github.com/pion/datachannel.ReadWriteCloserDeadliner (interface) *github.com/pion/dtls/v2.Conn *github.com/pion/dtls/v3.Conn *github.com/pion/ice/v4.Conn github.com/pion/ice/v4/internal/fakenet.PacketConn *github.com/pion/sctp.Stream github.com/pion/stun.Connection (interface) github.com/pion/stun/v3.Connection (interface) github.com/pion/transport/v2.TCPConn (interface) github.com/pion/transport/v2.UDPConn (interface) *github.com/pion/transport/v2/packetio.Buffer *github.com/pion/transport/v2/udp.Conn github.com/pion/transport/v3.TCPConn (interface) github.com/pion/transport/v3.UDPConn (interface) *github.com/pion/transport/v3/packetio.Buffer *github.com/pion/transport/v3/vnet.UDPConn github.com/pion/turn/v4/internal/client.TCPConn *github.com/pion/webrtc/v4/internal/mux.Endpoint *github.com/polarsignals/wal/fs.File github.com/quic-go/quic-go.Stream (interface) github.com/quic-go/quic-go/http3.RequestStream (interface) github.com/quic-go/quic-go/http3.Stream (interface) github.com/quic-go/webtransport-go.Stream (interface) *github.com/soheilhy/cmux.MuxConn golang.org/x/crypto/ssh.Channel (interface) golang.org/x/net/internal/socks.Conn *golang.org/x/net/ipv4.RawConn *internal/poll.FD net.Conn (interface) *net.IPConn *net.TCPConn *net.UDPConn *net.UnixConn *os.File ReadWriteCloser : Closer ReadWriteCloser : ReadCloser ReadWriteCloser : Reader ReadWriteCloser : ReadWriter ReadWriteCloser : WriteCloser ReadWriteCloser : Writer ReadWriteCloser : github.com/miekg/dns.Writer ReadWriteCloser : github.com/pion/stun.Connection ReadWriteCloser : github.com/pion/stun/v3.Connection ReadWriteCloser : github.com/prometheus/common/expfmt.Closer ReadWriteCloser : internal/bisect.Writer func github.com/cenkalti/rpc2.NewClient(conn ReadWriteCloser) *rpc2.Client func github.com/cenkalti/rpc2.NewGobCodec(conn ReadWriteCloser) rpc2.Codec func github.com/cenkalti/rpc2.(*Server).ServeConn(conn ReadWriteCloser) func github.com/libp2p/go-libp2p/core/protocol.Negotiator.Handle(rwc ReadWriteCloser) error func github.com/libp2p/go-libp2p/core/protocol.Negotiator.Negotiate(rwc ReadWriteCloser) (protocol.ID, protocol.HandlerFunc, error) func github.com/libp2p/go-libp2p/core/protocol.Switch.Handle(rwc ReadWriteCloser) error func github.com/libp2p/go-libp2p/core/protocol.Switch.Negotiate(rwc ReadWriteCloser) (protocol.ID, protocol.HandlerFunc, error) func github.com/multiformats/go-multistream.NewMSSelect[T](c ReadWriteCloser, proto T) multistream.LazyConn func github.com/multiformats/go-multistream.NewMultistream[T](c ReadWriteCloser, proto T) multistream.LazyConn func github.com/multiformats/go-multistream.SelectOneOf[T](protos []T, rwc ReadWriteCloser) (proto T, err error) func github.com/multiformats/go-multistream.SelectProtoOrFail[T](proto T, rwc ReadWriteCloser) (err error) func github.com/multiformats/go-multistream.(*MultistreamMuxer)[T].Handle(rwc ReadWriteCloser) error func github.com/multiformats/go-multistream.(*MultistreamMuxer)[T].Negotiate(rwc ReadWriteCloser) (proto T, handler multistream.HandlerFunc[T], err error) func net/rpc.NewClient(conn ReadWriteCloser) *rpc.Client func net/rpc.ServeConn(conn ReadWriteCloser) func net/rpc.(*Server).ServeConn(conn ReadWriteCloser) func net/textproto.NewConn(conn ReadWriteCloser) *textproto.Conn
ReadWriter is the interface that groups the basic Read and Write methods. ( ReadWriter) Read(p []byte) (n int, err error) ( ReadWriter) Write([]byte) (int, error) ReadWriteCloser (interface) ReadWriteSeeker (interface) bufio.ReadWriter *bytes.Buffer *crypto/internal/fips140/sha3.SHAKE *crypto/sha3.SHAKE *crypto/tls.Conn github.com/apache/thrift/lib/go/thrift.RichTransport *github.com/apache/thrift/lib/go/thrift.StreamTransport *github.com/apache/thrift/lib/go/thrift.TBufferedTransport *github.com/apache/thrift/lib/go/thrift.TFramedTransport *github.com/apache/thrift/lib/go/thrift.THeaderTransport *github.com/apache/thrift/lib/go/thrift.THttpClient github.com/apache/thrift/lib/go/thrift.TMemoryBuffer github.com/apache/thrift/lib/go/thrift.TRichTransport (interface) *github.com/apache/thrift/lib/go/thrift.TSocket *github.com/apache/thrift/lib/go/thrift.TSSLSocket github.com/apache/thrift/lib/go/thrift.TTransport (interface) *github.com/apache/thrift/lib/go/thrift.TZlibTransport github.com/coreos/etcd/pkg/fileutil.LockedFile github.com/gdamore/tcell/v2.Tty (interface) github.com/gliderlabs/ssh.Session (interface) *github.com/libp2p/go-buffer-pool.Buffer github.com/libp2p/go-libp2p/core/network.MuxedStream (interface) github.com/libp2p/go-libp2p/core/network.Stream (interface) github.com/libp2p/go-libp2p/core/sec.SecureConn (interface) github.com/libp2p/go-libp2p/core/sec/insecure.Conn *github.com/libp2p/go-libp2p/p2p/net/swarm.Stream *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.Conn github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface (interface) *github.com/libp2p/go-libp2p/p2p/transport/websocket.Conn github.com/libp2p/go-msgio.ReadWriteCloser (interface) github.com/libp2p/go-msgio.ReadWriter (interface) *github.com/libp2p/go-yamux/v5.Stream github.com/marten-seemann/tcp.Conn *github.com/miekg/dns.Conn github.com/miekg/dns.Transfer github.com/multiformats/go-multiaddr/net.Conn (interface) github.com/multiformats/go-multistream.LazyConn (interface) *github.com/ncruces/go-sqlite3.Blob *github.com/pion/datachannel.DataChannel github.com/pion/datachannel.ReadWriteCloser (interface) github.com/pion/datachannel.ReadWriteCloserDeadliner (interface) *github.com/pion/dtls/v2.Conn *github.com/pion/dtls/v3.Conn *github.com/pion/ice/v4.Conn github.com/pion/ice/v4/internal/fakenet.PacketConn *github.com/pion/sctp.Stream github.com/pion/stun.Connection (interface) github.com/pion/stun/v3.Connection (interface) github.com/pion/transport/v2.TCPConn (interface) github.com/pion/transport/v2.UDPConn (interface) *github.com/pion/transport/v2/packetio.Buffer *github.com/pion/transport/v2/udp.Conn github.com/pion/transport/v3.TCPConn (interface) github.com/pion/transport/v3.UDPConn (interface) *github.com/pion/transport/v3/packetio.Buffer *github.com/pion/transport/v3/vnet.UDPConn github.com/pion/turn/v4/internal/client.TCPConn *github.com/pion/webrtc/v4/internal/mux.Endpoint *github.com/polarsignals/wal/fs.File github.com/quic-go/quic-go.Stream (interface) github.com/quic-go/quic-go/http3.RequestStream (interface) github.com/quic-go/quic-go/http3.Stream (interface) github.com/quic-go/webtransport-go.Stream (interface) *github.com/soheilhy/cmux.MuxConn golang.org/x/crypto/blake2b.XOF (interface) golang.org/x/crypto/blake2s.XOF (interface) golang.org/x/crypto/sha3.ShakeHash (interface) golang.org/x/crypto/ssh.Channel (interface) golang.org/x/net/internal/socks.Conn golang.org/x/net/ipv4.RawConn hash.XOF (interface) *internal/poll.FD net.Conn (interface) *net.IPConn *net.TCPConn *net.UDPConn *net.UnixConn *os.File ReadWriter : Reader ReadWriter : Writer ReadWriter : github.com/miekg/dns.Writer ReadWriter : internal/bisect.Writer func github.com/gliderlabs/ssh.Session.Stderr() ReadWriter func golang.org/x/crypto/ssh.Channel.Stderr() ReadWriter func github.com/apache/thrift/lib/go/thrift.NewStreamTransportRW(rw ReadWriter) *thrift.StreamTransport func github.com/gobwas/ws.Upgrade(conn ReadWriter) (ws.Handshake, error) func github.com/gobwas/ws.Dialer.Upgrade(conn ReadWriter, u *url.URL) (br *bufio.Reader, hs ws.Handshake, err error) func github.com/gobwas/ws.Upgrader.Upgrade(conn ReadWriter) (hs ws.Handshake, err error) func github.com/gobwas/ws/wsutil.ReadClientBinary(rw ReadWriter) ([]byte, error) func github.com/gobwas/ws/wsutil.ReadClientData(rw ReadWriter) ([]byte, ws.OpCode, error) func github.com/gobwas/ws/wsutil.ReadClientText(rw ReadWriter) ([]byte, error) func github.com/gobwas/ws/wsutil.ReadData(rw ReadWriter, s ws.State) ([]byte, ws.OpCode, error) func github.com/gobwas/ws/wsutil.ReadServerBinary(rw ReadWriter) ([]byte, error) func github.com/gobwas/ws/wsutil.ReadServerData(rw ReadWriter) ([]byte, ws.OpCode, error) func github.com/gobwas/ws/wsutil.ReadServerText(rw ReadWriter) ([]byte, error) func github.com/gobwas/ws/wsutil.(*DebugUpgrader).Upgrade(conn ReadWriter) (hs ws.Handshake, err error) func github.com/libp2p/go-msgio.NewReadWriter(rw ReadWriter) msgio.ReadWriteCloser func golang.org/x/net/internal/socks.(*UsernamePassword).Authenticate(ctx context.Context, rw ReadWriter, auth socks.AuthMethod) error func golang.org/x/term.NewTerminal(c ReadWriter, prompt string) *term.Terminal
ReadWriteSeeker is the interface that groups the basic Read, Write and Seek methods. ( ReadWriteSeeker) Read(p []byte) (n int, err error) ( ReadWriteSeeker) Seek(offset int64, whence int) (int64, error) ( ReadWriteSeeker) Write([]byte) (int, error) github.com/coreos/etcd/pkg/fileutil.LockedFile *github.com/ncruces/go-sqlite3.Blob *github.com/polarsignals/wal/fs.File *internal/poll.FD *os.File ReadWriteSeeker : Reader ReadWriteSeeker : ReadSeeker ReadWriteSeeker : ReadWriter ReadWriteSeeker : Seeker ReadWriteSeeker : Writer ReadWriteSeeker : WriteSeeker ReadWriteSeeker : github.com/miekg/dns.Writer ReadWriteSeeker : internal/bisect.Writer func github.com/parquet-go/parquet-go.BufferPool.GetBuffer() ReadWriteSeeker func github.com/parquet-go/parquet-go.BufferPool.PutBuffer(ReadWriteSeeker)
RuneReader is the interface that wraps the ReadRune method. ReadRune reads a single encoded Unicode character and returns the rune and its size in bytes. If no character is available, err will be set. ( RuneReader) ReadRune() (r rune, size int, err error) RuneScanner (interface) *bufio.Reader bufio.ReadWriter *bytes.Buffer *bytes.Reader fmt.ScanState (interface) github.com/apache/thrift/lib/go/thrift.TBufferedTransport github.com/apache/thrift/lib/go/thrift.TMemoryBuffer github.com/yuin/goldmark/text.BlockReader (interface) github.com/yuin/goldmark/text.Reader (interface) *strings.Reader func github.com/dop251/goja.String.Reader() RuneReader func regexp.MatchReader(pattern string, r RuneReader) (matched bool, err error) func regexp.(*Regexp).FindReaderIndex(r RuneReader) (loc []int) func regexp.(*Regexp).FindReaderSubmatchIndex(r RuneReader) []int func regexp.(*Regexp).MatchReader(r RuneReader) bool
RuneScanner is the interface that adds the UnreadRune method to the basic ReadRune method. UnreadRune causes the next call to ReadRune to return the last rune read. If the last operation was not a successful call to ReadRune, UnreadRune may return an error, unread the last rune read (or the rune prior to the last-unread rune), or (in implementations that support the [Seeker] interface) seek to the start of the rune before the current offset. ( RuneScanner) ReadRune() (r rune, size int, err error) ( RuneScanner) UnreadRune() error *bufio.Reader bufio.ReadWriter *bytes.Buffer *bytes.Reader fmt.ScanState (interface) github.com/apache/thrift/lib/go/thrift.TBufferedTransport github.com/apache/thrift/lib/go/thrift.TMemoryBuffer *strings.Reader RuneScanner : RuneReader
SectionReader implements Read, Seek, and ReadAt on a section of an underlying [ReaderAt]. Outer returns the underlying [ReaderAt] and offsets for the section. The returned values are the same that were passed to [NewSectionReader] when the [SectionReader] was created. (*SectionReader) Read(p []byte) (n int, err error) (*SectionReader) ReadAt(p []byte, off int64) (n int, err error) (*SectionReader) Seek(offset int64, whence int) (int64, error) Size returns the size of the section in bytes. *SectionReader : Reader *SectionReader : ReaderAt *SectionReader : ReadSeeker *SectionReader : Seeker *SectionReader : github.com/apache/arrow-go/v18/arrow/ipc.ReadAtSeeker *SectionReader : github.com/apache/arrow-go/v18/internal/utils.Reader *SectionReader : github.com/apache/arrow-go/v18/parquet.ReaderAtSeeker func NewSectionReader(r ReaderAt, off int64, n int64) *SectionReader
Seeker is the interface that wraps the basic Seek method. Seek sets the offset for the next Read or Write to offset, interpreted according to whence: [SeekStart] means relative to the start of the file, [SeekCurrent] means relative to the current offset, and [SeekEnd] means relative to the end (for example, offset = -2 specifies the penultimate byte of the file). Seek returns the new offset relative to the start of the file or an error, if any. Seeking to an offset before the start of the file is an error. Seeking to any positive offset may be allowed, but if the new offset exceeds the size of the underlying object the behavior of subsequent I/O operations is implementation-dependent. ( Seeker) Seek(offset int64, whence int) (int64, error) *OffsetWriter ReadSeekCloser (interface) ReadSeeker (interface) ReadWriteSeeker (interface) *SectionReader WriteSeeker (interface) *bytes.Reader github.com/apache/arrow-go/v18/arrow/ipc.ReadAtSeeker (interface) github.com/apache/arrow-go/v18/internal/utils.Reader (interface) github.com/apache/arrow-go/v18/parquet.ReaderAtSeeker (interface) github.com/coreos/etcd/pkg/fileutil.LockedFile *github.com/klauspost/compress/s2.ReadSeeker *github.com/ncruces/go-sqlite3.Blob *github.com/polarsignals/wal/fs.File *golang.org/x/text/unicode/norm.Iter *internal/poll.FD *lukechampine.com/blake3.OutputReader mime/multipart.File (interface) net/http.File (interface) *os.File *strings.Reader *vendor/golang.org/x/text/unicode/norm.Iter
StringWriter is the interface that wraps the WriteString method. ( StringWriter) WriteString(s string) (n int, err error) bufio.ReadWriter *bufio.Writer *bytes.Buffer *github.com/apache/thrift/lib/go/thrift.RichTransport *github.com/apache/thrift/lib/go/thrift.StreamTransport github.com/apache/thrift/lib/go/thrift.TBufferedTransport *github.com/apache/thrift/lib/go/thrift.TFramedTransport *github.com/apache/thrift/lib/go/thrift.THttpClient github.com/apache/thrift/lib/go/thrift.TMemoryBuffer github.com/apache/thrift/lib/go/thrift.TRichTransport (interface) *github.com/cespare/xxhash/v2.Digest github.com/coreos/etcd/pkg/fileutil.LockedFile *github.com/klauspost/compress/zstd/internal/xxhash.Digest *github.com/libp2p/go-buffer-pool.Buffer *github.com/libp2p/go-buffer-pool.Writer *github.com/polarsignals/wal/fs.File github.com/redis/go-redis/v9/internal/proto.Writer github.com/yuin/goldmark/util.BufWriter (interface) *github.com/zeebo/xxh3.Hasher *go.uber.org/zap/buffer.Buffer *gorm.io/gorm.Statement gorm.io/gorm/clause.Builder (interface) gorm.io/gorm/clause.Writer (interface) *hash/maphash.Hash *log/slog/internal/buffer.Buffer mvdan.cc/sh/v3/syntax.Printer *net/http/httptest.ResponseRecorder net/http/internal.FlushAfterChunkWriter *os.File *strings.Builder func github.com/spf13/cobra.WriteStringAndCheck(b StringWriter, s string)
WriteCloser is the interface that groups the basic Write and Close methods. ( WriteCloser) Close() error ( WriteCloser) Write([]byte) (int, error) *PipeWriter ReadWriteCloser (interface) *compress/flate.Writer *compress/gzip.Writer *compress/zlib.Writer crypto/cipher.StreamWriter *crypto/tls.Conn *github.com/andybalholm/brotli.Writer *github.com/andybalholm/brotli/matchfinder.Writer github.com/apache/thrift/lib/go/thrift.RichTransport *github.com/apache/thrift/lib/go/thrift.StreamTransport *github.com/apache/thrift/lib/go/thrift.TBufferedTransport *github.com/apache/thrift/lib/go/thrift.TFramedTransport *github.com/apache/thrift/lib/go/thrift.THeaderTransport *github.com/apache/thrift/lib/go/thrift.THttpClient *github.com/apache/thrift/lib/go/thrift.TMemoryBuffer *github.com/apache/thrift/lib/go/thrift.TransformWriter *github.com/apache/thrift/lib/go/thrift.TSocket *github.com/apache/thrift/lib/go/thrift.TSSLSocket github.com/apache/thrift/lib/go/thrift.TTransport (interface) *github.com/apache/thrift/lib/go/thrift.TZlibTransport github.com/coreos/etcd/pkg/fileutil.LockedFile github.com/gdamore/tcell/v2.Tty (interface) github.com/gliderlabs/ssh.Session (interface) *github.com/golang/snappy.Writer *github.com/hamba/avro/v2/ocf.Encoder *github.com/klauspost/compress/flate.Writer *github.com/klauspost/compress/gzip.Writer *github.com/klauspost/compress/internal/snapref.Writer *github.com/klauspost/compress/s2.Writer *github.com/klauspost/compress/zstd.Encoder *github.com/libp2p/go-buffer-pool.Writer github.com/libp2p/go-libp2p/core/network.MuxedStream (interface) github.com/libp2p/go-libp2p/core/network.Stream (interface) github.com/libp2p/go-libp2p/core/sec.SecureConn (interface) github.com/libp2p/go-libp2p/core/sec/insecure.Conn *github.com/libp2p/go-libp2p/p2p/net/swarm.Stream *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.Conn github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface (interface) *github.com/libp2p/go-libp2p/p2p/transport/websocket.Conn github.com/libp2p/go-msgio.ReadWriteCloser (interface) github.com/libp2p/go-msgio.WriteCloser (interface) *github.com/libp2p/go-yamux/v5.Stream github.com/marten-seemann/tcp.Conn *github.com/miekg/dns.Conn github.com/miekg/dns.ResponseWriter (interface) github.com/miekg/dns.Transfer github.com/multiformats/go-multiaddr/net.Conn (interface) github.com/multiformats/go-multistream.LazyConn (interface) *github.com/ncruces/go-sqlite3.Blob github.com/parquet-go/parquet-go/compress.Writer (interface) *github.com/pierrec/lz4/v4.Writer *github.com/pion/datachannel.DataChannel github.com/pion/datachannel.ReadWriteCloser (interface) github.com/pion/datachannel.ReadWriteCloserDeadliner (interface) *github.com/pion/dtls/v2.Conn *github.com/pion/dtls/v3.Conn *github.com/pion/ice/v4.Conn github.com/pion/ice/v4/internal/fakenet.PacketConn *github.com/pion/sctp.Stream github.com/pion/stun.Connection (interface) github.com/pion/stun/v3.Connection (interface) github.com/pion/transport/v2.TCPConn (interface) github.com/pion/transport/v2.UDPConn (interface) *github.com/pion/transport/v2/packetio.Buffer *github.com/pion/transport/v2/udp.Conn github.com/pion/transport/v3.TCPConn (interface) github.com/pion/transport/v3.UDPConn (interface) *github.com/pion/transport/v3/packetio.Buffer *github.com/pion/transport/v3/vnet.UDPConn github.com/pion/turn/v4/internal/client.TCPConn *github.com/pion/webrtc/v4/internal/mux.Endpoint *github.com/polarsignals/wal/fs.File *github.com/quic-go/qpack.Decoder github.com/quic-go/quic-go.SendStream (interface) github.com/quic-go/quic-go.Stream (interface) github.com/quic-go/quic-go/http3.RequestStream (interface) github.com/quic-go/quic-go/http3.Stream (interface) github.com/quic-go/webtransport-go.SendStream (interface) github.com/quic-go/webtransport-go.Stream (interface) *github.com/redis/go-redis/v9/internal/pool.Conn github.com/soheilhy/cmux.MuxConn go.uber.org/zap.Sink (interface) golang.org/x/crypto/ssh.Channel (interface) *golang.org/x/net/http2/hpack.Decoder golang.org/x/net/internal/socks.Conn *golang.org/x/net/ipv4.RawConn *golang.org/x/text/transform.Writer *internal/poll.FD *log/syslog.Writer *mime/quotedprintable.Writer net.Conn (interface) *net.IPConn *net.TCPConn *net.UDPConn *net.UnixConn *os.File *vendor/golang.org/x/net/http2/hpack.Decoder *vendor/golang.org/x/text/transform.Writer WriteCloser : Closer WriteCloser : Writer WriteCloser : github.com/miekg/dns.Writer WriteCloser : github.com/prometheus/common/expfmt.Closer WriteCloser : internal/bisect.Writer func encoding/base32.NewEncoder(enc *base32.Encoding, w Writer) WriteCloser func encoding/base64.NewEncoder(enc *base64.Encoding, w Writer) WriteCloser func encoding/hex.Dumper(w Writer) WriteCloser func github.com/andybalholm/brotli.HTTPCompressor(w http.ResponseWriter, r *http.Request) WriteCloser func github.com/apache/arrow-go/v18/parquet/compress.StreamingCodec.NewWriter(Writer) WriteCloser func github.com/apache/arrow-go/v18/parquet/compress.StreamingCodec.NewWriterLevel(Writer, int) (WriteCloser, error) func github.com/apache/thrift/lib/go/thrift.NewTransformWriter(baseWriter Writer, transforms []thrift.THeaderTransformID) (WriteCloser, error) func github.com/coder/websocket.(*Conn).Writer(ctx context.Context, typ websocket.MessageType) (WriteCloser, error) func github.com/gorilla/websocket.(*Conn).NextWriter(messageType int) (WriteCloser, error) func github.com/klauspost/compress/flate.NewStatelessWriter(dst Writer) WriteCloser func github.com/multiformats/go-base32.NewEncoder(enc *base32.Encoding, w Writer) WriteCloser func github.com/quic-go/quic-go/internal/utils.NewBufferedWriteCloser(writer *bufio.Writer, closer Closer) WriteCloser func golang.org/x/crypto/ssh.(*Session).StdinPipe() (WriteCloser, error) func golang.org/x/text/unicode/norm.Form.Writer(w Writer) WriteCloser func google.golang.org/grpc/encoding.Compressor.Compress(w Writer) (WriteCloser, error) func net/http/httputil.NewChunkedWriter(w Writer) WriteCloser func net/http/internal.NewChunkedWriter(w Writer) WriteCloser func net/textproto.(*Writer).DotWriter() WriteCloser func os/exec.(*Cmd).StdinPipe() (WriteCloser, error) func vendor/golang.org/x/text/unicode/norm.Form.Writer(w Writer) WriteCloser func github.com/goccy/go-json.DebugDOT(w WriteCloser) json.EncodeOptionFunc func github.com/quic-go/quic-go/qlog.NewConnectionTracer(w WriteCloser, p logging.Perspective, odcid protocol.ConnectionID) *logging.ConnectionTracer func github.com/quic-go/quic-go/qlog.NewTracer(w WriteCloser) *logging.Tracer func google.golang.org/grpc/internal/binarylog.NewBufferedSink(o WriteCloser) binarylog.Sink
Writer is the interface that wraps the basic Write method. Write writes len(p) bytes from p to the underlying data stream. It returns the number of bytes written from p (0 <= n <= len(p)) and any error encountered that caused the write to stop early. Write must return a non-nil error if it returns n < len(p). Write must not modify the slice data, even temporarily. Implementations must not retain p. ( Writer) Write([]byte) (int, error) *OffsetWriter *PipeWriter ReadWriteCloser (interface) ReadWriter (interface) ReadWriteSeeker (interface) WriteCloser (interface) WriteSeeker (interface) bufio.ReadWriter *bufio.Writer *bytes.Buffer *compress/flate.Writer *compress/gzip.Writer *compress/zlib.Writer crypto/cipher.StreamWriter *crypto/internal/fips140/hmac.HMAC *crypto/internal/fips140/sha256.Digest *crypto/internal/fips140/sha3.Digest *crypto/internal/fips140/sha3.SHAKE *crypto/internal/fips140/sha512.Digest *crypto/sha3.SHA3 *crypto/sha3.SHAKE *crypto/tls.Conn fmt.State (interface) *github.com/andybalholm/brotli.Writer *github.com/andybalholm/brotli/matchfinder.Writer github.com/apache/thrift/lib/go/thrift.RichTransport *github.com/apache/thrift/lib/go/thrift.StreamTransport *github.com/apache/thrift/lib/go/thrift.TBufferedTransport *github.com/apache/thrift/lib/go/thrift.TFramedTransport *github.com/apache/thrift/lib/go/thrift.THeaderTransport *github.com/apache/thrift/lib/go/thrift.THttpClient github.com/apache/thrift/lib/go/thrift.TMemoryBuffer github.com/apache/thrift/lib/go/thrift.TRichTransport (interface) github.com/apache/thrift/lib/go/thrift.TransformWriter *github.com/apache/thrift/lib/go/thrift.TSocket *github.com/apache/thrift/lib/go/thrift.TSSLSocket github.com/apache/thrift/lib/go/thrift.TTransport (interface) *github.com/apache/thrift/lib/go/thrift.TZlibTransport *github.com/cespare/xxhash/v2.Digest github.com/coder/websocket/internal/util.WriterFunc github.com/coreos/etcd/pkg/fileutil.LockedFile github.com/gdamore/tcell/v2.Tty (interface) github.com/gliderlabs/ssh.Session (interface) github.com/go-kit/log.StdlibAdapter github.com/go-kit/log.StdlibWriter *github.com/gobwas/ws/wsutil.CipherWriter *github.com/gobwas/ws/wsutil.ControlWriter *github.com/gobwas/ws/wsutil.Writer *github.com/golang/snappy.Writer *github.com/hamba/avro/v2.Writer *github.com/hamba/avro/v2/ocf.Encoder *github.com/hibiken/asynq.ResultWriter *github.com/json-iterator/go.Stream *github.com/klauspost/compress/flate.Writer *github.com/klauspost/compress/gzip.Writer *github.com/klauspost/compress/internal/snapref.Writer *github.com/klauspost/compress/s2.Writer *github.com/klauspost/compress/zstd.Encoder *github.com/klauspost/compress/zstd/internal/xxhash.Digest *github.com/libp2p/go-buffer-pool.Buffer *github.com/libp2p/go-buffer-pool.Writer github.com/libp2p/go-libp2p/core/network.MuxedStream (interface) github.com/libp2p/go-libp2p/core/network.Stream (interface) github.com/libp2p/go-libp2p/core/sec.SecureConn (interface) github.com/libp2p/go-libp2p/core/sec/insecure.Conn *github.com/libp2p/go-libp2p/p2p/net/swarm.Stream *github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.Conn github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface (interface) *github.com/libp2p/go-libp2p/p2p/transport/websocket.Conn *github.com/libp2p/go-msgio.LimitedWriter github.com/libp2p/go-msgio.ReadWriteCloser (interface) github.com/libp2p/go-msgio.ReadWriter (interface) github.com/libp2p/go-msgio.WriteCloser (interface) github.com/libp2p/go-msgio.Writer (interface) *github.com/libp2p/go-yamux/v5.Stream github.com/marten-seemann/tcp.Conn *github.com/miekg/dns.Conn github.com/miekg/dns.ResponseWriter (interface) github.com/miekg/dns.Transfer github.com/miekg/dns.Writer (interface) github.com/multiformats/go-multiaddr/net.Conn (interface) github.com/multiformats/go-multihash.Writer (interface) github.com/multiformats/go-multistream.LazyConn (interface) *github.com/ncruces/go-sqlite3.Blob github.com/pancsta/asyncmachine-go/pkg/helpers.SlogToMachLog *github.com/pancsta/cview.TextView github.com/parquet-go/parquet-go/compress.Writer (interface) *github.com/pierrec/lz4/v4.Writer *github.com/pierrec/lz4/v4/internal/xxh32.XXHZero *github.com/pion/datachannel.DataChannel github.com/pion/datachannel.ReadWriteCloser (interface) github.com/pion/datachannel.ReadWriteCloserDeadliner (interface) *github.com/pion/dtls/v2.Conn *github.com/pion/dtls/v3.Conn *github.com/pion/ice/v4.CandidatePair *github.com/pion/ice/v4.Conn github.com/pion/ice/v4/internal/fakenet.PacketConn *github.com/pion/sctp.Stream *github.com/pion/srtp/v3.WriteStreamSRTCP *github.com/pion/srtp/v3.WriteStreamSRTP github.com/pion/stun.Connection (interface) *github.com/pion/stun.Message github.com/pion/stun/v3.Connection (interface) *github.com/pion/stun/v3.Message github.com/pion/transport/v2.TCPConn (interface) github.com/pion/transport/v2.UDPConn (interface) *github.com/pion/transport/v2/packetio.Buffer *github.com/pion/transport/v2/udp.Conn github.com/pion/transport/v3.TCPConn (interface) github.com/pion/transport/v3.UDPConn (interface) *github.com/pion/transport/v3/packetio.Buffer *github.com/pion/transport/v3/vnet.UDPConn github.com/pion/turn/v4/internal/client.TCPConn *github.com/pion/webrtc/v4.TrackLocalStaticRTP github.com/pion/webrtc/v4.TrackLocalWriter (interface) *github.com/pion/webrtc/v4/internal/mux.Endpoint *github.com/polarsignals/wal/fs.File *github.com/quic-go/qpack.Decoder github.com/quic-go/quic-go.SendStream (interface) github.com/quic-go/quic-go.Stream (interface) github.com/quic-go/quic-go/http3.RequestStream (interface) github.com/quic-go/quic-go/http3.Stream (interface) github.com/quic-go/quic-go/quicvarint.Writer (interface) github.com/quic-go/webtransport-go.SendStream (interface) github.com/quic-go/webtransport-go.Stream (interface) *github.com/redis/go-redis/v9/internal/pool.Conn github.com/redis/go-redis/v9/internal/proto.Writer github.com/soheilhy/cmux.MuxConn github.com/spaolacci/murmur3.Hash128 (interface) github.com/yuin/goldmark/util.BufWriter (interface) *github.com/zeebo/xxh3.Hasher go.uber.org/zap.Sink (interface) *go.uber.org/zap/buffer.Buffer *go.uber.org/zap/zapcore.BufferedWriteSyncer go.uber.org/zap/zapcore.WriteSyncer (interface) golang.org/x/crypto/blake2b.XOF (interface) golang.org/x/crypto/blake2s.XOF (interface) *golang.org/x/crypto/internal/poly1305.MAC golang.org/x/crypto/sha3.ShakeHash (interface) golang.org/x/crypto/ssh.Channel (interface) *golang.org/x/net/http2/hpack.Decoder golang.org/x/net/internal/socks.Conn golang.org/x/net/ipv4.RawConn *golang.org/x/term.Terminal golang.org/x/text/internal/format.State (interface) *golang.org/x/text/transform.Writer hash.Cloner (interface) hash.Hash (interface) hash.Hash32 (interface) hash.Hash64 (interface) hash.XOF (interface) *hash/maphash.Hash internal/bisect.Writer (interface) *internal/poll.FD *log/slog/internal/buffer.Buffer *log/syslog.Writer *lukechampine.com/blake3.Hasher *mime/quotedprintable.Writer mvdan.cc/sh/v3/syntax.Printer net.Conn (interface) *net.IPConn *net.TCPConn *net.UDPConn *net.UnixConn net/http.ResponseWriter (interface) *net/http/httptest.ResponseRecorder net/http/internal.FlushAfterChunkWriter *os.File *strings.Builder *text/tabwriter.Writer *vendor/golang.org/x/crypto/internal/poly1305.MAC *vendor/golang.org/x/net/http2/hpack.Decoder *vendor/golang.org/x/text/transform.Writer Writer : github.com/miekg/dns.Writer Writer : internal/bisect.Writer func MultiWriter(writers ...Writer) Writer func encoding/hex.NewEncoder(w Writer) Writer func flag.(*FlagSet).Output() Writer func github.com/efficientgo/core/testutil.TB.Output() Writer func github.com/go-kit/log.NewStdlibAdapter(logger log.Logger, options ...log.StdlibAdapterOption) Writer func github.com/go-kit/log.NewSyncWriter(w Writer) Writer func github.com/pancsta/cview.ANSIWriter(writer Writer) Writer func github.com/parquet-go/parquet-go/encoding/thrift.Writer.Writer() Writer func github.com/parquet-go/parquet-go/internal/debug.Writer(writer Writer, prefix string) Writer func github.com/spf13/cobra.(*Command).ErrOrStderr() Writer func github.com/spf13/cobra.(*Command).OutOrStderr() Writer func github.com/spf13/cobra.(*Command).OutOrStdout() Writer func github.com/spf13/pflag.(*FlagSet).Output() Writer func github.com/vmihailenco/msgpack/v5.(*Encoder).Writer() Writer func golang.org/x/text/encoding.(*Encoder).Writer(w Writer) Writer func google.golang.org/grpc/mem.NewWriter(buffers *mem.BufferSlice, pool mem.BufferPool) Writer func log.Writer() Writer func log.(*Logger).Writer() Writer func mime/multipart.(*Writer).CreateFormField(fieldname string) (Writer, error) func mime/multipart.(*Writer).CreateFormFile(fieldname, filename string) (Writer, error) func mime/multipart.(*Writer).CreatePart(header textproto.MIMEHeader) (Writer, error) func testing.TB.Output() Writer func Copy(dst Writer, src Reader) (written int64, err error) func CopyBuffer(dst Writer, src Reader, buf []byte) (written int64, err error) func CopyN(dst Writer, src Reader, n int64) (written int64, err error) func MultiWriter(writers ...Writer) Writer func TeeReader(r Reader, w Writer) Reader func WriteString(w Writer, s string) (n int, err error) func WriterTo.WriteTo(w Writer) (n int64, err error) func bufio.NewWriter(w Writer) *bufio.Writer func bufio.NewWriterSize(w Writer, size int) *bufio.Writer func bufio.(*Reader).WriteTo(w Writer) (n int64, err error) func bufio.(*Writer).Reset(w Writer) func bytes.(*Buffer).WriteTo(w Writer) (n int64, err error) func bytes.(*Reader).WriteTo(w Writer) (n int64, err error) func compress/flate.NewWriter(w Writer, level int) (*flate.Writer, error) func compress/flate.NewWriterDict(w Writer, level int, dict []byte) (*flate.Writer, error) func compress/flate.(*Writer).Reset(dst Writer) func compress/gzip.NewWriter(w Writer) *gzip.Writer func compress/gzip.NewWriterLevel(w Writer, level int) (*gzip.Writer, error) func compress/gzip.(*Writer).Reset(w Writer) func compress/zlib.NewWriter(w Writer) *zlib.Writer func compress/zlib.NewWriterLevel(w Writer, level int) (*zlib.Writer, error) func compress/zlib.NewWriterLevelDict(w Writer, level int, dict []byte) (*zlib.Writer, error) func compress/zlib.(*Writer).Reset(w Writer) func encoding/base32.NewEncoder(enc *base32.Encoding, w Writer) WriteCloser func encoding/base64.NewEncoder(enc *base64.Encoding, w Writer) WriteCloser func encoding/binary.Write(w Writer, order binary.ByteOrder, data any) error func encoding/csv.NewWriter(w Writer) *csv.Writer func encoding/gob.NewEncoder(w Writer) *gob.Encoder func encoding/hex.Dumper(w Writer) WriteCloser func encoding/hex.NewEncoder(w Writer) Writer func encoding/json.NewEncoder(w Writer) *json.Encoder func encoding/pem.Encode(out Writer, b *pem.Block) error func encoding/xml.Escape(w Writer, s []byte) func encoding/xml.EscapeText(w Writer, s []byte) error func encoding/xml.NewEncoder(w Writer) *xml.Encoder func flag.(*FlagSet).SetOutput(output Writer) func fmt.Fprint(w Writer, a ...any) (n int, err error) func fmt.Fprintf(w Writer, format string, a ...any) (n int, err error) func fmt.Fprintln(w Writer, a ...any) (n int, err error) func github.com/alecthomas/chroma/v2.Formatter.Format(w Writer, style *chroma.Style, iterator chroma.Iterator) error func github.com/alecthomas/chroma/v2.FormatterFunc.Format(w Writer, s *chroma.Style, it chroma.Iterator) (err error) func github.com/alecthomas/chroma/v2/formatters/html.(*Formatter).Format(w Writer, style *chroma.Style, iterator chroma.Iterator) (err error) func github.com/alecthomas/chroma/v2/formatters/html.(*Formatter).WriteCSS(w Writer, style *chroma.Style) error func github.com/alecthomas/chroma/v2/formatters/svg.(*Formatter).Format(w Writer, style *chroma.Style, iterator chroma.Iterator) (err error) func github.com/alexflint/go-arg.(*Parser).WriteHelp(w Writer) func github.com/alexflint/go-arg.(*Parser).WriteHelpForSubcommand(w Writer, subcommand ...string) error func github.com/alexflint/go-arg.(*Parser).WriteUsage(w Writer) func github.com/alexflint/go-arg.(*Parser).WriteUsageForSubcommand(w Writer, subcommand ...string) error func github.com/andybalholm/brotli.NewWriter(dst Writer) *brotli.Writer func github.com/andybalholm/brotli.NewWriterLevel(dst Writer, level int) *brotli.Writer func github.com/andybalholm/brotli.NewWriterOptions(dst Writer, options brotli.WriterOptions) *brotli.Writer func github.com/andybalholm/brotli.NewWriterV2(dst Writer, level int) *matchfinder.Writer func github.com/andybalholm/brotli.(*Writer).Reset(dst Writer) func github.com/andybalholm/brotli/matchfinder.(*Writer).Reset(newDest Writer) func github.com/apache/arrow-go/v18/arrow/array.RecordToJSON(rec arrow.RecordBatch, w Writer) error func github.com/apache/arrow-go/v18/arrow/ipc.NewFileWriter(w Writer, opts ...ipc.Option) (*ipc.FileWriter, error) func github.com/apache/arrow-go/v18/arrow/ipc.NewWriter(w Writer, opts ...ipc.Option) *ipc.Writer func github.com/apache/arrow-go/v18/arrow/ipc.(*Payload).SerializeBody(w Writer) error func github.com/apache/arrow-go/v18/arrow/ipc.(*Payload).WritePayload(w Writer) (int, error) func github.com/apache/arrow-go/v18/internal/json.NewEncoder(w Writer) *json.Encoder func github.com/apache/arrow-go/v18/parquet/compress.StreamingCodec.NewWriter(Writer) WriteCloser func github.com/apache/arrow-go/v18/parquet/compress.StreamingCodec.NewWriterLevel(Writer, int) (WriteCloser, error) func github.com/apache/arrow-go/v18/parquet/schema.PrintSchema(n schema.Node, w Writer, indentWidth int) func github.com/apache/thrift/lib/go/thrift.NewStreamTransport(r Reader, w Writer) *thrift.StreamTransport func github.com/apache/thrift/lib/go/thrift.NewStreamTransportFactory(reader Reader, writer Writer, isReadWriter bool) *thrift.StreamTransportFactory func github.com/apache/thrift/lib/go/thrift.NewStreamTransportW(w Writer) *thrift.StreamTransport func github.com/apache/thrift/lib/go/thrift.NewTransformWriter(baseWriter Writer, transforms []thrift.THeaderTransformID) (WriteCloser, error) func github.com/bits-and-blooms/bitset.(*BitSet).WriteTo(stream Writer) (int64, error) func github.com/chromedp/chromedp.CombinedOutput(w Writer) chromedp.ExecAllocatorOption func github.com/coreos/pkg/capnslog.NewDefaultFormatter(out Writer) capnslog.Formatter func github.com/coreos/pkg/capnslog.NewGlogFormatter(w Writer) *capnslog.GlogFormatter func github.com/coreos/pkg/capnslog.NewLogFormatter(w Writer, prefix string, flag int) capnslog.Formatter func github.com/coreos/pkg/capnslog.NewPrettyFormatter(w Writer, debug bool) capnslog.Formatter func github.com/coreos/pkg/capnslog.NewStringFormatter(w Writer) capnslog.Formatter func github.com/davecgh/go-spew/spew.Fdump(w Writer, a ...interface{}) func github.com/davecgh/go-spew/spew.Fprint(w Writer, a ...interface{}) (n int, err error) func github.com/davecgh/go-spew/spew.Fprintf(w Writer, format string, a ...interface{}) (n int, err error) func github.com/davecgh/go-spew/spew.Fprintln(w Writer, a ...interface{}) (n int, err error) func github.com/davecgh/go-spew/spew.(*ConfigState).Fdump(w Writer, a ...interface{}) func github.com/davecgh/go-spew/spew.(*ConfigState).Fprint(w Writer, a ...interface{}) (n int, err error) func github.com/davecgh/go-spew/spew.(*ConfigState).Fprintf(w Writer, format string, a ...interface{}) (n int, err error) func github.com/davecgh/go-spew/spew.(*ConfigState).Fprintln(w Writer, a ...interface{}) (n int, err error) func github.com/dop251/goja.StartProfile(w Writer) error func github.com/efficientgo/core/testutil/internal.WriteUnifiedDiff(writer Writer, diff internal.UnifiedDiff) error func github.com/francoispqt/gojay.BorrowEncoder(w Writer) *gojay.Encoder func github.com/francoispqt/gojay.NewEncoder(w Writer) *gojay.Encoder func github.com/gdamore/tcell/v2/terminfo.(*Terminfo).TPuts(w Writer, s string) func github.com/go-echarts/go-echarts/v2/render.Renderer.Render(w Writer) error func github.com/go-kit/log.NewJSONLogger(w Writer) log.Logger func github.com/go-kit/log.NewLogfmtLogger(w Writer) log.Logger func github.com/go-kit/log.NewSyncWriter(w Writer) Writer func github.com/go-logfmt/logfmt.NewEncoder(w Writer) *logfmt.Encoder func github.com/gobwas/httphead.WriteOptions(dest Writer, options []httphead.Option) (n int, err error) func github.com/gobwas/pool/pbufio.GetWriter(w Writer, size int) *bufio.Writer func github.com/gobwas/pool/pbufio.(*WriterPool).Get(w Writer, size int) *bufio.Writer func github.com/gobwas/ws.MustWriteFrame(w Writer, f ws.Frame) func github.com/gobwas/ws.WriteFrame(w Writer, f ws.Frame) error func github.com/gobwas/ws.WriteHeader(w Writer, h ws.Header) error func github.com/gobwas/ws.HandshakeHeader.WriteTo(w Writer) (n int64, err error) func github.com/gobwas/ws.HandshakeHeaderBytes.WriteTo(w Writer) (int64, error) func github.com/gobwas/ws.HandshakeHeaderFunc.WriteTo(w Writer) (int64, error) func github.com/gobwas/ws.HandshakeHeaderHTTP.WriteTo(w Writer) (int64, error) func github.com/gobwas/ws.HandshakeHeaderString.WriteTo(w Writer) (int64, error) func github.com/gobwas/ws/wsutil.ControlFrameHandler(w Writer, state ws.State) wsutil.FrameHandlerFunc func github.com/gobwas/ws/wsutil.GetWriter(dest Writer, state ws.State, op ws.OpCode, n int) *wsutil.Writer func github.com/gobwas/ws/wsutil.HandleClientControlMessage(conn Writer, msg wsutil.Message) error func github.com/gobwas/ws/wsutil.HandleControlMessage(conn Writer, state ws.State, msg wsutil.Message) error func github.com/gobwas/ws/wsutil.HandleServerControlMessage(conn Writer, msg wsutil.Message) error func github.com/gobwas/ws/wsutil.NewCipherWriter(w Writer, mask [4]byte) *wsutil.CipherWriter func github.com/gobwas/ws/wsutil.NewControlWriter(dest Writer, state ws.State, op ws.OpCode) *wsutil.ControlWriter func github.com/gobwas/ws/wsutil.NewControlWriterBuffer(dest Writer, state ws.State, op ws.OpCode, buf []byte) *wsutil.ControlWriter func github.com/gobwas/ws/wsutil.NewWriter(dest Writer, state ws.State, op ws.OpCode) *wsutil.Writer func github.com/gobwas/ws/wsutil.NewWriterBuffer(dest Writer, state ws.State, op ws.OpCode, buf []byte) *wsutil.Writer func github.com/gobwas/ws/wsutil.NewWriterBufferSize(dest Writer, state ws.State, op ws.OpCode, n int) *wsutil.Writer func github.com/gobwas/ws/wsutil.NewWriterSize(dest Writer, state ws.State, op ws.OpCode, n int) *wsutil.Writer func github.com/gobwas/ws/wsutil.WriteClientBinary(w Writer, p []byte) error func github.com/gobwas/ws/wsutil.WriteClientMessage(w Writer, op ws.OpCode, p []byte) error func github.com/gobwas/ws/wsutil.WriteClientText(w Writer, p []byte) error func github.com/gobwas/ws/wsutil.WriteMessage(w Writer, s ws.State, op ws.OpCode, p []byte) error func github.com/gobwas/ws/wsutil.WriteServerBinary(w Writer, p []byte) error func github.com/gobwas/ws/wsutil.WriteServerMessage(w Writer, op ws.OpCode, p []byte) error func github.com/gobwas/ws/wsutil.WriteServerText(w Writer, p []byte) error func github.com/gobwas/ws/wsutil.(*CipherWriter).Reset(w Writer, mask [4]byte) func github.com/gobwas/ws/wsutil.(*Writer).Reset(dest Writer, state ws.State, op ws.OpCode) func github.com/goccy/go-json.DebugWith(w Writer) json.EncodeOptionFunc func github.com/goccy/go-json.NewEncoder(w Writer) *json.Encoder func github.com/gogo/protobuf/proto.CompactText(w Writer, pb proto.Message) error func github.com/gogo/protobuf/proto.MarshalText(w Writer, pb proto.Message) error func github.com/gogo/protobuf/proto.(*TextMarshaler).Marshal(w Writer, pb proto.Message) error func github.com/golang/protobuf/proto.CompactText(w Writer, m proto.Message) error func github.com/golang/protobuf/proto.MarshalText(w Writer, m proto.Message) error func github.com/golang/protobuf/proto.(*TextMarshaler).Marshal(w Writer, m proto.Message) error func github.com/golang/snappy.NewBufferedWriter(w Writer) *snappy.Writer func github.com/golang/snappy.NewWriter(w Writer) *snappy.Writer func github.com/golang/snappy.(*Writer).Reset(writer Writer) func github.com/gomarkdown/markdown.Renderer.RenderFooter(w Writer, ast ast.Node) func github.com/gomarkdown/markdown.Renderer.RenderHeader(w Writer, ast ast.Node) func github.com/gomarkdown/markdown.Renderer.RenderNode(w Writer, node ast.Node, entering bool) ast.WalkStatus func github.com/gomarkdown/markdown/ast.Print(dst Writer, doc ast.Node) func github.com/gomarkdown/markdown/ast.PrintWithPrefix(w Writer, doc ast.Node, prefix string) func github.com/gomarkdown/markdown/html.Escape(w Writer, text []byte) func github.com/gomarkdown/markdown/html.EscapeHTML(w Writer, d []byte) func github.com/gomarkdown/markdown/html.EscLink(w Writer, text []byte) func github.com/gomarkdown/markdown/html.(*Renderer).Callout(w Writer, node *ast.Callout) func github.com/gomarkdown/markdown/html.(*Renderer).Caption(w Writer, caption *ast.Caption, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).CaptionFigure(w Writer, figure *ast.CaptionFigure, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).Citation(w Writer, node *ast.Citation) func github.com/gomarkdown/markdown/html.(*Renderer).Code(w Writer, node *ast.Code) func github.com/gomarkdown/markdown/html.(*Renderer).CodeBlock(w Writer, codeBlock *ast.CodeBlock) func github.com/gomarkdown/markdown/html.(*Renderer).CR(w Writer) func github.com/gomarkdown/markdown/html.(*Renderer).DocumentMatter(w Writer, node *ast.DocumentMatter, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).EscapeHTMLCallouts(w Writer, d []byte) func github.com/gomarkdown/markdown/html.(*Renderer).HardBreak(w Writer, node *ast.Hardbreak) func github.com/gomarkdown/markdown/html.(*Renderer).Heading(w Writer, hdr *ast.Heading, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).HeadingEnter(w Writer, hdr *ast.Heading) func github.com/gomarkdown/markdown/html.(*Renderer).HeadingExit(w Writer, hdr *ast.Heading) func github.com/gomarkdown/markdown/html.(*Renderer).HorizontalRule(w Writer, node *ast.HorizontalRule) func github.com/gomarkdown/markdown/html.(*Renderer).HTMLBlock(w Writer, node *ast.HTMLBlock) func github.com/gomarkdown/markdown/html.(*Renderer).HTMLSpan(w Writer, span *ast.HTMLSpan) func github.com/gomarkdown/markdown/html.(*Renderer).Image(w Writer, node *ast.Image, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).Index(w Writer, node *ast.Index) func github.com/gomarkdown/markdown/html.(*Renderer).Link(w Writer, link *ast.Link, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).List(w Writer, list *ast.List, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).ListItem(w Writer, listItem *ast.ListItem, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).NonBlockingSpace(w Writer, node *ast.NonBlockingSpace) func github.com/gomarkdown/markdown/html.(*Renderer).Out(w Writer, d []byte) func github.com/gomarkdown/markdown/html.(*Renderer).OutHRTag(w Writer, attrs []string) func github.com/gomarkdown/markdown/html.(*Renderer).OutOneOf(w Writer, outFirst bool, first string, second string) func github.com/gomarkdown/markdown/html.(*Renderer).OutOneOfCr(w Writer, outFirst bool, first string, second string) func github.com/gomarkdown/markdown/html.(*Renderer).Outs(w Writer, s string) func github.com/gomarkdown/markdown/html.(*Renderer).OutTag(w Writer, name string, attrs []string) func github.com/gomarkdown/markdown/html.(*Renderer).Paragraph(w Writer, para *ast.Paragraph, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).RenderFooter(w Writer, _ ast.Node) func github.com/gomarkdown/markdown/html.(*Renderer).RenderHeader(w Writer, ast ast.Node) func github.com/gomarkdown/markdown/html.(*Renderer).RenderNode(w Writer, node ast.Node, entering bool) ast.WalkStatus func github.com/gomarkdown/markdown/html.(*Renderer).TableBody(w Writer, node *ast.TableBody, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).TableCell(w Writer, tableCell *ast.TableCell, entering bool) func github.com/gomarkdown/markdown/html.(*Renderer).Text(w Writer, text *ast.Text) func github.com/gomarkdown/markdown/html.(*SPRenderer).Process(w Writer, text []byte) func github.com/google/go-github/v66/github.MessageSigner.Sign(w Writer, r Reader) error func github.com/google/go-github/v66/github.MessageSignerFunc.Sign(w Writer, r Reader) error func github.com/google/pprof/profile.(*Profile).Write(w Writer) error func github.com/google/pprof/profile.(*Profile).WriteUncompressed(w Writer) error func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.(*JSONBuiltin).NewEncoder(w Writer) runtime.Encoder func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.(*JSONPb).NewEncoder(w Writer) runtime.Encoder func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.Marshaler.NewEncoder(w Writer) runtime.Encoder func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.(*ProtoMarshaller).NewEncoder(writer Writer) runtime.Encoder func github.com/hamba/avro/v2.NewEncoder(s string, w Writer) (*avro.Encoder, error) func github.com/hamba/avro/v2.NewEncoderForSchema(schema avro.Schema, w Writer) *avro.Encoder func github.com/hamba/avro/v2.NewWriter(out Writer, bufSize int, opts ...avro.WriterFunc) *avro.Writer func github.com/hamba/avro/v2.API.NewEncoder(schema avro.Schema, w Writer) *avro.Encoder func github.com/hamba/avro/v2.(*Writer).Reset(out Writer) func github.com/hamba/avro/v2/ocf.NewEncoder(s string, w Writer, opts ...ocf.EncoderFunc) (*ocf.Encoder, error) func github.com/hamba/avro/v2/ocf.NewEncoderWithSchema(schema avro.Schema, w Writer, opts ...ocf.EncoderFunc) (*ocf.Encoder, error) func github.com/ipfs/go-cid.Cid.WriteBytes(w Writer) (int, error) func github.com/json-iterator/go.NewEncoder(writer Writer) *jsoniter.Encoder func github.com/json-iterator/go.NewStream(cfg jsoniter.API, out Writer, bufSize int) *jsoniter.Stream func github.com/json-iterator/go.API.BorrowStream(writer Writer) *jsoniter.Stream func github.com/json-iterator/go.API.NewEncoder(writer Writer) *jsoniter.Encoder func github.com/json-iterator/go.(*Stream).Reset(out Writer) func github.com/json-iterator/go.StreamPool.BorrowStream(writer Writer) *jsoniter.Stream func github.com/klauspost/compress/flate.NewStatelessWriter(dst Writer) WriteCloser func github.com/klauspost/compress/flate.NewWriter(w Writer, level int) (*flate.Writer, error) func github.com/klauspost/compress/flate.NewWriterDict(w Writer, level int, dict []byte) (*flate.Writer, error) func github.com/klauspost/compress/flate.NewWriterWindow(w Writer, windowSize int) (*flate.Writer, error) func github.com/klauspost/compress/flate.StatelessDeflate(out Writer, in []byte, eof bool, dict []byte) error func github.com/klauspost/compress/flate.(*Writer).Reset(dst Writer) func github.com/klauspost/compress/flate.(*Writer).ResetDict(dst Writer, dict []byte) func github.com/klauspost/compress/gzip.NewWriter(w Writer) *gzip.Writer func github.com/klauspost/compress/gzip.NewWriterLevel(w Writer, level int) (*gzip.Writer, error) func github.com/klauspost/compress/gzip.NewWriterWindow(w Writer, windowSize int) (*gzip.Writer, error) func github.com/klauspost/compress/gzip.(*Reader).WriteTo(w Writer) (int64, error) func github.com/klauspost/compress/gzip.(*Writer).Reset(w Writer) func github.com/klauspost/compress/internal/snapref.NewBufferedWriter(w Writer) *snapref.Writer func github.com/klauspost/compress/internal/snapref.NewWriter(w Writer) *snapref.Writer func github.com/klauspost/compress/internal/snapref.(*Writer).Reset(writer Writer) func github.com/klauspost/compress/s2.NewWriter(w Writer, opts ...s2.WriterOption) *s2.Writer func github.com/klauspost/compress/s2.(*Reader).DecodeConcurrent(w Writer, concurrent int) (written int64, err error) func github.com/klauspost/compress/s2.(*Writer).Reset(writer Writer) func github.com/klauspost/compress/snappy.NewBufferedWriter(w Writer) *snappy.Writer func github.com/klauspost/compress/snappy.NewWriter(w Writer) *snappy.Writer func github.com/klauspost/compress/zstd.NewWriter(w Writer, opts ...zstd.EOption) (*zstd.Encoder, error) func github.com/klauspost/compress/zstd.(*Decoder).WriteTo(w Writer) (int64, error) func github.com/klauspost/compress/zstd.(*Encoder).Reset(w Writer) func github.com/klauspost/compress/zstd.(*Encoder).ResetContentSize(w Writer, size int64) func github.com/klauspost/compress/zstd.(*SnappyConverter).Convert(in Reader, w Writer) (int64, error) func github.com/libp2p/go-buffer-pool.(*Buffer).WriteTo(w Writer) (int64, error) func github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/util.NewDelimitedWriter(w Writer) pbio.WriteCloser func github.com/libp2p/go-libp2p/p2p/security/tls.WithKeyLogWriter(w Writer) libp2ptls.IdentityOption func github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface.WriteTo(w Writer) (n int64, err error) func github.com/libp2p/go-msgio.NewLimitedWriter(w Writer) *msgio.LimitedWriter func github.com/libp2p/go-msgio.NewVarintWriter(w Writer) msgio.WriteCloser func github.com/libp2p/go-msgio.NewVarintWriterWithPool(w Writer, p *pool.BufferPool) msgio.WriteCloser func github.com/libp2p/go-msgio.NewWriter(w Writer) msgio.WriteCloser func github.com/libp2p/go-msgio.NewWriterWithPool(w Writer, p *pool.BufferPool) msgio.WriteCloser func github.com/libp2p/go-msgio.WriteLen(w Writer, l int) error func github.com/libp2p/go-msgio/pbio.NewDelimitedWriter(w Writer) pbio.WriteCloser func github.com/libp2p/go-msgio/protoio.NewDelimitedWriter(w Writer) protoio.WriteCloser func github.com/mailru/easyjson.MarshalToWriter(v easyjson.Marshaler, w Writer) (written int, err error) func github.com/mailru/easyjson/buffer.(*Buffer).DumpTo(w Writer) (written int, err error) func github.com/mailru/easyjson/jwriter.(*Writer).DumpTo(out Writer) (written int, err error) func github.com/multiformats/go-base32.NewEncoder(enc *base32.Encoding, w Writer) WriteCloser func github.com/multiformats/go-multihash.NewWriter(w Writer) multihash.Writer func github.com/ncruces/go-sqlite3.(*Blob).WriteTo(w Writer) (n int64, err error) func github.com/olekukonko/tablewriter.NewCSV(writer Writer, fileName string, hasHeader bool) (*tablewriter.Table, error) func github.com/olekukonko/tablewriter.NewCSVReader(writer Writer, csvReader *csv.Reader, hasHeader bool) (*tablewriter.Table, error) func github.com/olekukonko/tablewriter.NewWriter(writer Writer) *tablewriter.Table func github.com/pancsta/asyncmachine-go/scripts/gen_website.RenderHook(w Writer, node ast.Node, entering bool) (ast.WalkStatus, bool) func github.com/pancsta/cview.ANSIWriter(writer Writer) Writer func github.com/parquet-go/parquet-go.NewGenericWriter[T](output Writer, options ...parquet.WriterOption) *parquet.GenericWriter[T] func github.com/parquet-go/parquet-go.NewSortingWriter[T](output Writer, sortRowCount int64, options ...parquet.WriterOption) *parquet.SortingWriter[T] func github.com/parquet-go/parquet-go.NewWriter(output Writer, options ...parquet.WriterOption) *parquet.Writer func github.com/parquet-go/parquet-go.PrintColumnChunk(w Writer, columnChunk parquet.ColumnChunk) error func github.com/parquet-go/parquet-go.PrintPage(w Writer, page parquet.Page) error func github.com/parquet-go/parquet-go.PrintRowGroup(w Writer, rowGroup parquet.RowGroup) error func github.com/parquet-go/parquet-go.PrintSchema(w Writer, name string, node parquet.Node) error func github.com/parquet-go/parquet-go.PrintSchemaIndent(w Writer, name string, node parquet.Node, pattern, newline string) error func github.com/parquet-go/parquet-go.Write[T](w Writer, rows []T, options ...parquet.WriterOption) error func github.com/parquet-go/parquet-go.(*GenericWriter)[T].Reset(output Writer) func github.com/parquet-go/parquet-go.(*SortingWriter)[T].Reset(output Writer) func github.com/parquet-go/parquet-go.(*Writer).Reset(output Writer) func github.com/parquet-go/parquet-go/compress.Writer.Reset(Writer) func github.com/parquet-go/parquet-go/encoding/thrift.(*BinaryProtocol).NewWriter(w Writer) thrift.Writer func github.com/parquet-go/parquet-go/encoding/thrift.(*CompactProtocol).NewWriter(w Writer) thrift.Writer func github.com/parquet-go/parquet-go/encoding/thrift.Protocol.NewWriter(w Writer) thrift.Writer func github.com/parquet-go/parquet-go/internal/debug.Writer(writer Writer, prefix string) Writer func github.com/pierrec/lz4/v4.NewWriter(w Writer) *lz4.Writer func github.com/pierrec/lz4/v4.(*Reader).WriteTo(w Writer) (n int64, err error) func github.com/pierrec/lz4/v4.(*Writer).Reset(writer Writer) func github.com/pierrec/lz4/v4/internal/lz4stream.(*Frame).CloseW(dst Writer, num int) error func github.com/pierrec/lz4/v4/internal/lz4stream.(*Frame).InitW(dst Writer, num int, legacy bool) func github.com/pierrec/lz4/v4/internal/lz4stream.(*FrameDataBlock).Write(f *lz4stream.Frame, dst Writer) error func github.com/pierrec/lz4/v4/internal/lz4stream.(*FrameDescriptor).Write(f *lz4stream.Frame, dst Writer) error func github.com/pion/logging.NewDefaultLeveledLoggerForScope(scope string, level logging.LogLevel, writer Writer) *logging.DefaultLeveledLogger func github.com/pion/logging.(*DefaultLeveledLogger).WithOutput(output Writer) *logging.DefaultLeveledLogger func github.com/pion/stun.(*Message).WriteTo(w Writer) (int64, error) func github.com/pion/stun/v3.(*Message).WriteTo(w Writer) (int64, error) func github.com/pion/webrtc/v4.(*SettingEngine).SetDTLSKeyLogWriter(writer Writer) func github.com/pmezard/go-difflib/difflib.WriteContextDiff(writer Writer, diff difflib.ContextDiff) error func github.com/pmezard/go-difflib/difflib.WriteUnifiedDiff(writer Writer, diff difflib.UnifiedDiff) error func github.com/polarsignals/frostdb.WriteSnapshot(ctx context.Context, tx uint64, db *frostdb.DB, w Writer) error func github.com/polarsignals/frostdb.(*TableBlock).Serialize(writer Writer) error func github.com/polarsignals/frostdb/dynparquet.ParquetWriter.Reset(writer Writer) func github.com/polarsignals/frostdb/dynparquet.(*Schema).GetWriter(w Writer, dynamicColumns map[string][]string, sorting bool) (*dynparquet.PooledWriter, error) func github.com/polarsignals/frostdb/dynparquet.(*Schema).NewWriter(w Writer, dynamicColumns map[string][]string, sorting bool, options ...parquet.WriterOption) (dynparquet.ParquetWriter, error) func github.com/polarsignals/frostdb/dynparquet.(*Schema).SerializeBuffer(w Writer, buffer *dynparquet.Buffer) error func github.com/polarsignals/frostdb/parts.Part.Write(Writer) error func github.com/polarsignals/iceberg-go.WriteManifestListV1(w Writer, files []iceberg.ManifestFile) error func github.com/polarsignals/iceberg-go.WriteManifestV1(w Writer, schema *iceberg.Schema, entries []iceberg.ManifestEntry) error func github.com/prometheus/client_golang/prometheus/internal.WriteUnifiedDiff(writer Writer, diff internal.UnifiedDiff) error func github.com/prometheus/common/expfmt.FinalizeOpenMetrics(w Writer) (written int, err error) func github.com/prometheus/common/expfmt.MetricFamilyToOpenMetrics(out Writer, in *dto.MetricFamily, options ...expfmt.EncoderOption) (written int, err error) func github.com/prometheus/common/expfmt.MetricFamilyToText(out Writer, in *dto.MetricFamily) (written int, err error) func github.com/prometheus/common/expfmt.NewEncoder(w Writer, format expfmt.Format, options ...expfmt.EncoderOption) expfmt.Encoder func github.com/PuerkitoBio/goquery.Render(w Writer, s *goquery.Selection) error func github.com/quic-go/qpack.NewEncoder(w Writer) *qpack.Encoder func github.com/quic-go/quic-go/quicvarint.NewWriter(w Writer) quicvarint.Writer func github.com/RoaringBitmap/roaring.(*Bitmap).WriteFrozenTo(wr Writer) (int, error) func github.com/RoaringBitmap/roaring.(*Bitmap).WriteTo(stream Writer) (int64, error) func github.com/shirou/gopsutil/v3/internal/common.Write(w Writer, order common.ByteOrder, data interface{}) error func github.com/spf13/cobra.(*Command).GenBashCompletion(w Writer) error func github.com/spf13/cobra.(*Command).GenBashCompletionV2(w Writer, includeDesc bool) error func github.com/spf13/cobra.(*Command).GenFishCompletion(w Writer, includeDesc bool) error func github.com/spf13/cobra.(*Command).GenPowerShellCompletion(w Writer) error func github.com/spf13/cobra.(*Command).GenPowerShellCompletionWithDesc(w Writer) error func github.com/spf13/cobra.(*Command).GenZshCompletion(w Writer) error func github.com/spf13/cobra.(*Command).GenZshCompletionNoDesc(w Writer) error func github.com/spf13/cobra.(*Command).SetErr(newErr Writer) func github.com/spf13/cobra.(*Command).SetOut(newOut Writer) func github.com/spf13/cobra.(*Command).SetOutput(output Writer) func github.com/spf13/pflag.(*FlagSet).SetOutput(output Writer) func github.com/tetratelabs/wazero.ModuleConfig.WithStderr(Writer) wazero.ModuleConfig func github.com/tetratelabs/wazero.ModuleConfig.WithStdout(Writer) wazero.ModuleConfig func github.com/tetratelabs/wazero/internal/sys.NewContext(max uint32, args, environ [][]byte, stdin Reader, stdout, stderr Writer, randSource Reader, walltime sys.Walltime, walltimeResolution sys.ClockResolution, nanotime sys.Nanotime, nanotimeResolution sys.ClockResolution, nanosleep sys.Nanosleep, osyield sys.Osyield, fs []experimentalsys.FS, guestPaths []string, tcpListeners []*net.TCPListener) (sysCtx *sys.Context, err error) func github.com/tetratelabs/wazero/internal/sys.(*Context).InitFSContext(stdin Reader, stdout, stderr Writer, fs []sys.FS, guestPaths []string, tcpListeners []*net.TCPListener) (err error) func github.com/vmihailenco/msgpack/v5.NewEncoder(w Writer) *msgpack.Encoder func github.com/vmihailenco/msgpack/v5.(*Encoder).Reset(w Writer) func github.com/vmihailenco/msgpack/v5.(*Encoder).ResetDict(w Writer, dict map[string]int) func github.com/vmihailenco/msgpack/v5.(*Encoder).ResetWriter(w Writer) func github.com/yuin/goldmark.Convert(source []byte, w Writer, opts ...parser.ParseOption) error func github.com/yuin/goldmark.Markdown.Convert(source []byte, writer Writer, opts ...parser.ParseOption) error func github.com/yuin/goldmark/renderer.Renderer.Render(w Writer, source []byte, n ast.Node) error func go/ast.Fprint(w Writer, fset *token.FileSet, x any, f ast.FieldFilter) error func go/doc.ToHTML(w Writer, text string, words map[string]string) func go/doc.ToText(w Writer, text string, prefix, codePrefix string, width int) func go/scanner.PrintError(w Writer, err error) func go.etcd.io/bbolt.(*Tx).Copy(w Writer) error func go.etcd.io/bbolt.(*Tx).WriteTo(w Writer) (n int64, err error) func go.uber.org/dig.Visualize(c *dig.Container, w Writer, opts ...dig.VisualizeOption) error func go.uber.org/fx/internal/fxlog.DefaultLogger(w Writer) fxevent.Logger func go.uber.org/zap/zapcore.AddSync(w Writer) zapcore.WriteSyncer func golang.org/x/image/font/sfnt.(*Font).WriteSourceTo(b *sfnt.Buffer, w Writer) (int64, error) func golang.org/x/net/html.Render(w Writer, n *html.Node) error func golang.org/x/net/http2.NewFramer(w Writer, r Reader) *http2.Framer func golang.org/x/net/http2/hpack.HuffmanDecode(w Writer, v []byte) (int, error) func golang.org/x/net/http2/hpack.NewEncoder(w Writer) *hpack.Encoder func golang.org/x/net/trace.Render(w Writer, req *http.Request, sensitive bool) func golang.org/x/text/encoding.(*Encoder).Writer(w Writer) Writer func golang.org/x/text/message.(*Printer).Fprint(w Writer, a ...interface{}) (n int, err error) func golang.org/x/text/message.(*Printer).Fprintf(w Writer, key message.Reference, a ...interface{}) (n int, err error) func golang.org/x/text/message.(*Printer).Fprintln(w Writer, a ...interface{}) (n int, err error) func golang.org/x/text/transform.NewWriter(w Writer, t transform.Transformer) *transform.Writer func golang.org/x/text/unicode/norm.Form.Writer(w Writer) WriteCloser func gonum.org/v1/plot/vg.CanvasWriterTo.WriteTo(w Writer) (n int64, err error) func google.golang.org/grpc.Compressor.Do(w Writer, p []byte) error func google.golang.org/grpc/encoding.Compressor.Compress(w Writer) (WriteCloser, error) func google.golang.org/grpc/grpclog.NewLoggerV2(infoW, warningW, errorW Writer) grpclog.LoggerV2 func google.golang.org/grpc/grpclog.NewLoggerV2WithVerbosity(infoW, warningW, errorW Writer, v int) grpclog.LoggerV2 func google.golang.org/grpc/grpclog/internal.NewLoggerV2(infoW, warningW, errorW Writer, c internal.LoggerV2Config) internal.LoggerV2 func google.golang.org/protobuf/encoding/protodelim.MarshalTo(w Writer, m proto.Message) (int, error) func google.golang.org/protobuf/encoding/protodelim.MarshalOptions.MarshalTo(w Writer, m proto.Message) (int, error) func gopkg.in/yaml.v3.NewEncoder(w Writer) *yaml.Encoder func html/template.HTMLEscape(w Writer, b []byte) func html/template.JSEscape(w Writer, b []byte) func html/template.(*Template).Execute(wr Writer, data any) error func html/template.(*Template).ExecuteTemplate(wr Writer, name string, data any) error func internal/profile.(*Profile).Write(w Writer) error func log.New(out Writer, prefix string, flag int) *log.Logger func log.SetOutput(w Writer) func log.(*Logger).SetOutput(w Writer) func log/slog.NewJSONHandler(w Writer, opts *slog.HandlerOptions) *slog.JSONHandler func log/slog.NewTextHandler(w Writer, opts *slog.HandlerOptions) *slog.TextHandler func lukechampine.com/blake3.BaoDecode(dst Writer, data, outboard Reader, root [32]byte) (bool, error) func lukechampine.com/blake3/bao.Decode(dst Writer, data, outboard Reader, group int, root [32]byte) (bool, error) func lukechampine.com/blake3/bao.DecodeSlice(dst Writer, data Reader, group int, offset, length uint64, root [32]byte) (bool, error) func lukechampine.com/blake3/bao.ExtractSlice(dst Writer, data, outboard Reader, group int, offset uint64, length uint64) error func mime/multipart.NewWriter(w Writer) *multipart.Writer func mime/quotedprintable.NewWriter(w Writer) *quotedprintable.Writer func mvdan.cc/sh/v3/syntax.DebugPrint(w Writer, node syntax.Node) error func mvdan.cc/sh/v3/syntax.(*Printer).Print(w Writer, node syntax.Node) error func net.(*Buffers).WriteTo(w Writer) (n int64, err error) func net.(*TCPConn).WriteTo(w Writer) (int64, error) func net/http.Header.Write(w Writer) error func net/http.Header.WriteSubset(w Writer, exclude map[string]bool) error func net/http.(*Request).Write(w Writer) error func net/http.(*Request).WriteProxy(w Writer) error func net/http.(*Response).Write(w Writer) error func net/http/httputil.NewChunkedWriter(w Writer) WriteCloser func net/http/internal.NewChunkedWriter(w Writer) WriteCloser func os.(*File).WriteTo(w Writer) (n int64, err error) func runtime/pprof.StartCPUProfile(w Writer) error func runtime/pprof.WriteHeapProfile(w Writer) error func runtime/pprof.(*Profile).WriteTo(w Writer, debug int) error func runtime/trace.Start(w Writer) error func runtime/trace.(*FlightRecorder).WriteTo(w Writer) (n int64, err error) func strings.(*Reader).WriteTo(w Writer) (n int64, err error) func strings.(*Replacer).WriteString(w Writer, s string) (n int, err error) func text/tabwriter.NewWriter(output Writer, minwidth, tabwidth, padding int, padchar byte, flags uint) *tabwriter.Writer func text/tabwriter.(*Writer).Init(output Writer, minwidth, tabwidth, padding int, padchar byte, flags uint) *tabwriter.Writer func text/template.HTMLEscape(w Writer, b []byte) func text/template.JSEscape(w Writer, b []byte) func text/template.(*Template).Execute(wr Writer, data any) error func text/template.(*Template).ExecuteTemplate(wr Writer, name string, data any) error func vendor/golang.org/x/net/http2/hpack.HuffmanDecode(w Writer, v []byte) (int, error) func vendor/golang.org/x/net/http2/hpack.NewEncoder(w Writer) *hpack.Encoder func vendor/golang.org/x/text/transform.NewWriter(w Writer, t transform.Transformer) *transform.Writer func vendor/golang.org/x/text/unicode/norm.Form.Writer(w Writer) WriteCloser var Discard var io/ioutil.Discard
WriterAt is the interface that wraps the basic WriteAt method. WriteAt writes len(p) bytes from p to the underlying data stream at offset off. It returns the number of bytes written from p (0 <= n <= len(p)) and any error encountered that caused the write to stop early. WriteAt must return a non-nil error if it returns n < len(p). If WriteAt is writing to a destination with a seek offset, WriteAt should not affect nor be affected by the underlying seek offset. Clients of WriteAt can execute parallel WriteAt calls on the same destination if the ranges do not overlap. Implementations must not retain p. ( WriterAt) WriteAt(p []byte, off int64) (n int, err error) *OffsetWriter github.com/coreos/etcd/pkg/fileutil.LockedFile github.com/ncruces/go-sqlite3/vfs.File (interface) github.com/ncruces/go-sqlite3/vfs.FileBatchAtomicWrite (interface) github.com/ncruces/go-sqlite3/vfs.FileBusyHandler (interface) github.com/ncruces/go-sqlite3/vfs.FileCheckpoint (interface) github.com/ncruces/go-sqlite3/vfs.FileChunkSize (interface) github.com/ncruces/go-sqlite3/vfs.FileCommitPhaseTwo (interface) github.com/ncruces/go-sqlite3/vfs.FileHasMoved (interface) github.com/ncruces/go-sqlite3/vfs.FileLockState (interface) github.com/ncruces/go-sqlite3/vfs.FileOverwrite (interface) github.com/ncruces/go-sqlite3/vfs.FilePersistWAL (interface) github.com/ncruces/go-sqlite3/vfs.FilePowersafeOverwrite (interface) github.com/ncruces/go-sqlite3/vfs.FilePragma (interface) github.com/ncruces/go-sqlite3/vfs.FileSharedMemory (interface) github.com/ncruces/go-sqlite3/vfs.FileSizeHint (interface) github.com/ncruces/go-sqlite3/vfs.FileSync (interface) github.com/ncruces/go-sqlite3/vfs.FileUnwrap (interface) *github.com/polarsignals/wal/fs.File github.com/polarsignals/wal/types.WritableFile (interface) *os.File func NewOffsetWriter(w WriterAt, off int64) *OffsetWriter func lukechampine.com/blake3.BaoEncode(dst WriterAt, data Reader, dataLen int64, outboard bool) ([32]byte, error) func lukechampine.com/blake3/bao.Encode(dst WriterAt, data Reader, dataLen int64, group int, outboard bool) ([32]byte, error)
WriterTo is the interface that wraps the WriteTo method. WriteTo writes data to w until there's no more data to write or when an error occurs. The return value n is the number of bytes written. Any error encountered during the write is also returned. The Copy function uses WriterTo if available. ( WriterTo) WriteTo(w Writer) (n int64, err error) *bufio.Reader bufio.ReadWriter *bytes.Buffer *bytes.Reader github.com/apache/thrift/lib/go/thrift.TBufferedTransport github.com/apache/thrift/lib/go/thrift.TMemoryBuffer *github.com/bits-and-blooms/bitset.BitSet github.com/coreos/etcd/pkg/fileutil.LockedFile github.com/gobwas/ws.HandshakeHeader (interface) github.com/gobwas/ws.HandshakeHeaderBytes github.com/gobwas/ws.HandshakeHeaderFunc github.com/gobwas/ws.HandshakeHeaderHTTP github.com/gobwas/ws.HandshakeHeaderString *github.com/klauspost/compress/gzip.Reader *github.com/klauspost/compress/zstd.Decoder *github.com/libp2p/go-buffer-pool.Buffer github.com/libp2p/go-libp2p/p2p/transport/tcpreuse/internal/sampledconn.ManetTCPConnInterface (interface) *github.com/ncruces/go-sqlite3.Blob *github.com/pierrec/lz4/v4.Reader *github.com/pion/stun.Message *github.com/pion/stun/v3.Message *github.com/polarsignals/wal/fs.File *github.com/RoaringBitmap/roaring.Bitmap *go.etcd.io/bbolt.Tx gonum.org/v1/plot/vg.CanvasWriterTo (interface) *net.Buffers *net.TCPConn *os.File *runtime/trace.FlightRecorder *strings.Reader WriterTo : github.com/gobwas/ws.HandshakeHeader
WriteSeeker is the interface that groups the basic Write and Seek methods. ( WriteSeeker) Seek(offset int64, whence int) (int64, error) ( WriteSeeker) Write([]byte) (int, error) *OffsetWriter ReadWriteSeeker (interface) github.com/coreos/etcd/pkg/fileutil.LockedFile *github.com/ncruces/go-sqlite3.Blob *github.com/polarsignals/wal/fs.File *internal/poll.FD *os.File WriteSeeker : Seeker WriteSeeker : Writer WriteSeeker : github.com/miekg/dns.Writer WriteSeeker : internal/bisect.Writer
Package-Level Functions (total 15)
Copy copies from src to dst until either EOF is reached on src or an error occurs. It returns the number of bytes copied and the first error encountered while copying, if any. A successful Copy returns err == nil, not err == EOF. Because Copy is defined to read from src until EOF, it does not treat an EOF from Read as an error to be reported. If src implements [WriterTo], the copy is implemented by calling src.WriteTo(dst). Otherwise, if dst implements [ReaderFrom], the copy is implemented by calling dst.ReadFrom(src).
CopyBuffer is identical to Copy except that it stages through the provided buffer (if one is required) rather than allocating a temporary one. If buf is nil, one is allocated; otherwise if it has zero length, CopyBuffer panics. If either src implements [WriterTo] or dst implements [ReaderFrom], buf will not be used to perform the copy.
CopyN copies n bytes (or until an error) from src to dst. It returns the number of bytes copied and the earliest error encountered while copying. On return, written == n if and only if err == nil. If dst implements [ReaderFrom], the copy is implemented using it.
LimitReader returns a Reader that reads from r but stops with EOF after n bytes. The underlying implementation is a *LimitedReader.
MultiReader returns a Reader that's the logical concatenation of the provided input readers. They're read sequentially. Once all inputs have returned EOF, Read will return EOF. If any of the readers return a non-nil, non-EOF error, Read will return that error.
MultiWriter creates a writer that duplicates its writes to all the provided writers, similar to the Unix tee(1) command. Each write is written to each listed writer, one at a time. If a listed writer returns an error, that overall write operation stops and returns the error; it does not continue down the list.
NewOffsetWriter returns an [OffsetWriter] that writes to w starting at offset off.
NewSectionReader returns a [SectionReader] that reads from r starting at offset off and stops with EOF after n bytes.
NopCloser returns a [ReadCloser] with a no-op Close method wrapping the provided [Reader] r. If r implements [WriterTo], the returned [ReadCloser] will implement [WriterTo] by forwarding calls to r.
Pipe creates a synchronous in-memory pipe. It can be used to connect code expecting an [io.Reader] with code expecting an [io.Writer]. Reads and Writes on the pipe are matched one to one except when multiple Reads are needed to consume a single Write. That is, each Write to the [PipeWriter] blocks until it has satisfied one or more Reads from the [PipeReader] that fully consume the written data. The data is copied directly from the Write to the corresponding Read (or Reads); there is no internal buffering. It is safe to call Read and Write in parallel with each other or with Close. Parallel calls to Read and parallel calls to Write are also safe: the individual calls will be gated sequentially.
ReadAll reads from r until an error or EOF and returns the data it read. A successful call returns err == nil, not err == EOF. Because ReadAll is defined to read from src until EOF, it does not treat an EOF from Read as an error to be reported.
ReadAtLeast reads from r into buf until it has read at least min bytes. It returns the number of bytes copied and an error if fewer bytes were read. The error is EOF only if no bytes were read. If an EOF happens after reading fewer than min bytes, ReadAtLeast returns [ErrUnexpectedEOF]. If min is greater than the length of buf, ReadAtLeast returns [ErrShortBuffer]. On return, n >= min if and only if err == nil. If r returns an error having read at least min bytes, the error is dropped.
ReadFull reads exactly len(buf) bytes from r into buf. It returns the number of bytes copied and an error if fewer bytes were read. The error is EOF only if no bytes were read. If an EOF happens after reading some but not all the bytes, ReadFull returns [ErrUnexpectedEOF]. On return, n == len(buf) if and only if err == nil. If r returns an error having read at least len(buf) bytes, the error is dropped.
TeeReader returns a [Reader] that writes to w what it reads from r. All reads from r performed through it are matched with corresponding writes to w. There is no internal buffering - the write must complete before the read completes. Any error encountered while writing is reported as a read error.
WriteString writes the contents of the string s to w, which accepts a slice of bytes. If w implements [StringWriter], [StringWriter.WriteString] is invoked directly. Otherwise, [Writer.Write] is called exactly once.
Package-Level Variables (total 7)
Discard is a [Writer] on which all Write calls succeed without doing anything.
EOF is the error returned by Read when no more input is available. (Read must return EOF itself, not an error wrapping EOF, because callers will test for EOF using ==.) Functions should return EOF only to signal a graceful end of input. If the EOF occurs unexpectedly in a structured data stream, the appropriate error is either [ErrUnexpectedEOF] or some other error giving more detail.
ErrClosedPipe is the error used for read or write operations on a closed pipe.
ErrNoProgress is returned by some clients of a [Reader] when many calls to Read have failed to return any data or error, usually the sign of a broken [Reader] implementation.
ErrShortBuffer means that a read required a longer buffer than was provided.
ErrShortWrite means that a write accepted fewer bytes than requested but failed to return an explicit error.
ErrUnexpectedEOF means that EOF was encountered in the middle of reading a fixed-size block or data structure.
Package-Level Constants (total 3)
Seek whence values.
Seek whence values.
Seek whence values.