Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 169 for atomic (0.24 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 26 12:43:10 GMT 2024
    - Last Modified: Sun Jun 20 10:45:35 GMT 2021
    - 2.5K 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. 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 26 12:43:10 GMT 2024
    - Last Modified: Tue Feb 16 03:24:50 GMT 2021
    - 6.2K bytes
    - Viewed (0)
  4. 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)
  5. internal/rest/rpc-stats.go

    // GetRPCStats returns RPC stats, include calls errors and dhcp/tcp metrics
    func GetRPCStats() RPCStats {
    	s := RPCStats{
    		Errs:     atomic.LoadUint64(&globalStats.errs),
    		DialErrs: atomic.LoadUint64(&globalStats.tcpDialErrs),
    	}
    	if v := atomic.LoadUint64(&globalStats.tcpDialCount); v > 0 {
    		s.DialAvgDuration = atomic.LoadUint64(&globalStats.tcpDialTotalDur) / v
    	}
    	return s
    }
    
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Thu Sep 29 16:27:58 GMT 2022
    - 2.3K bytes
    - Viewed (0)
  6. 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)
  7. 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)
  8. 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)
  9. internal/bucket/bandwidth/measurement.go

    //
    // You should have received a copy of the GNU Affero General Public License
    // along with this program.  If not, see <http://www.gnu.org/licenses/>.
    
    package bandwidth
    
    import (
    	"sync"
    	"sync/atomic"
    	"time"
    )
    
    const (
    	// betaBucket is the weight used to calculate exponential moving average
    	betaBucket = 0.1 // Number of averages considered = 1/(1-betaObject)
    )
    
    Go
    - Registered: Sun Apr 28 19:28:10 GMT 2024
    - Last Modified: Sat Jun 03 20:41:51 GMT 2023
    - 2.9K bytes
    - Viewed (0)
  10. internal/once/init.go

    func (l *Init) Do(f func() error) error {
    	if atomic.LoadUint32(&l.done) == 0 {
    		return l.do(f)
    	}
    	return nil
    }
    
    func (l *Init) do(f func() error) error {
    	l.m.Lock()
    	defer l.m.Unlock()
    	if atomic.LoadUint32(&l.done) == 0 {
    		if err := f(); err != nil {
    			return err
    		}
    		// Mark as done only when f() is successful
    		atomic.StoreUint32(&l.done, 1)
    	}
    	return nil
    }
    
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Tue May 09 04:20:31 GMT 2023
    - 2.1K bytes
    - Viewed (0)
Back to top