Search Options

Results per page
Sort
Preferred Languages
Advance

Results 11 - 20 of 479 for cancel (0.2 sec)

  1. android/guava-tests/test/com/google/common/util/concurrent/SettableFutureTest.java

        async.setFuture(inner);
        async.cancel(false);
        assertTrue(inner.isCancelled());
        assertFalse(inner.wasInterrupted());
        assertThrows(CancellationException.class, () -> inner.get());
      }
    
      public void testCancel_beforeSet() throws Exception {
        SettableFuture<Object> async = SettableFuture.create();
        async.cancel(true);
        assertFalse(async.set(42));
      }
    
    Java
    - Registered: Fri Apr 26 12:43:10 GMT 2024
    - Last Modified: Wed Sep 06 17:04:31 GMT 2023
    - 7.3K bytes
    - Viewed (0)
  2. internal/grid/muxclient.go

    		return &Stream{responses: responseCh, Requests: nil, ctx: m.ctx, cancel: m.cancelFn, muxID: m.MuxID}, nil
    	}
    
    	// Deliver responses and send unblocks back to the server.
    	go m.handleTwowayResponses(responseCh, responses)
    	go m.handleTwowayRequests(responses, requests)
    
    	return &Stream{responses: responseCh, Requests: requests, ctx: m.ctx, cancel: m.cancelFn, muxID: m.MuxID}, nil
    }
    
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Thu Apr 04 12:04:40 GMT 2024
    - 14.2K bytes
    - Viewed (0)
  3. cni/pkg/nodeagent/ztunnelserver_test.go

    var ztunnelTestCounter atomic.Uint32
    
    func TestZtunnelSendsPodSnapshot(t *testing.T) {
    	ztunnelKeepAliveCheckInterval = time.Second / 10
    	mt := monitortest.New(t)
    	setupLogging()
    	ctx, cancel := context.WithCancel(context.Background())
    	defer cancel()
    
    	fixture := connect(ctx)
    	ztunClient := fixture.ztunClient
    	uid := fixture.uid
    
    	m, fds := readRequest(t, ztunClient)
    Go
    - Registered: Wed Apr 24 22:53:08 GMT 2024
    - Last Modified: Fri Apr 12 21:47:31 GMT 2024
    - 8.6K bytes
    - Viewed (0)
  4. internal/grid/stream.go

    // If any error is returned by the callback, the stream will be canceled.
    // If the context is canceled, the stream will be canceled.
    func (s *Stream) Results(next func(b []byte) error) (err error) {
    	done := false
    	defer func() {
    		if s.cancel != nil {
    			s.cancel(err)
    		}
    
    		if !done {
    			// Drain channel.
    			for range s.responses {
    			}
    		}
    	}()
    	doneCh := s.ctx.Done()
    	for {
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Wed Feb 28 18:05:18 GMT 2024
    - 2.8K bytes
    - Viewed (0)
  5. cmd/shared-lock.go

    		select {
    		case <-ctx1.Done():
    		case <-ctx2.Done():
    		// The lock acquirer decides to cancel, exit this goroutine
    		case <-ctx.Done():
    		}
    
    		cancel()
    	}()
    	return ctx, cancel
    }
    
    func (ld sharedLock) GetLock(ctx context.Context) (context.Context, context.CancelFunc) {
    	l := <-ld.lockContext
    	return mergeContext(l.Context(), ctx)
    }
    
    Go
    - Registered: Sun Apr 28 19:28:10 GMT 2024
    - Last Modified: Mon Feb 13 09:26:38 GMT 2023
    - 2.3K bytes
    - Viewed (0)
  6. android/guava-tests/test/com/google/common/util/concurrent/FuturesTest.java

      }
    
      private static void doTestSuccessfulAsList_resultCancelledRacingInputDone() throws Exception {
        // Simple (combined.cancel -> input.cancel -> setOneValue):
        successfulAsList(ImmutableList.of(SettableFuture.create())).cancel(true);
    
        /*
         * Complex (combined.cancel -> input.cancel -> other.set -> setOneValue),
         * to show that this isn't just about problems with the input future we just
         * cancelled:
    Java
    - Registered: Fri Apr 26 12:43:10 GMT 2024
    - Last Modified: Tue Feb 20 17:00:05 GMT 2024
    - 144.5K bytes
    - Viewed (0)
  7. okhttp-sse/src/test/java/okhttp3/sse/internal/EventSourceRecorder.kt

        get().log("[ES] onFailure", Platform.INFO, t)
        events.add(Failure(t, response))
        drainCancelQueue(eventSource)
      }
    
      private fun drainCancelQueue(eventSource: EventSource) {
        if (cancel) {
          cancel = false
          eventSource.cancel()
        }
      }
    
      private fun nextEvent(): Any {
        return events.poll(10, TimeUnit.SECONDS)
          ?: throw AssertionError("Timed out waiting for event.")
      }
    
    Plain Text
    - Registered: Fri Apr 26 11:42:10 GMT 2024
    - Last Modified: Mon Jan 08 01:13:22 GMT 2024
    - 3.1K bytes
    - Viewed (0)
  8. internal/grid/muxserver.go

    		ctx, cancel = context.WithTimeout(ctx, time.Duration(msg.DeadlineMS)*time.Millisecond)
    	} else {
    		ctx, cancel = context.WithCancel(ctx)
    	}
    	m := muxServer{
    		ID:        msg.MuxID,
    		RecvSeq:   msg.Seq + 1,
    		SendSeq:   msg.Seq,
    		ctx:       ctx,
    		cancel:    cancel,
    		parent:    c,
    		LastPing:  time.Now().Unix(),
    		BaseFlags: c.baseFlags,
    	}
    	go func() {
    		// TODO: Handle
    	}()
    
    	return &m
    }
    
    Go
    - Registered: Sun Apr 21 19:28:08 GMT 2024
    - Last Modified: Thu Apr 04 12:04:40 GMT 2024
    - 9.1K bytes
    - Viewed (0)
  9. cmd/etcd.go

    	timeoutCtx, cancel := context.WithTimeout(ctx, defaultContextTimeout)
    	defer cancel()
    
    	_, err := client.Delete(timeoutCtx, key)
    	etcdLogIf(ctx, err)
    	return etcdErrToErr(err, client.Endpoints())
    }
    
    func readKeyEtcd(ctx context.Context, client *etcd.Client, key string) ([]byte, error) {
    	timeoutCtx, cancel := context.WithTimeout(ctx, defaultContextTimeout)
    	defer cancel()
    	resp, err := client.Get(timeoutCtx, key)
    Go
    - Registered: Sun Apr 28 19:28:10 GMT 2024
    - Last Modified: Thu Apr 04 12:04:40 GMT 2024
    - 2.9K bytes
    - Viewed (0)
  10. cmd/healthcheck-handler.go

    	if objLayer == nil {
    		w.Header().Set(xhttp.MinIOServerStatus, unavailable)
    		writeResponse(w, http.StatusServiceUnavailable, nil, mimeNone)
    		return
    	}
    
    	ctx, cancel := context.WithTimeout(ctx, globalAPIConfig.getClusterDeadline())
    	defer cancel()
    
    	opts := HealthOptions{
    		Maintenance:    r.Form.Get("maintenance") == "true",
    		DeploymentType: r.Form.Get("deployment-type"),
    	}
    	result := objLayer.Health(ctx, opts)
    Go
    - Registered: Sun Apr 28 19:28:10 GMT 2024
    - Last Modified: Wed Apr 03 21:13:20 GMT 2024
    - 6.5K bytes
    - Viewed (0)
Back to top