Search Options

Results per page
Sort
Preferred Languages
Advance

Results 11 - 20 of 3,642 for ctan (0.11 sec)

  1. 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)
  2. 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)
  3. internal/bpool/bpool.go

    package bpool
    
    import "github.com/klauspost/reedsolomon"
    
    // BytePoolCap implements a leaky pool of []byte in the form of a bounded channel.
    type BytePoolCap struct {
    	c    chan []byte
    	w    int
    	wcap int
    }
    
    // NewBytePoolCap creates a new BytePool bounded to the given maxSize, with new
    // byte arrays sized based on width.
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri Apr 19 16:44:59 UTC 2024
    - 2.6K bytes
    - Viewed (0)
  4. src/cmd/compile/internal/types2/api_test.go

    		},
    		{`package t3; type C[T any] interface{chan<- T}; func f[T any, P C[T], Q C[[]*P]]() []T { return nil }; func _() { _ = f[int] }`,
    			[]testInst{
    				{`C`, []string{`T`}, `interface{chan<- T}`},
    				{`C`, []string{`[]*P`}, `interface{chan<- []*P}`},
    				{`f`, []string{`int`, `chan<- int`, `chan<- []*chan<- int`}, `func() []int`},
    			},
    		},
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue May 07 20:08:23 UTC 2024
    - 93.3K bytes
    - Viewed (0)
  5. pilot/pkg/serviceregistry/kube/controller/fake.go

    	MeshWatcher       mesh.Watcher
    	ServiceHandler    model.ServiceHandler
    	ClusterID         cluster.ID
    	WatchedNamespaces string
    	DomainSuffix      string
    	XDSUpdater        model.XDSUpdater
    	Stop              chan struct{}
    	SkipRun           bool
    	ConfigCluster     bool
    	SystemNamespace   string
    }
    
    type FakeController struct {
    	*Controller
    	Endpoints *model.EndpointIndex
    }
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu May 23 21:07:03 UTC 2024
    - 4K bytes
    - Viewed (0)
  6. internal/grid/benchmark_test.go

    		// Register a single handler which echos the payload.
    		errFatal(remote.RegisterStreamingHandler(handlerTest, StreamHandler{
    			// Send 10x response.
    			Handle: func(ctx context.Context, payload []byte, _ <-chan []byte, out chan<- []byte) *RemoteErr {
    				for i := 0; i < responses; i++ {
    					toSend := GetByteBuffer()[:0]
    					toSend = append(toSend, byte(i))
    					toSend = append(toSend, payload...)
    					select {
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri Jun 07 15:51:52 UTC 2024
    - 15.7K bytes
    - Viewed (0)
  7. pkg/controller/tainteviction/taint_eviction.go

    		tc.nodeUpdateChannels = append(tc.nodeUpdateChannels, make(chan nodeUpdateItem, NodeUpdateChannelSize))
    		tc.podUpdateChannels = append(tc.podUpdateChannels, make(chan podUpdateItem, podUpdateChannelSize))
    	}
    
    	// Functions that are responsible for taking work items out of the workqueues and putting them
    	// into channels.
    	go func(stopCh <-chan struct{}) {
    		for {
    			nodeUpdate, shutdown := tc.nodeUpdateQueue.Get()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 19.9K bytes
    - Viewed (0)
  8. pkg/kube/krt/helpers.go

    func keyFunc(name, namespace string) string {
    	if len(namespace) == 0 {
    		return name
    	}
    	return namespace + "/" + name
    }
    
    func waitForCacheSync(name string, stop <-chan struct{}, collections ...<-chan struct{}) (r bool) {
    	t := time.NewTicker(time.Second * 5)
    	defer t.Stop()
    	t0 := time.Now()
    	defer func() {
    		if r {
    			log.WithLabels("name", name, "time", time.Since(t0)).Debugf("sync complete")
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri May 10 23:33:56 UTC 2024
    - 3.4K bytes
    - Viewed (0)
  9. pilot/pkg/trustbundle/trustbundle.go

    	sourceConfig       map[Source]TrustAnchorConfig
    	mutex              sync.RWMutex
    	mergedCerts        []string
    	updatecb           func()
    	endpointMutex      sync.RWMutex
    	endpoints          []string
    	endpointUpdateChan chan struct{}
    	remoteCaCertPool   *x509.CertPool
    	meshConfig         mesh.Watcher
    }
    
    var (
    	trustBundleLog = log.RegisterScope("trustBundle", "Workload mTLS trust bundle logs")
    	remoteTimeout  = 10 * time.Second
    )
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu May 23 21:07:03 UTC 2024
    - 7.8K bytes
    - Viewed (0)
  10. src/reflect/iter.go

    // If v's kind is Pointer, the pointer element type must have kind Array.
    // Otherwise v's kind must be Int, Int8, Int16, Int32, Int64,
    // Uint, Uint8, Uint16, Uint32, Uint64, Uintptr,
    // Array, Chan, Map, Slice, or String.
    func (v Value) Seq() iter.Seq[Value] {
    	if canRangeFunc(v.typ()) {
    		return func(yield func(Value) bool) {
    			rf := MakeFunc(v.Type().In(0), func(in []Value) []Value {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed May 22 13:40:11 UTC 2024
    - 3.9K bytes
    - Viewed (0)
Back to top