]> Cypherpunks.ru repositories - gostls13.git/blob - src/runtime/mgcsweep.go
runtime: refactor runtime->tracer API to appear more like a lock
[gostls13.git] / src / runtime / mgcsweep.go
1 // Copyright 2009 The Go Authors. All rights reserved.
2 // Use of this source code is governed by a BSD-style
3 // license that can be found in the LICENSE file.
4
5 // Garbage collector: sweeping
6
7 // The sweeper consists of two different algorithms:
8 //
9 // * The object reclaimer finds and frees unmarked slots in spans. It
10 //   can free a whole span if none of the objects are marked, but that
11 //   isn't its goal. This can be driven either synchronously by
12 //   mcentral.cacheSpan for mcentral spans, or asynchronously by
13 //   sweepone, which looks at all the mcentral lists.
14 //
15 // * The span reclaimer looks for spans that contain no marked objects
16 //   and frees whole spans. This is a separate algorithm because
17 //   freeing whole spans is the hardest task for the object reclaimer,
18 //   but is critical when allocating new spans. The entry point for
19 //   this is mheap_.reclaim and it's driven by a sequential scan of
20 //   the page marks bitmap in the heap arenas.
21 //
22 // Both algorithms ultimately call mspan.sweep, which sweeps a single
23 // heap span.
24
25 package runtime
26
27 import (
28         "internal/goexperiment"
29         "runtime/internal/atomic"
30         "unsafe"
31 )
32
33 var sweep sweepdata
34
35 // State of background sweep.
36 type sweepdata struct {
37         lock   mutex
38         g      *g
39         parked bool
40
41         // active tracks outstanding sweepers and the sweep
42         // termination condition.
43         active activeSweep
44
45         // centralIndex is the current unswept span class.
46         // It represents an index into the mcentral span
47         // sets. Accessed and updated via its load and
48         // update methods. Not protected by a lock.
49         //
50         // Reset at mark termination.
51         // Used by mheap.nextSpanForSweep.
52         centralIndex sweepClass
53 }
54
55 // sweepClass is a spanClass and one bit to represent whether we're currently
56 // sweeping partial or full spans.
57 type sweepClass uint32
58
59 const (
60         numSweepClasses            = numSpanClasses * 2
61         sweepClassDone  sweepClass = sweepClass(^uint32(0))
62 )
63
64 func (s *sweepClass) load() sweepClass {
65         return sweepClass(atomic.Load((*uint32)(s)))
66 }
67
68 func (s *sweepClass) update(sNew sweepClass) {
69         // Only update *s if its current value is less than sNew,
70         // since *s increases monotonically.
71         sOld := s.load()
72         for sOld < sNew && !atomic.Cas((*uint32)(s), uint32(sOld), uint32(sNew)) {
73                 sOld = s.load()
74         }
75         // TODO(mknyszek): This isn't the only place we have
76         // an atomic monotonically increasing counter. It would
77         // be nice to have an "atomic max" which is just implemented
78         // as the above on most architectures. Some architectures
79         // like RISC-V however have native support for an atomic max.
80 }
81
82 func (s *sweepClass) clear() {
83         atomic.Store((*uint32)(s), 0)
84 }
85
86 // split returns the underlying span class as well as
87 // whether we're interested in the full or partial
88 // unswept lists for that class, indicated as a boolean
89 // (true means "full").
90 func (s sweepClass) split() (spc spanClass, full bool) {
91         return spanClass(s >> 1), s&1 == 0
92 }
93
94 // nextSpanForSweep finds and pops the next span for sweeping from the
95 // central sweep buffers. It returns ownership of the span to the caller.
96 // Returns nil if no such span exists.
97 func (h *mheap) nextSpanForSweep() *mspan {
98         sg := h.sweepgen
99         for sc := sweep.centralIndex.load(); sc < numSweepClasses; sc++ {
100                 spc, full := sc.split()
101                 c := &h.central[spc].mcentral
102                 var s *mspan
103                 if full {
104                         s = c.fullUnswept(sg).pop()
105                 } else {
106                         s = c.partialUnswept(sg).pop()
107                 }
108                 if s != nil {
109                         // Write down that we found something so future sweepers
110                         // can start from here.
111                         sweep.centralIndex.update(sc)
112                         return s
113                 }
114         }
115         // Write down that we found nothing.
116         sweep.centralIndex.update(sweepClassDone)
117         return nil
118 }
119
120 const sweepDrainedMask = 1 << 31
121
122 // activeSweep is a type that captures whether sweeping
123 // is done, and whether there are any outstanding sweepers.
124 //
125 // Every potential sweeper must call begin() before they look
126 // for work, and end() after they've finished sweeping.
127 type activeSweep struct {
128         // state is divided into two parts.
129         //
130         // The top bit (masked by sweepDrainedMask) is a boolean
131         // value indicating whether all the sweep work has been
132         // drained from the queue.
133         //
134         // The rest of the bits are a counter, indicating the
135         // number of outstanding concurrent sweepers.
136         state atomic.Uint32
137 }
138
139 // begin registers a new sweeper. Returns a sweepLocker
140 // for acquiring spans for sweeping. Any outstanding sweeper blocks
141 // sweep termination.
142 //
143 // If the sweepLocker is invalid, the caller can be sure that all
144 // outstanding sweep work has been drained, so there is nothing left
145 // to sweep. Note that there may be sweepers currently running, so
146 // this does not indicate that all sweeping has completed.
147 //
148 // Even if the sweepLocker is invalid, its sweepGen is always valid.
149 func (a *activeSweep) begin() sweepLocker {
150         for {
151                 state := a.state.Load()
152                 if state&sweepDrainedMask != 0 {
153                         return sweepLocker{mheap_.sweepgen, false}
154                 }
155                 if a.state.CompareAndSwap(state, state+1) {
156                         return sweepLocker{mheap_.sweepgen, true}
157                 }
158         }
159 }
160
161 // end deregisters a sweeper. Must be called once for each time
162 // begin is called if the sweepLocker is valid.
163 func (a *activeSweep) end(sl sweepLocker) {
164         if sl.sweepGen != mheap_.sweepgen {
165                 throw("sweeper left outstanding across sweep generations")
166         }
167         for {
168                 state := a.state.Load()
169                 if (state&^sweepDrainedMask)-1 >= sweepDrainedMask {
170                         throw("mismatched begin/end of activeSweep")
171                 }
172                 if a.state.CompareAndSwap(state, state-1) {
173                         if state != sweepDrainedMask {
174                                 return
175                         }
176                         if debug.gcpacertrace > 0 {
177                                 live := gcController.heapLive.Load()
178                                 print("pacer: sweep done at heap size ", live>>20, "MB; allocated ", (live-mheap_.sweepHeapLiveBasis)>>20, "MB during sweep; swept ", mheap_.pagesSwept.Load(), " pages at ", mheap_.sweepPagesPerByte, " pages/byte\n")
179                         }
180                         return
181                 }
182         }
183 }
184
185 // markDrained marks the active sweep cycle as having drained
186 // all remaining work. This is safe to be called concurrently
187 // with all other methods of activeSweep, though may race.
188 //
189 // Returns true if this call was the one that actually performed
190 // the mark.
191 func (a *activeSweep) markDrained() bool {
192         for {
193                 state := a.state.Load()
194                 if state&sweepDrainedMask != 0 {
195                         return false
196                 }
197                 if a.state.CompareAndSwap(state, state|sweepDrainedMask) {
198                         return true
199                 }
200         }
201 }
202
203 // sweepers returns the current number of active sweepers.
204 func (a *activeSweep) sweepers() uint32 {
205         return a.state.Load() &^ sweepDrainedMask
206 }
207
208 // isDone returns true if all sweep work has been drained and no more
209 // outstanding sweepers exist. That is, when the sweep phase is
210 // completely done.
211 func (a *activeSweep) isDone() bool {
212         return a.state.Load() == sweepDrainedMask
213 }
214
215 // reset sets up the activeSweep for the next sweep cycle.
216 //
217 // The world must be stopped.
218 func (a *activeSweep) reset() {
219         assertWorldStopped()
220         a.state.Store(0)
221 }
222
223 // finishsweep_m ensures that all spans are swept.
224 //
225 // The world must be stopped. This ensures there are no sweeps in
226 // progress.
227 //
228 //go:nowritebarrier
229 func finishsweep_m() {
230         assertWorldStopped()
231
232         // Sweeping must be complete before marking commences, so
233         // sweep any unswept spans. If this is a concurrent GC, there
234         // shouldn't be any spans left to sweep, so this should finish
235         // instantly. If GC was forced before the concurrent sweep
236         // finished, there may be spans to sweep.
237         for sweepone() != ^uintptr(0) {
238         }
239
240         // Make sure there aren't any outstanding sweepers left.
241         // At this point, with the world stopped, it means one of two
242         // things. Either we were able to preempt a sweeper, or that
243         // a sweeper didn't call sweep.active.end when it should have.
244         // Both cases indicate a bug, so throw.
245         if sweep.active.sweepers() != 0 {
246                 throw("active sweepers found at start of mark phase")
247         }
248
249         // Reset all the unswept buffers, which should be empty.
250         // Do this in sweep termination as opposed to mark termination
251         // so that we can catch unswept spans and reclaim blocks as
252         // soon as possible.
253         sg := mheap_.sweepgen
254         for i := range mheap_.central {
255                 c := &mheap_.central[i].mcentral
256                 c.partialUnswept(sg).reset()
257                 c.fullUnswept(sg).reset()
258         }
259
260         // Sweeping is done, so there won't be any new memory to
261         // scavenge for a bit.
262         //
263         // If the scavenger isn't already awake, wake it up. There's
264         // definitely work for it to do at this point.
265         scavenger.wake()
266
267         nextMarkBitArenaEpoch()
268 }
269
270 func bgsweep(c chan int) {
271         sweep.g = getg()
272
273         lockInit(&sweep.lock, lockRankSweep)
274         lock(&sweep.lock)
275         sweep.parked = true
276         c <- 1
277         goparkunlock(&sweep.lock, waitReasonGCSweepWait, traceBlockGCSweep, 1)
278
279         for {
280                 // bgsweep attempts to be a "low priority" goroutine by intentionally
281                 // yielding time. It's OK if it doesn't run, because goroutines allocating
282                 // memory will sweep and ensure that all spans are swept before the next
283                 // GC cycle. We really only want to run when we're idle.
284                 //
285                 // However, calling Gosched after each span swept produces a tremendous
286                 // amount of tracing events, sometimes up to 50% of events in a trace. It's
287                 // also inefficient to call into the scheduler so much because sweeping a
288                 // single span is in general a very fast operation, taking as little as 30 ns
289                 // on modern hardware. (See #54767.)
290                 //
291                 // As a result, bgsweep sweeps in batches, and only calls into the scheduler
292                 // at the end of every batch. Furthermore, it only yields its time if there
293                 // isn't spare idle time available on other cores. If there's available idle
294                 // time, helping to sweep can reduce allocation latencies by getting ahead of
295                 // the proportional sweeper and having spans ready to go for allocation.
296                 const sweepBatchSize = 10
297                 nSwept := 0
298                 for sweepone() != ^uintptr(0) {
299                         nSwept++
300                         if nSwept%sweepBatchSize == 0 {
301                                 goschedIfBusy()
302                         }
303                 }
304                 for freeSomeWbufs(true) {
305                         // N.B. freeSomeWbufs is already batched internally.
306                         goschedIfBusy()
307                 }
308                 lock(&sweep.lock)
309                 if !isSweepDone() {
310                         // This can happen if a GC runs between
311                         // gosweepone returning ^0 above
312                         // and the lock being acquired.
313                         unlock(&sweep.lock)
314                         continue
315                 }
316                 sweep.parked = true
317                 goparkunlock(&sweep.lock, waitReasonGCSweepWait, traceBlockGCSweep, 1)
318         }
319 }
320
321 // sweepLocker acquires sweep ownership of spans.
322 type sweepLocker struct {
323         // sweepGen is the sweep generation of the heap.
324         sweepGen uint32
325         valid    bool
326 }
327
328 // sweepLocked represents sweep ownership of a span.
329 type sweepLocked struct {
330         *mspan
331 }
332
333 // tryAcquire attempts to acquire sweep ownership of span s. If it
334 // successfully acquires ownership, it blocks sweep completion.
335 func (l *sweepLocker) tryAcquire(s *mspan) (sweepLocked, bool) {
336         if !l.valid {
337                 throw("use of invalid sweepLocker")
338         }
339         // Check before attempting to CAS.
340         if atomic.Load(&s.sweepgen) != l.sweepGen-2 {
341                 return sweepLocked{}, false
342         }
343         // Attempt to acquire sweep ownership of s.
344         if !atomic.Cas(&s.sweepgen, l.sweepGen-2, l.sweepGen-1) {
345                 return sweepLocked{}, false
346         }
347         return sweepLocked{s}, true
348 }
349
350 // sweepone sweeps some unswept heap span and returns the number of pages returned
351 // to the heap, or ^uintptr(0) if there was nothing to sweep.
352 func sweepone() uintptr {
353         gp := getg()
354
355         // Increment locks to ensure that the goroutine is not preempted
356         // in the middle of sweep thus leaving the span in an inconsistent state for next GC
357         gp.m.locks++
358
359         // TODO(austin): sweepone is almost always called in a loop;
360         // lift the sweepLocker into its callers.
361         sl := sweep.active.begin()
362         if !sl.valid {
363                 gp.m.locks--
364                 return ^uintptr(0)
365         }
366
367         // Find a span to sweep.
368         npages := ^uintptr(0)
369         var noMoreWork bool
370         for {
371                 s := mheap_.nextSpanForSweep()
372                 if s == nil {
373                         noMoreWork = sweep.active.markDrained()
374                         break
375                 }
376                 if state := s.state.get(); state != mSpanInUse {
377                         // This can happen if direct sweeping already
378                         // swept this span, but in that case the sweep
379                         // generation should always be up-to-date.
380                         if !(s.sweepgen == sl.sweepGen || s.sweepgen == sl.sweepGen+3) {
381                                 print("runtime: bad span s.state=", state, " s.sweepgen=", s.sweepgen, " sweepgen=", sl.sweepGen, "\n")
382                                 throw("non in-use span in unswept list")
383                         }
384                         continue
385                 }
386                 if s, ok := sl.tryAcquire(s); ok {
387                         // Sweep the span we found.
388                         npages = s.npages
389                         if s.sweep(false) {
390                                 // Whole span was freed. Count it toward the
391                                 // page reclaimer credit since these pages can
392                                 // now be used for span allocation.
393                                 mheap_.reclaimCredit.Add(npages)
394                         } else {
395                                 // Span is still in-use, so this returned no
396                                 // pages to the heap and the span needs to
397                                 // move to the swept in-use list.
398                                 npages = 0
399                         }
400                         break
401                 }
402         }
403         sweep.active.end(sl)
404
405         if noMoreWork {
406                 // The sweep list is empty. There may still be
407                 // concurrent sweeps running, but we're at least very
408                 // close to done sweeping.
409
410                 // Move the scavenge gen forward (signaling
411                 // that there's new work to do) and wake the scavenger.
412                 //
413                 // The scavenger is signaled by the last sweeper because once
414                 // sweeping is done, we will definitely have useful work for
415                 // the scavenger to do, since the scavenger only runs over the
416                 // heap once per GC cycle. This update is not done during sweep
417                 // termination because in some cases there may be a long delay
418                 // between sweep done and sweep termination (e.g. not enough
419                 // allocations to trigger a GC) which would be nice to fill in
420                 // with scavenging work.
421                 if debug.scavtrace > 0 {
422                         systemstack(func() {
423                                 lock(&mheap_.lock)
424
425                                 // Get released stats.
426                                 releasedBg := mheap_.pages.scav.releasedBg.Load()
427                                 releasedEager := mheap_.pages.scav.releasedEager.Load()
428
429                                 // Print the line.
430                                 printScavTrace(releasedBg, releasedEager, false)
431
432                                 // Update the stats.
433                                 mheap_.pages.scav.releasedBg.Add(-releasedBg)
434                                 mheap_.pages.scav.releasedEager.Add(-releasedEager)
435                                 unlock(&mheap_.lock)
436                         })
437                 }
438                 scavenger.ready()
439         }
440
441         gp.m.locks--
442         return npages
443 }
444
445 // isSweepDone reports whether all spans are swept.
446 //
447 // Note that this condition may transition from false to true at any
448 // time as the sweeper runs. It may transition from true to false if a
449 // GC runs; to prevent that the caller must be non-preemptible or must
450 // somehow block GC progress.
451 func isSweepDone() bool {
452         return sweep.active.isDone()
453 }
454
455 // Returns only when span s has been swept.
456 //
457 //go:nowritebarrier
458 func (s *mspan) ensureSwept() {
459         // Caller must disable preemption.
460         // Otherwise when this function returns the span can become unswept again
461         // (if GC is triggered on another goroutine).
462         gp := getg()
463         if gp.m.locks == 0 && gp.m.mallocing == 0 && gp != gp.m.g0 {
464                 throw("mspan.ensureSwept: m is not locked")
465         }
466
467         // If this operation fails, then that means that there are
468         // no more spans to be swept. In this case, either s has already
469         // been swept, or is about to be acquired for sweeping and swept.
470         sl := sweep.active.begin()
471         if sl.valid {
472                 // The caller must be sure that the span is a mSpanInUse span.
473                 if s, ok := sl.tryAcquire(s); ok {
474                         s.sweep(false)
475                         sweep.active.end(sl)
476                         return
477                 }
478                 sweep.active.end(sl)
479         }
480
481         // Unfortunately we can't sweep the span ourselves. Somebody else
482         // got to it first. We don't have efficient means to wait, but that's
483         // OK, it will be swept fairly soon.
484         for {
485                 spangen := atomic.Load(&s.sweepgen)
486                 if spangen == sl.sweepGen || spangen == sl.sweepGen+3 {
487                         break
488                 }
489                 osyield()
490         }
491 }
492
493 // sweep frees or collects finalizers for blocks not marked in the mark phase.
494 // It clears the mark bits in preparation for the next GC round.
495 // Returns true if the span was returned to heap.
496 // If preserve=true, don't return it to heap nor relink in mcentral lists;
497 // caller takes care of it.
498 func (sl *sweepLocked) sweep(preserve bool) bool {
499         // It's critical that we enter this function with preemption disabled,
500         // GC must not start while we are in the middle of this function.
501         gp := getg()
502         if gp.m.locks == 0 && gp.m.mallocing == 0 && gp != gp.m.g0 {
503                 throw("mspan.sweep: m is not locked")
504         }
505
506         s := sl.mspan
507         if !preserve {
508                 // We'll release ownership of this span. Nil it out to
509                 // prevent the caller from accidentally using it.
510                 sl.mspan = nil
511         }
512
513         sweepgen := mheap_.sweepgen
514         if state := s.state.get(); state != mSpanInUse || s.sweepgen != sweepgen-1 {
515                 print("mspan.sweep: state=", state, " sweepgen=", s.sweepgen, " mheap.sweepgen=", sweepgen, "\n")
516                 throw("mspan.sweep: bad span state")
517         }
518
519         trace := traceAcquire()
520         if trace.ok() {
521                 trace.GCSweepSpan(s.npages * _PageSize)
522                 traceRelease(trace)
523         }
524
525         mheap_.pagesSwept.Add(int64(s.npages))
526
527         spc := s.spanclass
528         size := s.elemsize
529
530         // The allocBits indicate which unmarked objects don't need to be
531         // processed since they were free at the end of the last GC cycle
532         // and were not allocated since then.
533         // If the allocBits index is >= s.freeindex and the bit
534         // is not marked then the object remains unallocated
535         // since the last GC.
536         // This situation is analogous to being on a freelist.
537
538         // Unlink & free special records for any objects we're about to free.
539         // Two complications here:
540         // 1. An object can have both finalizer and profile special records.
541         //    In such case we need to queue finalizer for execution,
542         //    mark the object as live and preserve the profile special.
543         // 2. A tiny object can have several finalizers setup for different offsets.
544         //    If such object is not marked, we need to queue all finalizers at once.
545         // Both 1 and 2 are possible at the same time.
546         hadSpecials := s.specials != nil
547         siter := newSpecialsIter(s)
548         for siter.valid() {
549                 // A finalizer can be set for an inner byte of an object, find object beginning.
550                 objIndex := uintptr(siter.s.offset) / size
551                 p := s.base() + objIndex*size
552                 mbits := s.markBitsForIndex(objIndex)
553                 if !mbits.isMarked() {
554                         // This object is not marked and has at least one special record.
555                         // Pass 1: see if it has at least one finalizer.
556                         hasFin := false
557                         endOffset := p - s.base() + size
558                         for tmp := siter.s; tmp != nil && uintptr(tmp.offset) < endOffset; tmp = tmp.next {
559                                 if tmp.kind == _KindSpecialFinalizer {
560                                         // Stop freeing of object if it has a finalizer.
561                                         mbits.setMarkedNonAtomic()
562                                         hasFin = true
563                                         break
564                                 }
565                         }
566                         // Pass 2: queue all finalizers _or_ handle profile record.
567                         for siter.valid() && uintptr(siter.s.offset) < endOffset {
568                                 // Find the exact byte for which the special was setup
569                                 // (as opposed to object beginning).
570                                 special := siter.s
571                                 p := s.base() + uintptr(special.offset)
572                                 if special.kind == _KindSpecialFinalizer || !hasFin {
573                                         siter.unlinkAndNext()
574                                         freeSpecial(special, unsafe.Pointer(p), size)
575                                 } else {
576                                         // The object has finalizers, so we're keeping it alive.
577                                         // All other specials only apply when an object is freed,
578                                         // so just keep the special record.
579                                         siter.next()
580                                 }
581                         }
582                 } else {
583                         // object is still live
584                         if siter.s.kind == _KindSpecialReachable {
585                                 special := siter.unlinkAndNext()
586                                 (*specialReachable)(unsafe.Pointer(special)).reachable = true
587                                 freeSpecial(special, unsafe.Pointer(p), size)
588                         } else {
589                                 // keep special record
590                                 siter.next()
591                         }
592                 }
593         }
594         if hadSpecials && s.specials == nil {
595                 spanHasNoSpecials(s)
596         }
597
598         if debug.allocfreetrace != 0 || debug.clobberfree != 0 || raceenabled || msanenabled || asanenabled {
599                 // Find all newly freed objects. This doesn't have to
600                 // efficient; allocfreetrace has massive overhead.
601                 mbits := s.markBitsForBase()
602                 abits := s.allocBitsForIndex(0)
603                 for i := uintptr(0); i < uintptr(s.nelems); i++ {
604                         if !mbits.isMarked() && (abits.index < uintptr(s.freeindex) || abits.isMarked()) {
605                                 x := s.base() + i*s.elemsize
606                                 if debug.allocfreetrace != 0 {
607                                         tracefree(unsafe.Pointer(x), size)
608                                 }
609                                 if debug.clobberfree != 0 {
610                                         clobberfree(unsafe.Pointer(x), size)
611                                 }
612                                 // User arenas are handled on explicit free.
613                                 if raceenabled && !s.isUserArenaChunk {
614                                         racefree(unsafe.Pointer(x), size)
615                                 }
616                                 if msanenabled && !s.isUserArenaChunk {
617                                         msanfree(unsafe.Pointer(x), size)
618                                 }
619                                 if asanenabled && !s.isUserArenaChunk {
620                                         asanpoison(unsafe.Pointer(x), size)
621                                 }
622                         }
623                         mbits.advance()
624                         abits.advance()
625                 }
626         }
627
628         // Check for zombie objects.
629         if s.freeindex < s.nelems {
630                 // Everything < freeindex is allocated and hence
631                 // cannot be zombies.
632                 //
633                 // Check the first bitmap byte, where we have to be
634                 // careful with freeindex.
635                 obj := uintptr(s.freeindex)
636                 if (*s.gcmarkBits.bytep(obj / 8)&^*s.allocBits.bytep(obj / 8))>>(obj%8) != 0 {
637                         s.reportZombies()
638                 }
639                 // Check remaining bytes.
640                 for i := obj/8 + 1; i < divRoundUp(uintptr(s.nelems), 8); i++ {
641                         if *s.gcmarkBits.bytep(i)&^*s.allocBits.bytep(i) != 0 {
642                                 s.reportZombies()
643                         }
644                 }
645         }
646
647         // Count the number of free objects in this span.
648         nalloc := uint16(s.countAlloc())
649         nfreed := s.allocCount - nalloc
650         if nalloc > s.allocCount {
651                 // The zombie check above should have caught this in
652                 // more detail.
653                 print("runtime: nelems=", s.nelems, " nalloc=", nalloc, " previous allocCount=", s.allocCount, " nfreed=", nfreed, "\n")
654                 throw("sweep increased allocation count")
655         }
656
657         s.allocCount = nalloc
658         s.freeindex = 0 // reset allocation index to start of span.
659         s.freeIndexForScan = 0
660         if traceEnabled() {
661                 getg().m.p.ptr().trace.reclaimed += uintptr(nfreed) * s.elemsize
662         }
663
664         // gcmarkBits becomes the allocBits.
665         // get a fresh cleared gcmarkBits in preparation for next GC
666         s.allocBits = s.gcmarkBits
667         s.gcmarkBits = newMarkBits(uintptr(s.nelems))
668
669         // refresh pinnerBits if they exists
670         if s.pinnerBits != nil {
671                 s.refreshPinnerBits()
672         }
673
674         // Initialize alloc bits cache.
675         s.refillAllocCache(0)
676
677         // The span must be in our exclusive ownership until we update sweepgen,
678         // check for potential races.
679         if state := s.state.get(); state != mSpanInUse || s.sweepgen != sweepgen-1 {
680                 print("mspan.sweep: state=", state, " sweepgen=", s.sweepgen, " mheap.sweepgen=", sweepgen, "\n")
681                 throw("mspan.sweep: bad span state after sweep")
682         }
683         if s.sweepgen == sweepgen+1 || s.sweepgen == sweepgen+3 {
684                 throw("swept cached span")
685         }
686
687         // We need to set s.sweepgen = h.sweepgen only when all blocks are swept,
688         // because of the potential for a concurrent free/SetFinalizer.
689         //
690         // But we need to set it before we make the span available for allocation
691         // (return it to heap or mcentral), because allocation code assumes that a
692         // span is already swept if available for allocation.
693         //
694         // Serialization point.
695         // At this point the mark bits are cleared and allocation ready
696         // to go so release the span.
697         atomic.Store(&s.sweepgen, sweepgen)
698
699         if s.isUserArenaChunk {
700                 if preserve {
701                         // This is a case that should never be handled by a sweeper that
702                         // preserves the span for reuse.
703                         throw("sweep: tried to preserve a user arena span")
704                 }
705                 if nalloc > 0 {
706                         // There still exist pointers into the span or the span hasn't been
707                         // freed yet. It's not ready to be reused. Put it back on the
708                         // full swept list for the next cycle.
709                         mheap_.central[spc].mcentral.fullSwept(sweepgen).push(s)
710                         return false
711                 }
712
713                 // It's only at this point that the sweeper doesn't actually need to look
714                 // at this arena anymore, so subtract from pagesInUse now.
715                 mheap_.pagesInUse.Add(-s.npages)
716                 s.state.set(mSpanDead)
717
718                 // The arena is ready to be recycled. Remove it from the quarantine list
719                 // and place it on the ready list. Don't add it back to any sweep lists.
720                 systemstack(func() {
721                         // It's the arena code's responsibility to get the chunk on the quarantine
722                         // list by the time all references to the chunk are gone.
723                         if s.list != &mheap_.userArena.quarantineList {
724                                 throw("user arena span is on the wrong list")
725                         }
726                         lock(&mheap_.lock)
727                         mheap_.userArena.quarantineList.remove(s)
728                         mheap_.userArena.readyList.insert(s)
729                         unlock(&mheap_.lock)
730                 })
731                 return false
732         }
733
734         if spc.sizeclass() != 0 {
735                 // Handle spans for small objects.
736                 if nfreed > 0 {
737                         // Only mark the span as needing zeroing if we've freed any
738                         // objects, because a fresh span that had been allocated into,
739                         // wasn't totally filled, but then swept, still has all of its
740                         // free slots zeroed.
741                         s.needzero = 1
742                         stats := memstats.heapStats.acquire()
743                         atomic.Xadd64(&stats.smallFreeCount[spc.sizeclass()], int64(nfreed))
744                         memstats.heapStats.release()
745
746                         // Count the frees in the inconsistent, internal stats.
747                         gcController.totalFree.Add(int64(nfreed) * int64(s.elemsize))
748                 }
749                 if !preserve {
750                         // The caller may not have removed this span from whatever
751                         // unswept set its on but taken ownership of the span for
752                         // sweeping by updating sweepgen. If this span still is in
753                         // an unswept set, then the mcentral will pop it off the
754                         // set, check its sweepgen, and ignore it.
755                         if nalloc == 0 {
756                                 // Free totally free span directly back to the heap.
757                                 mheap_.freeSpan(s)
758                                 return true
759                         }
760                         // Return span back to the right mcentral list.
761                         if nalloc == s.nelems {
762                                 mheap_.central[spc].mcentral.fullSwept(sweepgen).push(s)
763                         } else {
764                                 mheap_.central[spc].mcentral.partialSwept(sweepgen).push(s)
765                         }
766                 }
767         } else if !preserve {
768                 // Handle spans for large objects.
769                 if nfreed != 0 {
770                         // Free large object span to heap.
771
772                         // NOTE(rsc,dvyukov): The original implementation of efence
773                         // in CL 22060046 used sysFree instead of sysFault, so that
774                         // the operating system would eventually give the memory
775                         // back to us again, so that an efence program could run
776                         // longer without running out of memory. Unfortunately,
777                         // calling sysFree here without any kind of adjustment of the
778                         // heap data structures means that when the memory does
779                         // come back to us, we have the wrong metadata for it, either in
780                         // the mspan structures or in the garbage collection bitmap.
781                         // Using sysFault here means that the program will run out of
782                         // memory fairly quickly in efence mode, but at least it won't
783                         // have mysterious crashes due to confused memory reuse.
784                         // It should be possible to switch back to sysFree if we also
785                         // implement and then call some kind of mheap.deleteSpan.
786                         if debug.efence > 0 {
787                                 s.limit = 0 // prevent mlookup from finding this span
788                                 sysFault(unsafe.Pointer(s.base()), size)
789                         } else {
790                                 mheap_.freeSpan(s)
791                         }
792                         if goexperiment.AllocHeaders && s.largeType != nil && s.largeType.Kind_&kindGCProg != 0 {
793                                 // In the allocheaders experiment, the unrolled GCProg bitmap is allocated separately.
794                                 // Free the space for the unrolled bitmap.
795                                 systemstack(func() {
796                                         s := spanOf(uintptr(unsafe.Pointer(s.largeType)))
797                                         mheap_.freeManual(s, spanAllocPtrScalarBits)
798                                 })
799                                 s.largeType = nil
800                         }
801
802                         // Count the free in the consistent, external stats.
803                         stats := memstats.heapStats.acquire()
804                         atomic.Xadd64(&stats.largeFreeCount, 1)
805                         atomic.Xadd64(&stats.largeFree, int64(size))
806                         memstats.heapStats.release()
807
808                         // Count the free in the inconsistent, internal stats.
809                         gcController.totalFree.Add(int64(size))
810
811                         return true
812                 }
813
814                 // Add a large span directly onto the full+swept list.
815                 mheap_.central[spc].mcentral.fullSwept(sweepgen).push(s)
816         }
817         return false
818 }
819
820 // reportZombies reports any marked but free objects in s and throws.
821 //
822 // This generally means one of the following:
823 //
824 // 1. User code converted a pointer to a uintptr and then back
825 // unsafely, and a GC ran while the uintptr was the only reference to
826 // an object.
827 //
828 // 2. User code (or a compiler bug) constructed a bad pointer that
829 // points to a free slot, often a past-the-end pointer.
830 //
831 // 3. The GC two cycles ago missed a pointer and freed a live object,
832 // but it was still live in the last cycle, so this GC cycle found a
833 // pointer to that object and marked it.
834 func (s *mspan) reportZombies() {
835         printlock()
836         print("runtime: marked free object in span ", s, ", elemsize=", s.elemsize, " freeindex=", s.freeindex, " (bad use of unsafe.Pointer? try -d=checkptr)\n")
837         mbits := s.markBitsForBase()
838         abits := s.allocBitsForIndex(0)
839         for i := uintptr(0); i < uintptr(s.nelems); i++ {
840                 addr := s.base() + i*s.elemsize
841                 print(hex(addr))
842                 alloc := i < uintptr(s.freeindex) || abits.isMarked()
843                 if alloc {
844                         print(" alloc")
845                 } else {
846                         print(" free ")
847                 }
848                 if mbits.isMarked() {
849                         print(" marked  ")
850                 } else {
851                         print(" unmarked")
852                 }
853                 zombie := mbits.isMarked() && !alloc
854                 if zombie {
855                         print(" zombie")
856                 }
857                 print("\n")
858                 if zombie {
859                         length := s.elemsize
860                         if length > 1024 {
861                                 length = 1024
862                         }
863                         hexdumpWords(addr, addr+length, nil)
864                 }
865                 mbits.advance()
866                 abits.advance()
867         }
868         throw("found pointer to free object")
869 }
870
871 // deductSweepCredit deducts sweep credit for allocating a span of
872 // size spanBytes. This must be performed *before* the span is
873 // allocated to ensure the system has enough credit. If necessary, it
874 // performs sweeping to prevent going in to debt. If the caller will
875 // also sweep pages (e.g., for a large allocation), it can pass a
876 // non-zero callerSweepPages to leave that many pages unswept.
877 //
878 // deductSweepCredit makes a worst-case assumption that all spanBytes
879 // bytes of the ultimately allocated span will be available for object
880 // allocation.
881 //
882 // deductSweepCredit is the core of the "proportional sweep" system.
883 // It uses statistics gathered by the garbage collector to perform
884 // enough sweeping so that all pages are swept during the concurrent
885 // sweep phase between GC cycles.
886 //
887 // mheap_ must NOT be locked.
888 func deductSweepCredit(spanBytes uintptr, callerSweepPages uintptr) {
889         if mheap_.sweepPagesPerByte == 0 {
890                 // Proportional sweep is done or disabled.
891                 return
892         }
893
894         trace := traceAcquire()
895         if trace.ok() {
896                 trace.GCSweepStart()
897                 traceRelease(trace)
898         }
899
900         // Fix debt if necessary.
901 retry:
902         sweptBasis := mheap_.pagesSweptBasis.Load()
903         live := gcController.heapLive.Load()
904         liveBasis := mheap_.sweepHeapLiveBasis
905         newHeapLive := spanBytes
906         if liveBasis < live {
907                 // Only do this subtraction when we don't overflow. Otherwise, pagesTarget
908                 // might be computed as something really huge, causing us to get stuck
909                 // sweeping here until the next mark phase.
910                 //
911                 // Overflow can happen here if gcPaceSweeper is called concurrently with
912                 // sweeping (i.e. not during a STW, like it usually is) because this code
913                 // is intentionally racy. A concurrent call to gcPaceSweeper can happen
914                 // if a GC tuning parameter is modified and we read an older value of
915                 // heapLive than what was used to set the basis.
916                 //
917                 // This state should be transient, so it's fine to just let newHeapLive
918                 // be a relatively small number. We'll probably just skip this attempt to
919                 // sweep.
920                 //
921                 // See issue #57523.
922                 newHeapLive += uintptr(live - liveBasis)
923         }
924         pagesTarget := int64(mheap_.sweepPagesPerByte*float64(newHeapLive)) - int64(callerSweepPages)
925         for pagesTarget > int64(mheap_.pagesSwept.Load()-sweptBasis) {
926                 if sweepone() == ^uintptr(0) {
927                         mheap_.sweepPagesPerByte = 0
928                         break
929                 }
930                 if mheap_.pagesSweptBasis.Load() != sweptBasis {
931                         // Sweep pacing changed. Recompute debt.
932                         goto retry
933                 }
934         }
935
936         trace = traceAcquire()
937         if trace.ok() {
938                 trace.GCSweepDone()
939                 traceRelease(trace)
940         }
941 }
942
943 // clobberfree sets the memory content at x to bad content, for debugging
944 // purposes.
945 func clobberfree(x unsafe.Pointer, size uintptr) {
946         // size (span.elemsize) is always a multiple of 4.
947         for i := uintptr(0); i < size; i += 4 {
948                 *(*uint32)(add(x, i)) = 0xdeadbeef
949         }
950 }
951
952 // gcPaceSweeper updates the sweeper's pacing parameters.
953 //
954 // Must be called whenever the GC's pacing is updated.
955 //
956 // The world must be stopped, or mheap_.lock must be held.
957 func gcPaceSweeper(trigger uint64) {
958         assertWorldStoppedOrLockHeld(&mheap_.lock)
959
960         // Update sweep pacing.
961         if isSweepDone() {
962                 mheap_.sweepPagesPerByte = 0
963         } else {
964                 // Concurrent sweep needs to sweep all of the in-use
965                 // pages by the time the allocated heap reaches the GC
966                 // trigger. Compute the ratio of in-use pages to sweep
967                 // per byte allocated, accounting for the fact that
968                 // some might already be swept.
969                 heapLiveBasis := gcController.heapLive.Load()
970                 heapDistance := int64(trigger) - int64(heapLiveBasis)
971                 // Add a little margin so rounding errors and
972                 // concurrent sweep are less likely to leave pages
973                 // unswept when GC starts.
974                 heapDistance -= 1024 * 1024
975                 if heapDistance < _PageSize {
976                         // Avoid setting the sweep ratio extremely high
977                         heapDistance = _PageSize
978                 }
979                 pagesSwept := mheap_.pagesSwept.Load()
980                 pagesInUse := mheap_.pagesInUse.Load()
981                 sweepDistancePages := int64(pagesInUse) - int64(pagesSwept)
982                 if sweepDistancePages <= 0 {
983                         mheap_.sweepPagesPerByte = 0
984                 } else {
985                         mheap_.sweepPagesPerByte = float64(sweepDistancePages) / float64(heapDistance)
986                         mheap_.sweepHeapLiveBasis = heapLiveBasis
987                         // Write pagesSweptBasis last, since this
988                         // signals concurrent sweeps to recompute
989                         // their debt.
990                         mheap_.pagesSweptBasis.Store(pagesSwept)
991                 }
992         }
993 }