Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 1,229 for Chan (0.14 sec)

  1. internal/store/store.go

    type Key struct {
    	Name   string
    	IsLast bool
    }
    
    // replayItems - Reads the items from the store and replays.
    func replayItems[I any](store Store[I], doneCh <-chan struct{}, log logger, id string) <-chan Key {
    	keyCh := make(chan Key)
    
    	go func() {
    		defer xioutil.SafeClose(keyCh)
    
    		retryTicker := time.NewTicker(retryInterval)
    		defer retryTicker.Stop()
    
    		for {
    			names, err := store.List()
    Go
    - Registered: Sun Apr 07 19:28:10 GMT 2024
    - Last Modified: Mon Mar 25 16:44:20 GMT 2024
    - 3.5K bytes
    - Viewed (0)
  2. istioctl/pkg/wait/wait.go

    	})
    	return g
    }
    
    type watcher struct {
    	resultsChan chan string
    	errorChan   chan error
    	ctx         context.Context
    }
    
    func withContext(ctx context.Context) *watcher {
    	return &watcher{
    		resultsChan: make(chan string, 1),
    		errorChan:   make(chan error, 1),
    		ctx:         ctx,
    	}
    }
    
    func (w *watcher) Go(f func(chan string) error) {
    	go func() {
    		if err := f(w.resultsChan); err != nil {
    Go
    - Registered: Wed Apr 17 22:53:10 GMT 2024
    - Last Modified: Sat Feb 17 12:24:17 GMT 2024
    - 10.1K bytes
    - Viewed (0)
  3. internal/pubsub/pubsub.go

    			select {
    			case sub.ch <- item:
    			default:
    			}
    		}
    	}
    }
    
    // Subscribe - Adds a subscriber to pubsub system
    func (ps *PubSub[T, M]) Subscribe(mask M, subCh chan T, doneCh <-chan struct{}, filter func(entry T) bool) error {
    	totalSubs := atomic.AddInt32(&ps.numSubscribers, 1)
    	if ps.maxSubscribers > 0 && totalSubs > ps.maxSubscribers {
    		atomic.AddInt32(&ps.numSubscribers, -1)
    Go
    - Registered: Sun Apr 07 19:28:10 GMT 2024
    - Last Modified: Tue Feb 06 16:57:30 GMT 2024
    - 5.2K bytes
    - Viewed (0)
  4. internal/s3select/simdj/reader.go

    )
    
    // Reader - JSON record reader for S3Select.
    type Reader struct {
    	args    *json.ReaderArgs
    	input   chan simdjson.Stream
    	decoded chan simdjson.Object
    
    	// err will only be returned after decoded has been closed.
    	err          *error
    	readCloser   io.ReadCloser
    	onReaderExit func()
    
    	exitReader chan struct{}
    	readerWg   sync.WaitGroup
    }
    
    // Read - reads single record.
    Go
    - Registered: Sun Apr 07 19:28:10 GMT 2024
    - Last Modified: Tue May 30 17:02:22 GMT 2023
    - 4.9K bytes
    - Viewed (0)
  5. cmd/service.go

    	globalServiceFreezeMu.Lock()
    	// Close when we reach 0
    	globalServiceFreezeCnt--
    	if globalServiceFreezeCnt <= 0 {
    		// Set to a nil channel.
    		var _ch chan struct{}
    		if val := globalServiceFreeze.Swap(_ch); val != nil {
    			if ch, ok := val.(chan struct{}); ok && ch != nil {
    				// Close previous non-nil channel.
    				xioutil.SafeClose(ch)
    			}
    		}
    		globalServiceFreezeCnt = 0 // Don't risk going negative.
    	}
    Go
    - Registered: Sun Apr 14 19:28:10 GMT 2024
    - Last Modified: Wed Feb 28 07:02:14 GMT 2024
    - 3.8K bytes
    - Viewed (0)
  6. internal/pubsub/pubsub_test.go

    		t.Fatalf("want %d subscribers, got %d", want, got)
    	}
    }
    
    func TestSubscribeExceedingLimit(t *testing.T) {
    	ps := New[Maskable, Maskable](2)
    	ch1 := make(chan Maskable, 1)
    	ch2 := make(chan Maskable, 1)
    	ch3 := make(chan Maskable, 1)
    	doneCh := make(chan struct{})
    	defer close(doneCh)
    	if err := ps.Subscribe(MaskAll, ch1, doneCh, nil); err != nil {
    		t.Fatalf("unexpected error: %v", err)
    	}
    Go
    - Registered: Sun Apr 07 19:28:10 GMT 2024
    - Last Modified: Thu Jan 18 07:03:17 GMT 2024
    - 5.8K bytes
    - Viewed (0)
  7. internal/grid/muxserver.go

    		if debugPrint {
    			fmt.Println("connected stream mux:", ack.MuxID)
    		}
    	}()
    
    	// Data inbound to the handler
    	var handlerIn chan []byte
    	if inboundCap > 0 {
    		m.inbound = make(chan []byte, inboundCap)
    		handlerIn = make(chan []byte, 1)
    		go func(inbound chan []byte) {
    			wg.Wait()
    			defer xioutil.SafeClose(handlerIn)
    			m.handleInbound(c, inbound, handlerIn)
    		}(m.inbound)
    	}
    Go
    - Registered: Sun Apr 07 19:28:10 GMT 2024
    - Last Modified: Thu Apr 04 12:04:40 GMT 2024
    - 9.1K bytes
    - Viewed (0)
  8. 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()
    Go
    - Registered: Wed Apr 17 22:53:10 GMT 2024
    - Last Modified: Tue May 23 17:08:31 GMT 2023
    - 1.2K bytes
    - Viewed (0)
  9. internal/grid/grid_test.go

    	remoteHost := remote.HostName()
    
    	// 1: Echo
    	serverSent := make(chan struct{})
    	serverCanceled := make(chan struct{})
    	register := func(manager *Manager) {
    		errFatal(manager.RegisterStreamingHandler(handlerTest, StreamHandler{
    			Handle: func(ctx context.Context, payload []byte, _ <-chan []byte, resp chan<- []byte) *RemoteErr {
    				// Send many responses.
    				// Test that this doesn't block.
    Go
    - Registered: Sun Apr 07 19:28:10 GMT 2024
    - Last Modified: Thu Feb 08 18:15:27 GMT 2024
    - 30.1K bytes
    - Viewed (0)
  10. 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 {
    Go
    - Registered: Sun Apr 14 19:28:10 GMT 2024
    - Last Modified: Fri Apr 12 18:13:36 GMT 2024
    - 44.5K bytes
    - Viewed (0)
Back to top