Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 235 for atomic (0.34 sec)

  1. android/guava/src/com/google/common/util/concurrent/AtomicLongMap.java

        outer:
        while (true) {
          AtomicLong atomic = map.get(key);
          if (atomic == null) {
            atomic = map.putIfAbsent(key, new AtomicLong(delta));
            if (atomic == null) {
              return delta;
            }
            // atomic is now non-null; fall through
          }
    
          while (true) {
            long oldValue = atomic.get();
            if (oldValue == 0L) {
    Java
    - Registered: Fri Apr 26 12:43:10 GMT 2024
    - Last Modified: Mon Apr 01 16:15:01 GMT 2024
    - 14.1K bytes
    - Viewed (0)
  2. internal/pubsub/pubsub.go

    			}
    		}
    		atomic.StoreUint64(&ps.types, uint64(remainTypes))
    		atomic.AddInt32(&ps.numSubscribers, -1)
    	}()
    
    	return nil
    }
    
    // SubscribeJSON - Adds a subscriber to pubsub system and returns results with JSON encoding.
    func (ps *PubSub[T, M]) SubscribeJSON(mask M, subCh chan<- []byte, doneCh <-chan struct{}, filter func(entry T) bool, wg *sync.WaitGroup) error {
    	totalSubs := atomic.AddInt32(&ps.numSubscribers, 1)
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Tue Feb 06 16:57:30 GMT 2024
    - 5.2K bytes
    - Viewed (0)
  3. cmd/bucket-replication-stats.go

    	defer r.qCache.Unlock()
    	v, ok := r.qCache.bucketStats[bucket]
    	if !ok {
    		v = newInQueueStats(r.registry, bucket)
    	}
    	atomic.AddInt64(&v.nowBytes, sz)
    	atomic.AddInt64(&v.nowCount, 1)
    	r.qCache.bucketStats[bucket] = v
    	atomic.AddInt64(&r.qCache.srQueueStats.nowBytes, sz)
    	atomic.AddInt64(&r.qCache.srQueueStats.nowCount, 1)
    }
    
    Go
    - Registered: Sun Apr 28 19:28:10 GMT 2024
    - Last Modified: Thu Feb 22 06:26:06 GMT 2024
    - 13.4K bytes
    - Viewed (0)
  4. internal/logger/target/kafka/kafka.go

    	}
    	logJSON, err := json.Marshal(&entry)
    	if err != nil {
    		return err
    	}
    	msg := sarama.ProducerMessage{
    		Topic: h.kconfig.Topic,
    		Value: sarama.ByteEncoder(logJSON),
    	}
    	_, _, err = h.producer.SendMessage(&msg)
    	if err != nil {
    		atomic.StoreInt32(&h.status, statusOffline)
    	} else {
    		atomic.StoreInt32(&h.status, statusOnline)
    	}
    	return err
    }
    
    // Init initialize kafka target
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Thu Feb 22 06:26:06 GMT 2024
    - 10.1K bytes
    - Viewed (1)
  5. cmd/bucket-replication-metrics.go

    func (p *ProxyMetric) add(p2 ProxyMetric) {
    	atomic.AddUint64(&p.GetTotal, p2.GetTotal)
    	atomic.AddUint64(&p.HeadTotal, p2.HeadTotal)
    	atomic.AddUint64(&p.GetTagTotal, p2.GetTagTotal)
    	atomic.AddUint64(&p.PutTagTotal, p2.PutTagTotal)
    	atomic.AddUint64(&p.RmvTagTotal, p2.RmvTagTotal)
    	atomic.AddUint64(&p.GetFailedTotal, p2.GetFailedTotal)
    	atomic.AddUint64(&p.HeadFailedTotal, p2.HeadFailedTotal)
    Go
    - Registered: Sun Apr 28 19:28:10 GMT 2024
    - Last Modified: Tue Feb 06 06:00:45 GMT 2024
    - 14.2K bytes
    - Viewed (0)
  6. internal/logger/target/http/http.go

    func (h *Target) IsOnline(ctx context.Context) bool {
    	return atomic.LoadInt32(&h.status) == statusOnline
    }
    
    // Stats returns the target statistics.
    func (h *Target) Stats() types.TargetStats {
    	h.logChMu.RLock()
    	queueLength := len(h.logCh)
    	h.logChMu.RUnlock()
    	stats := types.TargetStats{
    		TotalMessages:  atomic.LoadInt64(&h.totalMessages),
    		FailedMessages: atomic.LoadInt64(&h.failedMessages),
    		QueueLength:    queueLength,
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Mon Mar 25 16:44:20 GMT 2024
    - 14.9K bytes
    - Viewed (0)
  7. cmd/consolelogger.go

    	return logger.ConsoleLoggerTgt
    }
    
    // Stats returns the target statistics.
    func (sys *HTTPConsoleLoggerSys) Stats() types.TargetStats {
    	return types.TargetStats{
    		TotalMessages:  atomic.LoadInt64(&sys.totalMessages),
    		FailedMessages: atomic.LoadInt64(&sys.failedMessages),
    		QueueLength:    0,
    	}
    }
    
    // Content returns the console stdout log
    func (sys *HTTPConsoleLoggerSys) Content() (logs []log.Entry) {
    	sys.RLock()
    Go
    - Registered: Sun Apr 28 19:28:10 GMT 2024
    - Last Modified: Fri Feb 02 00:13:57 GMT 2024
    - 5.4K bytes
    - Viewed (0)
  8. cmd/http-stats.go

    	serverStats := ServerHTTPStats{}
    	serverStats.S3RequestsIncoming = atomic.SwapUint64(&st.s3RequestsIncoming, 0)
    	serverStats.S3RequestsInQueue = atomic.LoadInt32(&st.s3RequestsInQueue)
    	serverStats.TotalS3RejectedAuth = atomic.LoadUint64(&st.rejectedRequestsAuth)
    	serverStats.TotalS3RejectedTime = atomic.LoadUint64(&st.rejectedRequestsTime)
    	serverStats.TotalS3RejectedHeader = atomic.LoadUint64(&st.rejectedRequestsHeader)
    Go
    - Registered: Sun Apr 28 19:28:10 GMT 2024
    - Last Modified: Sun Mar 10 09:15:15 GMT 2024
    - 11.4K bytes
    - Viewed (0)
  9. cni/pkg/nodeagent/healthServer.go

    		_ = http.ListenAndServe(":"+constants.ReadinessPort, router)
    	}()
    
    	return
    }
    
    func initRouter(router *http.ServeMux) (installReady *atomic.Value, watchReady *atomic.Value) {
    	installReady = &atomic.Value{}
    	watchReady = &atomic.Value{}
    	installReady.Store(false)
    	watchReady.Store(false)
    
    	router.HandleFunc(constants.LivenessEndpoint, healthz)
    	router.HandleFunc(constants.ReadinessEndpoint, readyz(installReady, watchReady))
    
    	return
    Go
    - Registered: Wed May 01 22:53:12 GMT 2024
    - Last Modified: Mon Apr 15 01:29:35 GMT 2024
    - 1.8K bytes
    - Viewed (0)
  10. cni/pkg/nodeagent/fakes_test.go

    	return &fakeFileFakeFds{File: f, fd: 0}
    }
    
    type fakeIptablesDeps struct {
    	AddRouteErr           error
    	AddInpodMarkIPRuleCnt atomic.Int32
    	DelInpodMarkIPRuleCnt atomic.Int32
    	AddLoopbackRoutesCnt  atomic.Int32
    	DelLoopbackRoutesCnt  atomic.Int32
    }
    
    var _ iptables.NetlinkDependencies = &fakeIptablesDeps{}
    
    func (r *fakeIptablesDeps) AddInpodMarkIPRule(cfg *iptables.Config) error {
    Go
    - Registered: Wed May 01 22:53:12 GMT 2024
    - Last Modified: Fri Apr 12 21:47:31 GMT 2024
    - 3.9K bytes
    - Viewed (0)
Back to top