Search Options

Results per page
Sort
Preferred Languages
Advance

Results 21 - 30 of 237 for errchk (0.23 sec)

  1. pkg/config/mesh/kubemesh/watcher_test.go

    		errCh := make(chan error, 2)
    		for i := 0; i < 100; i++ {
    			t.Log("iter", i)
    			write := fmt.Sprint(i)
    			wg := sync.WaitGroup{}
    			wg.Add(2)
    			go func() {
    				defer wg.Done()
    				if _, err := cms.Update(context.Background(), mkMap(extraCmName, write), metav1.UpdateOptions{}); err != nil {
    					errCh <- err
    				}
    			}()
    			go func() {
    				defer wg.Done()
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Tue Oct 31 14:48:28 UTC 2023
    - 7.7K bytes
    - Viewed (0)
  2. cni/pkg/util/pluginutil.go

    	watcher, err := fsnotify.NewWatcher()
    	if err != nil {
    		return nil, fmt.Errorf("watcher create: %v", err)
    	}
    
    	fileModified, errChan := make(chan struct{}), make(chan error)
    	go watchFiles(watcher, fileModified, errChan)
    
    	for _, path := range paths {
    		if !file.Exists(path) {
    			log.Infof("file watcher skipping watch on non-existent path: %v", path)
    			continue
    		}
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jan 26 20:34:28 UTC 2024
    - 3.6K bytes
    - Viewed (0)
  3. cmd/kube-proxy/app/server.go

    	if ent.Has(fsnotify.Write) || ent.Has(fsnotify.Rename) {
    		// error out when ConfigFile is updated
    		o.errCh <- fmt.Errorf("content of the proxy server's configuration file was updated")
    		return
    	}
    	o.errCh <- nil
    }
    
    func (o *Options) errorHandler(err error) {
    	o.errCh <- err
    }
    
    // processHostnameOverrideFlag processes hostname-override flag
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Fri Apr 26 13:27:41 UTC 2024
    - 46.8K bytes
    - Viewed (0)
  4. cni/pkg/install/install_test.go

    			// Should detect a valid configuration and wait indefinitely for a file modification
    			errChan := make(chan error)
    			go func(ctx context.Context) {
    				errChan <- in.sleepWatchInstall(ctx, sets.String{})
    			}(ctx)
    
    			select {
    			case <-readyChan:
    				assert.Equal(t, isReady.Load(), true)
    			case err := <-errChan:
    				if err == nil {
    					t.Fatal("invalid configuration detected")
    				}
    				t.Fatal(err)
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jan 26 20:34:28 UTC 2024
    - 11.1K bytes
    - Viewed (0)
  5. src/net/http/socks_bundle.go

    	}
    	if ctx != context.Background() {
    		errCh := make(chan error, 1)
    		done := make(chan struct{})
    		defer func() {
    			close(done)
    			if ctxErr == nil {
    				ctxErr = <-errCh
    			}
    		}()
    		go func() {
    			select {
    			case <-ctx.Done():
    				c.SetDeadline(socksaLongTimeAgo)
    				errCh <- ctx.Err()
    			case <-done:
    				errCh <- nil
    			}
    		}()
    	}
    
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue Apr 11 22:42:18 UTC 2023
    - 12.9K bytes
    - Viewed (0)
  6. cni/pkg/nodeagent/ztunnelserver_test.go

    	ztunnelServer := fixture.ztunServer
    	errChan := make(chan error)
    	go func() {
    		errChan <- ztunnelServer.PodDeleted(ctx, uid)
    	}()
    	// read the msg to delete from ztunnel
    	m, fds = readRequest(t, ztunClient)
    	assert.Equal(t, len(fds), 0)
    	assert.Equal(t, m.Payload.(*zdsapi.WorkloadRequest_Del).Del.Uid, uid)
    	sendAck(ztunClient)
    
    	assert.NoError(t, <-errChan)
    
    	ztunClient.Close()
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Apr 12 21:47:31 UTC 2024
    - 8.6K bytes
    - Viewed (0)
  7. pilot/pkg/xds/discovery_test.go

    			pushingCh := make(chan struct{}, 1)
    			errCh := make(chan error, 1)
    
    			var partialPushes int32
    			var fullPushes int32
    
    			wg := sync.WaitGroup{}
    
    			fakePush := func(req *model.PushRequest) {
    				if req.Full {
    					select {
    					case pushingCh <- struct{}{}:
    					default:
    						errCh <- fmt.Errorf("multiple pushes happen simultaneously")
    						return
    					}
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Tue Apr 30 00:26:45 UTC 2024
    - 9.2K bytes
    - Viewed (0)
  8. pkg/controller/replicaset/replica_set.go

    		errCh := make(chan error, batchSize)
    		var wg sync.WaitGroup
    		wg.Add(batchSize)
    		for i := 0; i < batchSize; i++ {
    			go func() {
    				defer wg.Done()
    				if err := fn(); err != nil {
    					errCh <- err
    				}
    			}()
    		}
    		wg.Wait()
    		curSuccesses := batchSize - len(errCh)
    		successes += curSuccesses
    		if len(errCh) > 0 {
    			return successes, <-errCh
    		}
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 33.2K bytes
    - Viewed (0)
  9. cni/pkg/install/cniconfig_test.go

    			defer cancel()
    			resultChan, errChan := make(chan string, 1), make(chan error, 1)
    			go func(resultChan chan string, errChan chan error, ctx context.Context, cniConfName, mountedCNINetDir string, chained bool) {
    				result, err := getCNIConfigFilepath(ctx, cniConfName, mountedCNINetDir, chained)
    				if err != nil {
    					errChan <- err
    					return
    				}
    				resultChan <- result
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Tue May 21 18:32:01 UTC 2024
    - 15.4K bytes
    - Viewed (0)
  10. internal/s3select/message.go

    	getProgressFunc func() (int64, int64)
    	bytesReturned   int64
    
    	payloadBuffer      []byte
    	payloadBufferIndex int
    	payloadCh          chan *bytes.Buffer
    
    	finBytesScanned, finBytesProcessed int64
    
    	errCh  chan []byte
    	doneCh chan struct{}
    }
    
    func (writer *messageWriter) write(data []byte) bool {
    	if _, err := writer.writer.Write(data); err != nil {
    		return false
    	}
    
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Tue Aug 30 15:26:43 UTC 2022
    - 15.2K bytes
    - Viewed (0)
Back to top