Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 14 for AddInt64 (0.2 sec)

  1. 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)
    }
    
    func (r *ReplicationStats) decQ(bucket string, sz int64, isDelMarker bool, opType replication.Type) {
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Thu Feb 22 06:26:06 GMT 2024
    - 13.4K bytes
    - Viewed (0)
  2. internal/grid/benchmark_test.go

    						if err != nil {
    							if debugReqs {
    								fmt.Println(err.Error())
    							}
    							b.Fatal(err.Error())
    						}
    						PutByteBuffer(resp)
    						n++
    					}
    					atomic.AddInt64(&ops, int64(n))
    					atomic.AddInt64(&lat, latency)
    				})
    				spent := time.Since(t)
    				if spent > 0 && n > 0 {
    					// Since we are benchmarking n parallel servers we need to multiply by n.
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Tue Nov 21 01:09:35 GMT 2023
    - 12.2K bytes
    - Viewed (0)
  3. internal/logger/target/http/http.go

    retry:
    	select {
    	case h.logCh <- entry:
    		atomic.AddInt64(&h.totalMessages, 1)
    	case <-ctx.Done():
    		// return error only for context timedout.
    		if errors.Is(ctx.Err(), context.DeadlineExceeded) {
    			return ctx.Err()
    		}
    		return nil
    	default:
    		if h.workers < h.maxWorkers {
    			goto retry
    		}
    		atomic.AddInt64(&h.totalMessages, 1)
    		atomic.AddInt64(&h.failedMessages, 1)
    		return errors.New("log buffer full")
    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)
  4. internal/logger/target/kafka/kafka.go

    	// from an internal channel.
    	for entry := range logCh {
    		h.logEntry(entry)
    	}
    }
    
    func (h *Target) logEntry(entry interface{}) {
    	atomic.AddInt64(&h.totalMessages, 1)
    	if err := h.send(entry); err != nil {
    		atomic.AddInt64(&h.failedMessages, 1)
    		h.kconfig.LogOnce(context.Background(), err, h.kconfig.Topic)
    	}
    }
    
    func (h *Target) send(entry interface{}) error {
    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. internal/config/lambda/target/webhook.go

    func (target *WebhookTarget) Send(eventData event.Event) (resp *http.Response, err error) {
    	atomic.AddInt64(&target.activeRequests, 1)
    	defer atomic.AddInt64(&target.activeRequests, -1)
    
    	atomic.AddInt64(&target.totalRequests, 1)
    	defer func() {
    		if err != nil {
    			atomic.AddInt64(&target.failedRequests, 1)
    		}
    	}()
    
    	if err = target.init(); err != nil {
    		return nil, err
    	}
    
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Fri Nov 17 20:02:26 GMT 2023
    - 6.7K bytes
    - Viewed (0)
  6. cmd/consolelogger.go

    	case string:
    		lg = log.Info{ConsoleMsg: e, NodeName: sys.nodeName}
    	}
    	atomic.AddInt64(&sys.totalMessages, 1)
    
    	sys.pubsub.Publish(lg)
    	sys.Lock()
    	// add log to ring buffer
    	sys.logBuf.Value = lg
    	sys.logBuf = sys.logBuf.Next()
    	sys.Unlock()
    	err := sys.console.Send(entry)
    	if err != nil {
    		atomic.AddInt64(&sys.failedMessages, 1)
    	}
    	return err
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Fri Feb 02 00:13:57 GMT 2024
    - 5.4K bytes
    - Viewed (0)
  7. cmd/site-replication-metrics.go

    			Bytes: rt.SinceUptime.Bytes,
    		},
    		ErrCounts: errCounts,
    	}
    }
    
    func (rt *RTimedMetrics) addsize(size int64, err error) {
    	// failures seen since uptime
    	atomic.AddInt64(&rt.SinceUptime.Bytes, size)
    	atomic.AddInt64(&rt.SinceUptime.Count, 1)
    	rt.LastMinute.addsize(size)
    	rt.LastHour.addsize(size)
    	if err != nil && minio.ToErrorResponse(err).Code == "AccessDenied" {
    		if rt.ErrCounts == nil {
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Tue Feb 06 06:00:45 GMT 2024
    - 8.2K bytes
    - Viewed (0)
  8. internal/s3select/progress.go

    var bz2Limiter = pbzip2.CreateConcurrencyPool((runtime.GOMAXPROCS(0) + 1) / 2)
    
    func (r *countUpReader) Read(p []byte) (n int, err error) {
    	n, err = r.reader.Read(p)
    	atomic.AddInt64(&r.bytesRead, int64(n))
    	return n, err
    }
    
    func (r *countUpReader) BytesRead() int64 {
    	if r == nil {
    		return 0
    	}
    	return atomic.LoadInt64(&r.bytesRead)
    }
    
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Mon Oct 18 15:44:36 GMT 2021
    - 4.2K bytes
    - Viewed (0)
  9. cmd/dynamic-timeouts.go

    	dt.logEntry(maxDuration)
    }
    
    // logEntry stores a log entry
    func (dt *dynamicTimeout) logEntry(duration time.Duration) {
    	if duration < 0 {
    		return
    	}
    	entries := int(atomic.AddInt64(&dt.entries, 1))
    	index := entries - 1
    	if index < dynamicTimeoutLogSize {
    		dt.mutex.Lock()
    		dt.log[index] = duration
    
    		// We leak entries while we copy
    		if entries == dynamicTimeoutLogSize {
    
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Fri Aug 19 23:21:05 GMT 2022
    - 4.5K bytes
    - Viewed (0)
  10. cmd/xl-storage-disk-id-check.go

    			acc = newAcc
    		} else {
    			// We may be able to grab the new accumulator by yielding.
    			runtime.Gosched()
    			acc = e.cached.Load()
    		}
    	}
    	atomic.AddInt64(&acc.N, 1)
    	atomic.AddInt64(&acc.Total, int64(value))
    	atomic.AddInt64(&acc.Size, sz)
    }
    
    // total returns the total call count and latency for the last minute.
    func (e *lockedLastMinuteLatency) total() AccElem {
    	e.mu.Lock()
    	defer e.mu.Unlock()
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Mon Apr 15 08:25:46 GMT 2024
    - 32.7K bytes
    - Viewed (0)
Back to top