]> Cypherpunks.ru repositories - gostls13.git/blobdiff - src/testing/benchmark.go
testing: add available godoc link
[gostls13.git] / src / testing / benchmark.go
index 2d0de180d71863f9b30a72cee389221091c0d555..b197ea37bc8da2fae38a676a35975e9b9050142a 100644 (file)
@@ -7,17 +7,62 @@ package testing
 import (
        "flag"
        "fmt"
-       "internal/race"
+       "internal/sysinfo"
+       "io"
+       "math"
        "os"
        "runtime"
+       "sort"
+       "strconv"
+       "strings"
        "sync"
        "sync/atomic"
        "time"
+       "unicode"
 )
 
-var matchBenchmarks = flag.String("test.bench", "", "run only benchmarks matching `regexp`")
-var benchTime = flag.Duration("test.benchtime", 1*time.Second, "run each benchmark for duration `d`")
-var benchmarkMemory = flag.Bool("test.benchmem", false, "print memory allocations for benchmarks")
+func initBenchmarkFlags() {
+       matchBenchmarks = flag.String("test.bench", "", "run only benchmarks matching `regexp`")
+       benchmarkMemory = flag.Bool("test.benchmem", false, "print memory allocations for benchmarks")
+       flag.Var(&benchTime, "test.benchtime", "run each benchmark for duration `d` or N times if `d` is of the form Nx")
+}
+
+var (
+       matchBenchmarks *string
+       benchmarkMemory *bool
+
+       benchTime = durationOrCountFlag{d: 1 * time.Second} // changed during test of testing package
+)
+
+type durationOrCountFlag struct {
+       d         time.Duration
+       n         int
+       allowZero bool
+}
+
+func (f *durationOrCountFlag) String() string {
+       if f.n > 0 {
+               return fmt.Sprintf("%dx", f.n)
+       }
+       return f.d.String()
+}
+
+func (f *durationOrCountFlag) Set(s string) error {
+       if strings.HasSuffix(s, "x") {
+               n, err := strconv.ParseInt(s[:len(s)-1], 10, 0)
+               if err != nil || n < 0 || (!f.allowZero && n == 0) {
+                       return fmt.Errorf("invalid count")
+               }
+               *f = durationOrCountFlag{n: int(n)}
+               return nil
+       }
+       d, err := time.ParseDuration(s)
+       if err != nil || d < 0 || (!f.allowZero && d == 0) {
+               return fmt.Errorf("invalid duration")
+       }
+       *f = durationOrCountFlag{d: d}
+       return nil
+}
 
 // Global lock to ensure only one benchmark runs at a time.
 var benchmarkLock sync.Mutex
@@ -25,14 +70,14 @@ var benchmarkLock sync.Mutex
 // Used for every benchmark for measuring memory.
 var memStats runtime.MemStats
 
-// An internal type but exported because it is cross-package; part of the implementation
-// of the "go test" command.
+// InternalBenchmark is an internal type but exported because it is cross-package;
+// it is part of the implementation of the "go test" command.
 type InternalBenchmark struct {
        Name string
        F    func(b *B)
 }
 
-// B is a type passed to Benchmark functions to manage benchmark
+// B is a type passed to [Benchmark] functions to manage benchmark
 // timing and to specify the number of iterations to run.
 //
 // A benchmark ends when its Benchmark function returns or calls any of the methods
@@ -42,7 +87,7 @@ type InternalBenchmark struct {
 // may be called simultaneously from multiple goroutines.
 //
 // Like in tests, benchmark logs are accumulated during execution
-// and dumped to standard error when done. Unlike in tests, benchmark logs
+// and dumped to standard output when done. Unlike in tests, benchmark logs
 // are always printed, so as not to hide output whose existence may be
 // affecting benchmark results.
 type B struct {
@@ -53,7 +98,7 @@ type B struct {
        previousN        int           // number of iterations in the previous run
        previousDuration time.Duration // total duration of the previous run
        benchFunc        func(b *B)
-       benchTime        time.Duration
+       benchTime        durationOrCountFlag
        bytes            int64
        missingBytes     bool // one of the subbenchmarks does not have bytes set.
        timerOn          bool
@@ -66,11 +111,13 @@ type B struct {
        // The net total of this test after being run.
        netAllocs uint64
        netBytes  uint64
+       // Extra metrics collected by ReportMetric.
+       extra map[string]float64
 }
 
 // StartTimer starts timing a test. This function is called automatically
-// before a benchmark starts, but it can also used to resume timing after
-// a call to StopTimer.
+// before a benchmark starts, but it can also be used to resume timing after
+// a call to [B.StopTimer].
 func (b *B) StartTimer() {
        if !b.timerOn {
                runtime.ReadMemStats(&memStats)
@@ -94,9 +141,17 @@ func (b *B) StopTimer() {
        }
 }
 
-// ResetTimer zeros the elapsed benchmark time and memory allocation counters.
+// ResetTimer zeroes the elapsed benchmark time and memory allocation counters
+// and deletes user-reported metrics.
 // It does not affect whether the timer is running.
 func (b *B) ResetTimer() {
+       if b.extra == nil {
+               // Allocate the extra map before reading memory stats.
+               // Pre-size it to make more allocation unlikely.
+               b.extra = make(map[string]float64, 16)
+       } else {
+               clear(b.extra)
+       }
        if b.timerOn {
                runtime.ReadMemStats(&memStats)
                b.startAllocs = memStats.Mallocs
@@ -119,21 +174,18 @@ func (b *B) ReportAllocs() {
        b.showAllocResult = true
 }
 
-func (b *B) nsPerOp() int64 {
-       if b.N <= 0 {
-               return 0
-       }
-       return b.duration.Nanoseconds() / int64(b.N)
-}
-
 // runN runs a single benchmark for the specified number of iterations.
 func (b *B) runN(n int) {
        benchmarkLock.Lock()
        defer benchmarkLock.Unlock()
+       defer func() {
+               b.runCleanup(normalPanic)
+               b.checkRaces()
+       }()
        // Try to get a comparable environment for each run
        // by clearing garbage from previous runs.
        runtime.GC()
-       b.raceErrors = -race.Errors()
+       b.resetRaces()
        b.N = n
        b.parallelism = 1
        b.ResetTimer()
@@ -142,60 +194,9 @@ func (b *B) runN(n int) {
        b.StopTimer()
        b.previousN = n
        b.previousDuration = b.duration
-       b.raceErrors += race.Errors()
-       if b.raceErrors > 0 {
-               b.Errorf("race detected during execution of benchmark")
-       }
-}
-
-func min(x, y int) int {
-       if x > y {
-               return y
-       }
-       return x
-}
-
-func max(x, y int) int {
-       if x < y {
-               return y
-       }
-       return x
-}
-
-// roundDown10 rounds a number down to the nearest power of 10.
-func roundDown10(n int) int {
-       var tens = 0
-       // tens = floor(log_10(n))
-       for n >= 10 {
-               n = n / 10
-               tens++
-       }
-       // result = 10^tens
-       result := 1
-       for i := 0; i < tens; i++ {
-               result *= 10
-       }
-       return result
-}
-
-// roundUp rounds x up to a number of the form [1eX, 2eX, 3eX, 5eX].
-func roundUp(n int) int {
-       base := roundDown10(n)
-       switch {
-       case n <= base:
-               return base
-       case n <= (2 * base):
-               return 2 * base
-       case n <= (3 * base):
-               return 3 * base
-       case n <= (5 * base):
-               return 5 * base
-       default:
-               return 10 * base
-       }
 }
 
-// run1 runs the first iteration of benchFunc. It returns whether more
+// run1 runs the first iteration of benchFunc. It reports whether more
 // iterations of this benchmarks should be run.
 func (b *B) run1() bool {
        if ctx := b.context; ctx != nil {
@@ -215,19 +216,22 @@ func (b *B) run1() bool {
        }()
        <-b.signal
        if b.failed {
-               fmt.Fprintf(b.w, "--- FAIL: %s\n%s", b.name, b.output)
+               fmt.Fprintf(b.w, "%s--- FAIL: %s\n%s", b.chatty.prefix(), b.name, b.output)
                return false
        }
        // Only print the output if we know we are not going to proceed.
        // Otherwise it is printed in processBench.
-       if atomic.LoadInt32(&b.hasSub) != 0 || b.finished {
+       b.mu.RLock()
+       finished := b.finished
+       b.mu.RUnlock()
+       if b.hasSub.Load() || finished {
                tag := "BENCH"
                if b.skipped {
                        tag = "SKIP"
                }
-               if b.chatty && (len(b.output) > 0 || b.finished) {
+               if b.chatty != nil && (len(b.output) > 0 || finished) {
                        b.trimOutput()
-                       fmt.Fprintf(b.w, "--- %s: %s\n%s", tag, b.name, b.output)
+                       fmt.Fprintf(b.w, "%s--- %s: %s\n%s", b.chatty.prefix(), tag, b.name, b.output)
                }
                return false
        }
@@ -245,6 +249,9 @@ func (b *B) run() {
                if b.importPath != "" {
                        fmt.Fprintf(b.w, "pkg: %s\n", b.importPath)
                }
+               if cpu := sysinfo.CPUName(); cpu != "" {
+                       fmt.Fprintf(b.w, "cpu: %s\n", cpu)
+               }
        })
        if b.context != nil {
                // Running go test --test.bench
@@ -273,82 +280,202 @@ func (b *B) launch() {
        }()
 
        // Run the benchmark for at least the specified amount of time.
-       d := b.benchTime
-       for n := 1; !b.failed && b.duration < d && n < 1e9; {
-               last := n
-               // Predict required iterations.
-               n = int(d.Nanoseconds())
-               if nsop := b.nsPerOp(); nsop != 0 {
-                       n /= int(nsop)
+       if b.benchTime.n > 0 {
+               // We already ran a single iteration in run1.
+               // If -benchtime=1x was requested, use that result.
+               // See https://golang.org/issue/32051.
+               if b.benchTime.n > 1 {
+                       b.runN(b.benchTime.n)
+               }
+       } else {
+               d := b.benchTime.d
+               for n := int64(1); !b.failed && b.duration < d && n < 1e9; {
+                       last := n
+                       // Predict required iterations.
+                       goalns := d.Nanoseconds()
+                       prevIters := int64(b.N)
+                       prevns := b.duration.Nanoseconds()
+                       if prevns <= 0 {
+                               // Round up, to avoid div by zero.
+                               prevns = 1
+                       }
+                       // Order of operations matters.
+                       // For very fast benchmarks, prevIters ~= prevns.
+                       // If you divide first, you get 0 or 1,
+                       // which can hide an order of magnitude in execution time.
+                       // So multiply first, then divide.
+                       n = goalns * prevIters / prevns
+                       // Run more iterations than we think we'll need (1.2x).
+                       n += n / 5
+                       // Don't grow too fast in case we had timing errors previously.
+                       n = min(n, 100*last)
+                       // Be sure to run at least one more than last time.
+                       n = max(n, last+1)
+                       // Don't run more than 1e9 times. (This also keeps n in int range on 32 bit platforms.)
+                       n = min(n, 1e9)
+                       b.runN(int(n))
                }
-               // Run more iterations than we think we'll need (1.2x).
-               // Don't grow too fast in case we had timing errors previously.
-               // Be sure to run at least one more than last time.
-               n = max(min(n+n/5, 100*last), last+1)
-               // Round up to something easy to read.
-               n = roundUp(n)
-               b.runN(n)
        }
-       b.result = BenchmarkResult{b.N, b.duration, b.bytes, b.netAllocs, b.netBytes}
+       b.result = BenchmarkResult{b.N, b.duration, b.bytes, b.netAllocs, b.netBytes, b.extra}
 }
 
-// The results of a benchmark run.
+// Elapsed returns the measured elapsed time of the benchmark.
+// The duration reported by Elapsed matches the one measured by
+// [B.StartTimer], [B.StopTimer], and [B.ResetTimer].
+func (b *B) Elapsed() time.Duration {
+       d := b.duration
+       if b.timerOn {
+               d += time.Since(b.start)
+       }
+       return d
+}
+
+// ReportMetric adds "n unit" to the reported benchmark results.
+// If the metric is per-iteration, the caller should divide by b.N,
+// and by convention units should end in "/op".
+// ReportMetric overrides any previously reported value for the same unit.
+// ReportMetric panics if unit is the empty string or if unit contains
+// any whitespace.
+// If unit is a unit normally reported by the benchmark framework itself
+// (such as "allocs/op"), ReportMetric will override that metric.
+// Setting "ns/op" to 0 will suppress that built-in metric.
+func (b *B) ReportMetric(n float64, unit string) {
+       if unit == "" {
+               panic("metric unit must not be empty")
+       }
+       if strings.IndexFunc(unit, unicode.IsSpace) >= 0 {
+               panic("metric unit must not contain whitespace")
+       }
+       b.extra[unit] = n
+}
+
+// BenchmarkResult contains the results of a benchmark run.
 type BenchmarkResult struct {
        N         int           // The number of iterations.
        T         time.Duration // The total time taken.
        Bytes     int64         // Bytes processed in one iteration.
        MemAllocs uint64        // The total number of memory allocations.
        MemBytes  uint64        // The total number of bytes allocated.
+
+       // Extra records additional metrics reported by ReportMetric.
+       Extra map[string]float64
 }
 
+// NsPerOp returns the "ns/op" metric.
 func (r BenchmarkResult) NsPerOp() int64 {
+       if v, ok := r.Extra["ns/op"]; ok {
+               return int64(v)
+       }
        if r.N <= 0 {
                return 0
        }
        return r.T.Nanoseconds() / int64(r.N)
 }
 
+// mbPerSec returns the "MB/s" metric.
 func (r BenchmarkResult) mbPerSec() float64 {
+       if v, ok := r.Extra["MB/s"]; ok {
+               return v
+       }
        if r.Bytes <= 0 || r.T <= 0 || r.N <= 0 {
                return 0
        }
        return (float64(r.Bytes) * float64(r.N) / 1e6) / r.T.Seconds()
 }
 
-// AllocsPerOp returns r.MemAllocs / r.N.
+// AllocsPerOp returns the "allocs/op" metric,
+// which is calculated as r.MemAllocs / r.N.
 func (r BenchmarkResult) AllocsPerOp() int64 {
+       if v, ok := r.Extra["allocs/op"]; ok {
+               return int64(v)
+       }
        if r.N <= 0 {
                return 0
        }
        return int64(r.MemAllocs) / int64(r.N)
 }
 
-// AllocedBytesPerOp returns r.MemBytes / r.N.
+// AllocedBytesPerOp returns the "B/op" metric,
+// which is calculated as r.MemBytes / r.N.
 func (r BenchmarkResult) AllocedBytesPerOp() int64 {
+       if v, ok := r.Extra["B/op"]; ok {
+               return int64(v)
+       }
        if r.N <= 0 {
                return 0
        }
        return int64(r.MemBytes) / int64(r.N)
 }
 
+// String returns a summary of the benchmark results.
+// It follows the benchmark result line format from
+// https://golang.org/design/14313-benchmark-format, not including the
+// benchmark name.
+// Extra metrics override built-in metrics of the same name.
+// String does not include allocs/op or B/op, since those are reported
+// by [BenchmarkResult.MemString].
 func (r BenchmarkResult) String() string {
-       mbs := r.mbPerSec()
-       mb := ""
-       if mbs != 0 {
-               mb = fmt.Sprintf("\t%7.2f MB/s", mbs)
-       }
-       nsop := r.NsPerOp()
-       ns := fmt.Sprintf("%10d ns/op", nsop)
-       if r.N > 0 && nsop < 100 {
-               // The format specifiers here make sure that
-               // the ones digits line up for all three possible formats.
-               if nsop < 10 {
-                       ns = fmt.Sprintf("%13.2f ns/op", float64(r.T.Nanoseconds())/float64(r.N))
-               } else {
-                       ns = fmt.Sprintf("%12.1f ns/op", float64(r.T.Nanoseconds())/float64(r.N))
+       buf := new(strings.Builder)
+       fmt.Fprintf(buf, "%8d", r.N)
+
+       // Get ns/op as a float.
+       ns, ok := r.Extra["ns/op"]
+       if !ok {
+               ns = float64(r.T.Nanoseconds()) / float64(r.N)
+       }
+       if ns != 0 {
+               buf.WriteByte('\t')
+               prettyPrint(buf, ns, "ns/op")
+       }
+
+       if mbs := r.mbPerSec(); mbs != 0 {
+               fmt.Fprintf(buf, "\t%7.2f MB/s", mbs)
+       }
+
+       // Print extra metrics that aren't represented in the standard
+       // metrics.
+       var extraKeys []string
+       for k := range r.Extra {
+               switch k {
+               case "ns/op", "MB/s", "B/op", "allocs/op":
+                       // Built-in metrics reported elsewhere.
+                       continue
                }
+               extraKeys = append(extraKeys, k)
+       }
+       sort.Strings(extraKeys)
+       for _, k := range extraKeys {
+               buf.WriteByte('\t')
+               prettyPrint(buf, r.Extra[k], k)
+       }
+       return buf.String()
+}
+
+func prettyPrint(w io.Writer, x float64, unit string) {
+       // Print all numbers with 10 places before the decimal point
+       // and small numbers with four sig figs. Field widths are
+       // chosen to fit the whole part in 10 places while aligning
+       // the decimal point of all fractional formats.
+       var format string
+       switch y := math.Abs(x); {
+       case y == 0 || y >= 999.95:
+               format = "%10.0f %s"
+       case y >= 99.995:
+               format = "%12.1f %s"
+       case y >= 9.9995:
+               format = "%13.2f %s"
+       case y >= 0.99995:
+               format = "%14.3f %s"
+       case y >= 0.099995:
+               format = "%15.4f %s"
+       case y >= 0.0099995:
+               format = "%16.5f %s"
+       case y >= 0.00099995:
+               format = "%17.6f %s"
+       default:
+               format = "%18.7f %s"
        }
-       return fmt.Sprintf("%8d\t%s%s", r.N, ns, mb)
+       fmt.Fprintf(w, format, x, unit)
 }
 
 // MemString returns r.AllocedBytesPerOp and r.AllocsPerOp in the same format as 'go test'.
@@ -372,8 +499,8 @@ type benchContext struct {
        extLen int // Maximum extension length.
 }
 
-// An internal function but exported because it is cross-package; part of the implementation
-// of the "go test" command.
+// RunBenchmarks is an internal function but exported because it is cross-package;
+// it is part of the implementation of the "go test" command.
 func RunBenchmarks(matchString func(pat, str string) (bool, error), benchmarks []InternalBenchmark) {
        runBenchmarks("", matchString, benchmarks)
 }
@@ -391,7 +518,7 @@ func runBenchmarks(importPath string, matchString func(pat, str string) (bool, e
                }
        }
        ctx := &benchContext{
-               match:  newMatcher(matchString, *matchBenchmarks, "-test.bench"),
+               match:  newMatcher(matchString, *matchBenchmarks, "-test.bench", *skip),
                extLen: len(benchmarkName("", maxprocs)),
        }
        var bs []InternalBenchmark
@@ -406,9 +533,9 @@ func runBenchmarks(importPath string, matchString func(pat, str string) (bool, e
        }
        main := &B{
                common: common{
-                       name:   "Main",
-                       w:      os.Stdout,
-                       chatty: *chatty,
+                       name:  "Main",
+                       w:     os.Stdout,
+                       bench: true,
                },
                importPath: importPath,
                benchFunc: func(b *B) {
@@ -416,9 +543,12 @@ func runBenchmarks(importPath string, matchString func(pat, str string) (bool, e
                                b.Run(Benchmark.Name, Benchmark.F)
                        }
                },
-               benchTime: *benchTime,
+               benchTime: benchTime,
                context:   ctx,
        }
+       if Verbose() {
+               main.chatty = newChattyPrinter(main.w)
+       }
        main.runN(1)
        return !main.failed
 }
@@ -429,7 +559,11 @@ func (ctx *benchContext) processBench(b *B) {
                for j := uint(0); j < *count; j++ {
                        runtime.GOMAXPROCS(procs)
                        benchName := benchmarkName(b.name, procs)
-                       fmt.Fprintf(b.w, "%-*s\t", ctx.maxLen, benchName)
+
+                       // If it's chatty, we've already printed this information.
+                       if b.chatty == nil {
+                               fmt.Fprintf(b.w, "%-*s\t", ctx.maxLen, benchName)
+                       }
                        // Recompute the running time for all but the first iteration.
                        if i > 0 || j > 0 {
                                b = &B{
@@ -438,6 +572,7 @@ func (ctx *benchContext) processBench(b *B) {
                                                name:   b.name,
                                                w:      b.w,
                                                chatty: b.chatty,
+                                               bench:  true,
                                        },
                                        benchFunc: b.benchFunc,
                                        benchTime: b.benchTime,
@@ -449,10 +584,13 @@ func (ctx *benchContext) processBench(b *B) {
                                // The output could be very long here, but probably isn't.
                                // We print it all, regardless, because we don't want to trim the reason
                                // the benchmark failed.
-                               fmt.Fprintf(b.w, "--- FAIL: %s\n%s", benchName, b.output)
+                               fmt.Fprintf(b.w, "%s--- FAIL: %s\n%s", b.chatty.prefix(), benchName, b.output)
                                continue
                        }
                        results := r.String()
+                       if b.chatty != nil {
+                               fmt.Fprintf(b.w, "%-*s\t", ctx.maxLen, benchName)
+                       }
                        if *benchmarkMemory || b.showAllocResult {
                                results += "\t" + r.MemString()
                        }
@@ -461,27 +599,32 @@ func (ctx *benchContext) processBench(b *B) {
                        // benchmarks since the output generation time will skew the results.
                        if len(b.output) > 0 {
                                b.trimOutput()
-                               fmt.Fprintf(b.w, "--- BENCH: %s\n%s", benchName, b.output)
+                               fmt.Fprintf(b.w, "%s--- BENCH: %s\n%s", b.chatty.prefix(), benchName, b.output)
                        }
                        if p := runtime.GOMAXPROCS(-1); p != procs {
                                fmt.Fprintf(os.Stderr, "testing: %s left GOMAXPROCS set to %d\n", benchName, p)
                        }
+                       if b.chatty != nil && b.chatty.json {
+                               b.chatty.Updatef("", "=== NAME  %s\n", "")
+                       }
                }
        }
 }
 
+// If hideStdoutForTesting is true, Run does not print the benchName.
+// This avoids a spurious print during 'go test' on package testing itself,
+// which invokes b.Run in its own tests (see sub_test.go).
+var hideStdoutForTesting = false
+
 // Run benchmarks f as a subbenchmark with the given name. It reports
 // whether there were any failures.
 //
 // A subbenchmark is like any other benchmark. A benchmark that calls Run at
 // least once will not be measured itself and will be called once with N=1.
-//
-// Run may be called simultaneously from multiple goroutines, but all such
-// calls must return before the outer benchmark function for b returns.
 func (b *B) Run(name string, f func(b *B)) bool {
        // Since b has subbenchmarks, we will no longer run it as a benchmark itself.
        // Release the lock and acquire it on exit to ensure locks stay paired.
-       atomic.StoreInt32(&b.hasSub, 1)
+       b.hasSub.Store(true)
        benchmarkLock.Unlock()
        defer benchmarkLock.Lock()
 
@@ -492,14 +635,18 @@ func (b *B) Run(name string, f func(b *B)) bool {
        if !ok {
                return true
        }
+       var pc [maxStackLen]uintptr
+       n := runtime.Callers(2, pc[:])
        sub := &B{
                common: common{
-                       signal: make(chan bool),
-                       name:   benchName,
-                       parent: &b.common,
-                       level:  b.level + 1,
-                       w:      b.w,
-                       chatty: b.chatty,
+                       signal:  make(chan bool),
+                       name:    benchName,
+                       parent:  &b.common,
+                       level:   b.level + 1,
+                       creator: pc[:n],
+                       w:       b.w,
+                       chatty:  b.chatty,
+                       bench:   true,
                },
                importPath: b.importPath,
                benchFunc:  f,
@@ -509,8 +656,29 @@ func (b *B) Run(name string, f func(b *B)) bool {
        if partial {
                // Partial name match, like -bench=X/Y matching BenchmarkX.
                // Only process sub-benchmarks, if any.
-               atomic.StoreInt32(&sub.hasSub, 1)
+               sub.hasSub.Store(true)
        }
+
+       if b.chatty != nil {
+               labelsOnce.Do(func() {
+                       fmt.Printf("goos: %s\n", runtime.GOOS)
+                       fmt.Printf("goarch: %s\n", runtime.GOARCH)
+                       if b.importPath != "" {
+                               fmt.Printf("pkg: %s\n", b.importPath)
+                       }
+                       if cpu := sysinfo.CPUName(); cpu != "" {
+                               fmt.Printf("cpu: %s\n", cpu)
+                       }
+               })
+
+               if !hideStdoutForTesting {
+                       if b.chatty.json {
+                               b.chatty.Updatef(benchName, "=== RUN   %s\n", benchName)
+                       }
+                       fmt.Println(benchName)
+               }
+       }
+
        if sub.run1() {
                sub.run()
        }
@@ -584,13 +752,16 @@ func (pb *PB) Next() bool {
 // RunParallel runs a benchmark in parallel.
 // It creates multiple goroutines and distributes b.N iterations among them.
 // The number of goroutines defaults to GOMAXPROCS. To increase parallelism for
-// non-CPU-bound benchmarks, call SetParallelism before RunParallel.
+// non-CPU-bound benchmarks, call [B.SetParallelism] before RunParallel.
 // RunParallel is usually used with the go test -cpu flag.
 //
 // The body function will be run in each goroutine. It should set up any
 // goroutine-local state and then iterate until pb.Next returns false.
-// It should not use the StartTimer, StopTimer, or ResetTimer functions,
-// because they have global effect. It should also not call Run.
+// It should not use the [B.StartTimer], [B.StopTimer], or [B.ResetTimer] functions,
+// because they have global effect. It should also not call [B.Run].
+//
+// RunParallel reports ns/op values as wall time for the benchmark as a whole,
+// not the sum of wall time or CPU time over each parallel goroutine.
 func (b *B) RunParallel(body func(*PB)) {
        if b.N == 0 {
                return // Nothing to do when probing.
@@ -632,7 +803,7 @@ func (b *B) RunParallel(body func(*PB)) {
        }
 }
 
-// SetParallelism sets the number of goroutines used by RunParallel to p*GOMAXPROCS.
+// SetParallelism sets the number of goroutines used by [B.RunParallel] to p*GOMAXPROCS.
 // There is usually no need to call SetParallelism for CPU-bound benchmarks.
 // If p is less than 1, this call will have no effect.
 func (b *B) SetParallelism(p int) {
@@ -641,9 +812,12 @@ func (b *B) SetParallelism(p int) {
        }
 }
 
-// Benchmark benchmarks a single function. Useful for creating
+// Benchmark benchmarks a single function. It is useful for creating
 // custom benchmarks that do not use the "go test" command.
 //
+// If f depends on testing flags, then [Init] must be used to register
+// those flags before calling Benchmark and before calling [flag.Parse].
+//
 // If f calls Run, the result will be an estimate of running all its
 // subbenchmarks that don't call Run in sequence in a single benchmark.
 func Benchmark(f func(b *B)) BenchmarkResult {
@@ -653,7 +827,7 @@ func Benchmark(f func(b *B)) BenchmarkResult {
                        w:      discard{},
                },
                benchFunc: f,
-               benchTime: *benchTime,
+               benchTime: benchTime,
        }
        if b.run1() {
                b.run()