Source File
mgcsweep.go
Belonging Package
runtime
// Copyright 2009 The Go Authors. All rights reserved.
// Use of this source code is governed by a BSD-style
// license that can be found in the LICENSE file.
// Garbage collector: sweeping
// The sweeper consists of two different algorithms:
//
// * The object reclaimer finds and frees unmarked slots in spans. It
// can free a whole span if none of the objects are marked, but that
// isn't its goal. This can be driven either synchronously by
// mcentral.cacheSpan for mcentral spans, or asynchronously by
// sweepone, which looks at all the mcentral lists.
//
// * The span reclaimer looks for spans that contain no marked objects
// and frees whole spans. This is a separate algorithm because
// freeing whole spans is the hardest task for the object reclaimer,
// but is critical when allocating new spans. The entry point for
// this is mheap_.reclaim and it's driven by a sequential scan of
// the page marks bitmap in the heap arenas.
//
// Both algorithms ultimately call mspan.sweep, which sweeps a single
// heap span.
package runtime
import (
)
var sweep sweepdata
// State of background sweep.
type sweepdata struct {
lock mutex
g *g
parked bool
nbgsweep uint32
npausesweep uint32
// active tracks outstanding sweepers and the sweep
// termination condition.
active activeSweep
// centralIndex is the current unswept span class.
// It represents an index into the mcentral span
// sets. Accessed and updated via its load and
// update methods. Not protected by a lock.
//
// Reset at mark termination.
// Used by mheap.nextSpanForSweep.
centralIndex sweepClass
}
// sweepClass is a spanClass and one bit to represent whether we're currently
// sweeping partial or full spans.
type sweepClass uint32
const (
numSweepClasses = numSpanClasses * 2
sweepClassDone sweepClass = sweepClass(^uint32(0))
)
func ( *sweepClass) () sweepClass {
return sweepClass(atomic.Load((*uint32)()))
}
func ( *sweepClass) ( sweepClass) {
// Only update *s if its current value is less than sNew,
// since *s increases monotonically.
:= .load()
for < && !atomic.Cas((*uint32)(), uint32(), uint32()) {
= .load()
}
// TODO(mknyszek): This isn't the only place we have
// an atomic monotonically increasing counter. It would
// be nice to have an "atomic max" which is just implemented
// as the above on most architectures. Some architectures
// like RISC-V however have native support for an atomic max.
}
func ( *sweepClass) () {
atomic.Store((*uint32)(), 0)
}
// split returns the underlying span class as well as
// whether we're interested in the full or partial
// unswept lists for that class, indicated as a boolean
// (true means "full").
func ( sweepClass) () ( spanClass, bool) {
return spanClass( >> 1), &1 == 0
}
// nextSpanForSweep finds and pops the next span for sweeping from the
// central sweep buffers. It returns ownership of the span to the caller.
// Returns nil if no such span exists.
func ( *mheap) () *mspan {
:= .sweepgen
for := sweep.centralIndex.load(); < numSweepClasses; ++ {
, := .split()
:= &.central[].mcentral
var *mspan
if {
= .fullUnswept().pop()
} else {
= .partialUnswept().pop()
}
if != nil {
// Write down that we found something so future sweepers
// can start from here.
sweep.centralIndex.update()
return
}
}
// Write down that we found nothing.
sweep.centralIndex.update(sweepClassDone)
return nil
}
const sweepDrainedMask = 1 << 31
// activeSweep is a type that captures whether sweeping
// is done, and whether there are any outstanding sweepers.
//
// Every potential sweeper must call begin() before they look
// for work, and end() after they've finished sweeping.
type activeSweep struct {
// state is divided into two parts.
//
// The top bit (masked by sweepDrainedMask) is a boolean
// value indicating whether all the sweep work has been
// drained from the queue.
//
// The rest of the bits are a counter, indicating the
// number of outstanding concurrent sweepers.
state atomic.Uint32
}
// begin registers a new sweeper. Returns a sweepLocker
// for acquiring spans for sweeping. Any outstanding sweeper blocks
// sweep termination.
//
// If the sweepLocker is invalid, the caller can be sure that all
// outstanding sweep work has been drained, so there is nothing left
// to sweep. Note that there may be sweepers currently running, so
// this does not indicate that all sweeping has completed.
//
// Even if the sweepLocker is invalid, its sweepGen is always valid.
func ( *activeSweep) () sweepLocker {
for {
:= .state.Load()
if &sweepDrainedMask != 0 {
return sweepLocker{mheap_.sweepgen, false}
}
if .state.CompareAndSwap(, +1) {
return sweepLocker{mheap_.sweepgen, true}
}
}
}
// end deregisters a sweeper. Must be called once for each time
// begin is called if the sweepLocker is valid.
func ( *activeSweep) ( sweepLocker) {
if .sweepGen != mheap_.sweepgen {
throw("sweeper left outstanding across sweep generations")
}
for {
:= .state.Load()
if (&^sweepDrainedMask)-1 >= sweepDrainedMask {
throw("mismatched begin/end of activeSweep")
}
if .state.CompareAndSwap(, -1) {
if != sweepDrainedMask {
return
}
if debug.gcpacertrace > 0 {
:= gcController.heapLive.Load()
print("pacer: sweep done at heap size ", >>20, "MB; allocated ", (-mheap_.sweepHeapLiveBasis)>>20, "MB during sweep; swept ", mheap_.pagesSwept.Load(), " pages at ", mheap_.sweepPagesPerByte, " pages/byte\n")
}
return
}
}
}
// markDrained marks the active sweep cycle as having drained
// all remaining work. This is safe to be called concurrently
// with all other methods of activeSweep, though may race.
//
// Returns true if this call was the one that actually performed
// the mark.
func ( *activeSweep) () bool {
for {
:= .state.Load()
if &sweepDrainedMask != 0 {
return false
}
if .state.CompareAndSwap(, |sweepDrainedMask) {
return true
}
}
}
// sweepers returns the current number of active sweepers.
func ( *activeSweep) () uint32 {
return .state.Load() &^ sweepDrainedMask
}
// isDone returns true if all sweep work has been drained and no more
// outstanding sweepers exist. That is, when the sweep phase is
// completely done.
func ( *activeSweep) () bool {
return .state.Load() == sweepDrainedMask
}
// reset sets up the activeSweep for the next sweep cycle.
//
// The world must be stopped.
func ( *activeSweep) () {
assertWorldStopped()
.state.Store(0)
}
// finishsweep_m ensures that all spans are swept.
//
// The world must be stopped. This ensures there are no sweeps in
// progress.
//
//go:nowritebarrier
func () {
assertWorldStopped()
// Sweeping must be complete before marking commences, so
// sweep any unswept spans. If this is a concurrent GC, there
// shouldn't be any spans left to sweep, so this should finish
// instantly. If GC was forced before the concurrent sweep
// finished, there may be spans to sweep.
for sweepone() != ^uintptr(0) {
sweep.npausesweep++
}
// Make sure there aren't any outstanding sweepers left.
// At this point, with the world stopped, it means one of two
// things. Either we were able to preempt a sweeper, or that
// a sweeper didn't call sweep.active.end when it should have.
// Both cases indicate a bug, so throw.
if sweep.active.sweepers() != 0 {
throw("active sweepers found at start of mark phase")
}
// Reset all the unswept buffers, which should be empty.
// Do this in sweep termination as opposed to mark termination
// so that we can catch unswept spans and reclaim blocks as
// soon as possible.
:= mheap_.sweepgen
for := range mheap_.central {
:= &mheap_.central[].mcentral
.partialUnswept().reset()
.fullUnswept().reset()
}
// Sweeping is done, so there won't be any new memory to
// scavenge for a bit.
//
// If the scavenger isn't already awake, wake it up. There's
// definitely work for it to do at this point.
scavenger.wake()
nextMarkBitArenaEpoch()
}
func ( chan int) {
sweep.g = getg()
lockInit(&sweep.lock, lockRankSweep)
lock(&sweep.lock)
sweep.parked = true
<- 1
goparkunlock(&sweep.lock, waitReasonGCSweepWait, traceBlockGCSweep, 1)
for {
// bgsweep attempts to be a "low priority" goroutine by intentionally
// yielding time. It's OK if it doesn't run, because goroutines allocating
// memory will sweep and ensure that all spans are swept before the next
// GC cycle. We really only want to run when we're idle.
//
// However, calling Gosched after each span swept produces a tremendous
// amount of tracing events, sometimes up to 50% of events in a trace. It's
// also inefficient to call into the scheduler so much because sweeping a
// single span is in general a very fast operation, taking as little as 30 ns
// on modern hardware. (See #54767.)
//
// As a result, bgsweep sweeps in batches, and only calls into the scheduler
// at the end of every batch. Furthermore, it only yields its time if there
// isn't spare idle time available on other cores. If there's available idle
// time, helping to sweep can reduce allocation latencies by getting ahead of
// the proportional sweeper and having spans ready to go for allocation.
const = 10
:= 0
for sweepone() != ^uintptr(0) {
sweep.nbgsweep++
++
if % == 0 {
goschedIfBusy()
}
}
for freeSomeWbufs(true) {
// N.B. freeSomeWbufs is already batched internally.
goschedIfBusy()
}
lock(&sweep.lock)
if !isSweepDone() {
// This can happen if a GC runs between
// gosweepone returning ^0 above
// and the lock being acquired.
unlock(&sweep.lock)
continue
}
sweep.parked = true
goparkunlock(&sweep.lock, waitReasonGCSweepWait, traceBlockGCSweep, 1)
}
}
// sweepLocker acquires sweep ownership of spans.
type sweepLocker struct {
// sweepGen is the sweep generation of the heap.
sweepGen uint32
valid bool
}
// sweepLocked represents sweep ownership of a span.
type sweepLocked struct {
*mspan
}
// tryAcquire attempts to acquire sweep ownership of span s. If it
// successfully acquires ownership, it blocks sweep completion.
func ( *sweepLocker) ( *mspan) (sweepLocked, bool) {
if !.valid {
throw("use of invalid sweepLocker")
}
// Check before attempting to CAS.
if atomic.Load(&.sweepgen) != .sweepGen-2 {
return sweepLocked{}, false
}
// Attempt to acquire sweep ownership of s.
if !atomic.Cas(&.sweepgen, .sweepGen-2, .sweepGen-1) {
return sweepLocked{}, false
}
return sweepLocked{}, true
}
// sweepone sweeps some unswept heap span and returns the number of pages returned
// to the heap, or ^uintptr(0) if there was nothing to sweep.
func () uintptr {
:= getg()
// Increment locks to ensure that the goroutine is not preempted
// in the middle of sweep thus leaving the span in an inconsistent state for next GC
.m.locks++
// TODO(austin): sweepone is almost always called in a loop;
// lift the sweepLocker into its callers.
:= sweep.active.begin()
if !.valid {
.m.locks--
return ^uintptr(0)
}
// Find a span to sweep.
:= ^uintptr(0)
var bool
for {
:= mheap_.nextSpanForSweep()
if == nil {
= sweep.active.markDrained()
break
}
if := .state.get(); != mSpanInUse {
// This can happen if direct sweeping already
// swept this span, but in that case the sweep
// generation should always be up-to-date.
if !(.sweepgen == .sweepGen || .sweepgen == .sweepGen+3) {
print("runtime: bad span s.state=", , " s.sweepgen=", .sweepgen, " sweepgen=", .sweepGen, "\n")
throw("non in-use span in unswept list")
}
continue
}
if , := .tryAcquire(); {
// Sweep the span we found.
= .npages
if .sweep(false) {
// Whole span was freed. Count it toward the
// page reclaimer credit since these pages can
// now be used for span allocation.
mheap_.reclaimCredit.Add()
} else {
// Span is still in-use, so this returned no
// pages to the heap and the span needs to
// move to the swept in-use list.
= 0
}
break
}
}
sweep.active.end()
if {
// The sweep list is empty. There may still be
// concurrent sweeps running, but we're at least very
// close to done sweeping.
// Move the scavenge gen forward (signaling
// that there's new work to do) and wake the scavenger.
//
// The scavenger is signaled by the last sweeper because once
// sweeping is done, we will definitely have useful work for
// the scavenger to do, since the scavenger only runs over the
// heap once per GC cycle. This update is not done during sweep
// termination because in some cases there may be a long delay
// between sweep done and sweep termination (e.g. not enough
// allocations to trigger a GC) which would be nice to fill in
// with scavenging work.
if debug.scavtrace > 0 {
systemstack(func() {
lock(&mheap_.lock)
// Get released stats.
:= mheap_.pages.scav.releasedBg.Load()
:= mheap_.pages.scav.releasedEager.Load()
// Print the line.
printScavTrace(, , false)
// Update the stats.
mheap_.pages.scav.releasedBg.Add(-)
mheap_.pages.scav.releasedEager.Add(-)
unlock(&mheap_.lock)
})
}
scavenger.ready()
}
.m.locks--
return
}
// isSweepDone reports whether all spans are swept.
//
// Note that this condition may transition from false to true at any
// time as the sweeper runs. It may transition from true to false if a
// GC runs; to prevent that the caller must be non-preemptible or must
// somehow block GC progress.
func () bool {
return sweep.active.isDone()
}
// Returns only when span s has been swept.
//
//go:nowritebarrier
func ( *mspan) () {
// Caller must disable preemption.
// Otherwise when this function returns the span can become unswept again
// (if GC is triggered on another goroutine).
:= getg()
if .m.locks == 0 && .m.mallocing == 0 && != .m.g0 {
throw("mspan.ensureSwept: m is not locked")
}
// If this operation fails, then that means that there are
// no more spans to be swept. In this case, either s has already
// been swept, or is about to be acquired for sweeping and swept.
:= sweep.active.begin()
if .valid {
// The caller must be sure that the span is a mSpanInUse span.
if , := .tryAcquire(); {
.sweep(false)
sweep.active.end()
return
}
sweep.active.end()
}
// Unfortunately we can't sweep the span ourselves. Somebody else
// got to it first. We don't have efficient means to wait, but that's
// OK, it will be swept fairly soon.
for {
:= atomic.Load(&.sweepgen)
if == .sweepGen || == .sweepGen+3 {
break
}
osyield()
}
}
// sweep frees or collects finalizers for blocks not marked in the mark phase.
// It clears the mark bits in preparation for the next GC round.
// Returns true if the span was returned to heap.
// If preserve=true, don't return it to heap nor relink in mcentral lists;
// caller takes care of it.
func ( *sweepLocked) ( bool) bool {
// It's critical that we enter this function with preemption disabled,
// GC must not start while we are in the middle of this function.
:= getg()
if .m.locks == 0 && .m.mallocing == 0 && != .m.g0 {
throw("mspan.sweep: m is not locked")
}
:= .mspan
if ! {
// We'll release ownership of this span. Nil it out to
// prevent the caller from accidentally using it.
.mspan = nil
}
:= mheap_.sweepgen
if := .state.get(); != mSpanInUse || .sweepgen != -1 {
print("mspan.sweep: state=", , " sweepgen=", .sweepgen, " mheap.sweepgen=", , "\n")
throw("mspan.sweep: bad span state")
}
if traceEnabled() {
traceGCSweepSpan(.npages * _PageSize)
}
mheap_.pagesSwept.Add(int64(.npages))
:= .spanclass
:= .elemsize
// The allocBits indicate which unmarked objects don't need to be
// processed since they were free at the end of the last GC cycle
// and were not allocated since then.
// If the allocBits index is >= s.freeindex and the bit
// is not marked then the object remains unallocated
// since the last GC.
// This situation is analogous to being on a freelist.
// Unlink & free special records for any objects we're about to free.
// Two complications here:
// 1. An object can have both finalizer and profile special records.
// In such case we need to queue finalizer for execution,
// mark the object as live and preserve the profile special.
// 2. A tiny object can have several finalizers setup for different offsets.
// If such object is not marked, we need to queue all finalizers at once.
// Both 1 and 2 are possible at the same time.
:= .specials != nil
:= newSpecialsIter()
for .valid() {
// A finalizer can be set for an inner byte of an object, find object beginning.
:= uintptr(.s.offset) /
:= .base() + *
:= .markBitsForIndex()
if !.isMarked() {
// This object is not marked and has at least one special record.
// Pass 1: see if it has at least one finalizer.
:= false
:= - .base() +
for := .s; != nil && uintptr(.offset) < ; = .next {
if .kind == _KindSpecialFinalizer {
// Stop freeing of object if it has a finalizer.
.setMarkedNonAtomic()
= true
break
}
}
// Pass 2: queue all finalizers _or_ handle profile record.
for .valid() && uintptr(.s.offset) < {
// Find the exact byte for which the special was setup
// (as opposed to object beginning).
:= .s
:= .base() + uintptr(.offset)
if .kind == _KindSpecialFinalizer || ! {
.unlinkAndNext()
freeSpecial(, unsafe.Pointer(), )
} else {
// The object has finalizers, so we're keeping it alive.
// All other specials only apply when an object is freed,
// so just keep the special record.
.next()
}
}
} else {
// object is still live
if .s.kind == _KindSpecialReachable {
:= .unlinkAndNext()
(*specialReachable)(unsafe.Pointer()).reachable = true
freeSpecial(, unsafe.Pointer(), )
} else {
// keep special record
.next()
}
}
}
if && .specials == nil {
spanHasNoSpecials()
}
if debug.allocfreetrace != 0 || debug.clobberfree != 0 || raceenabled || msanenabled || asanenabled {
// Find all newly freed objects. This doesn't have to
// efficient; allocfreetrace has massive overhead.
:= .markBitsForBase()
:= .allocBitsForIndex(0)
for := uintptr(0); < .nelems; ++ {
if !.isMarked() && (.index < .freeindex || .isMarked()) {
:= .base() + *.elemsize
if debug.allocfreetrace != 0 {
tracefree(unsafe.Pointer(), )
}
if debug.clobberfree != 0 {
clobberfree(unsafe.Pointer(), )
}
// User arenas are handled on explicit free.
if raceenabled && !.isUserArenaChunk {
racefree(unsafe.Pointer(), )
}
if msanenabled && !.isUserArenaChunk {
msanfree(unsafe.Pointer(), )
}
if asanenabled && !.isUserArenaChunk {
asanpoison(unsafe.Pointer(), )
}
}
.advance()
.advance()
}
}
// Check for zombie objects.
if .freeindex < .nelems {
// Everything < freeindex is allocated and hence
// cannot be zombies.
//
// Check the first bitmap byte, where we have to be
// careful with freeindex.
:= .freeindex
if (*.gcmarkBits.bytep( / 8)&^*.allocBits.bytep( / 8))>>(%8) != 0 {
.reportZombies()
}
// Check remaining bytes.
for := /8 + 1; < divRoundUp(.nelems, 8); ++ {
if *.gcmarkBits.bytep()&^*.allocBits.bytep() != 0 {
.reportZombies()
}
}
}
// Count the number of free objects in this span.
:= uint16(.countAlloc())
:= .allocCount -
if > .allocCount {
// The zombie check above should have caught this in
// more detail.
print("runtime: nelems=", .nelems, " nalloc=", , " previous allocCount=", .allocCount, " nfreed=", , "\n")
throw("sweep increased allocation count")
}
.allocCount =
.freeindex = 0 // reset allocation index to start of span.
.freeIndexForScan = 0
if traceEnabled() {
getg().m.p.ptr().trace.reclaimed += uintptr() * .elemsize
}
// gcmarkBits becomes the allocBits.
// get a fresh cleared gcmarkBits in preparation for next GC
.allocBits = .gcmarkBits
.gcmarkBits = newMarkBits(.nelems)
// refresh pinnerBits if they exists
if .pinnerBits != nil {
.refreshPinnerBits()
}
// Initialize alloc bits cache.
.refillAllocCache(0)
// The span must be in our exclusive ownership until we update sweepgen,
// check for potential races.
if := .state.get(); != mSpanInUse || .sweepgen != -1 {
print("mspan.sweep: state=", , " sweepgen=", .sweepgen, " mheap.sweepgen=", , "\n")
throw("mspan.sweep: bad span state after sweep")
}
if .sweepgen == +1 || .sweepgen == +3 {
throw("swept cached span")
}
// We need to set s.sweepgen = h.sweepgen only when all blocks are swept,
// because of the potential for a concurrent free/SetFinalizer.
//
// But we need to set it before we make the span available for allocation
// (return it to heap or mcentral), because allocation code assumes that a
// span is already swept if available for allocation.
//
// Serialization point.
// At this point the mark bits are cleared and allocation ready
// to go so release the span.
atomic.Store(&.sweepgen, )
if .isUserArenaChunk {
if {
// This is a case that should never be handled by a sweeper that
// preserves the span for reuse.
throw("sweep: tried to preserve a user arena span")
}
if > 0 {
// There still exist pointers into the span or the span hasn't been
// freed yet. It's not ready to be reused. Put it back on the
// full swept list for the next cycle.
mheap_.central[].mcentral.fullSwept().push()
return false
}
// It's only at this point that the sweeper doesn't actually need to look
// at this arena anymore, so subtract from pagesInUse now.
mheap_.pagesInUse.Add(-.npages)
.state.set(mSpanDead)
// The arena is ready to be recycled. Remove it from the quarantine list
// and place it on the ready list. Don't add it back to any sweep lists.
systemstack(func() {
// It's the arena code's responsibility to get the chunk on the quarantine
// list by the time all references to the chunk are gone.
if .list != &mheap_.userArena.quarantineList {
throw("user arena span is on the wrong list")
}
lock(&mheap_.lock)
mheap_.userArena.quarantineList.remove()
mheap_.userArena.readyList.insert()
unlock(&mheap_.lock)
})
return false
}
if .sizeclass() != 0 {
// Handle spans for small objects.
if > 0 {
// Only mark the span as needing zeroing if we've freed any
// objects, because a fresh span that had been allocated into,
// wasn't totally filled, but then swept, still has all of its
// free slots zeroed.
.needzero = 1
:= memstats.heapStats.acquire()
atomic.Xadd64(&.smallFreeCount[.sizeclass()], int64())
memstats.heapStats.release()
// Count the frees in the inconsistent, internal stats.
gcController.totalFree.Add(int64() * int64(.elemsize))
}
if ! {
// The caller may not have removed this span from whatever
// unswept set its on but taken ownership of the span for
// sweeping by updating sweepgen. If this span still is in
// an unswept set, then the mcentral will pop it off the
// set, check its sweepgen, and ignore it.
if == 0 {
// Free totally free span directly back to the heap.
mheap_.freeSpan()
return true
}
// Return span back to the right mcentral list.
if uintptr() == .nelems {
mheap_.central[].mcentral.fullSwept().push()
} else {
mheap_.central[].mcentral.partialSwept().push()
}
}
} else if ! {
// Handle spans for large objects.
if != 0 {
// Free large object span to heap.
// NOTE(rsc,dvyukov): The original implementation of efence
// in CL 22060046 used sysFree instead of sysFault, so that
// the operating system would eventually give the memory
// back to us again, so that an efence program could run
// longer without running out of memory. Unfortunately,
// calling sysFree here without any kind of adjustment of the
// heap data structures means that when the memory does
// come back to us, we have the wrong metadata for it, either in
// the mspan structures or in the garbage collection bitmap.
// Using sysFault here means that the program will run out of
// memory fairly quickly in efence mode, but at least it won't
// have mysterious crashes due to confused memory reuse.
// It should be possible to switch back to sysFree if we also
// implement and then call some kind of mheap.deleteSpan.
if debug.efence > 0 {
.limit = 0 // prevent mlookup from finding this span
sysFault(unsafe.Pointer(.base()), )
} else {
mheap_.freeSpan()
}
// Count the free in the consistent, external stats.
:= memstats.heapStats.acquire()
atomic.Xadd64(&.largeFreeCount, 1)
atomic.Xadd64(&.largeFree, int64())
memstats.heapStats.release()
// Count the free in the inconsistent, internal stats.
gcController.totalFree.Add(int64())
return true
}
// Add a large span directly onto the full+swept list.
mheap_.central[].mcentral.fullSwept().push()
}
return false
}
// reportZombies reports any marked but free objects in s and throws.
//
// This generally means one of the following:
//
// 1. User code converted a pointer to a uintptr and then back
// unsafely, and a GC ran while the uintptr was the only reference to
// an object.
//
// 2. User code (or a compiler bug) constructed a bad pointer that
// points to a free slot, often a past-the-end pointer.
//
// 3. The GC two cycles ago missed a pointer and freed a live object,
// but it was still live in the last cycle, so this GC cycle found a
// pointer to that object and marked it.
func ( *mspan) () {
printlock()
print("runtime: marked free object in span ", , ", elemsize=", .elemsize, " freeindex=", .freeindex, " (bad use of unsafe.Pointer? try -d=checkptr)\n")
:= .markBitsForBase()
:= .allocBitsForIndex(0)
for := uintptr(0); < .nelems; ++ {
:= .base() + *.elemsize
print(hex())
:= < .freeindex || .isMarked()
if {
print(" alloc")
} else {
print(" free ")
}
if .isMarked() {
print(" marked ")
} else {
print(" unmarked")
}
:= .isMarked() && !
if {
print(" zombie")
}
print("\n")
if {
:= .elemsize
if > 1024 {
= 1024
}
hexdumpWords(, +, nil)
}
.advance()
.advance()
}
throw("found pointer to free object")
}
// deductSweepCredit deducts sweep credit for allocating a span of
// size spanBytes. This must be performed *before* the span is
// allocated to ensure the system has enough credit. If necessary, it
// performs sweeping to prevent going in to debt. If the caller will
// also sweep pages (e.g., for a large allocation), it can pass a
// non-zero callerSweepPages to leave that many pages unswept.
//
// deductSweepCredit makes a worst-case assumption that all spanBytes
// bytes of the ultimately allocated span will be available for object
// allocation.
//
// deductSweepCredit is the core of the "proportional sweep" system.
// It uses statistics gathered by the garbage collector to perform
// enough sweeping so that all pages are swept during the concurrent
// sweep phase between GC cycles.
//
// mheap_ must NOT be locked.
func ( uintptr, uintptr) {
if mheap_.sweepPagesPerByte == 0 {
// Proportional sweep is done or disabled.
return
}
if traceEnabled() {
traceGCSweepStart()
}
// Fix debt if necessary.
:
:= mheap_.pagesSweptBasis.Load()
:= gcController.heapLive.Load()
:= mheap_.sweepHeapLiveBasis
:=
if < {
// Only do this subtraction when we don't overflow. Otherwise, pagesTarget
// might be computed as something really huge, causing us to get stuck
// sweeping here until the next mark phase.
//
// Overflow can happen here if gcPaceSweeper is called concurrently with
// sweeping (i.e. not during a STW, like it usually is) because this code
// is intentionally racy. A concurrent call to gcPaceSweeper can happen
// if a GC tuning parameter is modified and we read an older value of
// heapLive than what was used to set the basis.
//
// This state should be transient, so it's fine to just let newHeapLive
// be a relatively small number. We'll probably just skip this attempt to
// sweep.
//
// See issue #57523.
+= uintptr( - )
}
:= int64(mheap_.sweepPagesPerByte*float64()) - int64()
for > int64(mheap_.pagesSwept.Load()-) {
if sweepone() == ^uintptr(0) {
mheap_.sweepPagesPerByte = 0
break
}
if mheap_.pagesSweptBasis.Load() != {
// Sweep pacing changed. Recompute debt.
goto
}
}
if traceEnabled() {
traceGCSweepDone()
}
}
// clobberfree sets the memory content at x to bad content, for debugging
// purposes.
func ( unsafe.Pointer, uintptr) {
// size (span.elemsize) is always a multiple of 4.
for := uintptr(0); < ; += 4 {
*(*uint32)(add(, )) = 0xdeadbeef
}
}
// gcPaceSweeper updates the sweeper's pacing parameters.
//
// Must be called whenever the GC's pacing is updated.
//
// The world must be stopped, or mheap_.lock must be held.
func ( uint64) {
assertWorldStoppedOrLockHeld(&mheap_.lock)
// Update sweep pacing.
if isSweepDone() {
mheap_.sweepPagesPerByte = 0
} else {
// Concurrent sweep needs to sweep all of the in-use
// pages by the time the allocated heap reaches the GC
// trigger. Compute the ratio of in-use pages to sweep
// per byte allocated, accounting for the fact that
// some might already be swept.
:= gcController.heapLive.Load()
:= int64() - int64()
// Add a little margin so rounding errors and
// concurrent sweep are less likely to leave pages
// unswept when GC starts.
-= 1024 * 1024
if < _PageSize {
// Avoid setting the sweep ratio extremely high
= _PageSize
}
:= mheap_.pagesSwept.Load()
:= mheap_.pagesInUse.Load()
:= int64() - int64()
if <= 0 {
mheap_.sweepPagesPerByte = 0
} else {
mheap_.sweepPagesPerByte = float64() / float64()
mheap_.sweepHeapLiveBasis =
// Write pagesSweptBasis last, since this
// signals concurrent sweeps to recompute
// their debt.
mheap_.pagesSweptBasis.Store()
}
}
}
The pages are generated with Golds v0.6.7. (GOOS=linux GOARCH=amd64) Golds is a Go 101 project developed by Tapir Liu. PR and bug reports are welcome and can be submitted to the issue list. Please follow @Go100and1 (reachable from the left QR code) to get the latest news of Golds. |