Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 465 for atomic (0.18 sec)

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

    import com.google.common.annotations.GwtIncompatible;
    import java.util.concurrent.atomic.AtomicReference;
    import java.util.concurrent.atomic.AtomicReferenceArray;
    import org.checkerframework.checker.nullness.qual.Nullable;
    
    /**
     * Static utility methods pertaining to classes in the {@code java.util.concurrent.atomic} package.
     *
     * @author Kurt Alfred Kluever
     * @since 10.0
     */
    @GwtIncompatible
    Java
    - Registered: Fri Apr 12 12:43:09 GMT 2024
    - Last Modified: Sun Jun 20 10:45:35 GMT 2021
    - 2.5K bytes
    - Viewed (0)
  2. 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 12 12:43:09 GMT 2024
    - Last Modified: Mon Apr 01 16:15:01 GMT 2024
    - 14.1K 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 14 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 07 19:28:10 GMT 2024
    - Last Modified: Thu Feb 22 06:26:06 GMT 2024
    - 10.1K bytes
    - Viewed (1)
  5. 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 07 19:28:10 GMT 2024
    - Last Modified: Tue Feb 06 16:57:30 GMT 2024
    - 5.2K bytes
    - Viewed (0)
  6. api/go1.19.txt

    pkg sync/atomic, method (*Uintptr) Load() uintptr #50860
    pkg sync/atomic, method (*Uintptr) Store(uintptr) #50860
    pkg sync/atomic, method (*Uintptr) Swap(uintptr) uintptr #50860
    pkg sync/atomic, type Bool struct #50860
    pkg sync/atomic, type Int32 struct #50860
    pkg sync/atomic, type Int64 struct #50860
    pkg sync/atomic, type Pointer[$0 interface{}] struct #50860
    pkg sync/atomic, type Uint32 struct #50860
    Plain Text
    - Registered: Tue Apr 16 11:13:10 GMT 2024
    - Last Modified: Fri Dec 02 16:29:41 GMT 2022
    - 17.9K bytes
    - Viewed (1)
  7. android/guava-tests/test/com/google/common/util/concurrent/AbstractFutureFallbackAtomicHelperTest.java

        try {
          runTestMethod(NO_UNSAFE);
        } finally {
          Thread.currentThread().setContextClassLoader(oldClassLoader);
        }
    
        Thread.currentThread().setContextClassLoader(NO_ATOMIC_REFERENCE_FIELD_UPDATER);
        try {
          runTestMethod(NO_ATOMIC_REFERENCE_FIELD_UPDATER);
          // TODO(lukes): assert that the logs are full of errors
        } finally {
          Thread.currentThread().setContextClassLoader(oldClassLoader);
        }
      }
    Java
    - Registered: Fri Apr 12 12:43:09 GMT 2024
    - Last Modified: Tue Feb 16 03:24:50 GMT 2021
    - 6.2K bytes
    - Viewed (0)
  8. guava-tests/test/com/google/common/util/concurrent/AggregateFutureStateFallbackAtomicHelperTest.java

        checkHelperVersion(NO_ATOMIC_FIELD_UPDATER, "SynchronizedAtomicHelper");
    
        // Run the corresponding FuturesTest test method in a new classloader that disallows
        // certain core jdk classes.
        ClassLoader oldClassLoader = Thread.currentThread().getContextClassLoader();
        Thread.currentThread().setContextClassLoader(NO_ATOMIC_FIELD_UPDATER);
        try {
          runTestMethod(NO_ATOMIC_FIELD_UPDATER);
    Java
    - Registered: Fri Apr 12 12:43:09 GMT 2024
    - Last Modified: Mon Oct 10 19:45:10 GMT 2022
    - 5.9K bytes
    - Viewed (0)
  9. 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 14 19:28:10 GMT 2024
    - Last Modified: Tue Feb 06 06:00:45 GMT 2024
    - 14.2K bytes
    - Viewed (0)
  10. 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 07 19:28:10 GMT 2024
    - Last Modified: Mon Mar 25 16:44:20 GMT 2024
    - 14.9K bytes
    - Viewed (0)
Back to top