const time.Second

187 uses

	time (current package)
		format.go#L1364: 	"s":  int64(Second),
		time.go#L605: 	Second               = 1000 * Millisecond
		time.go#L606: 	Minute               = 60 * Second
		time.go#L625: 	if u < uint64(Second) {
		time.go#L748: 	sec := d / Second
		time.go#L749: 	nsec := d % Second
		time.go#L854: 	d := Duration(t.sec()-u.sec())*Second + Duration(t.nsec()-u.nsec())
		time.go#L1452: 	case d < Second && Second%(d+d) == 0:
		time.go#L1457: 	case d%Second == 0:
		time.go#L1458: 		d1 := int64(d / Second)
		time.go#L1460: 		r = Duration(sec%d1)*Second + Duration(nsec)

	archive/zip
		struct.go#L216: 	return time.FixedZone("", int(offset/time.Second))

	cloud.google.com/go/compute/metadata
		metadata.go#L67: 			Timeout:   2 * time.Second,
		metadata.go#L68: 			KeepAlive: 30 * time.Second,
		metadata.go#L162: 		timer := time.NewTimer(5 * time.Second)
		metadata.go#L474: 	const failedSubscribeSleep = time.Second * 5

	cloud.google.com/go/errorreporting
		errors.go#L126: 	bundler.DelayThreshold = 2 * time.Second

	cloud.google.com/go/iam
		iam.go#L55: 		Max:        60 * time.Second,

	cloud.google.com/go/logging
		logging.go#L74: 	DefaultDelayThreshold = time.Second

	cloud.google.com/go/storage
		bucket.go#L892: 		RetentionPeriod: int64(rp.RetentionPeriod / time.Second),
		bucket.go#L905: 		RetentionPeriod: time.Duration(rp.RetentionPeriod) * time.Second,
		bucket.go#L915: 			MaxAgeSeconds:  int64(v.MaxAge / time.Second),
		bucket.go#L928: 			MaxAge:          time.Duration(v.MaxAgeSeconds) * time.Second,
		storage.go#L505: 		cutoff := now.Add(604801 * time.Second) // 7 days + 1 second

	contrib.go.opencensus.io/exporter/stackdriver
		stackdriver.go#L289: const defaultTimeout = 5 * time.Second
		trace.go#L75: 		b.DelayThreshold = 2 * time.Second
		trace.go#L193: 	time.AfterFunc(5*time.Second, func() {

	crypto/rand
		rand_unix.go#L58: 		t := time.AfterFunc(60*time.Second, warnBlocked)

	crypto/tls
		conn.go#L1360: 		c.SetWriteDeadline(time.Now().Add(time.Second * 5))
		handshake_client_tls13.go#L651: 	lifetime := time.Duration(msg.lifetime) * time.Second
		handshake_server_tls13.go#L756: 	m.lifetime = uint32(maxSessionTicketLifetime / time.Second)

	database/sql
		sql.go#L997: 	const minInterval = time.Second

	github.com/aws/aws-sdk-go/aws/client
		default_retryer.go#L49: 	DefaultRetryerMaxRetryDelay = 300 * time.Second
		default_retryer.go#L52: 	DefaultRetryerMaxThrottleDelay = 300 * time.Second
		default_retryer.go#L163: 	return time.Duration(delay) * time.Second, true

	github.com/aws/aws-sdk-go/aws/credentials/stscreds
		assume_role_provider.go#L312: 		DurationSeconds:   aws.Int64(int64((p.Duration - jitter) / time.Second)),
		web_identity_provider.go#L125: 		duration = aws.Int64(int64(p.Duration / time.Second))

	github.com/aws/aws-sdk-go/aws/ec2metadata
		api.go#L36: 	ttl := strconv.FormatInt(int64(duration/time.Second), 10)
		service.go#L49: 	defaultTTL          = 21600 * time.Second
		service.go#L50: 	ttlExpirationWindow = 30 * time.Second
		service.go#L91: 			Timeout: 1 * time.Second,
		service.go#L202: 		t := time.Duration(i) * time.Second

	github.com/aws/aws-sdk-go/aws/session
		cabundle_transport.go#L17: 			Timeout:   30 * time.Second,
		cabundle_transport.go#L18: 			KeepAlive: 30 * time.Second,
		cabundle_transport.go#L22: 		IdleConnTimeout:       90 * time.Second,
		cabundle_transport.go#L23: 		TLSHandshakeTimeout:   10 * time.Second,
		cabundle_transport.go#L24: 		ExpectContinueTimeout: 1 * time.Second,
		shared_config.go#L281: 			d := time.Duration(section.Int(roleDurationSecondsKey)) * time.Second

	github.com/aws/aws-sdk-go/aws/signer/v4
		v4.go#L578: 		duration := int64(ctx.ExpireTime / time.Second)

	github.com/go-git/go-git/v5/plumbing/transport/internal/common
		common.go#L366: 	t := time.NewTicker(time.Second * readErrorSecondsTimeout)

	github.com/go-redis/redis/v8
		cluster.go#L101: 		opt.ReadTimeout = 3 * time.Second
		cluster.go#L650: 		if time.Since(state.createdAt) > 10*time.Second {
		commands.go#L13: 	return dur < time.Second || dur%time.Second != 0
		commands.go#L29: 	if dur > 0 && dur < time.Second {
		commands.go#L33: 			dur, time.Second,
		commands.go#L37: 	return int64(dur / time.Second)
		commands.go#L513: 	cmd := NewDurationCmd(ctx, time.Second, "object", "idletime", key)
		commands.go#L652: 	cmd := NewDurationCmd(ctx, time.Second, "ttl", key)
		options.go#L126: 		opt.DialTimeout = 5 * time.Second
		options.go#L147: 		opt.ReadTimeout = 3 * time.Second
		options.go#L156: 		opt.PoolTimeout = opt.ReadTimeout + time.Second
		pubsub.go#L17: 	pingTimeout     = time.Second
		redis.go#L348: 		return t + 10*time.Second

	github.com/go-redis/redis/v8/internal/pool
		pool.go#L203: 			time.Sleep(time.Second)

	github.com/go-redis/redis_rate/v9
		rate.go#L37: 	case time.Second:
		rate.go#L50: 		Period: time.Second,
		rate.go#L165: 	return time.Duration(f * float64(time.Second))

	github.com/golang-migrate/migrate/v4
		migrate.go#L29: var DefaultLockTimeout = 15 * time.Second

	github.com/golang/protobuf/ptypes
		duration.go#L28: 	d := time.Duration(dur.Seconds) * time.Second
		duration.go#L29: 	if int64(d/time.Second) != dur.Seconds {

	github.com/googleapis/gax-go/v2
		call_option.go#L119: 		bo.Initial = time.Second
		call_option.go#L125: 		bo.Max = 30 * time.Second

	github.com/jackc/pgconn
		config.go#L695: 	return time.Duration(timeout) * time.Second, nil
		pgconn.go#L586: 		deadline := time.Now().Add(time.Second * 15)

	github.com/jackc/pgx/v4/stdlib
		sql.go#L175: 	ctx, cancel := context.WithTimeout(context.Background(), 60*time.Second) // Ensure eventual timeout
		sql.go#L279: 	ctx, cancel := context.WithTimeout(context.Background(), time.Second*5)
		sql.go#L401: 	ctx, cancel := context.WithTimeout(context.Background(), time.Second*5)
		sql.go#L776: 		ctx, cancel := context.WithTimeout(context.Background(), time.Second)

	github.com/lib/pq
		conn.go#L343: 		duration := time.Duration(seconds) * time.Second
		conn_go18.go#L100: 				ctxCancel, cancel := context.WithTimeout(context.Background(), time.Second*10)

	github.com/prometheus/client_golang/prometheus
		go_collector.go#L84: 		msMaxWait: time.Second,

	github.com/prometheus/common/model
		time.go#L30: 	second = int64(time.Second / minimumTick)

	github.com/sergi/go-diff/diffmatchpatch
		diffmatchpatch.go#L38: 		DiffTimeout:          time.Second,

	go.opencensus.io/metric/metricexport
		reader.go#L39: 	defaultReportingDuration = 60 * time.Second
		reader.go#L40: 	minimumReportingDuration = 1 * time.Second

	go.opencensus.io/stats/view
		worker.go#L117: var defaultReportingDuration = 10 * time.Second

	go.opencensus.io/trace
		spanbucket.go#L22: const samplePeriod = time.Second
		spanbucket.go#L32: 	time.Second,
		spanbucket.go#L33: 	10 * time.Second,

	go.opencensus.io/zpages
		rpcz.go#L208: 	ageSec := float64(time.Since(programStartTime)) / float64(time.Second)
		tracez.go#L53: 		time.Second,
		tracez.go#L54: 		10 * time.Second,
		tracez.go#L55: 		100 * time.Second,
		tracez.go#L421: 				if l == 100*time.Second {

	golang.org/x/crypto/openpgp/packet
		signature.go#L463: 	expiry := sig.CreationTime.Add(time.Duration(*sig.KeyLifetimeSecs) * time.Second)

	golang.org/x/crypto/ssh/agent
		keyring.go#L174: 		t := time.Now().Add(time.Duration(key.LifetimeSecs) * time.Second)

	golang.org/x/net/http2
		server.go#L55: 	prefaceTimeout         = 10 * time.Second
		server.go#L56: 	firstSettingsTimeout   = 2 * time.Second // should be in-flight with preface anyway
		server.go#L1312: var goAwayTimeout = 1 * time.Second
		transport.go#L149: 		return 15 * time.Second
		transport.go#L488: 				case <-time.After(time.Second * time.Duration(backoff)):

	golang.org/x/net/internal/timeseries
		timeseries.go#L20: 	1 * time.Second,
		timeseries.go#L21: 	10 * time.Second,
		timeseries.go#L33: 	1 * time.Second,

	golang.org/x/net/trace
		events.go#L33: 	{10 * time.Second, "errs<10s"},
		trace.go#L581: 			{Cond: minCond(1 * time.Second)},
		trace.go#L582: 			{Cond: minCond(10 * time.Second)},
		trace.go#L583: 			{Cond: minCond(100 * time.Second)},
		trace.go#L939: 	if d < time.Second {

	golang.org/x/oauth2
		token.go#L22: const expiryDelta = 10 * time.Second

	golang.org/x/oauth2/google
		google.go#L200: 		Expiry:      time.Now().Add(time.Duration(res.ExpiresInSec) * time.Second),

	golang.org/x/oauth2/internal
		token.go#L70: 		return time.Now().Add(time.Duration(v) * time.Second)
		token.go#L265: 			token.Expiry = time.Now().Add(time.Duration(expires) * time.Second)

	golang.org/x/oauth2/jws
		jws.go#L58: 	now := time.Now().Add(-10 * time.Second)

	golang.org/x/oauth2/jwt
		jwt.go#L168: 		token.Expiry = time.Now().Add(time.Duration(secs) * time.Second)

	golang.org/x/pkgsite/cmd/frontend
		main.go#L184: 		middleware.Timeout(54*time.Second),

	golang.org/x/pkgsite/cmd/pkgsite
		main.go#L71: 	mw := middleware.Timeout(54 * time.Second)

	golang.org/x/pkgsite/cmd/prober
		main.go#L339: 	ctx, cancel := context.WithTimeout(context.Background(), 15*time.Second)

	golang.org/x/pkgsite/cmd/worker
		main.go#L166: 	return getRedis(ctx, cfg.RedisCacheHost, cfg.RedisCachePort, 0, 6*time.Second)

	golang.org/x/pkgsite/internal/database
		database.go#L52: 	ctx, cancel := context.WithTimeout(context.Background(), 30*time.Second)

	golang.org/x/pkgsite/internal/frontend
		fetch.go#L40: 	fetchTimeout                = 30 * time.Second
		fetch.go#L41: 	pollEvery                   = 1 * time.Second

	golang.org/x/pkgsite/internal/middleware
		caching.go#L198: 	setCtx, cancelSet := context.WithTimeout(context.Background(), 1*time.Second)

	golang.org/x/pkgsite/internal/queue
		queue.go#L125: 	ctx, cancel := context.WithTimeout(ctx, 30*time.Second)

	golang.org/x/pkgsite/internal/worker
		server.go#L653: 			return time.Since(t).Round(time.Second)
		server.go#L656: 			return t1.Sub(t2).Round(time.Second)

	google.golang.org/api/idtoken
		cache.go#L118: 	return c.now().Add(time.Duration(maxAge-age) * time.Second)

	google.golang.org/api/internal/gensupport
		resumable.go#L27: 	retryDeadline = 32 * time.Second

	google.golang.org/api/support/bundler
		bundler.go#L27: 	DefaultDelayThreshold       = time.Second

	google.golang.org/api/transport/http
		dial.go#L200: 			Timeout:   30 * time.Second,
		dial.go#L201: 			KeepAlive: 30 * time.Second,
		dial.go#L206: 		IdleConnTimeout:       90 * time.Second,
		dial.go#L207: 		TLSHandshakeTimeout:   10 * time.Second,
		dial.go#L208: 		ExpectContinueTimeout: 1 * time.Second,

	google.golang.org/grpc
		backoff.go#L35: 	MaxDelay: 120 * time.Second,
		clientconn.go#L55: 	minConnectTimeout = 20 * time.Second
		server.go#L153: 	connectionTimeout:     120 * time.Second,
		server.go#L227: 	if kp.Time > 0 && kp.Time < time.Second {
		server.go#L229: 		kp.Time = time.Second
		server.go#L730: 				if max := 1 * time.Second; tempDelay > max {
		service_config.go#L203: 		d = time.Duration(i) * time.Second

	google.golang.org/grpc/backoff
		backoff.go#L48: 	BaseDelay:  1.0 * time.Second,
		backoff.go#L51: 	MaxDelay:   120 * time.Second,

	google.golang.org/grpc/balancer/grpclb
		grpclb.go#L48: 	defaultFallbackTimeout = 10 * time.Second
		grpclb.go#L59: 	return time.Duration(d.Seconds)*time.Second + time.Duration(d.Nanos)*time.Nanosecond
		grpclb_remote_balancer.go#L236: 		Time:                20 * time.Second,
		grpclb_remote_balancer.go#L237: 		Timeout:             10 * time.Second,
		grpclb_util.go#L91: const subConnCacheTime = time.Second * 10

	google.golang.org/grpc/credentials/alts
		alts.go#L47: 	defaultTimeout = 30.0 * time.Second

	google.golang.org/grpc/credentials/google
		google.go#L34: const tokenRequestTimeout = 30 * time.Second

	google.golang.org/grpc/internal
		internal.go#L40: 	KeepaliveMinPingTime = 10 * time.Second

	google.golang.org/grpc/internal/binarylog
		sink.go#L118: 	bufFlushDuration = 60 * time.Second

	google.golang.org/grpc/internal/grpcutil
		encode_duration.go#L55: 	if d := div(t, time.Second); d <= maxTimeoutValue {

	google.golang.org/grpc/internal/resolver/dns
		dns_resolver.go#L78: 	minDNSResRate = 30 * time.Second

	google.golang.org/grpc/internal/transport
		defaults.go#L33: 	defaultClientKeepaliveTimeout = 20 * time.Second
		defaults.go#L39: 	defaultServerKeepaliveTimeout = 20 * time.Second
		http2_client.go#L1474: 	timer := time.NewTimer(time.Second)
		http2_server.go#L1247: 	timer := time.NewTimer(time.Second)
		http_util.go#L405: 		return time.Second, true

	google.golang.org/protobuf/types/known/durationpb
		duration.pb.go#L179: 	d := time.Duration(secs) * time.Second
		duration.pb.go#L180: 	overflow := d/time.Second != time.Duration(secs)

	net
		dial.go#L17: 	defaultTCPKeepAlive = 15 * time.Second
		dial.go#L148: 	const saneMinimum = 2 * time.Second
		dnsclient_unix.go#L358: 	if conf.lastChecked.After(now.Add(-5 * time.Second)) {
		dnsconfig_unix.go#L43: 		timeout:  5 * time.Second,
		dnsconfig_unix.go#L111: 					conf.timeout = time.Duration(n) * time.Second
		hosts.go#L13: const cacheMaxAge = 5 * time.Second
		interface.go#L197: 	if !force && zc.lastFetched.After(now.Add(-60*time.Second)) {
		tcpsockopt_darwin.go#L18: 	secs := int(roundDurationUp(d, time.Second))

	net/http
		fs.go#L433: 	modtime = modtime.Truncate(time.Second)
		fs.go#L484: 	modtime = modtime.Truncate(time.Second)
		h2_bundle.go#L3621: 	http2prefaceTimeout         = 10 * time.Second
		h2_bundle.go#L3622: 	http2firstSettingsTimeout   = 2 * time.Second // should be in-flight with preface anyway
		h2_bundle.go#L4881: var http2goAwayTimeout = 1 * time.Second
		h2_bundle.go#L6651: 		return 15 * time.Second
		h2_bundle.go#L6991: 				case <-time.After(time.Second * time.Duration(backoff)):
		server.go#L2994: 				if max := 1 * time.Second; tempDelay > max {
		transport.go#L45: 		Timeout:   30 * time.Second,
		transport.go#L46: 		KeepAlive: 30 * time.Second,
		transport.go#L50: 	IdleConnTimeout:       90 * time.Second,
		transport.go#L51: 	TLSHandshakeTimeout:   10 * time.Second,
		transport.go#L52: 	ExpectContinueTimeout: 1 * time.Second,

	net/http/httptest
		server.go#L230: 		t := time.AfterFunc(5*time.Second, s.logCloseHangDebugInfo)
		server.go#L279: 	timer := time.NewTimer(5 * time.Second)

	testing
		benchmark.go#L35: 	benchTime = benchTimeFlag{d: 1 * time.Second} // changed during test of testing package