Search Options

Results per page
Sort
Preferred Languages
Advance

Results 61 - 70 of 90 for buffer_end (0.55 sec)

  1. okhttp/src/main/kotlin/okhttp3/internal/http2/Http2Stream.kt

       *  * Both input and output streams have transmitted all data and headers.
       *
       * Note that the input stream may continue to yield data even after a stream reports itself as
       * not open. This is because input data is buffered.
       */
      val isOpen: Boolean
        get() {
          this.withLock {
            if (errorCode != null) {
              return false
            }
            if ((source.finished || source.closed) &&
    Registered: Sun Jun 16 04:42:17 UTC 2024
    - Last Modified: Sat Apr 20 17:03:43 UTC 2024
    - 23.2K bytes
    - Viewed (0)
  2. cmd/peer-rest-server.go

    	}
    
    	rulesMap := event.NewRulesMap(eventNames, pattern, event.TargetID{ID: mustGetUUID()})
    
    	// Listen Publisher uses nonblocking publish and hence does not wait for slow subscribers.
    	// Use buffered channel to take care of burst sends or slow w.Write()
    	ch := make(chan event.Event, globalAPIConfig.getRequestsPoolCapacity())
    	err := globalHTTPListen.Subscribe(mask, ch, ctx.Done(), func(ev event.Event) bool {
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Fri May 24 23:05:23 UTC 2024
    - 52.1K bytes
    - Viewed (0)
  3. src/net/http/h2_bundle.go

    func (cw http2closeWaiter) Wait() {
    	<-cw
    }
    
    // bufferedWriter is a buffered writer that writes to w.
    // Its buffered writer is lazily allocated as needed, to minimize
    // idle memory usage with many connections.
    type http2bufferedWriter struct {
    	_  http2incomparable
    	w  io.Writer     // immutable
    	bw *bufio.Writer // non-nil when data is buffered
    }
    
    func http2newBufferedWriter(w io.Writer) *http2bufferedWriter {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue Jun 04 16:19:04 UTC 2024
    - 364.1K bytes
    - Viewed (0)
  4. staging/src/k8s.io/apiserver/pkg/util/flowcontrol/apf_controller.go

    	haveExemptPL, haveCatchAllPL bool
    
    	// Buffered FlowSchema status updates to do.  Do them when the
    	// lock is not held, to avoid a deadlock due to such a request
    	// provoking a call into this controller while the lock held
    	// waiting on that request to complete.
    	fsStatusUpdates []fsStatusUpdate
    
    	maxWaitingRequests, maxExecutingRequests int
    }
    
    // A buffered set of status updates for FlowSchemas
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Sat May 04 18:33:12 UTC 2024
    - 48.8K bytes
    - Viewed (0)
  5. src/encoding/base32/base32.go

    	buf := make([]byte, enc.EncodedLen(len(src)))
    	enc.Encode(buf, src)
    	return string(buf)
    }
    
    type encoder struct {
    	err  error
    	enc  *Encoding
    	w    io.Writer
    	buf  [5]byte    // buffered data waiting to be encoded
    	nbuf int        // number of bytes in buf
    	out  [1024]byte // output buffer
    }
    
    func (e *encoder) Write(p []byte) (n int, err error) {
    	if e.err != nil {
    		return 0, e.err
    	}
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Tue May 14 16:25:54 UTC 2024
    - 15.9K bytes
    - Viewed (0)
  6. cmd/storage-rest-client.go

    }
    
    // where we keep old *Readers
    var readMsgpReaderPool = sync.Pool{New: func() interface{} { return &msgp.Reader{} }}
    
    // mspNewReader returns a *Reader that reads from the provided reader.
    // The reader will be buffered.
    // Return with readMsgpReaderPoolPut when done.
    func msgpNewReader(r io.Reader) *msgp.Reader {
    	p := readMsgpReaderPool.Get().(*msgp.Reader)
    	if p.R == nil {
    		p.R = xbufio.NewReaderSize(r, 4<<10)
    	} else {
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Mon Jun 10 15:51:27 UTC 2024
    - 27.4K bytes
    - Viewed (0)
  7. src/text/scanner/scanner.go

    	lastCharLen  int // length of last character in bytes
    
    	// Token text buffer
    	// Typically, token text is stored completely in srcBuf, but in general
    	// the token text's head may be buffered in tokBuf while the token text's
    	// tail is stored in srcBuf.
    	tokBuf bytes.Buffer // token text head that is not in srcBuf anymore
    	tokPos int          // token text tail position (srcBuf index); valid if >= 0
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Mon Feb 26 20:57:51 UTC 2024
    - 20.3K bytes
    - Viewed (0)
  8. src/time/sleep_test.go

    func await(slot int, result chan<- afterResult, ac <-chan Time) {
    	result <- afterResult{slot, <-ac}
    }
    
    func testAfterQueuing1(delta Duration, after func(Duration) <-chan Time) error {
    	// make the result channel buffered because we don't want
    	// to depend on channel queuing semantics that might
    	// possibly change in the future.
    	result := make(chan afterResult, len(slots))
    
    	t0 := Now()
    	for _, slot := range slots {
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri Mar 22 16:33:57 UTC 2024
    - 22.5K bytes
    - Viewed (0)
  9. src/cmd/vendor/golang.org/x/sys/unix/syscall_zos_s390x.go

    	responseBuffer := [4096]byte{0}
    	var bufferAlet, reasonCode uint32 = 0, 0
    	var bufferLen, returnValue, returnCode int32 = 4096, 0, 0
    
    	dsa := [18]uint64{0}
    	var argv [7]unsafe.Pointer
    	argv[0] = unsafe.Pointer(&jobname[0])
    	argv[1] = unsafe.Pointer(&responseBuffer[0])
    	argv[2] = unsafe.Pointer(&bufferAlet)
    	argv[3] = unsafe.Pointer(&bufferLen)
    	argv[4] = unsafe.Pointer(&returnValue)
    	argv[5] = unsafe.Pointer(&returnCode)
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Wed May 08 16:12:58 UTC 2024
    - 84.4K bytes
    - Viewed (0)
  10. cmd/bucket-lifecycle.go

    		es.stats.missedExpiryTasks.Add(1)
    	}
    }
    
    // globalExpiryState is the per-node instance which manages all ILM expiry tasks.
    var globalExpiryState *expiryState
    
    // newExpiryState creates an expiryState with buffered channels allocated for
    // each ILM expiry task type.
    func newExpiryState(ctx context.Context, objAPI ObjectLayer, n int) *expiryState {
    	es := &expiryState{
    		ctx:    ctx,
    		objAPI: objAPI,
    	}
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Mon Jun 10 15:31:51 UTC 2024
    - 33.3K bytes
    - Viewed (0)
Back to top