Search Options

Results per page
Sort
Preferred Languages
Advance

Results 51 - 60 of about 10,000 for ctan (0.14 sec)

  1. src/cmd/go/testdata/script/test_chatty_parallel_success.txt

    	parallel := flag.Lookup("test.parallel").Value.(flag.Getter).Get().(int)
    
    	// ready is a synchronization mechanism that causes subtests to execute
    	// round robin.
    	ready := make([]chan bool, parallel)
    	for i := range ready {
    		ready[i] = make(chan bool, 1)
    	}
    	ready[0] <- true
    
    	for i := range ready {
    		i := i
    		t.Run(fmt.Sprintf("sub-%d", i), func(t *testing.T) {
    			t.Parallel()
    			for j := 0; j < 2; j++ {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed Oct 26 19:50:36 UTC 2022
    - 1.9K bytes
    - Viewed (0)
  2. src/context/context.go

    		return c
    	}
    	return value(c.Context, key)
    }
    
    func (c *cancelCtx) Done() <-chan struct{} {
    	d := c.done.Load()
    	if d != nil {
    		return d.(chan struct{})
    	}
    	c.mu.Lock()
    	defer c.mu.Unlock()
    	d = c.done.Load()
    	if d == nil {
    		d = make(chan struct{})
    		c.done.Store(d)
    	}
    	return d.(chan struct{})
    }
    
    func (c *cancelCtx) Err() error {
    	c.mu.Lock()
    	err := c.err
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue Mar 26 19:58:28 UTC 2024
    - 23.7K bytes
    - Viewed (0)
  3. src/cmd/compile/internal/types2/typestring.go

    		w.typ(t.key)
    		w.byte(']')
    		w.typ(t.elem)
    
    	case *Chan:
    		var s string
    		var parens bool
    		switch t.dir {
    		case SendRecv:
    			s = "chan "
    			// chan (<-chan T) requires parentheses
    			if c, _ := t.elem.(*Chan); c != nil && c.dir == RecvOnly {
    				parens = true
    			}
    		case SendOnly:
    			s = "chan<- "
    		case RecvOnly:
    			s = "<-chan "
    		default:
    			w.error("unknown channel direction")
    		}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu May 23 03:01:18 UTC 2024
    - 12.2K bytes
    - Viewed (0)
  4. staging/src/k8s.io/apiserver/pkg/server/filters/goaway_test.go

    	urls := make(chan string, requestCount)
    	for i := 0; i < requestCount; i++ {
    		index := rand.Intn(len(urlsForTest))
    		url := urlsForTest[index]
    
    		if url == urlWatch || url == urlWatchWithGoaway {
    			expectWatchers++
    		}
    
    		urls <- url
    	}
    	close(urls)
    
    	wg := &sync.WaitGroup{}
    	wg.Add(workers)
    
    	watchers := make(chan (<-chan watchResponse), expectWatchers)
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Nov 17 12:58:54 UTC 2021
    - 13.9K bytes
    - Viewed (0)
  5. src/net/http/serve_test.go

    	}
    
    	readErrCh := make(chan error, 1)
    	errCh := make(chan error, 2)
    
    	server := newClientServerTest(t, mode, HandlerFunc(func(rw ResponseWriter, req *Request) {
    		go func(body io.Reader) {
    			_, err := body.Read(make([]byte, 100))
    			readErrCh <- err
    		}(req.Body)
    		time.Sleep(500 * time.Millisecond)
    	})).ts
    
    	closeConn := make(chan bool)
    	defer close(closeConn)
    	go func() {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri Jun 07 17:57:01 UTC 2024
    - 202K bytes
    - Viewed (0)
  6. cmd/notification.go

    			}
    			consolidatedReport.BucketStats[opts] = d
    		}
    	}
    	return consolidatedReport
    }
    
    func (sys *NotificationSys) collectPeerMetrics(ctx context.Context, peerChannels []<-chan MetricV2, g *errgroup.Group) <-chan MetricV2 {
    	ch := make(chan MetricV2)
    	var wg sync.WaitGroup
    	for index, err := range g.Wait() {
    		if err != nil {
    			if sys.peerClients[index] != nil {
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri May 24 23:05:23 UTC 2024
    - 44.9K bytes
    - Viewed (0)
  7. src/runtime/testdata/testprogcgo/lockosthread.go

    func LockOSThreadAlt() {
    	// This is running locked to the main OS thread.
    
    	var subThread C.pthread_t
    	ready := make(chan bool, 1)
    	C.threadExited = 0
    	go func() {
    		// This goroutine must be running on a new thread.
    		runtime.LockOSThread()
    		subThread = C.pthread_self()
    		// Register a pthread destructor so we can tell this
    		// thread has exited.
    		var key C.pthread_key_t
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu Feb 02 20:21:33 UTC 2023
    - 2.5K bytes
    - Viewed (0)
  8. staging/src/k8s.io/apiserver/pkg/server/healthz_test.go

    )
    
    func TestDelayedHealthCheck(t *testing.T) {
    	t.Run("test that liveness check returns true until the delay has elapsed", func(t *testing.T) {
    		t0 := time.Unix(0, 0)
    		c := testingclock.NewFakeClock(t0)
    		doneCh := make(chan struct{})
    
    		healthCheck := delayedHealthCheck(postStartHookHealthz{"test", doneCh}, c, time.Duration(10)*time.Second)
    		err := healthCheck.Check(nil)
    		if err != nil {
    			t.Errorf("Got %v, expected no error", err)
    		}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Sep 15 09:52:18 UTC 2021
    - 2.2K bytes
    - Viewed (0)
  9. pkg/kubelet/cm/devicemanager/plugin/v1beta1/stub.go

    	devs                       []*pluginapi.Device
    	socket                     string
    	resourceName               string
    	preStartContainerFlag      bool
    	getPreferredAllocationFlag bool
    
    	stop   chan interface{}
    	wg     sync.WaitGroup
    	update chan []*pluginapi.Device
    
    	server *grpc.Server
    
    	// allocFunc is used for handling allocation request
    	allocFunc stubAllocFunc
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Oct 17 11:19:10 UTC 2023
    - 11.5K bytes
    - Viewed (0)
  10. pkg/istio-agent/xds_proxy_delta.go

    		upstreamError:     make(chan error), // can be produced by recv and send
    		downstreamError:   make(chan error), // can be produced by recv and send
    		deltaRequestsChan: channels.NewUnbounded[*discovery.DeltaDiscoveryRequest](),
    		// Allow a buffer of 1. This ensures we queue up at most 2 (one in process, 1 pending) responses before forwarding.
    		deltaResponsesChan: make(chan *discovery.DeltaDiscoveryResponse, 1),
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Apr 04 20:29:08 UTC 2024
    - 11.7K bytes
    - Viewed (0)
Back to top