Search Options

Results per page
Sort
Preferred Languages
Advance

Results 31 - 40 of 57 for newConn (0.13 sec)

  1. src/internal/zstd/xxhash_test.go

    		}
    	}
    }
    
    func TestLargeXXHash(t *testing.T) {
    	if testing.Short() {
    		t.Skip("skipping expensive test in short mode")
    	}
    
    	data, err := os.ReadFile("../../testdata/Isaac.Newton-Opticks.txt")
    	if err != nil {
    		t.Fatal(err)
    	}
    
    	var xh xxhash64
    	xh.reset()
    	i := 0
    	for i < len(data) {
    		// Write varying amounts to test buffering.
    		c := i%4094 + 1
    		if i+c > len(data) {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu Nov 09 17:34:06 UTC 2023
    - 2.3K bytes
    - Viewed (0)
  2. src/internal/trace/testdata/testprog/stacks.go

    		case <-c2:
    		}
    	}()
    	var mu sync.Mutex
    	mu.Lock()
    	go func() { // func7
    		mu.Lock()
    		mu.Unlock()
    	}()
    	var wg sync.WaitGroup
    	wg.Add(1)
    	go func() { // func8
    		wg.Wait()
    	}()
    	cv := sync.NewCond(&sync.Mutex{})
    	go func() { // func9
    		cv.L.Lock()
    		cv.Wait()
    		cv.L.Unlock()
    	}()
    	ln, err := net.Listen("tcp", "127.0.0.1:0")
    	if err != nil {
    		log.Fatalf("failed to listen: %v", err)
    	}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri May 17 18:48:18 UTC 2024
    - 2.4K bytes
    - Viewed (0)
  3. staging/src/k8s.io/apiserver/pkg/util/flowcontrol/fairqueuing/testing/promise/counting.go

    	p := &countingPromise{
    		lock:          lock,
    		cond:          *sync.NewCond(lock),
    		activeCounter: activeCounter,
    		isSet:         initial != nil,
    		value:         initial,
    	}
    	if doneCh != nil {
    		activeCounter.Add(1) // count start of the following goroutine
    		go func() {
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Tue Aug 10 14:37:53 UTC 2021
    - 3.3K bytes
    - Viewed (0)
  4. src/math/cbrt.go

    	}
    
    	// new cbrt to 23 bits
    	r := t * t / x
    	s := C + r*t
    	t *= G + F/(s+E+D/s)
    
    	// chop to 22 bits, make larger than cbrt(x)
    	t = Float64frombits(Float64bits(t)&(0xFFFFFFFFC<<28) + 1<<30)
    
    	// one step newton iteration to 53 bits with error less than 0.667ulps
    	s = t * t // t*t is exact
    	r = x / s
    	w := t + t
    	r = (r - t) / (w + r) // r-s is exact
    	t = t + t*r
    
    	// restore the sign bit
    	if sign {
    		t = -t
    	}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Mon Apr 11 16:34:30 UTC 2022
    - 2.3K bytes
    - Viewed (0)
  5. src/net/http/serve_test.go

    	// our real tests. This idle connection used to block forever
    	// in the TLS handshake, preventing future connections from
    	// being accepted. It may prevent future accidental blocking
    	// in newConn.
    	idleConn, err := net.Dial("tcp", ts.Listener.Addr().String())
    	if err != nil {
    		t.Fatalf("Dial: %v", err)
    	}
    	defer idleConn.Close()
    
    	if !strings.HasPrefix(ts.URL, "https://") {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri Jun 07 17:57:01 UTC 2024
    - 202K bytes
    - Viewed (0)
  6. pkg/queue/instance.go

    		delay:       errorDelay,
    		tasks:       make([]*queueTask, 0),
    		closing:     false,
    		closed:      make(chan struct{}),
    		closeOnce:   &sync.Once{},
    		initialSync: atomic.NewBool(false),
    		cond:        sync.NewCond(&sync.Mutex{}),
    		id:          name,
    		metrics:     newQueueMetrics(name),
    	}
    }
    
    func (q *queueImpl) Push(item Task) {
    	q.cond.L.Lock()
    	defer q.cond.L.Unlock()
    	if !q.closing {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jul 21 16:30:36 UTC 2023
    - 4.1K bytes
    - Viewed (0)
  7. pilot/pkg/xds/pushqueue.go

    	shuttingDown bool
    }
    
    func NewPushQueue() *PushQueue {
    	return &PushQueue{
    		pending:    make(map[*Connection]*model.PushRequest),
    		processing: make(map[*Connection]*model.PushRequest),
    		cond:       sync.NewCond(&sync.Mutex{}),
    	}
    }
    
    // Enqueue will mark a proxy as pending a push. If it is already pending, pushInfo will be merged.
    // ServiceEntry updates will be added together, and full will be set if either were full
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Sep 16 01:37:15 UTC 2021
    - 3.8K bytes
    - Viewed (0)
  8. src/context/example_test.go

    		for !conditionMet() {
    			cond.Wait()
    			if ctx.Err() != nil {
    				return ctx.Err()
    			}
    		}
    
    		return nil
    	}
    
    	cond := sync.NewCond(new(sync.Mutex))
    
    	var wg sync.WaitGroup
    	for i := 0; i < 4; i++ {
    		wg.Add(1)
    		go func() {
    			defer wg.Done()
    
    			ctx, cancel := context.WithTimeout(context.Background(), 1*time.Millisecond)
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Mon Aug 21 20:24:28 UTC 2023
    - 6.7K bytes
    - Viewed (0)
  9. internal/ringbuffer/ring_buffer.go

    // This setting should be called before any Read or Write operation or after a Reset.
    func (r *RingBuffer) SetBlocking(block bool) *RingBuffer {
    	r.block = block
    	if block {
    		r.readCond = sync.NewCond(&r.mu)
    		r.writeCond = sync.NewCond(&r.mu)
    	}
    	return r
    }
    
    // WithCancel sets a context to cancel the ring buffer.
    // When the context is canceled, the ring buffer will be closed with the context error.
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Wed May 15 00:11:04 UTC 2024
    - 13.3K bytes
    - Viewed (0)
  10. src/compress/flate/deflate_test.go

    	{
    		"../testdata/e.txt",
    		"2.718281828...",
    		[...]int{100018, 50650, 50960, 51150, 50930, 50790, 50790, 50790, 50790, 50790, 43683},
    	},
    	{
    		"../../testdata/Isaac.Newton-Opticks.txt",
    		"Isaac.Newton-Opticks",
    		[...]int{567248, 218338, 198211, 193152, 181100, 175427, 175427, 173597, 173422, 173422, 325240},
    	},
    }
    
    func TestDeflateInflateString(t *testing.T) {
    	t.Parallel()
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed Jun 14 00:03:57 UTC 2023
    - 25.6K bytes
    - Viewed (0)
Back to top