Search Options

Results per page
Sort
Preferred Languages
Advance

Results 41 - 50 of 896 for chan2 (0.04 sec)

  1. pkg/kubelet/kuberuntime/kuberuntime_termination_order.go

    	to := &terminationOrdering{
    		prereqs:    map[string][]chan struct{}{},
    		terminated: map[string]chan struct{}{},
    	}
    
    	runningContainers := map[string]struct{}{}
    	for _, name := range runningContainerNames {
    		runningContainers[name] = struct{}{}
    	}
    
    	var mainContainerChannels []chan struct{}
    	// sidecar containers need to wait on main containers, so we create a channel per main container
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Oct 18 00:07:21 UTC 2023
    - 3.8K bytes
    - Viewed (0)
  2. src/runtime/rwmutex_test.go

    )
    
    func parallelReader(m *RWMutex, clocked chan bool, cunlock *atomic.Bool, cdone chan bool) {
    	m.RLock()
    	clocked <- true
    	for !cunlock.Load() {
    	}
    	m.RUnlock()
    	cdone <- true
    }
    
    func doTestParallelReaders(numReaders int) {
    	GOMAXPROCS(numReaders + 1)
    	var m RWMutex
    	m.Init()
    	clocked := make(chan bool, numReaders)
    	var cunlock atomic.Bool
    	cdone := make(chan bool)
    	for i := 0; i < numReaders; i++ {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri Dec 15 22:00:45 UTC 2023
    - 4.2K bytes
    - Viewed (0)
  3. pkg/kube/portforwarder.go

    	ErrChan() <-chan error
    
    	// WaitForStop blocks until connection closed (e.g. control-C interrupt)
    	WaitForStop()
    }
    
    var _ PortForwarder = &forwarder{}
    
    type forwarder struct {
    	stopCh       chan struct{}
    	restConfig   *rest.Config
    	podName      string
    	ns           string
    	localAddress string
    	localPort    int
    	podPort      int
    	errCh        chan error
    }
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Mon Aug 14 02:12:37 UTC 2023
    - 5.5K bytes
    - Viewed (0)
  4. internal/grid/grid_test.go

    	remoteHost := remote.HostName()
    
    	// 1: Echo
    	serverSent := make(chan struct{})
    	serverCanceled := make(chan struct{})
    	register := func(manager *Manager) {
    		errFatal(manager.RegisterStreamingHandler(handlerTest, StreamHandler{
    			Handle: func(ctx context.Context, payload []byte, _ <-chan []byte, resp chan<- []byte) *RemoteErr {
    				// Send many responses.
    				// Test that this doesn't block.
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri Jun 07 15:51:52 UTC 2024
    - 36.4K bytes
    - Viewed (0)
  5. pkg/kubelet/metrics/collectors/resource_metrics.go

    	if s.Memory == nil || s.Memory.WorkingSetBytes == nil {
    		return
    	}
    
    	ch <- metrics.NewLazyMetricWithTimestamp(s.Memory.Time.Time,
    		metrics.NewLazyConstMetric(nodeMemoryUsageDesc, metrics.GaugeValue, float64(*s.Memory.WorkingSetBytes)))
    }
    
    func (rc *resourceMetricsCollector) collectNodeSwapMetrics(ch chan<- metrics.Metric, s summary.NodeStats) {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Sep 08 07:13:37 UTC 2023
    - 9.2K bytes
    - Viewed (1)
  6. pilot/pkg/bootstrap/configcontroller.go

    		s.addTerminatingStartFunc("ingress status", func(stop <-chan struct{}) error {
    			leaderelection.
    				NewLeaderElection(args.Namespace, args.PodName, leaderelection.IngressController, args.Revision, s.kubeClient).
    				AddRunFunction(func(leaderStop <-chan struct{}) {
    					ingressSyncer := ingress.NewStatusSyncer(s.environment.Watcher, s.kubeClient)
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Wed Feb 28 16:41:38 UTC 2024
    - 14.1K bytes
    - Viewed (0)
  7. pkg/kube/kclient/crdwatcher.go

    	callbacks map[string][]func()
    
    	running chan struct{}
    	stop    <-chan struct{}
    }
    
    func init() {
    	// Unfortunate hack needed to avoid circular imports
    	kube.NewCrdWatcher = newCrdWatcher
    }
    
    // newCrdWatcher returns a new CRD watcher controller.
    func newCrdWatcher(client kube.Client) kubetypes.CrdWatcher {
    	c := &crdWatcher{
    		running:   make(chan struct{}),
    		callbacks: map[string][]func(){},
    	}
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Apr 25 14:44:17 UTC 2024
    - 5.7K bytes
    - Viewed (0)
  8. pkg/kubelet/config/mux.go

    	merger merger
    
    	// Sources and their lock.
    	sourceLock sync.RWMutex
    	// Maps source names to channels
    	sources map[string]chan interface{}
    }
    
    // newMux creates a new mux that can merge changes from multiple sources.
    func newMux(merger merger) *mux {
    	mux := &mux{
    		sources: make(map[string]chan interface{}),
    		merger:  merger,
    	}
    	return mux
    }
    
    // ChannelWithContext returns a channel where a configuration source
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Jan 30 20:02:23 UTC 2024
    - 2.3K bytes
    - Viewed (0)
  9. src/internal/types/testdata/check/decls0.go

    		I8
    	}
    	I9 /* ERROR "invalid recursive type" */ interface {
    		I10
    	}
    	I10 interface {
    		I11
    	}
    	I11 interface {
    		I9
    	}
    
    	C1 chan int
    	C2 <-chan int
    	C3 chan<- C3
    	C4 chan C5
    	C5 chan C6
    	C6 chan C4
    
    	M1 map[Last]string
    	M2 map[string]M2
    
    	Last int
    )
    
    // cycles in function/method declarations
    // (test cases for issues #5217, #25790 and variants)
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu May 30 19:19:55 UTC 2024
    - 4.1K bytes
    - Viewed (0)
  10. src/io/pipe_test.go

    	"testing"
    	"time"
    )
    
    func checkWrite(t *testing.T, w Writer, data []byte, c chan int) {
    	n, err := w.Write(data)
    	if err != nil {
    		t.Errorf("write: %v", err)
    	}
    	if n != len(data) {
    		t.Errorf("short write: %d != %d", n, len(data))
    	}
    	c <- 0
    }
    
    // Test a single read/write pair.
    func TestPipe1(t *testing.T) {
    	c := make(chan int)
    	r, w := Pipe()
    	var buf = make([]byte, 64)
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu May 23 01:00:11 UTC 2024
    - 9K bytes
    - Viewed (0)
Back to top