Search Options

Results per page
Sort
Preferred Languages
Advance

Results 1 - 10 of 37 for GOMAXPROCS (0.17 sec)

  1. internal/lsync/lrwmutex_test.go

    		clocked <- true
    		<-cunlock
    		m.RUnlock()
    		cdone <- true
    	}
    }
    
    // Borrowed from rwmutex_test.go
    func doTestParallelReaders(numReaders, gomaxprocs int) {
    	runtime.GOMAXPROCS(gomaxprocs)
    	m := NewLRWMutex()
    
    	clocked := make(chan bool)
    	cunlock := make(chan bool)
    	cdone := make(chan bool)
    	for i := 0; i < numReaders; i++ {
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Sun Mar 05 04:57:35 GMT 2023
    - 7.9K bytes
    - Viewed (0)
  2. internal/dsync/drwmutex_test.go

    		}
    	}
    	cdone <- true
    }
    
    // Borrowed from rwmutex_test.go
    func hammerRWMutex(t *testing.T, gomaxprocs, numReaders, numIterations int) {
    	t.Run(fmt.Sprintf("%d-%d-%d", gomaxprocs, numReaders, numIterations), func(t *testing.T) {
    		resource := "test"
    		runtime.GOMAXPROCS(gomaxprocs)
    		// Number of active readers + 10000 * number of active writers.
    		var activity int32
    		cdone := make(chan bool)
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Sat Dec 24 03:49:07 GMT 2022
    - 9.7K bytes
    - Viewed (0)
  3. cmd/untar.go

    	"github.com/klauspost/compress/s2"
    	"github.com/klauspost/compress/zstd"
    	gzip "github.com/klauspost/pgzip"
    	"github.com/pierrec/lz4"
    )
    
    // Max bzip2 concurrency across calls. 50% of GOMAXPROCS.
    var bz2Limiter = pbzip2.CreateConcurrencyPool((runtime.GOMAXPROCS(0) + 1) / 2)
    
    func detect(r *bufio.Reader) format {
    	z, err := r.Peek(4)
    	if err != nil {
    		return formatUnknown
    	}
    	for _, f := range magicHeaders {
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Thu Apr 04 12:04:40 GMT 2024
    - 6K bytes
    - Viewed (0)
  4. internal/s3select/progress.go

    	"github.com/pierrec/lz4"
    )
    
    type countUpReader struct {
    	reader    io.Reader
    	bytesRead int64
    }
    
    // Max bzip2 concurrency across calls. 50% of GOMAXPROCS.
    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
    }
    
    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)
  5. internal/s3select/json/preader.go

    // and a number of workers based on GOMAXPROCS.
    // If an error is returned no goroutines have been started and r.err will have been set.
    func (r *PReader) startReaders() {
    	r.bufferPool.New = func() interface{} {
    		return make([]byte, jsonSplitSize+1024)
    	}
    
    	// Create queue
    	r.queue = make(chan *queueItem, runtime.GOMAXPROCS(0))
    	r.input = make(chan *queueItem, runtime.GOMAXPROCS(0))
    	r.readerWg.Add(1)
    
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Sun Mar 05 04:57:35 GMT 2023
    - 6.4K bytes
    - Viewed (0)
  6. cmd/speedtest.go

    			// operations for now to begin with.
    			if concurrency < 4 {
    				concurrency = 4
    			}
    
    			// if GOMAXPROCS is set to a lower value then choose to use
    			// concurrency == GOMAXPROCS instead.
    			if runtime.GOMAXPROCS(0) < concurrency {
    				concurrency = runtime.GOMAXPROCS(0)
    			}
    		}
    
    		throughputHighestGet := uint64(0)
    		throughputHighestPut := uint64(0)
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Sun Jan 28 18:04:17 GMT 2024
    - 9K bytes
    - Viewed (0)
  7. src/cmd/cgo/internal/test/issue18146.go

    				attempts = max
    			}
    		}
    	}
    
    	if os.Getenv("test18146") == "exec" {
    		runtime.GOMAXPROCS(1)
    		for n := threads; n > 0; n-- {
    			go func() {
    				for {
    					_ = md5.Sum([]byte("Hello, !"))
    				}
    			}()
    		}
    		runtime.GOMAXPROCS(threads)
    		argv := append(os.Args, "-test.run=^$")
    		if err := syscall.Exec(os.Args[0], argv, os.Environ()); err != nil {
    			t.Fatal(err)
    		}
    Go
    - Registered: Tue Apr 23 11:13:09 GMT 2024
    - Last Modified: Tue Sep 05 23:35:32 GMT 2023
    - 2.8K bytes
    - Viewed (0)
  8. internal/s3select/csv/reader.go

    	// Check if first block is valid.
    	if !utf8.Valid(next) {
    		return errInvalidTextEncodingError()
    	}
    
    	// Create queue
    	r.queue = make(chan *queueItem, runtime.GOMAXPROCS(0))
    	r.input = make(chan *queueItem, runtime.GOMAXPROCS(0))
    	r.readerWg.Add(1)
    
    	// Start splitter
    	go func() {
    		defer close(r.input)
    		defer close(r.queue)
    		defer r.readerWg.Done()
    		for {
    			q := queueItem{
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Thu Feb 22 06:26:06 GMT 2024
    - 8.9K bytes
    - Viewed (0)
  9. cmd/admin-server-info.go

    			Alloc:      memstats.Alloc,
    			TotalAlloc: memstats.TotalAlloc,
    			Mallocs:    memstats.Mallocs,
    			Frees:      memstats.Frees,
    			HeapAlloc:  memstats.HeapAlloc,
    		},
    		GoMaxProcs:     runtime.GOMAXPROCS(0),
    		NumCPU:         runtime.NumCPU(),
    		RuntimeVersion: runtime.Version(),
    		GCStats: &madmin.GCStats{
    			LastGC:     gcStats.LastGC,
    			NumGC:      gcStats.NumGC,
    			PauseTotal: gcStats.PauseTotal,
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Thu Apr 04 12:04:40 GMT 2024
    - 4.8K bytes
    - Viewed (0)
  10. internal/grid/benchmark_test.go

    	errFatal(err)
    
    	// Wait for all to connect
    	// Parallel writes per server.
    	b.Run("bytes", func(b *testing.B) {
    		for par := 1; par <= 32; par *= 2 {
    			b.Run("par="+strconv.Itoa(par*runtime.GOMAXPROCS(0)), func(b *testing.B) {
    				defer timeout(60 * time.Second)()
    				ctx, cancel := context.WithTimeout(context.Background(), 30*time.Second)
    				defer cancel()
    				b.ReportAllocs()
    				b.SetBytes(int64(len(payload) * 2))
    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)
Back to top