Search Options

Results per page
Sort
Preferred Languages
Advance

Results 21 - 30 of 448 for pusha (0.04 sec)

  1. samples/builder/README.md

    ## Building for testing
    
    To build all images and push them:
    
    ```bash
    docker buildx bake --push
    ```
    
    This will push to `localhost:5000` by default, which you can override with `HUB=localhost:5000`.
    It will also build `linux/amd64,linux/arm64` which you can override with `PLATFORMS`.
    
    You can also build a set of images instead of all of them:
    
    ```bash
    docker buildx bake --push examples-helloworld-v1 tcp-echo-server
    ```
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Sat Mar 16 22:03:02 UTC 2024
    - 928 bytes
    - Viewed (0)
  2. pilot/pkg/status/resourcelock_test.go

    			Meta: config.Meta{Generation: 11},
    		}
    	}, 10)
    	ctx, cancel := context.WithCancel(context.Background())
    	workers.Run(ctx)
    	workers.Push(r1, c1, nil)
    	workers.Push(r1, c2, nil)
    	workers.Push(r1, c1, nil)
    	<-x
    	<-y
    	<-x
    	workers.Push(r1, c1, nil)
    	workers.Push(r1a, c1, nil)
    	<-y
    	<-x
    	select {
    	case <-x:
    		t.FailNow()
    	default:
    	}
    	<-y
    	result := atomic.LoadInt32(&runCount)
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Tue Oct 31 14:48:28 UTC 2023
    - 2.1K bytes
    - Viewed (0)
  3. pkg/queue/instance_test.go

    		}
    	}
    }
    
    func TestRetry(t *testing.T) {
    	q := NewQueue(1 * time.Microsecond)
    	stop := make(chan struct{})
    	defer close(stop)
    
    	// Push a task that fails the first time and retries.
    	wg := sync.WaitGroup{}
    	wg.Add(2)
    	failed := false
    	q.Push(func() error {
    		defer wg.Done()
    		if failed {
    			return nil
    		}
    		failed = true
    		return errors.New("fake error")
    	})
    
    	go q.Run(stop)
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jul 21 16:30:36 UTC 2023
    - 3.4K bytes
    - Viewed (0)
  4. src/syscall/mksyscall.pl

    				push @args, "uintptr($name)", "uintptr($name>>32)";
    			} else {
    				push @args, "uintptr($name)";
    			}
    		} elsif($type eq "int64" && $dragonfly) {
    			if ($func !~ /^extp(read|write)/i) {
    				push @args, "0";
    			}
    			if($_32bit eq "big-endian") {
    				push @args, "uintptr($name>>32)", "uintptr($name)";
    			} elsif($_32bit eq "little-endian") {
    				push @args, "uintptr($name)", "uintptr($name>>32)";
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Fri May 24 17:15:02 UTC 2024
    - 10.3K bytes
    - Viewed (0)
  5. src/regexp/backtrack.go

    			// If during the processing of inst.Out, we encounter
    			// inst.Arg via another path, we want to process it then.
    			// Pushing it here will inhibit that. Instead, re-push
    			// inst with arg==true as a reminder to push inst.Arg out
    			// later.
    			if arg {
    				// Finished inst.Out; try inst.Arg.
    				arg = false
    				pc = inst.Arg
    				goto CheckAndLoop
    			} else {
    				b.push(re, pc, pos, true)
    Registered: Wed Jun 12 16:32:35 UTC 2024
    - Last Modified: Thu Sep 14 17:25:39 UTC 2023
    - 8.8K bytes
    - Viewed (0)
  6. pilot/pkg/model/endpointshards.go

    	// Check if ServiceAccounts have changed. We should do a full push if they have changed.
    	saUpdated := updateShardServiceAccount(ep, hostname)
    
    	// For existing endpoints, we need to do full push if service accounts change.
    	if saUpdated && pushType != FullPush {
    		// Avoid extra logging if already a full push
    		log.Infof("Full push, service accounts changed, %v", hostname)
    		pushType = FullPush
    	}
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jun 14 04:34:37 UTC 2024
    - 15.6K bytes
    - Viewed (0)
  7. tensorflow/compiler/mlir/tensorflow/transforms/stack_ops_decomposition.cc

    LogicalResult HandleStackPushV2Op(
        TF::StackPushV2Op push,
        llvm::SmallDenseMap<Value, Value>* data_var_to_size_var) {
      auto it = data_var_to_size_var->find(push.getHandle());
      if (it == data_var_to_size_var->end()) {
        return push.emitOpError("unknown stack");
      }
      // Push output simply forward the input element.
      push.replaceAllUsesWith(push.getElem());
      OpBuilder builder(push);
      // Read the current buffer and size.
    Registered: Sun Jun 16 05:45:23 UTC 2024
    - Last Modified: Thu Apr 25 16:01:03 UTC 2024
    - 23.8K bytes
    - Viewed (0)
  8. pilot/pkg/xds/eds_test.go

    	})
    	ads := s.Connect(nil, nil, watchAll)
    	t.Run("Full Push", func(t *testing.T) {
    		s.Discovery.Push(&model.PushRequest{Full: true})
    		if _, err := ads.Wait(time.Second*5, watchAll...); err != nil {
    			t.Fatal(err)
    		}
    	})
    	t.Run("Incremental Push with updated services", func(t *testing.T) {
    		ads.WaitClear()
    		s.Discovery.Push(&model.PushRequest{
    			Full:           false,
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Feb 02 20:58:47 UTC 2024
    - 39.6K bytes
    - Viewed (0)
  9. pilot/pkg/networking/grpcgen/lds.go

    func (g *GrpcConfigGenerator) BuildListeners(node *model.Proxy, push *model.PushContext, names []string) model.Resources {
    	filter := newListenerNameFilter(names, node)
    
    	log.Debugf("building lds for %s with filter:\n%v", node.ID, filter)
    
    	resp := make(model.Resources, 0, len(filter))
    	resp = append(resp, buildOutboundListeners(node, push, filter)...)
    	resp = append(resp, buildInboundListeners(node, push, filter.inboundNames())...)
    
    	return resp
    }
    
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Wed Apr 17 22:20:44 UTC 2024
    - 14.6K bytes
    - Viewed (0)
  10. pkg/queue/delay.go

    				if !push(task) {
    					return
    				}
    			} else {
    				// not ready yet, don't block enqueueing
    				await := time.NewTimer(delay)
    				select {
    				case t := <-d.enqueue:
    					d.mu.Lock()
    					heap.Push(d.queue, t)
    					// put the old "head" back on the queue, it may be scheduled to execute after the one
    					// that was just pushed
    					heap.Push(d.queue, task)
    					d.mu.Unlock()
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Jul 20 06:27:31 UTC 2023
    - 6.7K bytes
    - Viewed (0)
Back to top