Search Options

Results per page
Sort
Preferred Languages
Advance

Results 21 - 30 of 49 for addLink (0.14 sec)

  1. RELEASE.md

            behavior.
        *   Adding `clear_losses` API to be able to clear losses at the end of
            forward pass in a custom training loop in eager.
        *   Add support for passing list of lists to the `metrics` param in Keras
            `compile`.
        *   Added top-k to precision and recall to keras metrics.
        *   Adding public APIs for `cumsum` and `cumprod` keras backend functions.
    Registered: Sun Jun 16 05:45:23 UTC 2024
    - Last Modified: Tue Jun 11 23:24:08 UTC 2024
    - 730.3K bytes
    - Viewed (0)
  2. pilot/pkg/networking/util/util.go

    // "istio" metadata has been created for the cluster. If the "istio" metadata field is not already
    // defined, the subset information will not be added (to prevent adding this information where not
    // needed). This is used for telemetry reporting.
    func AddSubsetToMetadata(md *core.Metadata, subset string) {
    	if istioMeta, ok := md.FilterMetadata[IstioMetadataKey]; ok {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Thu Jun 13 01:56:28 UTC 2024
    - 28.5K bytes
    - Viewed (0)
  3. tensorflow/compiler/mlir/tensorflow/transforms/passes.h

    std::unique_ptr<OperationPass<func::FuncOp>>
    CreateTPUColocateCompositeResourceOps();
    
    // Creates a pass that expands outside compilation cluster at the head/tail of
    // TPU computation by adding outside compilation attribute to identity/cast ops
    // that are only used for host computation.
    std::unique_ptr<OperationPass<func::FuncOp>>
    CreateTPUHostComputationExpansionPass();
    
    Registered: Sun Jun 16 05:45:23 UTC 2024
    - Last Modified: Wed Jun 12 21:18:05 UTC 2024
    - 31.8K bytes
    - Viewed (0)
  4. pilot/pkg/xds/delta.go

    	// clusters correctly. Without this check, InitContext() call below would
    	// initialize with empty config, leading to reconnected Envoys loosing
    	// configuration. This is an additional safety check inaddition to adding
    	// cachesSynced logic to readiness probe to handle cases where kube-proxy
    	// ip tables update latencies.
    	// See https://github.com/istio/istio/issues/25495.
    	if !s.IsServerReady() {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jun 14 04:34:37 UTC 2024
    - 25.6K bytes
    - Viewed (0)
  5. cmd/bucket-lifecycle.go

    		return err
    	}
    
    	// Delete remote object from warm-tier
    	err := deleteObjectFromRemoteTier(ctx, oi.TransitionedObject.Name, oi.TransitionedObject.VersionID, oi.TransitionedObject.Tier)
    	if err == nil {
    		// Skip adding free version since we successfully deleted the
    		// remote object
    		opts.SkipFreeVersion = true
    	} else {
    		transitionLogIf(ctx, err)
    	}
    
    	// Now, delete object from hot-tier namespace
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Mon Jun 10 15:31:51 UTC 2024
    - 33.3K bytes
    - Viewed (0)
  6. pkg/config/analysis/analyzers/analyzers_test.go

    		return nil, fmt.Errorf("error setting up file kube source on testcase %s: %v", tc.name, err)
    	}
    
    	// Include default resources
    	err = sa.AddDefaultResources()
    	if err != nil {
    		return nil, fmt.Errorf("error adding default resources: %v", err)
    	}
    
    	return sa, nil
    }
    
    func runAnalyzer(sa *local.IstiodAnalyzer) (local.AnalysisResult, error) {
    	cancel := make(chan struct{})
    	result, err := sa.Analyze(cancel)
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jun 14 07:22:31 UTC 2024
    - 42.6K bytes
    - Viewed (0)
  7. staging/src/k8s.io/apiserver/pkg/storage/cacher/cacher_whitebox_test.go

    			select {
    			case <-stopCh:
    				return
    			default:
    				cacher.Lock()
    				cacher.bookmarkWatchers.popExpiredWatchersThreadUnsafe()
    				cacher.Unlock()
    			}
    		}
    	}()
    
    	// wait for adding/removing watchers to end
    	wg.Wait()
    
    	if watchErr != nil {
    		t.Fatal(watchErr)
    	}
    
    	// wait out the expiration period and pop expired watchers
    	time.Sleep(2 * time.Second)
    	cacher.Lock()
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 10:12:02 UTC 2024
    - 82.9K bytes
    - Viewed (0)
  8. pilot/pkg/config/kube/gateway/conversion.go

    				// Record that we were able to bind to the parent
    				pr.AttachedRoutes++
    			}
    			parentRefs = append(parentRefs, rpi)
    		}
    		for _, gw := range gateways[gk] {
    			// Append all matches. Note we may be adding mismatch section or ports; this is handled later
    			appendParent(gw, pk)
    		}
    	}
    	// Ensure stable order
    	slices.SortBy(parentRefs, func(a routeParentReference) string {
    Registered: Fri Jun 14 15:00:06 UTC 2024
    - Last Modified: Fri Jun 14 04:34:37 UTC 2024
    - 84.7K bytes
    - Viewed (0)
  9. cmd/erasure-object.go

    	if !dstOpts.NoAuditLog {
    		auditObjectErasureSet(ctx, dstObject, &er)
    	}
    
    	// This call shouldn't be used for anything other than metadata updates or adding self referential versions.
    	if !srcInfo.metadataOnly {
    		return oi, NotImplemented{}
    	}
    
    	if !dstOpts.NoLock {
    		lk := er.NewNSLock(dstBucket, dstObject)
    		lkctx, err := lk.GetLock(ctx, globalOperationTimeout)
    Registered: Sun Jun 16 00:44:34 UTC 2024
    - Last Modified: Mon Jun 10 15:51:27 UTC 2024
    - 78.6K bytes
    - Viewed (0)
  10. pkg/features/kube_features.go

    // available throughout Kubernetes binaries.
    //
    // Entries are separated from each other with blank lines to avoid sweeping gofmt changes
    // when adding or removing one entry.
    var defaultKubernetesFeatureGates = map[featuregate.Feature]featuregate.FeatureSpec{
    	CrossNamespaceVolumeDataSource: {Default: false, PreRelease: featuregate.Alpha},
    
    Registered: Sat Jun 15 01:39:40 UTC 2024
    - Last Modified: Wed Jun 12 22:51:23 UTC 2024
    - 45.2K bytes
    - Viewed (0)
Back to top