Search Options

Results per page
Sort
Preferred Languages
Advance

Results 71 - 80 of 194 for St (0.15 sec)

  1. src/cmd/go/internal/modfetch/fetch.go

    	goSum.mu.Lock()
    	inited, err := initGoSum()
    	if err != nil {
    		goSum.mu.Unlock()
    		return err
    	}
    	done := inited && haveModSumLocked(mod, h)
    	if inited {
    		st := goSum.status[modSum{mod, h}]
    		st.used = true
    		goSum.status[modSum{mod, h}] = st
    	}
    	goSum.mu.Unlock()
    
    	if done {
    		return nil
    	}
    
    	// Not listed, so we want to add them.
    	// Consult checksum database if appropriate.
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu May 30 14:56:56 UTC 2024
    - 30.3K bytes
    - Viewed (0)
  2. src/cmd/trace/pprof.go

    			stack := ev.Stack()
    			if stack == trace.NoStack {
    				continue
    			}
    
    			// The state transition has to apply to a goroutine.
    			st := ev.StateTransition()
    			if st.Resource.Kind != trace.ResourceGoroutine {
    				continue
    			}
    			id := st.Resource.Goroutine()
    			_, new := st.Goroutine()
    
    			// Check if we're tracking this goroutine.
    			startEv := tracking[id]
    			if startEv == nil {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri May 17 18:48:18 UTC 2024
    - 10.1K bytes
    - Viewed (0)
  3. cmd/bucket-replication.go

    	s.Lock()
    	defer s.Unlock()
    	m := s.statusMap[opts.bucket]
    	st := m.TargetsMap[opts.arn]
    	st.Object = ts.Object
    	st.ReplicatedCount += ts.ReplicatedCount
    	st.FailedCount += ts.FailedCount
    	st.ReplicatedSize += ts.ReplicatedSize
    	st.FailedSize += ts.FailedSize
    	m.TargetsMap[opts.arn] = st
    	m.LastUpdate = UTCNow()
    	s.statusMap[opts.bucket] = m
    }
    
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Thu Jun 13 06:56:12 UTC 2024
    - 114.4K bytes
    - Viewed (0)
  4. pkg/scheduler/scheduler_test.go

    					},
    				},
    			},
    			waitSchedulingPods: []*v1.Pod{
    				st.MakePod().Name("pod1").UID("pod1").SchedulerName(testSchedulerProfile1).Obj(),
    				st.MakePod().Name("pod2").UID("pod2").SchedulerName(testSchedulerProfile1).Obj(),
    				st.MakePod().Name("pod3").UID("pod3").SchedulerName(testSchedulerProfile2).Obj(),
    				st.MakePod().Name("pod4").UID("pod4").SchedulerName(testSchedulerProfile3).Obj(),
    			},
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri May 17 09:07:27 UTC 2024
    - 42K bytes
    - Viewed (0)
  5. pkg/volume/csi/expander.go

    }
    
    func inUseError(err error) bool {
    	st, ok := status.FromError(err)
    	if !ok {
    		// not a grpc error
    		return false
    	}
    	// if this is a failed precondition error then that means driver does not support expansion
    	// of in-use volumes
    	// More info - https://github.com/container-storage-interface/spec/blob/master/spec.md#controllerexpandvolume-errors
    	return st.Code() == codes.FailedPrecondition
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jan 31 17:23:56 UTC 2024
    - 4.6K bytes
    - Viewed (0)
  6. cmd/bucket-replication-stats.go

    		case <-GlobalContext.Done():
    			return
    		}
    	}
    }
    
    func (r *ReplicationStats) updateMovingAvg() {
    	r.RLock()
    	for _, s := range r.Cache {
    		for _, st := range s.Stats {
    			st.XferRateLrg.measure.updateExponentialMovingAverage(time.Now())
    			st.XferRateSml.measure.updateExponentialMovingAverage(time.Now())
    		}
    	}
    	r.RUnlock()
    }
    
    // ActiveWorkers returns worker stats
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Thu Feb 22 06:26:06 UTC 2024
    - 13.4K bytes
    - Viewed (0)
  7. src/runtime/cgocall.go

    		if !top && !isPinned(ss.str) {
    			panic(errorString(msg))
    		}
    	case abi.Struct:
    		st := (*structtype)(unsafe.Pointer(t))
    		if !indir {
    			if len(st.Fields) != 1 {
    				throw("can't happen")
    			}
    			cgoCheckArg(st.Fields[0].Typ, p, st.Fields[0].Typ.Kind_&abi.KindDirectIface == 0, top, msg)
    			return
    		}
    		for _, f := range st.Fields {
    			if !f.Typ.Pointers() {
    				continue
    			}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu May 23 01:16:47 UTC 2024
    - 24.2K bytes
    - Viewed (0)
  8. cmd/local-locker.go

    }
    
    func (l *localLocker) stats() lockStats {
    	l.mutex.Lock()
    	defer l.mutex.Unlock()
    
    	st := lockStats{Total: len(l.lockMap)}
    	for _, v := range l.lockMap {
    		if len(v) == 0 {
    			continue
    		}
    		entry := v[0]
    		if entry.Writer {
    			st.Writes++
    		} else {
    			st.Reads += len(v)
    		}
    	}
    	return st
    }
    
    type localLockMap map[string][]lockRequesterInfo
    
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Mon Feb 19 22:54:46 UTC 2024
    - 10.6K bytes
    - Viewed (0)
  9. staging/src/k8s.io/apimachinery/pkg/util/runtime/runtime_test.go

    	start := make(chan struct{})
    	var wg sync.WaitGroup
    	for i := 0; i < 30; i++ {
    		wg.Add(1)
    		go func() {
    			<-start
    			r.OnError()
    			wg.Done()
    		}()
    	}
    	st := time.Now()
    	close(start)
    	wg.Wait()
    
    	if since := time.Since(st); since > 5*time.Second {
    		t.Errorf("OnError slept for too long: %s", since)
    	}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Mar 26 16:28:45 UTC 2024
    - 4.5K bytes
    - Viewed (0)
  10. pkg/scheduler/framework/types_test.go

    			}
    		})
    	}
    }
    
    func TestNewNodeInfo(t *testing.T) {
    	nodeName := "test-node"
    	pods := []*v1.Pod{
    		st.MakePod().UID("test-1").Namespace("node_info_cache_test").Name("test-1").Node(nodeName).
    			Containers([]v1.Container{st.MakeContainer().ResourceRequests(map[v1.ResourceName]string{
    				v1.ResourceCPU:    "100m",
    				v1.ResourceMemory: "500",
    			}).ContainerPort([]v1.ContainerPort{{
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Apr 24 18:25:29 UTC 2024
    - 45.9K bytes
    - Viewed (0)
Back to top