Search Options

Results per page
Sort
Preferred Languages
Advance

Results 41 - 50 of about 10,000 for ctan (0.22 sec)

  1. src/net/net_fake.go

    type packetQueue struct {
    	empty chan packetQueueState // contains configuration parameters when the queue is empty and not closed
    	ready chan packetQueueState // contains the packets when non-empty or closed
    	full  chan packetQueueState // contains the packets when buffer is full and not closed
    }
    
    func newPacketQueue(readBufferBytes int) *packetQueue {
    	pq := &packetQueue{
    		empty: make(chan packetQueueState, 1),
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue Feb 27 19:24:21 UTC 2024
    - 26.4K bytes
    - Viewed (0)
  2. cni/cmd/install-cni/main.go

    	"istio.io/istio/pkg/log"
    )
    
    func main() {
    	// Create context that cancels on termination signal
    	ctx, cancel := context.WithCancel(context.Background())
    	sigChan := make(chan os.Signal, 1)
    	signal.Notify(sigChan, os.Interrupt, syscall.SIGTERM)
    	go func(sigChan chan os.Signal, cancel context.CancelFunc) {
    		sig := <-sigChan
    		log.Infof("Exit signal received: %s", sig)
    		cancel()
    	}(sigChan, cancel)
    
    	rootCmd := cmd.GetCommand()
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Tue May 23 17:08:31 UTC 2023
    - 1.2K bytes
    - Viewed (0)
  3. src/cmd/compile/internal/typecheck/_builtin/runtime.go

    // *byte is really *runtime.Type
    func makechan64(chanType *byte, size int64) (hchan chan any)
    func makechan(chanType *byte, size int) (hchan chan any)
    func chanrecv1(hchan <-chan any, elem *any)
    func chanrecv2(hchan <-chan any, elem *any) bool
    func chansend1(hchan chan<- any, elem *any)
    func closechan(hchan chan<- any)
    func chanlen(hchan any) int
    func chancap(hchan any) int
    
    var writeBarrier struct {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue May 21 21:08:03 UTC 2024
    - 10.6K bytes
    - Viewed (0)
  4. src/cmd/go/internal/script/conds.go

    func (c *cachedCond) Usage() *CondUsage { return &c.usage }
    
    func (c *cachedCond) Eval(_ *State, suffix string) (bool, error) {
    	for {
    		var ready chan struct{}
    
    		v, loaded := c.m.Load(suffix)
    		if !loaded {
    			ready = make(chan struct{})
    			v, loaded = c.m.LoadOrStore(suffix, (<-chan struct{})(ready))
    
    			if !loaded {
    				inPanic := true
    				defer func() {
    					if inPanic {
    						c.m.Delete(suffix)
    					}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Mon Oct 24 21:26:10 UTC 2022
    - 5K bytes
    - Viewed (0)
  5. pkg/kubelet/pleg/evented.go

    	eventedPlegMaxStreamRetries int
    	// Indicates relisting related parameters
    	relistDuration *RelistDuration
    	// Stop the Evented PLEG by closing the channel.
    	stopCh chan struct{}
    	// Stops the periodic update of the cache global timestamp.
    	stopCacheUpdateCh chan struct{}
    	// Locks the start/stop operation of the Evented PLEG.
    	runningMu sync.Mutex
    }
    
    // NewEventedPLEG instantiates a new EventedPLEG object and return it.
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Thu Mar 07 10:46:06 UTC 2024
    - 16.4K bytes
    - Viewed (0)
  6. src/internal/types/testdata/spec/comparisons.go

    	_ = b == b
    	_ = a /* ERROR "[10]func() cannot be compared" */ == a
    	_ = l /* ERROR "slice can only be compared to nil" */ == l
    	_ = s /* ERROR "struct containing []byte cannot be compared" */ == s
    	_ = p == p
    	_ = f /* ERROR "func can only be compared to nil" */ == f
    	_ = i == i
    	_ = m /* ERROR "map can only be compared to nil" */ == m
    	_ = c == c
    
    	_ = b == nil /* ERROR "mismatched types" */
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue Jan 17 19:54:27 UTC 2023
    - 3K bytes
    - Viewed (0)
  7. internal/grid/stream.go

    	// All responses *must* be read by the caller until either an error is returned or the channel is closed.
    	// Canceling the context will cause the context cancellation error to be returned.
    	responses <-chan Response
    	cancel    context.CancelCauseFunc
    
    	// Requests sent to the server.
    	// If the handler is defined with 0 incoming capacity this will be nil.
    	// Channel *must* be closed to signal the end of the stream.
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri Jun 07 15:51:52 UTC 2024
    - 3.1K bytes
    - Viewed (0)
  8. src/net/net_test.go

    // See golang.org/cl/30164 which documented this. The net/http package
    // depends on this.
    func TestReadTimeoutUnblocksRead(t *testing.T) {
    	serverDone := make(chan struct{})
    	server := func(cs *TCPConn) error {
    		defer close(serverDone)
    		errc := make(chan error, 1)
    		go func() {
    			defer close(errc)
    			go func() {
    				// TODO: find a better way to wait
    				// until we're blocked in the cs.Read
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Mon Jan 22 21:04:44 UTC 2024
    - 13.3K bytes
    - Viewed (0)
  9. pkg/test/echo/server/forwarder/executor.go

    	activeRequests *atomic.Uint64
    	stopCh         chan struct{}
    }
    
    func newExecutor() *executor {
    	e := &executor{
    		totalRequests:  atomic.NewUint64(0),
    		activeRequests: atomic.NewUint64(0),
    		stopCh:         make(chan struct{}),
    	}
    
    	return e
    }
    
    func (e *executor) ActiveRequests() uint64 {
    	return e.activeRequests.Load()
    }
    
    // NewGroup creates a new group of tasks that can be managed collectively.
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Tue May 10 18:09:08 UTC 2022
    - 2K bytes
    - Viewed (0)
  10. src/net/mptcpsock_linux_test.go

    	defer ls.teardown()
    
    	if g, w := ls.Listener.Addr().Network(), "tcp"; g != w {
    		t.Fatalf("Network type mismatch: got %q, want %q", g, w)
    	}
    
    	genericCh := make(chan error)
    	mptcpCh := make(chan error)
    	handler := func(ls *localServer, ln Listener) {
    		ls.transponder(ln, genericCh)
    		postAcceptMPTCP(ls, mptcpCh)
    	}
    	if err := ls.buildup(handler); err != nil {
    		t.Fatal(err)
    	}
    
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue Jul 11 00:36:57 UTC 2023
    - 4.1K bytes
    - Viewed (0)
Back to top