Source File
time.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.
// Time-related runtime and pieces of package time.
package runtime
import (
)
// A timer is a potentially repeating trigger for calling t.f(t.arg, t.seq).
// Timers are allocated by client code, often as part of other data structures.
// Each P has a heap of pointers to timers that it manages.
//
// A timer is expected to be used by only one client goroutine at a time,
// but there will be concurrent access by the P managing that timer.
// Timer accesses are protected by the lock t.mu, with a snapshot of
// t's state bits published in t.astate to enable certain fast paths to make
// decisions about a timer without acquiring the lock.
type timer struct {
// mu protects reads and writes to all fields, with exceptions noted below.
mu mutex
astate atomic.Uint8 // atomic copy of state bits at last unlock
state uint8 // state bits
isChan bool // timer has a channel; immutable; can be read without lock
blocked uint32 // number of goroutines blocked on timer's channel
// Timer wakes up at when, and then at when+period, ... (period > 0 only)
// each time calling f(arg, seq, delay) in the timer goroutine, so f must be
// a well-behaved function and not block.
//
// The arg and seq are client-specified opaque arguments passed back to f.
// When used from netpoll, arg and seq have meanings defined by netpoll
// and are completely opaque to this code; in that context, seq is a sequence
// number to recognize and squech stale function invocations.
// When used from package time, arg is a channel (for After, NewTicker)
// or the function to call (for AfterFunc) and seq is unused (0).
//
// Package time does not know about seq, but if this is a channel timer (t.isChan == true),
// this file uses t.seq as a sequence number to recognize and squelch
// sends that correspond to an earlier (stale) timer configuration,
// similar to its use in netpoll. In this usage (that is, when t.isChan == true),
// writes to seq are protected by both t.mu and t.sendLock,
// so reads are allowed when holding either of the two mutexes.
//
// The delay argument is nanotime() - t.when, meaning the delay in ns between
// when the timer should have gone off and now. Normally that amount is
// small enough not to matter, but for channel timers that are fed lazily,
// the delay can be arbitrarily long; package time subtracts it out to make
// it look like the send happened earlier than it actually did.
// (No one looked at the channel since then, or the send would have
// not happened so late, so no one can tell the difference.)
when int64
period int64
f func(arg any, seq uintptr, delay int64)
arg any
seq uintptr
// If non-nil, the timers containing t.
ts *timers
// sendLock protects sends on the timer's channel.
// Not used for async (pre-Go 1.23) behavior when debug.asynctimerchan.Load() != 0.
sendLock mutex
}
// init initializes a newly allocated timer t.
// Any code that allocates a timer must call t.init before using it.
// The arg and f can be set during init, or they can be nil in init
// and set by a future call to t.modify.
func ( *timer) ( func( any, uintptr, int64), any) {
lockInit(&.mu, lockRankTimer)
.f =
.arg =
}
// A timers is a per-P set of timers.
type timers struct {
// mu protects timers; timers are per-P, but the scheduler can
// access the timers of another P, so we have to lock.
mu mutex
// heap is the set of timers, ordered by heap[i].when.
// Must hold lock to access.
heap []timerWhen
// len is an atomic copy of len(heap).
len atomic.Uint32
// zombies is the number of timers in the heap
// that are marked for removal.
zombies atomic.Int32
// raceCtx is the race context used while executing timer functions.
raceCtx uintptr
// minWhenHeap is the minimum heap[i].when value (= heap[0].when).
// The wakeTime method uses minWhenHeap and minWhenModified
// to determine the next wake time.
// If minWhenHeap = 0, it means there are no timers in the heap.
minWhenHeap atomic.Int64
// minWhenModified is a lower bound on the minimum
// heap[i].when over timers with the timerModified bit set.
// If minWhenModified = 0, it means there are no timerModified timers in the heap.
minWhenModified atomic.Int64
}
type timerWhen struct {
timer *timer
when int64
}
func ( *timers) () {
lock(&.mu)
}
func ( *timers) () {
// Update atomic copy of len(ts.heap).
// We only update at unlock so that the len is always
// the most recent unlocked length, not an ephemeral length.
// This matters if we lock ts, delete the only timer from the heap,
// add it back, and unlock. We want ts.len.Load to return 1 the
// entire time, never 0. This is important for pidleput deciding
// whether ts is empty.
.len.Store(uint32(len(.heap)))
unlock(&.mu)
}
// Timer state field.
const (
// timerHeaped is set when the timer is stored in some P's heap.
timerHeaped uint8 = 1 << iota
// timerModified is set when t.when has been modified
// but the heap's heap[i].when entry still needs to be updated.
// That change waits until the heap in which
// the timer appears can be locked and rearranged.
// timerModified is only set when timerHeaped is also set.
timerModified
// timerZombie is set when the timer has been stopped
// but is still present in some P's heap.
// Only set when timerHeaped is also set.
// It is possible for timerModified and timerZombie to both
// be set, meaning that the timer was modified and then stopped.
// A timer sending to a channel may be placed in timerZombie
// to take it out of the heap even though the timer is not stopped,
// as long as nothing is reading from the channel.
timerZombie
)
// timerDebug enables printing a textual debug trace of all timer operations to stderr.
const timerDebug = false
func ( *timer) ( string) {
if timerDebug {
.trace1()
}
}
func ( *timer) ( string) {
if !timerDebug {
return
}
:= [4]string{"h", "m", "z", "c"}
for := range 3 {
if .state&(1<<) == 0 {
[] = "-"
}
}
if !.isChan {
[3] = "-"
}
print("T ", , " ", [0], [1], [2], [3], " b=", .blocked, " ", , "\n")
}
func ( *timers) ( string) {
if timerDebug {
println("TS", , )
}
}
// lock locks the timer, allowing reading or writing any of the timer fields.
func ( *timer) () {
lock(&.mu)
.trace("lock")
}
// unlock updates t.astate and unlocks the timer.
func ( *timer) () {
.trace("unlock")
// Let heap fast paths know whether heap[i].when is accurate.
// Also let maybeRunChan know whether channel is in heap.
.astate.Store(.state)
unlock(&.mu)
}
// hchan returns the channel in t.arg.
// t must be a timer with a channel.
func ( *timer) () *hchan {
if !.isChan {
badTimer()
}
// Note: t.arg is a chan time.Time,
// and runtime cannot refer to that type,
// so we cannot use a type assertion.
return (*hchan)(efaceOf(&.arg).data)
}
// updateHeap updates t as directed by t.state, updating t.state
// and returning a bool indicating whether the state (and ts.heap[0].when) changed.
// The caller must hold t's lock, or the world can be stopped instead.
// The timer set t.ts must be non-nil and locked, t must be t.ts.heap[0], and updateHeap
// takes care of moving t within the timers heap to preserve the heap invariants.
// If ts == nil, then t must not be in a heap (or is in a heap that is
// temporarily not maintaining its invariant, such as during timers.adjust).
func ( *timer) () ( bool) {
assertWorldStoppedOrLockHeld(&.mu)
.trace("updateHeap")
:= .ts
if == nil || != .heap[0].timer {
badTimer()
}
assertLockHeld(&.mu)
if .state&timerZombie != 0 {
// Take timer out of heap.
.state &^= timerHeaped | timerZombie | timerModified
.zombies.Add(-1)
.deleteMin()
return true
}
if .state&timerModified != 0 {
// Update ts.heap[0].when and move within heap.
.state &^= timerModified
.heap[0].when = .when
.siftDown(0)
.updateMinWhenHeap()
return true
}
return false
}
// maxWhen is the maximum value for timer's when field.
const maxWhen = 1<<63 - 1
// verifyTimers can be set to true to add debugging checks that the
// timer heaps are valid.
const verifyTimers = false
// Package time APIs.
// Godoc uses the comments in package time, not these.
// time.now is implemented in assembly.
// timeSleep puts the current goroutine to sleep for at least ns nanoseconds.
//
//go:linkname timeSleep time.Sleep
func timeSleep( int64) {
if <= 0 {
return
}
:= getg()
:= .timer
if == nil {
= new(timer)
.init(goroutineReady, )
.timer =
}
:= nanotime() +
if < 0 { // check for overflow.
= maxWhen
}
.sleepWhen =
gopark(resetForSleep, nil, waitReasonSleep, traceBlockSleep, 1)
}
// resetForSleep is called after the goroutine is parked for timeSleep.
// We can't call timer.reset in timeSleep itself because if this is a short
// sleep and there are many goroutines then the P can wind up running the
// timer function, goroutineReady, before the goroutine has been parked.
func resetForSleep( *g, unsafe.Pointer) bool {
.timer.reset(.sleepWhen, 0)
return true
}
// A timeTimer is a runtime-allocated time.Timer or time.Ticker
// with the additional runtime state following it.
// The runtime state is inaccessible to package time.
type timeTimer struct {
c unsafe.Pointer // <-chan time.Time
init bool
timer
}
// newTimer allocates and returns a new time.Timer or time.Ticker (same layout)
// with the given parameters.
//
//go:linkname newTimer time.newTimer
func newTimer(, int64, func( any, uintptr, int64), any, *hchan) *timeTimer {
:= new(timeTimer)
.timer.init(nil, nil)
.trace("new")
if raceenabled {
racerelease(unsafe.Pointer(&.timer))
}
if != nil {
lockInit(&.sendLock, lockRankTimerSend)
.isChan = true
.timer = &.timer
if .dataqsiz == 0 {
throw("invalid timer channel: no capacity")
}
}
.modify(, , , , 0)
.init = true
return
}
// stopTimer stops a timer.
// It reports whether t was stopped before being run.
//
//go:linkname stopTimer time.stopTimer
func stopTimer( *timeTimer) bool {
return .stop()
}
// resetTimer resets an inactive timer, adding it to the timer heap.
//
// Reports whether the timer was modified before it was run.
//
//go:linkname resetTimer time.resetTimer
func resetTimer( *timeTimer, , int64) bool {
if raceenabled {
racerelease(unsafe.Pointer(&.timer))
}
return .reset(, )
}
// Go runtime.
// Ready the goroutine arg.
func goroutineReady( any, uintptr, int64) {
goready(.(*g), 0)
}
// addHeap adds t to the timers heap.
// The caller must hold ts.lock or the world must be stopped.
// The caller must also have checked that t belongs in the heap.
// Callers that are not sure can call t.maybeAdd instead,
// but note that maybeAdd has different locking requirements.
func ( *timers) ( *timer) {
assertWorldStoppedOrLockHeld(&.mu)
// Timers rely on the network poller, so make sure the poller
// has started.
if netpollInited.Load() == 0 {
netpollGenericInit()
}
if .ts != nil {
throw("ts set in timer")
}
.ts =
.heap = append(.heap, timerWhen{, .when})
.siftUp(len(.heap) - 1)
if == .heap[0].timer {
.updateMinWhenHeap()
}
}
// maybeRunAsync checks whether t needs to be triggered and runs it if so.
// The caller is responsible for locking the timer and for checking that we
// are running timers in async mode. If the timer needs to be run,
// maybeRunAsync will unlock and re-lock it.
// The timer is always locked on return.
func ( *timer) () {
assertLockHeld(&.mu)
if .state&timerHeaped == 0 && .isChan && .when > 0 {
// If timer should have triggered already (but nothing looked at it yet),
// trigger now, so that a receive after the stop sees the "old" value
// that should be there.
// (It is possible to have t.blocked > 0 if there is a racing receive
// in blockTimerChan, but timerHeaped not being set means
// it hasn't run t.maybeAdd yet; in that case, running the
// timer ourselves now is fine.)
if := nanotime(); .when <= {
systemstack(func() {
.unlockAndRun() // resets t.when
})
.lock()
}
}
}
// stop stops the timer t. It may be on some other P, so we can't
// actually remove it from the timers heap. We can only mark it as stopped.
// It will be removed in due course by the P whose heap it is on.
// Reports whether the timer was stopped before it was run.
func ( *timer) () bool {
:= debug.asynctimerchan.Load() != 0
if ! && .isChan {
lock(&.sendLock)
}
.lock()
.trace("stop")
if {
.maybeRunAsync()
}
if .state&timerHeaped != 0 {
.state |= timerModified
if .state&timerZombie == 0 {
.state |= timerZombie
.ts.zombies.Add(1)
}
}
:= .when > 0
.when = 0
if ! && .isChan {
// Stop any future sends with stale values.
// See timer.unlockAndRun.
.seq++
}
.unlock()
if ! && .isChan {
unlock(&.sendLock)
if timerchandrain(.hchan()) {
= true
}
}
return
}
// deleteMin removes timer 0 from ts.
// ts must be locked.
func ( *timers) () {
assertLockHeld(&.mu)
:= .heap[0].timer
if .ts != {
throw("wrong timers")
}
.ts = nil
:= len(.heap) - 1
if > 0 {
.heap[0] = .heap[]
}
.heap[] = timerWhen{}
.heap = .heap[:]
if > 0 {
.siftDown(0)
}
.updateMinWhenHeap()
if == 0 {
// If there are no timers, then clearly there are no timerModified timers.
.minWhenModified.Store(0)
}
}
// modify modifies an existing timer.
// This is called by the netpoll code or time.Ticker.Reset or time.Timer.Reset.
// Reports whether the timer was modified before it was run.
// If f == nil, then t.f, t.arg, and t.seq are not modified.
func ( *timer) (, int64, func( any, uintptr, int64), any, uintptr) bool {
if <= 0 {
throw("timer when must be positive")
}
if < 0 {
throw("timer period must be non-negative")
}
:= debug.asynctimerchan.Load() != 0
if ! && .isChan {
lock(&.sendLock)
}
.lock()
if {
.maybeRunAsync()
}
.trace("modify")
.period =
if != nil {
.f =
.arg =
.seq =
}
:= false
:= .when > 0
.when =
if .state&timerHeaped != 0 {
.state |= timerModified
if .state&timerZombie != 0 {
// In the heap but marked for removal (by a Stop).
// Unmark it, since it has been Reset and will be running again.
.ts.zombies.Add(-1)
.state &^= timerZombie
}
// The corresponding heap[i].when is updated later.
// See comment in type timer above and in timers.adjust below.
if := .ts.minWhenModified.Load(); == 0 || < {
= true
// Force timerModified bit out to t.astate before updating t.minWhenModified,
// to synchronize with t.ts.adjust. See comment in adjust.
.astate.Store(.state)
.ts.updateMinWhenModified()
}
}
:= .needsAdd()
if ! && .isChan {
// Stop any future sends with stale values.
// See timer.unlockAndRun.
.seq++
}
.unlock()
if ! && .isChan {
if timerchandrain(.hchan()) {
= true
}
unlock(&.sendLock)
}
if {
.maybeAdd()
}
if {
wakeNetPoller()
}
return
}
// needsAdd reports whether t needs to be added to a timers heap.
// t must be locked.
func ( *timer) () bool {
assertLockHeld(&.mu)
:= .state&timerHeaped == 0 && .when > 0 && (!.isChan || .blocked > 0)
if {
.trace("needsAdd+")
} else {
.trace("needsAdd-")
}
return
}
// maybeAdd adds t to the local timers heap if it needs to be in a heap.
// The caller must not hold t's lock nor any timers heap lock.
// The caller probably just unlocked t, but that lock must be dropped
// in order to acquire a ts.lock, to avoid lock inversions.
// (timers.adjust holds ts.lock while acquiring each t's lock,
// so we cannot hold any t's lock while acquiring ts.lock).
//
// Strictly speaking it *might* be okay to hold t.lock and
// acquire ts.lock at the same time, because we know that
// t is not in any ts.heap, so nothing holding a ts.lock would
// be acquiring the t.lock at the same time, meaning there
// isn't a possible deadlock. But it is easier and safer not to be
// too clever and respect the static ordering.
// (If we don't, we have to change the static lock checking of t and ts.)
//
// Concurrent calls to time.Timer.Reset or blockTimerChan
// may result in concurrent calls to t.maybeAdd,
// so we cannot assume that t is not in a heap on entry to t.maybeAdd.
func ( *timer) () {
// Note: Not holding any locks on entry to t.maybeAdd,
// so the current g can be rescheduled to a different M and P
// at any time, including between the ts := assignment and the
// call to ts.lock. If a reschedule happened then, we would be
// adding t to some other P's timers, perhaps even a P that the scheduler
// has marked as idle with no timers, in which case the timer could
// go unnoticed until long after t.when.
// Calling acquirem instead of using getg().m makes sure that
// we end up locking and inserting into the current P's timers.
:= acquirem()
:= &.p.ptr().timers
.lock()
.cleanHead()
.lock()
.trace("maybeAdd")
:= int64(0)
:= false
if .needsAdd() {
.state |= timerHeaped
= .when
:= .wakeTime()
= == 0 || <
.addHeap()
}
.unlock()
.unlock()
releasem()
if {
wakeNetPoller()
}
}
// reset resets the time when a timer should fire.
// If used for an inactive timer, the timer will become active.
// Reports whether the timer was active and was stopped.
func ( *timer) (, int64) bool {
return .modify(, , nil, nil, 0)
}
// cleanHead cleans up the head of the timer queue. This speeds up
// programs that create and delete timers; leaving them in the heap
// slows down heap operations.
// The caller must have locked ts.
func ( *timers) () {
.trace("cleanHead")
assertLockHeld(&.mu)
:= getg()
for {
if len(.heap) == 0 {
return
}
// This loop can theoretically run for a while, and because
// it is holding timersLock it cannot be preempted.
// If someone is trying to preempt us, just return.
// We can clean the timers later.
if .preemptStop {
return
}
// Delete zombies from tail of heap. It requires no heap adjustments at all,
// and doing so increases the chances that when we swap out a zombie
// in heap[0] for the tail of the heap, we'll get a non-zombie timer,
// shortening this loop.
:= len(.heap)
if := .heap[-1].timer; .astate.Load()&timerZombie != 0 {
.lock()
if .state&timerZombie != 0 {
.state &^= timerHeaped | timerZombie | timerModified
.ts = nil
.zombies.Add(-1)
.heap[-1] = timerWhen{}
.heap = .heap[:-1]
}
.unlock()
continue
}
:= .heap[0].timer
if .ts != {
throw("bad ts")
}
if .astate.Load()&(timerModified|timerZombie) == 0 {
// Fast path: head of timers does not need adjustment.
return
}
.lock()
:= .updateHeap()
.unlock()
if ! {
// Head of timers does not need adjustment.
return
}
}
}
// take moves any timers from src into ts
// and then clears the timer state from src,
// because src is being destroyed.
// The caller must not have locked either timers.
// For now this is only called when the world is stopped.
func ( *timers) ( *timers) {
.trace("take")
assertWorldStopped()
if len(.heap) > 0 {
// The world is stopped, so we ignore the locking of ts and src here.
// That would introduce a sched < timers lock ordering,
// which we'd rather avoid in the static ranking.
for , := range .heap {
:= .timer
.ts = nil
if .state&timerZombie != 0 {
.state &^= timerHeaped | timerZombie | timerModified
} else {
.state &^= timerModified
.addHeap()
}
}
.heap = nil
.zombies.Store(0)
.minWhenHeap.Store(0)
.minWhenModified.Store(0)
.len.Store(0)
.len.Store(uint32(len(.heap)))
}
}
// adjust looks through the timers in ts.heap for
// any timers that have been modified to run earlier, and puts them in
// the correct place in the heap. While looking for those timers,
// it also moves timers that have been modified to run later,
// and removes deleted timers. The caller must have locked ts.
func ( *timers) ( int64, bool) {
.trace("adjust")
assertLockHeld(&.mu)
// If we haven't yet reached the time of the earliest modified
// timer, don't do anything. This speeds up programs that adjust
// a lot of timers back and forth if the timers rarely expire.
// We'll postpone looking through all the adjusted timers until
// one would actually expire.
if ! {
:= .minWhenModified.Load()
if == 0 || > {
if verifyTimers {
.verify()
}
return
}
}
// minWhenModified is a lower bound on the earliest t.when
// among the timerModified timers. We want to make it more precise:
// we are going to scan the heap and clean out all the timerModified bits,
// at which point minWhenModified can be set to 0 (indicating none at all).
//
// Other P's can be calling ts.wakeTime concurrently, and we'd like to
// keep ts.wakeTime returning an accurate value throughout this entire process.
//
// Setting minWhenModified = 0 *before* the scan could make wakeTime
// return an incorrect value: if minWhenModified < minWhenHeap, then clearing
// it to 0 will make wakeTime return minWhenHeap (too late) until the scan finishes.
// To avoid that, we want to set minWhenModified to 0 *after* the scan.
//
// Setting minWhenModified = 0 *after* the scan could result in missing
// concurrent timer modifications in other goroutines; those will lock
// the specific timer, set the timerModified bit, and set t.when.
// To avoid that, we want to set minWhenModified to 0 *before* the scan.
//
// The way out of this dilemma is to preserve wakeTime a different way.
// wakeTime is min(minWhenHeap, minWhenModified), and minWhenHeap
// is protected by ts.lock, which we hold, so we can modify it however we like
// in service of keeping wakeTime accurate.
//
// So we can:
//
// 1. Set minWhenHeap = min(minWhenHeap, minWhenModified)
// 2. Set minWhenModified = 0
// (Other goroutines may modify timers and update minWhenModified now.)
// 3. Scan timers
// 4. Set minWhenHeap = heap[0].when
//
// That order preserves a correct value of wakeTime throughout the entire
// operation:
// Step 1 “locks in” an accurate wakeTime even with minWhenModified cleared.
// Step 2 makes sure concurrent t.when updates are not lost during the scan.
// Step 3 processes all modified timer values, justifying minWhenModified = 0.
// Step 4 corrects minWhenHeap to a precise value.
//
// The wakeTime method implementation reads minWhenModified *before* minWhenHeap,
// so that if the minWhenModified is observed to be 0, that means the minWhenHeap that
// follows will include the information that was zeroed out of it.
//
// Originally Step 3 locked every timer, which made sure any timer update that was
// already in progress during Steps 1+2 completed and was observed by Step 3.
// All that locking was too expensive, so now we do an atomic load of t.astate to
// decide whether we need to do a full lock. To make sure that we still observe any
// timer update already in progress during Steps 1+2, t.modify sets timerModified
// in t.astate *before* calling t.updateMinWhenModified. That ensures that the
// overwrite in Step 2 cannot lose an update: if it does overwrite an update, Step 3
// will see the timerModified and do a full lock.
.minWhenHeap.Store(.wakeTime())
.minWhenModified.Store(0)
:= false
for := 0; < len(.heap); ++ {
:= &.heap[]
:= .timer
if .ts != {
throw("bad ts")
}
if .astate.Load()&(timerModified|timerZombie) == 0 {
// Does not need adjustment.
continue
}
.lock()
switch {
case .state&timerHeaped == 0:
badTimer()
case .state&timerZombie != 0:
.zombies.Add(-1)
.state &^= timerHeaped | timerZombie | timerModified
:= len(.heap)
.heap[] = .heap[-1]
.heap[-1] = timerWhen{}
.heap = .heap[:-1]
.ts = nil
--
= true
case .state&timerModified != 0:
.when = .when
.state &^= timerModified
= true
}
.unlock()
}
if {
.initHeap()
}
.updateMinWhenHeap()
if verifyTimers {
.verify()
}
}
// wakeTime looks at ts's timers and returns the time when we
// should wake up the netpoller. It returns 0 if there are no timers.
// This function is invoked when dropping a P, so it must run without
// any write barriers.
//
//go:nowritebarrierrec
func ( *timers) () int64 {
// Note that the order of these two loads matters:
// adjust updates minWhen to make it safe to clear minNextWhen.
// We read minWhen after reading minNextWhen so that
// if we see a cleared minNextWhen, we are guaranteed to see
// the updated minWhen.
:= .minWhenModified.Load()
:= .minWhenHeap.Load()
if == 0 || ( != 0 && < ) {
=
}
return
}
// check runs any timers in ts that are ready.
// If now is not 0 it is the current time.
// It returns the passed time or the current time if now was passed as 0.
// and the time when the next timer should run or 0 if there is no next timer,
// and reports whether it ran any timers.
// If the time when the next timer should run is not 0,
// it is always larger than the returned time.
// We pass now in and out to avoid extra calls of nanotime.
//
//go:yeswritebarrierrec
func ( *timers) ( int64) (, int64, bool) {
.trace("check")
// If it's not yet time for the first timer, or the first adjusted
// timer, then there is nothing to do.
:= .wakeTime()
if == 0 {
// No timers to run or adjust.
return , 0, false
}
if == 0 {
= nanotime()
}
// If this is the local P, and there are a lot of deleted timers,
// clear them out. We only do this for the local P to reduce
// lock contention on timersLock.
:= .zombies.Load()
if < 0 {
badTimer()
}
:= == &getg().m.p.ptr().timers && int() > int(.len.Load())/4
if < && ! {
// Next timer is not ready to run, and we don't need to clear deleted timers.
return , , false
}
.lock()
if len(.heap) > 0 {
.adjust(, false)
for len(.heap) > 0 {
// Note that runtimer may temporarily unlock ts.
if := .run(); != 0 {
if > 0 {
=
}
break
}
= true
}
// Note: Delaying the forced adjustment until after the ts.run
// (as opposed to calling ts.adjust(now, force) above)
// is significantly faster under contention, such as in
// package time's BenchmarkTimerAdjust10000,
// though we do not fully understand why.
= == &getg().m.p.ptr().timers && int(.zombies.Load()) > int(.len.Load())/4
if {
.adjust(, true)
}
}
.unlock()
return , ,
}
// run examines the first timer in ts. If it is ready based on now,
// it runs the timer and removes or updates it.
// Returns 0 if it ran a timer, -1 if there are no more timers, or the time
// when the first timer should run.
// The caller must have locked ts.
// If a timer is run, this will temporarily unlock ts.
//
//go:systemstack
func ( *timers) ( int64) int64 {
.trace("run")
assertLockHeld(&.mu)
:
if len(.heap) == 0 {
return -1
}
:= .heap[0]
:= .timer
if .ts != {
throw("bad ts")
}
if .astate.Load()&(timerModified|timerZombie) == 0 && .when > {
// Fast path: not ready to run.
return .when
}
.lock()
if .updateHeap() {
.unlock()
goto
}
if .state&timerHeaped == 0 || .state&timerModified != 0 {
badTimer()
}
if .when > {
// Not ready to run.
.unlock()
return .when
}
.unlockAndRun()
assertLockHeld(&.mu) // t is unlocked now, but not ts
return 0
}
// unlockAndRun unlocks and runs the timer t (which must be locked).
// If t is in a timer set (t.ts != nil), the caller must also have locked the timer set,
// and this call will temporarily unlock the timer set while running the timer function.
// unlockAndRun returns with t unlocked and t.ts (re-)locked.
//
//go:systemstack
func ( *timer) ( int64) {
.trace("unlockAndRun")
assertLockHeld(&.mu)
if .ts != nil {
assertLockHeld(&.ts.mu)
}
if raceenabled {
// Note that we are running on a system stack,
// so there is no chance of getg().m being reassigned
// out from under us while this function executes.
:= &getg().m.p.ptr().timers
if .raceCtx == 0 {
.raceCtx = racegostart(abi.FuncPCABIInternal((*timers).run) + sys.PCQuantum)
}
raceacquirectx(.raceCtx, unsafe.Pointer())
}
if .state&(timerModified|timerZombie) != 0 {
badTimer()
}
:= .f
:= .arg
:= .seq
var int64
:= - .when
if .period > 0 {
// Leave in heap but adjust next time to fire.
= .when + .period*(1+/.period)
if < 0 { // check for overflow.
= maxWhen
}
} else {
= 0
}
:= .ts
.when =
if .state&timerHeaped != 0 {
.state |= timerModified
if == 0 {
.state |= timerZombie
.ts.zombies.Add(1)
}
.updateHeap()
}
.unlock()
if raceenabled {
// Temporarily use the current P's racectx for g0.
:= getg()
if .racectx != 0 {
throw("unexpected racectx")
}
.racectx = .m.p.ptr().timers.raceCtx
}
if != nil {
.unlock()
}
:= debug.asynctimerchan.Load() != 0
if ! && .isChan {
// For a timer channel, we want to make sure that no stale sends
// happen after a t.stop or t.modify, but we cannot hold t.mu
// during the actual send (which f does) due to lock ordering.
// It can happen that we are holding t's lock above, we decide
// it's time to send a time value (by calling f), grab the parameters,
// unlock above, and then a t.stop or t.modify changes the timer
// and returns. At that point, the send needs not to happen after all.
// The way we arrange for it not to happen is that t.stop and t.modify
// both increment t.seq while holding both t.mu and t.sendLock.
// We copied the seq value above while holding t.mu.
// Now we can acquire t.sendLock (which will be held across the send)
// and double-check that t.seq is still the seq value we saw above.
// If not, the timer has been updated and we should skip the send.
// We skip the send by reassigning f to a no-op function.
lock(&.sendLock)
if .seq != {
= func(any, uintptr, int64) {}
}
}
(, , )
if ! && .isChan {
unlock(&.sendLock)
}
if != nil {
.lock()
}
if raceenabled {
:= getg()
.racectx = 0
}
}
// verifyTimerHeap verifies that the timers is in a valid state.
// This is only for debugging, and is only called if verifyTimers is true.
// The caller must have locked ts.
func ( *timers) () {
assertLockHeld(&.mu)
for , := range .heap {
if == 0 {
// First timer has no parent.
continue
}
// The heap is timerHeapN-ary. See siftupTimer and siftdownTimer.
:= int(uint(-1) / timerHeapN)
if .when < .heap[].when {
print("bad timer heap at ", , ": ", , ": ", .heap[].when, ", ", , ": ", .when, "\n")
throw("bad timer heap")
}
}
if := int(.len.Load()); len(.heap) != {
println("timer heap len", len(.heap), "!= atomic len", )
throw("bad timer heap len")
}
}
// updateMinWhenHeap sets ts.minWhenHeap to ts.heap[0].when.
// The caller must have locked ts or the world must be stopped.
func ( *timers) () {
assertWorldStoppedOrLockHeld(&.mu)
if len(.heap) == 0 {
.minWhenHeap.Store(0)
} else {
.minWhenHeap.Store(.heap[0].when)
}
}
// updateMinWhenModified updates ts.minWhenModified to be <= when.
// ts need not be (and usually is not) locked.
func ( *timers) ( int64) {
for {
:= .minWhenModified.Load()
if != 0 && < {
return
}
if .minWhenModified.CompareAndSwap(, ) {
return
}
}
}
// timeSleepUntil returns the time when the next timer should fire. Returns
// maxWhen if there are no timers.
// This is only called by sysmon and checkdead.
func timeSleepUntil() int64 {
:= int64(maxWhen)
// Prevent allp slice changes. This is like retake.
lock(&allpLock)
for , := range allp {
if == nil {
// This can happen if procresize has grown
// allp but not yet created new Ps.
continue
}
if := .timers.wakeTime(); != 0 {
= min(, )
}
}
unlock(&allpLock)
return
}
const timerHeapN = 4
// Heap maintenance algorithms.
// These algorithms check for slice index errors manually.
// Slice index error can happen if the program is using racy
// access to timers. We don't want to panic here, because
// it will cause the program to crash with a mysterious
// "panic holding locks" message. Instead, we panic while not
// holding a lock.
// siftUp puts the timer at position i in the right place
// in the heap by moving it up toward the top of the heap.
func ( *timers) ( int) {
:= .heap
if >= len() {
badTimer()
}
:= []
:= .when
if <= 0 {
badTimer()
}
for > 0 {
:= int(uint(-1) / timerHeapN) // parent
if >= [].when {
break
}
[] = []
=
}
if [].timer != .timer {
[] =
}
}
// siftDown puts the timer at position i in the right place
// in the heap by moving it down toward the bottom of the heap.
func ( *timers) ( int) {
:= .heap
:= len()
if >= {
badTimer()
}
if *timerHeapN+1 >= {
return
}
:= []
:= .when
if <= 0 {
badTimer()
}
for {
:= *timerHeapN + 1
if >= {
break
}
:=
:= -1
for , := range [:min(+timerHeapN, )] {
if .when < {
= .when
= +
}
}
if < 0 {
break
}
[] = []
=
}
if [].timer != .timer {
[] =
}
}
// initHeap reestablishes the heap order in the slice ts.heap.
// It takes O(n) time for n=len(ts.heap), not the O(n log n) of n repeated add operations.
func ( *timers) () {
// Last possible element that needs sifting down is parent of last element;
// last element is len(t)-1; parent of last element is (len(t)-1-1)/timerHeapN.
if len(.heap) <= 1 {
return
}
for := int(uint(len(.heap)-1-1) / timerHeapN); >= 0; -- {
.siftDown()
}
}
// badTimer is called if the timer data structures have been corrupted,
// presumably due to racy use by the program. We panic here rather than
// panicking due to invalid slice access while holding locks.
// See issue #25686.
func badTimer() {
throw("timer data corruption")
}
// Timer channels.
// maybeRunChan checks whether the timer needs to run
// to send a value to its associated channel. If so, it does.
// The timer must not be locked.
func ( *timer) () {
if .astate.Load()&timerHeaped != 0 {
// If the timer is in the heap, the ordinary timer code
// is in charge of sending when appropriate.
return
}
.lock()
:= nanotime()
if .state&timerHeaped != 0 || .when == 0 || .when > {
.trace("maybeRunChan-")
// Timer in the heap, or not running at all, or not triggered.
.unlock()
return
}
.trace("maybeRunChan+")
systemstack(func() {
.unlockAndRun()
})
}
// blockTimerChan is called when a channel op has decided to block on c.
// The caller holds the channel lock for c and possibly other channels.
// blockTimerChan makes sure that c is in a timer heap,
// adding it if needed.
func blockTimerChan( *hchan) {
:= .timer
.lock()
.trace("blockTimerChan")
if !.isChan {
badTimer()
}
.blocked++
// If this is the first enqueue after a recent dequeue,
// the timer may still be in the heap but marked as a zombie.
// Unmark it in this case, if the timer is still pending.
if .state&timerHeaped != 0 && .state&timerZombie != 0 && .when > 0 {
.state &^= timerZombie
.ts.zombies.Add(-1)
}
// t.maybeAdd must be called with t unlocked,
// because it needs to lock t.ts before t.
// Then it will do nothing if t.needsAdd(state) is false.
// Check that now before the unlock,
// avoiding the extra lock-lock-unlock-unlock
// inside maybeAdd when t does not need to be added.
:= .needsAdd()
.unlock()
if {
.maybeAdd()
}
}
// unblockTimerChan is called when a channel op that was blocked on c
// is no longer blocked. Every call to blockTimerChan must be paired with
// a call to unblockTimerChan.
// The caller holds the channel lock for c and possibly other channels.
// unblockTimerChan removes c from the timer heap when nothing is
// blocked on it anymore.
func unblockTimerChan( *hchan) {
:= .timer
.lock()
.trace("unblockTimerChan")
if !.isChan || .blocked == 0 {
badTimer()
}
.blocked--
if .blocked == 0 && .state&timerHeaped != 0 && .state&timerZombie == 0 {
// Last goroutine that was blocked on this timer.
// Mark for removal from heap but do not clear t.when,
// so that we know what time it is still meant to trigger.
.state |= timerZombie
.ts.zombies.Add(1)
}
.unlock()
}
The pages are generated with Golds v0.7.0-preview. (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 @zigo_101 (reachable from the left QR code) to get the latest news of Golds. |