Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 59 for chan2 (0.27 sec)

  1. staging/src/k8s.io/apimachinery/pkg/watch/watch.go

    // ResultChan implements Interface
    func (w emptyWatch) ResultChan() <-chan Event {
    	return chan Event(w)
    }
    
    // FakeWatcher lets you test anything that consumes a watch.Interface; threadsafe.
    type FakeWatcher struct {
    	result  chan Event
    	stopped bool
    	sync.Mutex
    }
    
    func NewFake() *FakeWatcher {
    	return &FakeWatcher{
    		result: make(chan Event),
    	}
    }
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 20:06:22 UTC 2024
    - 8.1K bytes
    - Viewed (1)
  2. internal/grid/handlers.go

    func (h *StreamTypeHandler[Payload, Req, Resp]) RegisterNoPayload(m *Manager, handle func(ctx context.Context, in <-chan Req, out chan<- Resp) *RemoteErr, subroute ...string) error {
    	h.WithPayload = false
    	return h.register(m, func(ctx context.Context, p Payload, in <-chan Req, out chan<- Resp) *RemoteErr {
    		return handle(ctx, in, out)
    	}, subroute...)
    }
    
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Mon Jun 10 15:51:27 UTC 2024
    - 27.1K bytes
    - Viewed (0)
  3. src/time/tick_test.go

    	done := make(chan bool)
    	AfterFunc(60*Second, func() { close(done) })
    
    	// Set up a queuing goroutine to ping pong through the scheduler.
    	inQ := make(chan func())
    	outQ := make(chan func())
    
    	defer close(inQ)
    
    	wg.Add(1)
    	go func() {
    		defer wg.Done()
    		defer close(outQ)
    		var q []func()
    		for {
    			var sendTo chan func()
    			var send func()
    			if len(q) > 0 {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue Jun 11 17:10:37 UTC 2024
    - 14.7K bytes
    - Viewed (0)
  4. pilot/pkg/bootstrap/certcontroller.go

    		if err := s.fileWatcher.Add(file); err != nil {
    			return fmt.Errorf("could not watch %v: %v", file, err)
    		}
    	}
    	s.addStartFunc("certificate rotation", func(stop <-chan struct{}) error {
    		go func() {
    			var keyCertTimerC <-chan time.Time
    			for {
    				select {
    				case <-keyCertTimerC:
    					keyCertTimerC = nil
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Jun 13 17:48:28 UTC 2024
    - 11.3K bytes
    - Viewed (0)
  5. pkg/revisions/tag_watcher.go

    	"istio.io/istio/pkg/kube/kubetypes"
    	"istio.io/istio/pkg/util/sets"
    )
    
    // TagWatcher keeps track of the current tags and can notify watchers
    // when the tags change.
    type TagWatcher interface {
    	Run(stopCh <-chan struct{})
    	HasSynced() bool
    	AddHandler(handler TagHandler)
    	GetMyTags() sets.String
    }
    
    // TagHandler is a callback for when the tags revision change.
    type TagHandler func(sets.String)
    
    type tagWatcher struct {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jun 14 00:12:28 UTC 2024
    - 3.3K bytes
    - Viewed (0)
  6. pilot/pkg/bootstrap/server.go

    	log.Infof("starting discovery service")
    	// Implement EnvoyXdsServer grace shutdown
    	s.addStartFunc("xds server", func(stop <-chan struct{}) error {
    		log.Infof("Starting ADS server")
    		s.XDSServer.Start(stop)
    		return nil
    	})
    }
    
    // Wait for the stop, and do cleanups
    func (s *Server) waitForShutdown(stop <-chan struct{}) {
    	go func() {
    		<-stop
    		close(s.internalStop)
    		_ = s.fileWatcher.Close()
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Jun 13 17:48:28 UTC 2024
    - 46.3K bytes
    - Viewed (0)
  7. cmd/handler-api.go

    	"github.com/minio/minio/internal/logger"
    	"github.com/minio/minio/internal/mcontext"
    )
    
    type apiConfig struct {
    	mu sync.RWMutex
    
    	requestsDeadline      time.Duration
    	requestsPool          chan struct{}
    	clusterDeadline       time.Duration
    	listQuorum            string
    	corsAllowOrigins      []string
    	replicationPriority   string
    	replicationMaxWorkers int
    	transitionWorkers     int
    
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Wed Jun 12 08:13:12 UTC 2024
    - 10.4K bytes
    - Viewed (0)
  8. pilot/pkg/bootstrap/server_test.go

    				p.ShutdownDuration = 1 * time.Millisecond
    			})
    			g := NewWithT(t)
    			s, err := NewServer(args, func(s *Server) {
    				s.kubeClient = kube.NewFakeClient()
    			})
    			g.Expect(err).To(Succeed())
    			stop := make(chan struct{})
    			g.Expect(s.Start(stop)).To(Succeed())
    			defer func() {
    				close(stop)
    				s.WaitUntilCompletion()
    			}()
    
    			if c.expNewCert {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Jun 13 17:48:28 UTC 2024
    - 23.1K bytes
    - Viewed (0)
  9. cmd/bucket-lifecycle.go

    	es := &expiryState{
    		ctx:    ctx,
    		objAPI: objAPI,
    	}
    	workers := make([]chan expiryOp, 0, n)
    	es.workers.Store(&workers)
    	es.ResizeWorkers(n)
    	return es
    }
    
    func (es *expiryState) getWorkerCh(h uint64) chan<- expiryOp {
    	w := es.workers.Load()
    	if w == nil || len(*w) == 0 {
    		return nil
    	}
    	workers := *w
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Mon Jun 10 15:31:51 UTC 2024
    - 33.3K bytes
    - Viewed (0)
  10. cmd/bucket-replication.go

    	mrfMU      sync.Mutex
    	resyncer   *replicationResyncer
    
    	// workers:
    	workers    []chan ReplicationWorkerOperation
    	lrgworkers []chan ReplicationWorkerOperation
    
    	// mrf:
    	mrfWorkerKillCh chan struct{}
    	mrfReplicaCh    chan ReplicationWorkerOperation
    	mrfSaveCh       chan MRFReplicateEntry
    	mrfStopCh       chan struct{}
    	mrfWorkerSize   int
    }
    
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Thu Jun 13 06:56:12 UTC 2024
    - 114.4K bytes
    - Viewed (0)
Back to top