Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W 

A

ABORTED_VALUE - Static variable in enum org.tensorflow.framework.Code
The operation was aborted, typically due to a concurrency issue like sequencer check failures, transaction aborts, etc.
addAllAllocationRecords(Iterable<? extends AllocationRecord>) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
addAllArgOrder(Iterable<String>) - Method in class org.tensorflow.framework.ApiDef.Builder
List of original in_arg names to specify new argument order.
addAllArgument(Iterable<String>) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
repeated string argument = 1;
addAllAssetFileDef(Iterable<? extends AssetFileDef>) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
addAllAttr(Iterable<? extends ApiDef.Attr>) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
addAllAttr(Iterable<? extends OpDef.AttrDef>) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
addAllAttributes(Iterable<? extends CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor>) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
addAllAvailableDeviceInfo(Iterable<? extends AvailableDeviceInfo>) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
addAllB(Iterable<? extends Boolean>) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(bool)"
addAllBadConsumers(Iterable<? extends Integer>) - Method in class org.tensorflow.framework.VersionDef.Builder
Specific consumer versions which are disallowed (e.g.
addAllBoolVal(Iterable<? extends Boolean>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_BOOL
addAllBucket(Iterable<? extends Double>) - Method in class org.tensorflow.framework.HistogramProto.Builder
repeated double bucket = 7 [packed = true];
addAllBucketLimit(Iterable<? extends Double>) - Method in class org.tensorflow.framework.HistogramProto.Builder
Parallel arrays encoding the bucket boundaries and the bucket values.
addAllCcFlags(Iterable<String>) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
CC compiler flags, if known
addAllChildren(Iterable<? extends CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference>) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
addAllConstNodeInfo(Iterable<? extends GraphTransferConstNodeInfo>) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
addAllConstraint(Iterable<? extends KernelDef.AttrConstraint>) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
addAllControlInput(Iterable<? extends Integer>) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Ids of the control inputs for this node.
addAllCustomOptimizers(Iterable<? extends RewriterConfig.CustomGraphOptimizer>) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
addAllDcomplexVal(Iterable<? extends Double>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX128.
addAllDebugOps(Iterable<String>) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name(s) of the debugging op(s).
addAllDebugTensorWatchOpts(Iterable<? extends DebugTensorWatch>) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
addAllDebugUrls(Iterable<String>) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
URL(s) for debug targets(s).
addAllDefaultGraphInputTensorShape(Iterable<? extends RemoteFusedGraphExecuteInfo.TensorShapeTypeProto>) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
addAllDefaultGraphOutputTensorShape(Iterable<? extends RemoteFusedGraphExecuteInfo.TensorShapeTypeProto>) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
addAllDeviceFilters(Iterable<String>) - Method in class org.tensorflow.framework.ConfigProto.Builder
When any filters are present sessions will ignore all devices which do not match the filters.
addAllDeviceInfo(Iterable<? extends Any>) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
addAllDevicePersistentTensorAllocIds(Iterable<? extends Long>) - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
addAllDevStats(Iterable<? extends DeviceStepStats>) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
addAllDim(Iterable<? extends TensorShapeProto.Dim>) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
addAllDoubleVal(Iterable<? extends Double>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_DOUBLE.
addAllElement(Iterable<? extends MemmappedFileSystem.MemmappedFileSystemDirectoryElement>) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
addAllEnableOp(Iterable<String>) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
If present, only perform optimization for these ops.
addAllEndpoint(Iterable<? extends ApiDef.Endpoint>) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
addAllEnqueueOpName(Iterable<String>) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of enqueue operations.
addAllEntry(Iterable<? extends BenchmarkEntry>) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
addAllExtent(Iterable<? extends TensorSliceProto.Extent>) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
addAllF(Iterable<? extends Float>) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(float)"
addAllFeature(Iterable<? extends Feature>) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
addAllFeed(Iterable<String>) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be fed in the callable.
addAllFetch(Iterable<String>) - Method in class org.tensorflow.framework.CallableOptions.Builder
Fetches.
addAllFloatVal(Iterable<? extends Float>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_FLOAT.
addAllFullShape(Iterable<? extends Long>) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of the full variable.
addAllFunc(Iterable<? extends NameAttrList>) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
addAllFunction(Iterable<? extends FunctionDef>) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
addAllGradient(Iterable<? extends GradientDef>) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
addAllGraphInputNodeInfo(Iterable<? extends GraphTransferGraphInputNodeInfo>) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
addAllGraphInputNodeName(Iterable<String>) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph input node name
addAllGraphOutputNodeInfo(Iterable<? extends GraphTransferGraphOutputNodeInfo>) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
addAllGraphOutputNodeName(Iterable<String>) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph output node name
addAllHalfVal(Iterable<? extends Integer>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_HALF, DT_BFLOAT16.
addAllHostMemoryArg(Iterable<String>) - Method in class org.tensorflow.framework.KernelDef.Builder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
addAllI(Iterable<? extends Long>) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(int)"
addAllInArg(Iterable<? extends ApiDef.Arg>) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
addAllInput(Iterable<String>) - Method in class org.tensorflow.framework.NodeDef.Builder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
addAllInputArg(Iterable<? extends OpDef.ArgDef>) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
addAllInputInfo(Iterable<? extends CostGraphDef.Node.InputInfo>) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
addAllInt64Val(Iterable<? extends Long>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT64
addAllIntVal(Iterable<? extends Integer>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
addAllJob(Iterable<? extends JobDef>) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
addAllKernel(Iterable<? extends KernelDef>) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
addAllKeys(Iterable<String>) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
Keys for tensors in the VariantTensorDataProto.
addAllLines(Iterable<String>) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Line-by-line content of the source code file.
addAllLink(Iterable<? extends InterconnectLink>) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
addAllLoopEnterNames(Iterable<String>) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for enter tensors.
addAllLoopExitNames(Iterable<String>) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for exit tensors.
addAllMaxByteSize(Iterable<? extends Integer>) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
repeated int32 max_byte_size = 2;
addAllMemory(Iterable<? extends AllocatorMemoryUsed>) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
addAllMemoryLimitMb(Iterable<? extends Float>) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
Per "virtual" device memory limit, in MB.
addAllMetaGraphs(Iterable<? extends MetaGraphDef>) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
addAllNestedContexts(Iterable<? extends ControlFlowContextDef>) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
addAllNestedContexts(Iterable<? extends ControlFlowContextDef>) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
addAllNode(Iterable<? extends CostGraphDef.Node>) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
addAllNode(Iterable<? extends NodeDef>) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
addAllNodeDef(Iterable<? extends NodeDef>) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
addAllNodeInfo(Iterable<? extends GraphTransferNodeInfo>) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
addAllNodeInput(Iterable<? extends GraphTransferNodeInput>) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
addAllNodeInputInfo(Iterable<? extends GraphTransferNodeInputInfo>) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
addAllNodeOutputInfo(Iterable<? extends GraphTransferNodeOutputInfo>) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
addAllNodes(Iterable<? extends CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject>) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
addAllNodeStats(Iterable<? extends NodeExecStats>) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
addAllocationRecords(AllocationRecord) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
addAllocationRecords(int, AllocationRecord) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
addAllocationRecords(AllocationRecord.Builder) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
addAllocationRecords(int, AllocationRecord.Builder) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
addAllocationRecordsBuilder() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
addAllocationRecordsBuilder(int) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
addAllOp(Iterable<? extends ApiDef>) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
addAllOp(Iterable<? extends OpDef>) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
addAllOptimizers(Iterable<String>) - Method in class org.tensorflow.framework.RewriterConfig.Builder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
addAllOpts(Iterable<String>) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
Bazel compilation options, if known
addAllOriginalNodeNames(Iterable<String>) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
Opaque string inserted into error messages created by the runtime.
addAllOutArg(Iterable<? extends ApiDef.Arg>) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
addAllOutput(Iterable<? extends NodeOutput>) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
addAllOutputArg(Iterable<? extends OpDef.ArgDef>) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
addAllOutputInfo(Iterable<? extends CostGraphDef.Node.OutputInfo>) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
addAllPartitionGraphs(Iterable<? extends GraphDef>) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
addAllPersistentTensorAllocIds(Iterable<? extends Long>) - Method in class org.tensorflow.framework.MemoryStats.Builder
repeated int64 persistent_tensor_alloc_ids = 5;
addAllQueueClosedExceptionTypes(Iterable<? extends Code>) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
addAllQueueClosedExceptionTypesValue(Iterable<Integer>) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
addAllReferencedTensor(Iterable<? extends AllocationDescription>) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
addAllResourceHandleVal(Iterable<? extends ResourceHandleProto>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
addAllS(Iterable<? extends ByteString>) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(string)"
addAllScomplexVal(Iterable<? extends Float>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX64.
addAllSessionInterOpThreadPool(Iterable<? extends ThreadPoolOptionProto>) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
addAllShape(Iterable<? extends TensorShapeProto>) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
addAllShape(Iterable<? extends Long>) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
repeated int64 shape = 3;
addAllShape(Iterable<? extends Long>) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
repeated int64 shape = 2;
addAllShape(Iterable<? extends Long>) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
repeated int64 shape = 2;
addAllSlice(Iterable<? extends TensorSliceProto>) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
addAllSlices(Iterable<? extends TensorSliceProto>) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
addAllSlotVariables(Iterable<? extends CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference>) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
addAllSourceFiles(Iterable<? extends DebuggedSourceFile>) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
addAllStringVal(Iterable<? extends ByteString>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_STRING
addAllTags(Iterable<String>) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User supplied tag(s) on the meta_graph and included graph_def.
addAllTarget(Iterable<String>) - Method in class org.tensorflow.framework.CallableOptions.Builder
Target Nodes.
addAllTensor(Iterable<? extends TensorProto>) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
addAllTensor(Iterable<? extends SavedSliceMeta>) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
addAllTensorConnection(Iterable<? extends TensorConnection>) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
addAllTensorContent(Iterable<? extends ByteString>) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
repeated bytes tensor_content = 1;
addAllTensors(Iterable<? extends TensorProto>) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
addAllType(Iterable<? extends DataType>) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
addAllTypeValue(Iterable<Integer>) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
addAllUint32Val(Iterable<? extends Integer>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT32
addAllUint64Val(Iterable<? extends Long>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT64
addAllValue(Iterable<? extends ByteString>) - Method in class org.tensorflow.example.BytesList.Builder
repeated bytes value = 1;
addAllValue(Iterable<? extends Float>) - Method in class org.tensorflow.example.FloatList.Builder
repeated float value = 1 [packed = true];
addAllValue(Iterable<? extends Long>) - Method in class org.tensorflow.example.Int64List.Builder
repeated int64 value = 1 [packed = true];
addAllValue(Iterable<? extends Any>) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
addAllValue(Iterable<? extends ByteString>) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
repeated bytes value = 1;
addAllValue(Iterable<? extends Float>) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
repeated float value = 1 [packed = true];
addAllValue(Iterable<? extends Long>) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
repeated int64 value = 1 [packed = true];
addAllValue(Iterable<String>) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
repeated string value = 1;
addAllValue(Iterable<? extends Summary.Value>) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
addAllValues(Iterable<String>) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names that have been seen in this context.
addAllVariantVal(Iterable<? extends VariantTensorDataProto>) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
addAllVarOffset(Iterable<? extends Long>) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Offset of this variable into the full variable.
addAllVarShape(Iterable<? extends Long>) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of this variable.
addAllVirtualDevices(Iterable<? extends GPUOptions.Experimental.VirtualDevices>) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
addAllWorkerLog(Iterable<? extends Event>) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
addArgOrder(String) - Method in class org.tensorflow.framework.ApiDef.Builder
List of original in_arg names to specify new argument order.
addArgOrderBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Builder
List of original in_arg names to specify new argument order.
addArgument(String) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
repeated string argument = 1;
addArgumentBytes(ByteString) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
repeated string argument = 1;
addAssetFileDef(AssetFileDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
addAssetFileDef(int, AssetFileDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
addAssetFileDef(AssetFileDef.Builder) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
addAssetFileDef(int, AssetFileDef.Builder) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
addAssetFileDefBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
addAssetFileDefBuilder(int) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
addAttr(ApiDef.Attr) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
addAttr(int, ApiDef.Attr) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
addAttr(ApiDef.Attr.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
addAttr(int, ApiDef.Attr.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
addAttr(OpDef.AttrDef) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
addAttr(int, OpDef.AttrDef) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
addAttr(OpDef.AttrDef.Builder) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
addAttr(int, OpDef.AttrDef.Builder) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
addAttrBuilder() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
addAttrBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
addAttrBuilder() - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
addAttrBuilder(int) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
addAttributes(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
addAttributes(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
addAttributes(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
addAttributes(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
addAttributesBuilder() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
addAttributesBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
addAvailableDeviceInfo(AvailableDeviceInfo) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
addAvailableDeviceInfo(int, AvailableDeviceInfo) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
addAvailableDeviceInfo(AvailableDeviceInfo.Builder) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
addAvailableDeviceInfo(int, AvailableDeviceInfo.Builder) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
addAvailableDeviceInfoBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
addAvailableDeviceInfoBuilder(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
addB(boolean) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(bool)"
addBadConsumers(int) - Method in class org.tensorflow.framework.VersionDef.Builder
Specific consumer versions which are disallowed (e.g.
addBoolVal(boolean) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_BOOL
addBucket(double) - Method in class org.tensorflow.framework.HistogramProto.Builder
repeated double bucket = 7 [packed = true];
addBucketLimit(double) - Method in class org.tensorflow.framework.HistogramProto.Builder
Parallel arrays encoding the bucket boundaries and the bucket values.
addCcFlags(String) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
CC compiler flags, if known
addCcFlagsBytes(ByteString) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
CC compiler flags, if known
addChildren(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
addChildren(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
addChildren(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
addChildren(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
addChildrenBuilder() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
addChildrenBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
addConstNodeInfo(GraphTransferConstNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
addConstNodeInfo(int, GraphTransferConstNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
addConstNodeInfo(GraphTransferConstNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
addConstNodeInfo(int, GraphTransferConstNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
addConstNodeInfoBuilder() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
addConstNodeInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
addConstraint(KernelDef.AttrConstraint) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
addConstraint(int, KernelDef.AttrConstraint) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
addConstraint(KernelDef.AttrConstraint.Builder) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
addConstraint(int, KernelDef.AttrConstraint.Builder) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
addConstraintBuilder() - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
addConstraintBuilder(int) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
addControlInput(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Ids of the control inputs for this node.
addCustomOptimizers(RewriterConfig.CustomGraphOptimizer) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
addCustomOptimizers(int, RewriterConfig.CustomGraphOptimizer) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
addCustomOptimizers(RewriterConfig.CustomGraphOptimizer.Builder) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
addCustomOptimizers(int, RewriterConfig.CustomGraphOptimizer.Builder) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
addCustomOptimizersBuilder() - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
addCustomOptimizersBuilder(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
addDcomplexVal(double) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX128.
addDebugOps(String) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name(s) of the debugging op(s).
addDebugOpsBytes(ByteString) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name(s) of the debugging op(s).
addDebugTensorWatchOpts(DebugTensorWatch) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
addDebugTensorWatchOpts(int, DebugTensorWatch) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
addDebugTensorWatchOpts(DebugTensorWatch.Builder) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
addDebugTensorWatchOpts(int, DebugTensorWatch.Builder) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
addDebugTensorWatchOptsBuilder() - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
addDebugTensorWatchOptsBuilder(int) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
addDebugUrls(String) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
URL(s) for debug targets(s).
addDebugUrlsBytes(ByteString) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
URL(s) for debug targets(s).
addDefaultGraphInputTensorShape(RemoteFusedGraphExecuteInfo.TensorShapeTypeProto) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
addDefaultGraphInputTensorShape(int, RemoteFusedGraphExecuteInfo.TensorShapeTypeProto) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
addDefaultGraphInputTensorShape(RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
addDefaultGraphInputTensorShape(int, RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
addDefaultGraphInputTensorShapeBuilder() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
addDefaultGraphInputTensorShapeBuilder(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
addDefaultGraphOutputTensorShape(RemoteFusedGraphExecuteInfo.TensorShapeTypeProto) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
addDefaultGraphOutputTensorShape(int, RemoteFusedGraphExecuteInfo.TensorShapeTypeProto) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
addDefaultGraphOutputTensorShape(RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
addDefaultGraphOutputTensorShape(int, RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
addDefaultGraphOutputTensorShapeBuilder() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
addDefaultGraphOutputTensorShapeBuilder(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
addDeviceFilters(String) - Method in class org.tensorflow.framework.ConfigProto.Builder
When any filters are present sessions will ignore all devices which do not match the filters.
addDeviceFiltersBytes(ByteString) - Method in class org.tensorflow.framework.ConfigProto.Builder
When any filters are present sessions will ignore all devices which do not match the filters.
addDeviceInfo(Any) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
addDeviceInfo(int, Any) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
addDeviceInfo(Any.Builder) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
addDeviceInfo(int, Any.Builder) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
addDeviceInfoBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
addDeviceInfoBuilder(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
addDevicePersistentTensorAllocIds(long) - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
addDevStats(DeviceStepStats) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
addDevStats(int, DeviceStepStats) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
addDevStats(DeviceStepStats.Builder) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
addDevStats(int, DeviceStepStats.Builder) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
addDevStatsBuilder() - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
addDevStatsBuilder(int) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
addDim(TensorShapeProto.Dim) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
addDim(int, TensorShapeProto.Dim) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
addDim(TensorShapeProto.Dim.Builder) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
addDim(int, TensorShapeProto.Dim.Builder) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
addDimBuilder() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
addDimBuilder(int) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
addDoubleVal(double) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_DOUBLE.
addElement(MemmappedFileSystem.MemmappedFileSystemDirectoryElement) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
addElement(int, MemmappedFileSystem.MemmappedFileSystemDirectoryElement) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
addElement(MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
addElement(int, MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
addElementBuilder() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
addElementBuilder(int) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
addEnableOp(String) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
If present, only perform optimization for these ops.
addEnableOpBytes(ByteString) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
If present, only perform optimization for these ops.
addEndpoint(ApiDef.Endpoint) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
addEndpoint(int, ApiDef.Endpoint) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
addEndpoint(ApiDef.Endpoint.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
addEndpoint(int, ApiDef.Endpoint.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
addEndpointBuilder() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
addEndpointBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
addEnqueueOpName(String) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of enqueue operations.
addEnqueueOpNameBytes(ByteString) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of enqueue operations.
addEntry(BenchmarkEntry) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
addEntry(int, BenchmarkEntry) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
addEntry(BenchmarkEntry.Builder) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
addEntry(int, BenchmarkEntry.Builder) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
addEntryBuilder() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
addEntryBuilder(int) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
addExtent(TensorSliceProto.Extent) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
addExtent(int, TensorSliceProto.Extent) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
addExtent(TensorSliceProto.Extent.Builder) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
addExtent(int, TensorSliceProto.Extent.Builder) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
addExtentBuilder() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
addExtentBuilder(int) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
addF(float) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(float)"
addFeature(Feature) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
addFeature(int, Feature) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
addFeature(Feature.Builder) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
addFeature(int, Feature.Builder) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
addFeatureBuilder() - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
addFeatureBuilder(int) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
addFeed(String) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be fed in the callable.
addFeedBytes(ByteString) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be fed in the callable.
addFetch(String) - Method in class org.tensorflow.framework.CallableOptions.Builder
Fetches.
addFetchBytes(ByteString) - Method in class org.tensorflow.framework.CallableOptions.Builder
Fetches.
addFloatVal(float) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_FLOAT.
addFullShape(long) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of the full variable.
addFunc(NameAttrList) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
addFunc(int, NameAttrList) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
addFunc(NameAttrList.Builder) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
addFunc(int, NameAttrList.Builder) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
addFuncBuilder() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
addFuncBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
addFunction(FunctionDef) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
addFunction(int, FunctionDef) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
addFunction(FunctionDef.Builder) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
addFunction(int, FunctionDef.Builder) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
addFunctionBuilder() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
addFunctionBuilder(int) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
addGradient(GradientDef) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
addGradient(int, GradientDef) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
addGradient(GradientDef.Builder) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
addGradient(int, GradientDef.Builder) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
addGradientBuilder() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
addGradientBuilder(int) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
addGraphInputNodeInfo(GraphTransferGraphInputNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
addGraphInputNodeInfo(int, GraphTransferGraphInputNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
addGraphInputNodeInfo(GraphTransferGraphInputNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
addGraphInputNodeInfo(int, GraphTransferGraphInputNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
addGraphInputNodeInfoBuilder() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
addGraphInputNodeInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
addGraphInputNodeName(String) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph input node name
addGraphInputNodeNameBytes(ByteString) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph input node name
addGraphOutputNodeInfo(GraphTransferGraphOutputNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
addGraphOutputNodeInfo(int, GraphTransferGraphOutputNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
addGraphOutputNodeInfo(GraphTransferGraphOutputNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
addGraphOutputNodeInfo(int, GraphTransferGraphOutputNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
addGraphOutputNodeInfoBuilder() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
addGraphOutputNodeInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
addGraphOutputNodeName(String) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph output node name
addGraphOutputNodeNameBytes(ByteString) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph output node name
addHalfVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_HALF, DT_BFLOAT16.
addHostMemoryArg(String) - Method in class org.tensorflow.framework.KernelDef.Builder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
addHostMemoryArgBytes(ByteString) - Method in class org.tensorflow.framework.KernelDef.Builder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
addI(long) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(int)"
addInArg(ApiDef.Arg) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
addInArg(int, ApiDef.Arg) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
addInArg(ApiDef.Arg.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
addInArg(int, ApiDef.Arg.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
addInArgBuilder() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
addInArgBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
addInput(String) - Method in class org.tensorflow.framework.NodeDef.Builder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
addInputArg(OpDef.ArgDef) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
addInputArg(int, OpDef.ArgDef) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
addInputArg(OpDef.ArgDef.Builder) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
addInputArg(int, OpDef.ArgDef.Builder) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
addInputArgBuilder() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
addInputArgBuilder(int) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
addInputBytes(ByteString) - Method in class org.tensorflow.framework.NodeDef.Builder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
addInputInfo(CostGraphDef.Node.InputInfo) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
addInputInfo(int, CostGraphDef.Node.InputInfo) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
addInputInfo(CostGraphDef.Node.InputInfo.Builder) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
addInputInfo(int, CostGraphDef.Node.InputInfo.Builder) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
addInputInfoBuilder() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
addInputInfoBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
addInt64Val(long) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT64
addIntVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
addJob(JobDef) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
addJob(int, JobDef) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
addJob(JobDef.Builder) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
addJob(int, JobDef.Builder) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
addJobBuilder() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
addJobBuilder(int) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
addKernel(KernelDef) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
addKernel(int, KernelDef) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
addKernel(KernelDef.Builder) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
addKernel(int, KernelDef.Builder) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
addKernelBuilder() - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
addKernelBuilder(int) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
addKeys(String) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
Keys for tensors in the VariantTensorDataProto.
addKeysBytes(ByteString) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
Keys for tensors in the VariantTensorDataProto.
addLines(String) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Line-by-line content of the source code file.
addLinesBytes(ByteString) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Line-by-line content of the source code file.
addLink(InterconnectLink) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
addLink(int, InterconnectLink) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
addLink(InterconnectLink.Builder) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
addLink(int, InterconnectLink.Builder) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
addLinkBuilder() - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
addLinkBuilder(int) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
addLoopEnterNames(String) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for enter tensors.
addLoopEnterNamesBytes(ByteString) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for enter tensors.
addLoopExitNames(String) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for exit tensors.
addLoopExitNamesBytes(ByteString) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for exit tensors.
addMaxByteSize(int) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
repeated int32 max_byte_size = 2;
addMemory(AllocatorMemoryUsed) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
addMemory(int, AllocatorMemoryUsed) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
addMemory(AllocatorMemoryUsed.Builder) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
addMemory(int, AllocatorMemoryUsed.Builder) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
addMemoryBuilder() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
addMemoryBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
addMemoryLimitMb(float) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
Per "virtual" device memory limit, in MB.
addMetaGraphs(MetaGraphDef) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
addMetaGraphs(int, MetaGraphDef) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
addMetaGraphs(MetaGraphDef.Builder) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
addMetaGraphs(int, MetaGraphDef.Builder) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
addMetaGraphsBuilder() - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
addMetaGraphsBuilder(int) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
addNestedContexts(ControlFlowContextDef) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContexts(int, ControlFlowContextDef) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContexts(ControlFlowContextDef.Builder) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContexts(int, ControlFlowContextDef.Builder) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContexts(ControlFlowContextDef) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContexts(int, ControlFlowContextDef) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContexts(ControlFlowContextDef.Builder) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContexts(int, ControlFlowContextDef.Builder) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContextsBuilder() - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContextsBuilder(int) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContextsBuilder() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
addNestedContextsBuilder(int) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
addNode(CostGraphDef.Node) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
addNode(int, CostGraphDef.Node) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
addNode(CostGraphDef.Node.Builder) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
addNode(int, CostGraphDef.Node.Builder) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
addNode(NodeDef) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
addNode(int, NodeDef) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
addNode(NodeDef.Builder) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
addNode(int, NodeDef.Builder) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
addNodeBuilder() - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
addNodeBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
addNodeBuilder() - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
addNodeBuilder(int) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
addNodeDef(NodeDef) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
addNodeDef(int, NodeDef) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
addNodeDef(NodeDef.Builder) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
addNodeDef(int, NodeDef.Builder) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
addNodeDefBuilder() - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
addNodeDefBuilder(int) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
addNodeInfo(GraphTransferNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
addNodeInfo(int, GraphTransferNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
addNodeInfo(GraphTransferNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
addNodeInfo(int, GraphTransferNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
addNodeInfoBuilder() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
addNodeInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
addNodeInput(GraphTransferNodeInput) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
addNodeInput(int, GraphTransferNodeInput) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
addNodeInput(GraphTransferNodeInput.Builder) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
addNodeInput(int, GraphTransferNodeInput.Builder) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
addNodeInputBuilder() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
addNodeInputBuilder(int) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
addNodeInputInfo(GraphTransferNodeInputInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
addNodeInputInfo(int, GraphTransferNodeInputInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
addNodeInputInfo(GraphTransferNodeInputInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
addNodeInputInfo(int, GraphTransferNodeInputInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
addNodeInputInfoBuilder() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
addNodeInputInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
addNodeOutputInfo(GraphTransferNodeOutputInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
addNodeOutputInfo(int, GraphTransferNodeOutputInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
addNodeOutputInfo(GraphTransferNodeOutputInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
addNodeOutputInfo(int, GraphTransferNodeOutputInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
addNodeOutputInfoBuilder() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
addNodeOutputInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
addNodes(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
addNodes(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
addNodes(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
addNodes(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
addNodesBuilder() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
addNodesBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
addNodeStats(NodeExecStats) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
addNodeStats(int, NodeExecStats) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
addNodeStats(NodeExecStats.Builder) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
addNodeStats(int, NodeExecStats.Builder) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
addNodeStatsBuilder() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
addNodeStatsBuilder(int) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
addOp(ApiDef) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
addOp(int, ApiDef) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
addOp(ApiDef.Builder) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
addOp(int, ApiDef.Builder) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
addOp(OpDef) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
addOp(int, OpDef) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
addOp(OpDef.Builder) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
addOp(int, OpDef.Builder) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
addOpBuilder() - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
addOpBuilder(int) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
addOpBuilder() - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
addOpBuilder(int) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
addOptimizers(String) - Method in class org.tensorflow.framework.RewriterConfig.Builder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
addOptimizersBytes(ByteString) - Method in class org.tensorflow.framework.RewriterConfig.Builder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
addOpts(String) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
Bazel compilation options, if known
addOptsBytes(ByteString) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
Bazel compilation options, if known
addOriginalNodeNames(String) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
Opaque string inserted into error messages created by the runtime.
addOriginalNodeNamesBytes(ByteString) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
Opaque string inserted into error messages created by the runtime.
addOutArg(ApiDef.Arg) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
addOutArg(int, ApiDef.Arg) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
addOutArg(ApiDef.Arg.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
addOutArg(int, ApiDef.Arg.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
addOutArgBuilder() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
addOutArgBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
addOutput(NodeOutput) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
addOutput(int, NodeOutput) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
addOutput(NodeOutput.Builder) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
addOutput(int, NodeOutput.Builder) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
addOutputArg(OpDef.ArgDef) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
addOutputArg(int, OpDef.ArgDef) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
addOutputArg(OpDef.ArgDef.Builder) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
addOutputArg(int, OpDef.ArgDef.Builder) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
addOutputArgBuilder() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
addOutputArgBuilder(int) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
addOutputBuilder() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
addOutputBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
addOutputInfo(CostGraphDef.Node.OutputInfo) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
addOutputInfo(int, CostGraphDef.Node.OutputInfo) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
addOutputInfo(CostGraphDef.Node.OutputInfo.Builder) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
addOutputInfo(int, CostGraphDef.Node.OutputInfo.Builder) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
addOutputInfoBuilder() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
addOutputInfoBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
addPartitionGraphs(GraphDef) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
addPartitionGraphs(int, GraphDef) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
addPartitionGraphs(GraphDef.Builder) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
addPartitionGraphs(int, GraphDef.Builder) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
addPartitionGraphsBuilder() - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
addPartitionGraphsBuilder(int) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
addPersistentTensorAllocIds(long) - Method in class org.tensorflow.framework.MemoryStats.Builder
repeated int64 persistent_tensor_alloc_ids = 5;
addQueueClosedExceptionTypes(Code) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
addQueueClosedExceptionTypesValue(int) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
addReferencedTensor(AllocationDescription) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
addReferencedTensor(int, AllocationDescription) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
addReferencedTensor(AllocationDescription.Builder) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
addReferencedTensor(int, AllocationDescription.Builder) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
addReferencedTensorBuilder() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
addReferencedTensorBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.BytesList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.Example.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.Feature.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.FeatureList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.FeatureLists.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.Features.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.FloatList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.Int64List.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.SequenceExample.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ApiDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ApiDefs.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AttrValue.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CondContextDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DebugOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GPUOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GradientDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.HistogramProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.KernelDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.KernelList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.LocalLinks.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryStats.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NodeDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NodeOutput.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OpDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OpList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RPCOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RunMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RunOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SavedModel.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.StepStats.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.Summary.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.Summary.Image.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.Summary.Value.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorConnection.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorDescription.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.VariableDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.VersionDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.Event.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.LogMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SavedSlice.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SaverDef.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SessionLog.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
addResourceHandleVal(ResourceHandleProto) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
addResourceHandleVal(int, ResourceHandleProto) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
addResourceHandleVal(ResourceHandleProto.Builder) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
addResourceHandleVal(int, ResourceHandleProto.Builder) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
addResourceHandleValBuilder() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
addResourceHandleValBuilder(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
addS(ByteString) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(string)"
addScomplexVal(float) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX64.
addSessionInterOpThreadPool(ThreadPoolOptionProto) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
addSessionInterOpThreadPool(int, ThreadPoolOptionProto) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
addSessionInterOpThreadPool(ThreadPoolOptionProto.Builder) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
addSessionInterOpThreadPool(int, ThreadPoolOptionProto.Builder) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
addSessionInterOpThreadPoolBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
addSessionInterOpThreadPoolBuilder(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
addShape(TensorShapeProto) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
addShape(int, TensorShapeProto) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
addShape(TensorShapeProto.Builder) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
addShape(int, TensorShapeProto.Builder) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
addShape(long) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
repeated int64 shape = 3;
addShape(long) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
repeated int64 shape = 2;
addShape(long) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
repeated int64 shape = 2;
addShapeBuilder() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
addShapeBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
addSlice(TensorSliceProto) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
addSlice(int, TensorSliceProto) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
addSlice(TensorSliceProto.Builder) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
addSlice(int, TensorSliceProto.Builder) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
addSliceBuilder() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
addSliceBuilder(int) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
addSlices(TensorSliceProto) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
addSlices(int, TensorSliceProto) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
addSlices(TensorSliceProto.Builder) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
addSlices(int, TensorSliceProto.Builder) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
addSlicesBuilder() - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
addSlicesBuilder(int) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
addSlotVariables(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
addSlotVariables(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
addSlotVariables(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
addSlotVariables(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
addSlotVariablesBuilder() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
addSlotVariablesBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
addSourceFiles(DebuggedSourceFile) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
addSourceFiles(int, DebuggedSourceFile) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
addSourceFiles(DebuggedSourceFile.Builder) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
addSourceFiles(int, DebuggedSourceFile.Builder) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
addSourceFilesBuilder() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
addSourceFilesBuilder(int) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
addStringVal(ByteString) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_STRING
addTags(String) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User supplied tag(s) on the meta_graph and included graph_def.
addTagsBytes(ByteString) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User supplied tag(s) on the meta_graph and included graph_def.
addTarget(String) - Method in class org.tensorflow.framework.CallableOptions.Builder
Target Nodes.
addTargetBytes(ByteString) - Method in class org.tensorflow.framework.CallableOptions.Builder
Target Nodes.
addTensor(TensorProto) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
addTensor(int, TensorProto) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
addTensor(TensorProto.Builder) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
addTensor(int, TensorProto.Builder) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
addTensor(SavedSliceMeta) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
addTensor(int, SavedSliceMeta) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
addTensor(SavedSliceMeta.Builder) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
addTensor(int, SavedSliceMeta.Builder) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
addTensorBuilder() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
addTensorBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
addTensorBuilder() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
addTensorBuilder(int) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
addTensorConnection(TensorConnection) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
addTensorConnection(int, TensorConnection) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
addTensorConnection(TensorConnection.Builder) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
addTensorConnection(int, TensorConnection.Builder) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
addTensorConnectionBuilder() - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
addTensorConnectionBuilder(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
addTensorContent(ByteString) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
repeated bytes tensor_content = 1;
addTensors(TensorProto) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
addTensors(int, TensorProto) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
addTensors(TensorProto.Builder) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
addTensors(int, TensorProto.Builder) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
addTensorsBuilder() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
addTensorsBuilder(int) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
addType(DataType) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
addTypeValue(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
addUint32Val(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT32
addUint64Val(long) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT64
addValue(ByteString) - Method in class org.tensorflow.example.BytesList.Builder
repeated bytes value = 1;
addValue(float) - Method in class org.tensorflow.example.FloatList.Builder
repeated float value = 1 [packed = true];
addValue(long) - Method in class org.tensorflow.example.Int64List.Builder
repeated int64 value = 1 [packed = true];
addValue(Any) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
addValue(int, Any) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
addValue(Any.Builder) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
addValue(int, Any.Builder) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
addValue(ByteString) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
repeated bytes value = 1;
addValue(float) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
repeated float value = 1 [packed = true];
addValue(long) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
repeated int64 value = 1 [packed = true];
addValue(String) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
repeated string value = 1;
addValue(Summary.Value) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
addValue(int, Summary.Value) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
addValue(Summary.Value.Builder) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
addValue(int, Summary.Value.Builder) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
addValueBuilder() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
addValueBuilder(int) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
addValueBuilder() - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
addValueBuilder(int) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
addValueBytes(ByteString) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
repeated string value = 1;
addValues(String) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names that have been seen in this context.
addValuesBytes(ByteString) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names that have been seen in this context.
addVariantVal(VariantTensorDataProto) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
addVariantVal(int, VariantTensorDataProto) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
addVariantVal(VariantTensorDataProto.Builder) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
addVariantVal(int, VariantTensorDataProto.Builder) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
addVariantValBuilder() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
addVariantValBuilder(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
addVarOffset(long) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Offset of this variable into the full variable.
addVarShape(long) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of this variable.
addVirtualDevices(GPUOptions.Experimental.VirtualDevices) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
addVirtualDevices(int, GPUOptions.Experimental.VirtualDevices) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
addVirtualDevices(GPUOptions.Experimental.VirtualDevices.Builder) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
addVirtualDevices(int, GPUOptions.Experimental.VirtualDevices.Builder) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
addVirtualDevicesBuilder() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
addVirtualDevicesBuilder(int) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
addWorkerLog(Event) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
addWorkerLog(int, Event) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
addWorkerLog(Event.Builder) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
addWorkerLog(int, Event.Builder) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
addWorkerLogBuilder() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
addWorkerLogBuilder(int) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
AGGRESSIVE_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.Toggle
Enable some aggressive optimizations that use assumptions that TF graphs may break.
ALIAS_INPUT_PORT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
ALL_END_REL_MICROS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
ALL_END_REL_NANOS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
ALL_START_MICROS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
ALL_START_NANOS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
ALLOC_BYTES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocationRecord
 
ALLOC_MICROS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocationRecord
 
ALLOCATED_BYTES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocationDescription
 
ALLOCATION_DESCRIPTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorDescription
 
ALLOCATION_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocationDescription
 
ALLOCATION_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawAllocation
 
ALLOCATION_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawDeallocation
 
ALLOCATION_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
ALLOCATION_RECORDS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocatorMemoryUsed
 
AllocationDescription - Class in org.tensorflow.framework
Protobuf type tensorflow.AllocationDescription
AllocationDescription.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.AllocationDescription
AllocationDescriptionOrBuilder - Interface in org.tensorflow.framework
 
AllocationDescriptionProtos - Class in org.tensorflow.framework
 
AllocationRecord - Class in org.tensorflow.framework
An allocation/de-allocation operation performed by the allocator.
AllocationRecord.Builder - Class in org.tensorflow.framework
An allocation/de-allocation operation performed by the allocator.
AllocationRecordOrBuilder - Interface in org.tensorflow.framework
 
ALLOCATOR_BYTES_IN_USE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocatorMemoryUsed
 
ALLOCATOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocationDescription
 
ALLOCATOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocatorMemoryUsed
 
ALLOCATOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawAllocation
 
ALLOCATOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawDeallocation
 
ALLOCATOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
ALLOCATOR_TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions
 
AllocatorMemoryUsed - Class in org.tensorflow.framework
Protobuf type tensorflow.AllocatorMemoryUsed
AllocatorMemoryUsed.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.AllocatorMemoryUsed
AllocatorMemoryUsedOrBuilder - Interface in org.tensorflow.framework
 
ALLOW_GROWTH_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions
 
ALLOW_SOFT_PLACEMENT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
ALLOWED_VALUES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.KernelDef.AttrConstraint
 
ALLOWED_VALUES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.AttrDef
 
ALLOWS_UNINITIALIZED_INPUT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
ALREADY_EXISTS_VALUE - Static variable in enum org.tensorflow.framework.Code
Some entity that we attempted to create (e.g., file or directory) already exists.
ANDROID_BENCHMARK_VALUE - Static variable in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
ANDROID_BENCHMARK = 3;
ANY_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
ANY_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CollectionDef
 
ApiDef - Class in org.tensorflow.framework
Used to specify and override the default API & behavior in the generated code for client languages, from what you would get from the OpDef alone.
ApiDef.Arg - Class in org.tensorflow.framework
Protobuf type tensorflow.ApiDef.Arg
ApiDef.Arg.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.ApiDef.Arg
ApiDef.ArgOrBuilder - Interface in org.tensorflow.framework
 
ApiDef.Attr - Class in org.tensorflow.framework
Description of the graph-construction-time configuration of this Op.
ApiDef.Attr.Builder - Class in org.tensorflow.framework
Description of the graph-construction-time configuration of this Op.
ApiDef.AttrOrBuilder - Interface in org.tensorflow.framework
 
ApiDef.Builder - Class in org.tensorflow.framework
Used to specify and override the default API & behavior in the generated code for client languages, from what you would get from the OpDef alone.
ApiDef.Endpoint - Class in org.tensorflow.framework
If you specify any endpoint, this will replace all of the inherited endpoints.
ApiDef.Endpoint.Builder - Class in org.tensorflow.framework
If you specify any endpoint, this will replace all of the inherited endpoints.
ApiDef.EndpointOrBuilder - Interface in org.tensorflow.framework
 
ApiDef.Visibility - Enum in org.tensorflow.framework
Protobuf enum tensorflow.ApiDef.Visibility
ApiDefOrBuilder - Interface in org.tensorflow.framework
 
ApiDefProtos - Class in org.tensorflow.framework
 
ApiDefs - Class in org.tensorflow.framework
Protobuf type tensorflow.ApiDefs
ApiDefs.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.ApiDefs
ApiDefsOrBuilder - Interface in org.tensorflow.framework
 
ARG_ORDER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
ARGUMENT_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.RunConfiguration
 
ARITHMETIC_OPTIMIZATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
ASSET_FILE_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef
 
AssetFileDef - Class in org.tensorflow.framework
An asset file def for a single file or a set of sharded files with the same name.
AssetFileDef.Builder - Class in org.tensorflow.framework
An asset file def for a single file or a set of sharded files with the same name.
AssetFileDefOrBuilder - Interface in org.tensorflow.framework
 
ATTR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
ATTR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.FunctionDef
 
ATTR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NameAttrList
 
ATTR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeDef
 
ATTR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
ATTRIBUTES_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
AttrValue - Class in org.tensorflow.framework
Protocol buffer representing the value for an attr used to configure an Op.
AttrValue.Builder - Class in org.tensorflow.framework
Protocol buffer representing the value for an attr used to configure an Op.
AttrValue.ListValue - Class in org.tensorflow.framework
LINT.IfChange
AttrValue.ListValue.Builder - Class in org.tensorflow.framework
LINT.IfChange
AttrValue.ListValueOrBuilder - Interface in org.tensorflow.framework
 
AttrValue.ValueCase - Enum in org.tensorflow.framework
 
AttrValueOrBuilder - Interface in org.tensorflow.framework
 
AttrValueProtos - Class in org.tensorflow.framework
 
AUDIO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Value
 
AUTO_PARALLEL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
AutoParallelOptions - Class in org.tensorflow.framework
Protobuf type tensorflow.AutoParallelOptions
AutoParallelOptions.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.AutoParallelOptions
AutoParallelOptionsOrBuilder - Interface in org.tensorflow.framework
 
AVAILABLE_DEVICE_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.MachineConfiguration
 
AVAILABLE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.MemoryInfo
 
AvailableDeviceInfo - Class in org.tensorflow.util.testlog
Matches DeviceAttributes
AvailableDeviceInfo.Builder - Class in org.tensorflow.util.testlog
Matches DeviceAttributes
AvailableDeviceInfoOrBuilder - Interface in org.tensorflow.util.testlog
 

B

B_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue
 
B_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue.ListValue
 
BACK_PROP_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
BAD_CONSUMERS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VersionDef
 
BANDWIDTH_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
BENCHMARK_TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
BenchmarkEntries - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.BenchmarkEntries
BenchmarkEntries.Builder - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.BenchmarkEntries
BenchmarkEntriesOrBuilder - Interface in org.tensorflow.util.testlog
 
BenchmarkEntry - Class in org.tensorflow.util.testlog
Each unit test or benchmark in a test or benchmark run provides some set of information.
BenchmarkEntry.Builder - Class in org.tensorflow.util.testlog
Each unit test or benchmark in a test or benchmark run provides some set of information.
BenchmarkEntryOrBuilder - Interface in org.tensorflow.util.testlog
 
BIG_VALUE - Static variable in enum org.tensorflow.util.BundleHeaderProto.Endianness
BIG = 1;
BITS_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.PlatformInfo
 
BOOL_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
BRANCH_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CondContextDef
 
BUCKET_FIELD_NUMBER - Static variable in class org.tensorflow.framework.HistogramProto
 
BUCKET_LIMIT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.HistogramProto
 
build() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
build() - Method in class org.tensorflow.distruntime.JobDef.Builder
 
build() - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
build() - Method in class org.tensorflow.example.BytesList.Builder
 
build() - Method in class org.tensorflow.example.Example.Builder
 
build() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
build() - Method in class org.tensorflow.example.Feature.Builder
 
build() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
build() - Method in class org.tensorflow.example.FeatureList.Builder
 
build() - Method in class org.tensorflow.example.FeatureLists.Builder
 
build() - Method in class org.tensorflow.example.Features.Builder
 
build() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
build() - Method in class org.tensorflow.example.FloatList.Builder
 
build() - Method in class org.tensorflow.example.Int64List.Builder
 
build() - Method in class org.tensorflow.example.SequenceExample.Builder
 
build() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
build() - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
build() - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
build() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
build() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
build() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
build() - Method in class org.tensorflow.framework.ApiDef.Builder
 
build() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
build() - Method in class org.tensorflow.framework.ApiDefs.Builder
 
build() - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
build() - Method in class org.tensorflow.framework.AttrValue.Builder
 
build() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
build() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
build() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
build() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
build() - Method in class org.tensorflow.framework.CollectionDef.Builder
 
build() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
build() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
build() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
build() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
build() - Method in class org.tensorflow.framework.CondContextDef.Builder
 
build() - Method in class org.tensorflow.framework.ConfigProto.Builder
 
build() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
build() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
build() - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
build() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
build() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
build() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
build() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
build() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
build() - Method in class org.tensorflow.framework.DebugOptions.Builder
 
build() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
build() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
build() - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
build() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
build() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
build() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
build() - Method in class org.tensorflow.framework.GPUOptions.Builder
 
build() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
build() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
build() - Method in class org.tensorflow.framework.GradientDef.Builder
 
build() - Method in class org.tensorflow.framework.GraphDef.Builder
 
build() - Method in class org.tensorflow.framework.GraphOptions.Builder
 
build() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
build() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
build() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
build() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
build() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
build() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
build() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
build() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
build() - Method in class org.tensorflow.framework.HistogramProto.Builder
 
build() - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
build() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
build() - Method in class org.tensorflow.framework.KernelDef.Builder
 
build() - Method in class org.tensorflow.framework.KernelList.Builder
 
build() - Method in class org.tensorflow.framework.LocalLinks.Builder
 
build() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
build() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
build() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
build() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
build() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
build() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
build() - Method in class org.tensorflow.framework.MemoryStats.Builder
 
build() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
build() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
build() - Method in class org.tensorflow.framework.NameAttrList.Builder
 
build() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
build() - Method in class org.tensorflow.framework.NodeDef.Builder
 
build() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
build() - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
build() - Method in class org.tensorflow.framework.NodeOutput.Builder
 
build() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
build() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
build() - Method in class org.tensorflow.framework.OpDef.Builder
 
build() - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
build() - Method in class org.tensorflow.framework.OpList.Builder
 
build() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
build() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
build() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
build() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
build() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
build() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
build() - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
build() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
build() - Method in class org.tensorflow.framework.RPCOptions.Builder
 
build() - Method in class org.tensorflow.framework.RunMetadata.Builder
 
build() - Method in class org.tensorflow.framework.RunOptions.Builder
 
build() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
build() - Method in class org.tensorflow.framework.SavedModel.Builder
 
build() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
build() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
build() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
build() - Method in class org.tensorflow.framework.StepStats.Builder
 
build() - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
build() - Method in class org.tensorflow.framework.Summary.Builder
 
build() - Method in class org.tensorflow.framework.Summary.Image.Builder
 
build() - Method in class org.tensorflow.framework.Summary.Value.Builder
 
build() - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
build() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
build() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
build() - Method in class org.tensorflow.framework.TensorConnection.Builder
 
build() - Method in class org.tensorflow.framework.TensorDescription.Builder
 
build() - Method in class org.tensorflow.framework.TensorInfo.Builder
 
build() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
build() - Method in class org.tensorflow.framework.TensorProto.Builder
 
build() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
build() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
build() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
build() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
build() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
build() - Method in class org.tensorflow.framework.ValuesDef.Builder
 
build() - Method in class org.tensorflow.framework.VariableDef.Builder
 
build() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
build() - Method in class org.tensorflow.framework.VersionDef.Builder
 
build() - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
build() - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
build() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
build() - Method in class org.tensorflow.util.Event.Builder
 
build() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
build() - Method in class org.tensorflow.util.LogMessage.Builder
 
build() - Method in class org.tensorflow.util.SavedSlice.Builder
 
build() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
build() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
build() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
build() - Method in class org.tensorflow.util.SaverDef.Builder
 
build() - Method in class org.tensorflow.util.SessionLog.Builder
 
build() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
build() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
build() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
build() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
build() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
build() - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
build() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
build() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
build() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
build() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
build() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
build() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
build() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
build() - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
build() - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
build() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
build() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
build() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
build() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
build() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
build() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
build() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
build() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
build() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
build() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
build() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
build() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
BUILD_CONFIGURATION_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
BUILD_COST_MODEL_AFTER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphOptions
 
BUILD_COST_MODEL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphOptions
 
BuildConfiguration - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.BuildConfiguration
BuildConfiguration.Builder - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.BuildConfiguration
BuildConfigurationOrBuilder - Interface in org.tensorflow.util.testlog
 
buildPartial() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
buildPartial() - Method in class org.tensorflow.distruntime.JobDef.Builder
 
buildPartial() - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
buildPartial() - Method in class org.tensorflow.example.BytesList.Builder
 
buildPartial() - Method in class org.tensorflow.example.Example.Builder
 
buildPartial() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
buildPartial() - Method in class org.tensorflow.example.Feature.Builder
 
buildPartial() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
buildPartial() - Method in class org.tensorflow.example.FeatureList.Builder
 
buildPartial() - Method in class org.tensorflow.example.FeatureLists.Builder
 
buildPartial() - Method in class org.tensorflow.example.Features.Builder
 
buildPartial() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
buildPartial() - Method in class org.tensorflow.example.FloatList.Builder
 
buildPartial() - Method in class org.tensorflow.example.Int64List.Builder
 
buildPartial() - Method in class org.tensorflow.example.SequenceExample.Builder
 
buildPartial() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
buildPartial() - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
buildPartial() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ApiDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ApiDefs.Builder
 
buildPartial() - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.AttrValue.Builder
 
buildPartial() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
buildPartial() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CollectionDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CondContextDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ConfigProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
buildPartial() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
buildPartial() - Method in class org.tensorflow.framework.DebugOptions.Builder
 
buildPartial() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
buildPartial() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
buildPartial() - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
buildPartial() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
buildPartial() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GPUOptions.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GradientDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GraphDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GraphOptions.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.HistogramProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
buildPartial() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
buildPartial() - Method in class org.tensorflow.framework.KernelDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.KernelList.Builder
 
buildPartial() - Method in class org.tensorflow.framework.LocalLinks.Builder
 
buildPartial() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
buildPartial() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
buildPartial() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
buildPartial() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
buildPartial() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
buildPartial() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
buildPartial() - Method in class org.tensorflow.framework.MemoryStats.Builder
 
buildPartial() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.NameAttrList.Builder
 
buildPartial() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.NodeDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
buildPartial() - Method in class org.tensorflow.framework.NodeOutput.Builder
 
buildPartial() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.OpDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
buildPartial() - Method in class org.tensorflow.framework.OpList.Builder
 
buildPartial() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
buildPartial() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
buildPartial() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
buildPartial() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
buildPartial() - Method in class org.tensorflow.framework.RPCOptions.Builder
 
buildPartial() - Method in class org.tensorflow.framework.RunMetadata.Builder
 
buildPartial() - Method in class org.tensorflow.framework.RunOptions.Builder
 
buildPartial() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
buildPartial() - Method in class org.tensorflow.framework.SavedModel.Builder
 
buildPartial() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
buildPartial() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.StepStats.Builder
 
buildPartial() - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
buildPartial() - Method in class org.tensorflow.framework.Summary.Builder
 
buildPartial() - Method in class org.tensorflow.framework.Summary.Image.Builder
 
buildPartial() - Method in class org.tensorflow.framework.Summary.Value.Builder
 
buildPartial() - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
buildPartial() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
buildPartial() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
buildPartial() - Method in class org.tensorflow.framework.TensorConnection.Builder
 
buildPartial() - Method in class org.tensorflow.framework.TensorDescription.Builder
 
buildPartial() - Method in class org.tensorflow.framework.TensorInfo.Builder
 
buildPartial() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
buildPartial() - Method in class org.tensorflow.framework.TensorProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
buildPartial() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.ValuesDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.VariableDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
buildPartial() - Method in class org.tensorflow.framework.VersionDef.Builder
 
buildPartial() - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
buildPartial() - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
buildPartial() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
buildPartial() - Method in class org.tensorflow.util.Event.Builder
 
buildPartial() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
buildPartial() - Method in class org.tensorflow.util.LogMessage.Builder
 
buildPartial() - Method in class org.tensorflow.util.SavedSlice.Builder
 
buildPartial() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
buildPartial() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
buildPartial() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
buildPartial() - Method in class org.tensorflow.util.SaverDef.Builder
 
buildPartial() - Method in class org.tensorflow.util.SessionLog.Builder
 
buildPartial() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
buildPartial() - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
buildPartial() - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
buildPartial() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
buildPartial() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
buildPartial() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
buildPartial() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
buildPartial() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
buildPartial() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
buildPartial() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
buildPartial() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
buildPartial() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
buildPartial() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
buildPartial() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
buildPartial() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
BundleEntryProto - Class in org.tensorflow.util
Describes the metadata related to a checkpointed tensor.
BundleEntryProto.Builder - Class in org.tensorflow.util
Describes the metadata related to a checkpointed tensor.
BundleEntryProtoOrBuilder - Interface in org.tensorflow.util
 
BundleHeaderProto - Class in org.tensorflow.util
Special header that is associated with a bundle.
BundleHeaderProto.Builder - Class in org.tensorflow.util
Special header that is associated with a bundle.
BundleHeaderProto.Endianness - Enum in org.tensorflow.util
An enum indicating the endianness of the platform that produced this bundle.
BundleHeaderProtoOrBuilder - Interface in org.tensorflow.util
 
BUS_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceLocality
 
BUS_ID_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.GPUInfo
 
BYTES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebuggedSourceFile
 
BYTES_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.example.Feature
 
BYTES_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CollectionDef
 
BytesList - Class in org.tensorflow.example
Containers to hold repeated fundamental values.
BytesList.Builder - Class in org.tensorflow.example
Containers to hold repeated fundamental values.
BytesListOrBuilder - Interface in org.tensorflow.example
 

C

CACHE_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.CPUInfo
 
CallableOptions - Class in org.tensorflow.framework
Defines a subgraph in another `GraphDef` as a set of feed points and nodes to be fetched or executed.
CallableOptions.Builder - Class in org.tensorflow.framework
Defines a subgraph in another `GraphDef` as a set of feed points and nodes to be fetched or executed.
CallableOptionsOrBuilder - Interface in org.tensorflow.framework
 
CANCEL_OP_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.QueueRunnerDef
 
CANCELLED_VALUE - Static variable in enum org.tensorflow.framework.Code
The operation was cancelled (typically by the caller).
CC_FLAGS_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.BuildConfiguration
 
CHANGELIST_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.CommitId
 
CHECKPOINT_KEY_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
CHECKPOINT_PATH_FIELD_NUMBER - Static variable in class org.tensorflow.util.SessionLog
 
CHECKPOINT_VALUE - Static variable in enum org.tensorflow.util.SessionLog.SessionStatus
CHECKPOINT = 3;
CheckpointableObjectGraphOuterClass - Class in tensorflow
 
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph - Class in tensorflow
Protobuf type tensorflow.CheckpointableObjectGraph
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder - Class in tensorflow
Protobuf type tensorflow.CheckpointableObjectGraph
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject - Class in tensorflow
Protobuf type tensorflow.CheckpointableObjectGraph.CheckpointableObject
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder - Class in tensorflow
Protobuf type tensorflow.CheckpointableObjectGraph.CheckpointableObject
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference - Class in tensorflow
Protobuf type tensorflow.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder - Class in tensorflow
Protobuf type tensorflow.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReferenceOrBuilder - Interface in tensorflow
 
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor - Class in tensorflow
Protobuf type tensorflow.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder - Class in tensorflow
Protobuf type tensorflow.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensorOrBuilder - Interface in tensorflow
 
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference - Class in tensorflow
Protobuf type tensorflow.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder - Class in tensorflow
Protobuf type tensorflow.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReferenceOrBuilder - Interface in tensorflow
 
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder - Interface in tensorflow
 
CheckpointableObjectGraphOuterClass.CheckpointableObjectGraphOrBuilder - Interface in tensorflow
 
CHILDREN_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
clear() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
clear() - Method in class org.tensorflow.distruntime.JobDef.Builder
 
clear() - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
clear() - Method in class org.tensorflow.example.BytesList.Builder
 
clear() - Method in class org.tensorflow.example.Example.Builder
 
clear() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
clear() - Method in class org.tensorflow.example.Feature.Builder
 
clear() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
clear() - Method in class org.tensorflow.example.FeatureList.Builder
 
clear() - Method in class org.tensorflow.example.FeatureLists.Builder
 
clear() - Method in class org.tensorflow.example.Features.Builder
 
clear() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
clear() - Method in class org.tensorflow.example.FloatList.Builder
 
clear() - Method in class org.tensorflow.example.Int64List.Builder
 
clear() - Method in class org.tensorflow.example.SequenceExample.Builder
 
clear() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
clear() - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
clear() - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
clear() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
clear() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
clear() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
clear() - Method in class org.tensorflow.framework.ApiDef.Builder
 
clear() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
clear() - Method in class org.tensorflow.framework.ApiDefs.Builder
 
clear() - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
clear() - Method in class org.tensorflow.framework.AttrValue.Builder
 
clear() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
clear() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
clear() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
clear() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
clear() - Method in class org.tensorflow.framework.CollectionDef.Builder
 
clear() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
clear() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
clear() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
clear() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
clear() - Method in class org.tensorflow.framework.CondContextDef.Builder
 
clear() - Method in class org.tensorflow.framework.ConfigProto.Builder
 
clear() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
clear() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
clear() - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
clear() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
clear() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
clear() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
clear() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
clear() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
clear() - Method in class org.tensorflow.framework.DebugOptions.Builder
 
clear() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
clear() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
clear() - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
clear() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
clear() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
clear() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
clear() - Method in class org.tensorflow.framework.GPUOptions.Builder
 
clear() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
clear() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
clear() - Method in class org.tensorflow.framework.GradientDef.Builder
 
clear() - Method in class org.tensorflow.framework.GraphDef.Builder
 
clear() - Method in class org.tensorflow.framework.GraphOptions.Builder
 
clear() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
clear() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
clear() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
clear() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
clear() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
clear() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
clear() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
clear() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
clear() - Method in class org.tensorflow.framework.HistogramProto.Builder
 
clear() - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
clear() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
clear() - Method in class org.tensorflow.framework.KernelDef.Builder
 
clear() - Method in class org.tensorflow.framework.KernelList.Builder
 
clear() - Method in class org.tensorflow.framework.LocalLinks.Builder
 
clear() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
clear() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
clear() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
clear() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
clear() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
clear() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
clear() - Method in class org.tensorflow.framework.MemoryStats.Builder
 
clear() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
clear() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
clear() - Method in class org.tensorflow.framework.NameAttrList.Builder
 
clear() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
clear() - Method in class org.tensorflow.framework.NodeDef.Builder
 
clear() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
clear() - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
clear() - Method in class org.tensorflow.framework.NodeOutput.Builder
 
clear() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
clear() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
clear() - Method in class org.tensorflow.framework.OpDef.Builder
 
clear() - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
clear() - Method in class org.tensorflow.framework.OpList.Builder
 
clear() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
clear() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
clear() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
clear() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
clear() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
clear() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
clear() - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
clear() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
clear() - Method in class org.tensorflow.framework.RPCOptions.Builder
 
clear() - Method in class org.tensorflow.framework.RunMetadata.Builder
 
clear() - Method in class org.tensorflow.framework.RunOptions.Builder
 
clear() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
clear() - Method in class org.tensorflow.framework.SavedModel.Builder
 
clear() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
clear() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
clear() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
clear() - Method in class org.tensorflow.framework.StepStats.Builder
 
clear() - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
clear() - Method in class org.tensorflow.framework.Summary.Builder
 
clear() - Method in class org.tensorflow.framework.Summary.Image.Builder
 
clear() - Method in class org.tensorflow.framework.Summary.Value.Builder
 
clear() - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
clear() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
clear() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
clear() - Method in class org.tensorflow.framework.TensorConnection.Builder
 
clear() - Method in class org.tensorflow.framework.TensorDescription.Builder
 
clear() - Method in class org.tensorflow.framework.TensorInfo.Builder
 
clear() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
clear() - Method in class org.tensorflow.framework.TensorProto.Builder
 
clear() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
clear() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
clear() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
clear() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
clear() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
clear() - Method in class org.tensorflow.framework.ValuesDef.Builder
 
clear() - Method in class org.tensorflow.framework.VariableDef.Builder
 
clear() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
clear() - Method in class org.tensorflow.framework.VersionDef.Builder
 
clear() - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
clear() - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
clear() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
clear() - Method in class org.tensorflow.util.Event.Builder
 
clear() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
clear() - Method in class org.tensorflow.util.LogMessage.Builder
 
clear() - Method in class org.tensorflow.util.SavedSlice.Builder
 
clear() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
clear() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
clear() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
clear() - Method in class org.tensorflow.util.SaverDef.Builder
 
clear() - Method in class org.tensorflow.util.SessionLog.Builder
 
clear() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
clear() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
clear() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
clear() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
clear() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
clear() - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
clear() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
clear() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
clear() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
clear() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
clear() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
clear() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
clear() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
clear() - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
clear() - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
clear() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
clear() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
clear() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
clear() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
clear() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
clear() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
clear() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
clear() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
clear() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
clear() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
clear() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
clear() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
clearAliasInputPort() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
If >= 0, the output is an alias of an input.
clearAllEndRelMicros() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_end_rel_micros = 5;
clearAllEndRelNanos() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_end_rel_nanos = 16;
clearAllocatedBytes() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Total number of bytes allocated if known
clearAllocationDescription() - Method in class org.tensorflow.framework.TensorDescription.Builder
Information about the size and allocator used for the data
clearAllocationId() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Identifier of the allocated buffer if known
clearAllocationId() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Id of the tensor buffer being allocated, used to match to a corresponding deallocation.
clearAllocationId() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Id of the tensor buffer being deallocated, used to match to a corresponding allocation.
clearAllocationId() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
Id of the tensor buffer being deallocated, used to match to a corresponding allocation.
clearAllocationRecords() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
clearAllocatorBytesInUse() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
These are snapshots of the overall allocator memory stats.
clearAllocatorName() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Name of the allocator used
clearAllocatorName() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
string allocator_name = 1;
clearAllocatorName() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Name of the allocator used.
clearAllocatorName() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Name of the allocator used.
clearAllocatorName() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
Name of the allocator used.
clearAllocatorType() - Method in class org.tensorflow.framework.GPUOptions.Builder
The type of GPU allocation strategy to use.
clearAllocBytes() - Method in class org.tensorflow.framework.AllocationRecord.Builder
Number of bytes allocated, or de-allocated if negative.
clearAllocMicros() - Method in class org.tensorflow.framework.AllocationRecord.Builder
The timestamp of the operation.
clearAllowedValues() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
A list of values that this kernel supports for this attr.
clearAllowedValues() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
The set of allowed values.
clearAllowGrowth() - Method in class org.tensorflow.framework.GPUOptions.Builder
If true, the allocator does not pre-allocate the entire specified GPU memory region, instead starting small and growing as needed.
clearAllowSoftPlacement() - Method in class org.tensorflow.framework.ConfigProto.Builder
Whether soft placement is allowed.
clearAllowsUninitializedInput() - Method in class org.tensorflow.framework.OpDef.Builder
By default, all inputs to an Op must be initialized Tensors.
clearAllStartMicros() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_start_micros = 2;
clearAllStartNanos() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_start_nanos = 13;
clearAnyInfo() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A serialized protobuf.
clearAnyList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.AnyList any_list = 5;
clearArgOrder() - Method in class org.tensorflow.framework.ApiDef.Builder
List of original in_arg names to specify new argument order.
clearArgument() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
repeated string argument = 1;
clearArithmeticOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Arithmetic optimizations (default is ON) e.g.
clearAssetFileDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
clearAttr() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
clearAttr() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
clearAttr() - Method in class org.tensorflow.framework.NameAttrList.Builder
 
clearAttr() - Method in class org.tensorflow.framework.NodeDef.Builder
 
clearAttr() - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
clearAttributes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
clearAudio() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Audio audio = 6;
clearAutoParallel() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
clearAvailable() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
Immediately available memory in bytes
clearAvailableDeviceInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
clearB() - Method in class org.tensorflow.framework.AttrValue.Builder
"bool"
clearB() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(bool)"
clearBackProp() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Whether backprop is enabled for this while loop.
clearBadConsumers() - Method in class org.tensorflow.framework.VersionDef.Builder
Specific consumer versions which are disallowed (e.g.
clearBandwidth() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Memory bandwidth in KB/s
clearBenchmarkType() - Method in class org.tensorflow.util.testlog.TestResults.Builder
.tensorflow.TestResults.BenchmarkType benchmark_type = 10;
clearBits() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
clearBoolVal() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_BOOL
clearBranch() - Method in class org.tensorflow.framework.CondContextDef.Builder
Branch prediction.
clearBucket() - Method in class org.tensorflow.framework.HistogramProto.Builder
repeated double bucket = 7 [packed = true];
clearBucketLimit() - Method in class org.tensorflow.framework.HistogramProto.Builder
Parallel arrays encoding the bucket boundaries and the bucket values.
clearBuildConfiguration() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The configuration of the build (compiled opt? with cuda? any copts?)
clearBuildCostModel() - Method in class org.tensorflow.framework.GraphOptions.Builder
The number of steps to run before returning a cost model detailing the memory usage and performance of each node of the graph.
clearBuildCostModelAfter() - Method in class org.tensorflow.framework.GraphOptions.Builder
The number of steps to skip before collecting statistics for the cost model.
clearBusId() - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional bus locality of device.
clearBusId() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
e.g.
clearBytes() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Byte size of the file.
clearBytesList() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.BytesList bytes_list = 1;
clearBytesList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
clearCacheSize() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
clearCancelOpName() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
The operation to run to cancel the queue.
clearCcFlags() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
CC compiler flags, if known
clearChangelist() - Method in class org.tensorflow.util.testlog.CommitId.Builder
Submitted changelist.
clearCheckpointKey() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
The generated name of the Tensor in the checkpoint.
clearCheckpointPath() - Method in class org.tensorflow.util.SessionLog.Builder
This checkpoint_path contains both the path and filename.
clearChildren() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
clearCloseOpName() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
The operation to run to close the queue.
clearCluster() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The cluster of which this server is a member.
clearClusterDef() - Method in class org.tensorflow.framework.ConfigProto.Builder
Optional list of all workers to use in this session.
clearCollectionDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
clearCollectiveGraphKey() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
If non-zero, declares that this graph is going to use collective ops and must synchronize step_ids with any other graph with this same group_key value (in a distributed computation where tasks run disjoint graphs).
clearCollectiveGroupLeader() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Task name for group resolution.
clearCollectiveRingOrder() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If non-empty, defines a good GPU ring order on a single worker based on device interconnect.
clearColorspace() - Method in class org.tensorflow.framework.Summary.Image.Builder
Valid colorspace values are 1 - grayscale 2 - grayscale + alpha 3 - RGB 4 - RGBA 5 - DIGITAL_YUV 6 - BGRA
clearCommitId() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The commit id (git hash or changelist)
clearCompressionAlgorithm() - Method in class org.tensorflow.framework.RPCOptions.Builder
The compression algorithm to be used.
clearCompressionLevel() - Method in class org.tensorflow.framework.RPCOptions.Builder
If compression_algorithm is set, the compression level to be used.
clearComputeCost() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Estimate of the computational cost of this node, in microseconds.
clearComputeTime() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Analytical estimate of the computational cost of this node, in microseconds.
clearCondCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.CondContextDef cond_ctxt = 1;
clearConfig() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
clearConstantFolding() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Fold constants (default is ON) Statically infer the value of tensors when possible, and materialize the result using constants.
clearConstNodeInfo() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
clearConstraint() - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
clearContainer() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Container in which this resource is placed.
clearContent() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
The content to store for the plugin.
clearContentType() - Method in class org.tensorflow.framework.Summary.Audio.Builder
string content_type = 5;
clearContext() - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.Features context = 1;
clearContextName() - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the context.
clearContextName() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the context.
clearControlInput() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Ids of the control inputs for this node.
clearCooSparse() - Method in class org.tensorflow.framework.TensorInfo.Builder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
clearCostGraph() - Method in class org.tensorflow.framework.RunMetadata.Builder
The cost graph for the computation defined by the run call.
clearCpuGovernor() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
What kind of cpu scaling is enabled on the host.
clearCpuInfo() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Additional cpu information.
clearCpuInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
CPU Information.
clearCpuTime() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Total cpu time used for all iterations (in seconds)
clearCrc32C() - Method in class org.tensorflow.util.BundleEntryProto.Builder
The CRC32C checksum of the tensor bytes.
clearCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
clearCurrentWork() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
bytes current_work = 4;
clearCustomOptimizers() - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
clearData() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
bytes data = 4;
clearData() - Method in class org.tensorflow.util.SavedSlice.Builder
The raw data of the slice is stored as a TensorProto.
clearData() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This exists in all but the first item of each checkpoint file.
clearDcomplexVal() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX128.
clearDebugOps() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name(s) of the debugging op(s).
clearDebugOptions() - Method in class org.tensorflow.framework.RunOptions.Builder
EXPERIMENTAL.
clearDebugStripper() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Strips debug-related nodes from the graph (off by default).
clearDebugTensorWatchOpts() - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
clearDebugUrls() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
URL(s) for debug targets(s).
clearDefaultGraphInputTensorShape() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
clearDefaultGraphOutputTensorShape() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
clearDefaultSessionConfig() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The default configuration for sessions that run on this server.
clearDefaultValue() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorProto default_value = 3;
clearDefaultValue() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Specify a new default value to use for this attr.
clearDefaultValue() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A reasonable default for this attribute if the user does not supply a value.
clearDeferred() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
True if the deallocation is queued and will be performed later, e.g.
clearDeferredDeletionBytes() - Method in class org.tensorflow.framework.GPUOptions.Builder
Delay deletion of up to this many bytes to reduce the number of interactions with gpu driver code.
clearDenseShapeTensorName() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The dynamic logical shape represented by the SparseTensor is recorded in the Tensor referenced here.
clearDependencyOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Control dependency optimizations (default is ON).
clearDeprecated() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Set if this endpoint is deprecated.
clearDeprecation() - Method in class org.tensorflow.framework.OpDef.Builder
Optional deprecation based on GraphDef versions.
clearDeprecationMessage() - Method in class org.tensorflow.framework.ApiDef.Builder
If this op is deprecated, set deprecation message to the message that should be logged when this op is used.
clearDeprecationVersion() - Method in class org.tensorflow.framework.ApiDef.Builder
Major version when the op will be deleted.
clearDeprecationVersion() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Major version when an endpoint will be deleted.
clearDescription() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
Note: this will replace any inherited arg doc.
clearDescription() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Note: this will replace any inherited attr doc, there is no current way of modifying attr descriptions as can be done with op descriptions.
clearDescription() - Method in class org.tensorflow.framework.ApiDef.Builder
Additional, longer human-readable description of what the Op does.
clearDescription() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Human readable description.
clearDescription() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
Human-readable description.
clearDescription() - Method in class org.tensorflow.framework.OpDef.Builder
Additional, longer human-readable description of what the Op does.
clearDescriptionPrefix() - Method in class org.tensorflow.framework.ApiDef.Builder
Modify an existing/inherited description by adding text to the beginning or end.
clearDescriptionSuffix() - Method in class org.tensorflow.framework.ApiDef.Builder
string description_suffix = 10;
clearDestination() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Destination of graph transfer
clearDevice() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The device of the node.
clearDevice() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
string device = 1;
clearDevice() - Method in class org.tensorflow.framework.NodeDef.Builder
A (possibly partial) specification for the device on which this node should be placed.
clearDevice() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Unique name for the device containing the resource.
clearDeviceCount() - Method in class org.tensorflow.framework.ConfigProto.Builder
 
clearDeviceFilters() - Method in class org.tensorflow.framework.ConfigProto.Builder
When any filters are present sessions will ignore all devices which do not match the filters.
clearDeviceId() - Method in class org.tensorflow.framework.InterconnectLink.Builder
int32 device_id = 1;
clearDeviceInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
clearDevicePersistentMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Deprecated.
clearDevicePersistentMemorySize() - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
clearDevicePersistentTensorAllocIds() - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
clearDeviceTempMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Deprecated.
clearDeviceTempMemorySize() - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
clearDeviceType() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
String representation of device_type.
clearDeviceType() - Method in class org.tensorflow.framework.KernelDef.Builder
Type of device this kernel runs on.
clearDevStats() - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
clearDim() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
clearDisableMetaOptimizer() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Disable the entire meta optimizer (off by default).
clearDisableModelPruning() - Method in class org.tensorflow.framework.RewriterConfig.Builder
If true, don't remove unnecessary ops from the graph
clearDisplayName() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Display name for viewing in TensorBoard.
clearDoCommonSubexpressionElimination() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
If true, optimize the graph using common subexpression elimination.
clearDoConstantFolding() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
If true, perform constant folding optimization on the graph.
clearDoFunctionInlining() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
If true, perform function inlining on the graph.
clearDoubleVal() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_DOUBLE.
clearDoubleValue() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
double double_value = 1;
clearDtype() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.DataType dtype = 1;
clearDtype() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
.tensorflow.DataType dtype = 1;
clearDtype() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.DataType dtype = 4;
clearDtype() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
.tensorflow.DataType dtype = 5;
clearDtype() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
.tensorflow.DataType dtype = 3;
clearDtype() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
.tensorflow.DataType dtype = 3;
clearDtype() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.DataType dtype = 1;
clearDtype() - Method in class org.tensorflow.framework.TensorDescription.Builder
Data type of tensor elements
clearDtype() - Method in class org.tensorflow.framework.TensorInfo.Builder
.tensorflow.DataType dtype = 2;
clearDtype() - Method in class org.tensorflow.framework.TensorProto.Builder
.tensorflow.DataType dtype = 1;
clearDtype() - Method in class org.tensorflow.util.BundleEntryProto.Builder
The tensor dtype and shape.
clearElement() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
clearEnable() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
bool enable = 1;
clearEnableBfloat16Sendrecv() - Method in class org.tensorflow.framework.GraphOptions.Builder
If true, transfer float values between processes as bfloat16.
clearEnableOp() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
If present, only perform optimization for these ops.
clearEnableRecvScheduling() - Method in class org.tensorflow.framework.GraphOptions.Builder
If true, use control flow to schedule the activation of Recv nodes.
clearEncodedAudioString() - Method in class org.tensorflow.framework.Summary.Audio.Builder
Encoded audio data and its associated RFC 2045 content type (e.g.
clearEncodedImageString() - Method in class org.tensorflow.framework.Summary.Image.Builder
Image data in encoded format.
clearEncoding() - Method in class org.tensorflow.framework.TensorInfo.Builder
 
clearEndianness() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
.tensorflow.BundleHeaderProto.Endianness endianness = 2;
clearEndpoint() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
clearEnqueueOpName() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of enqueue operations.
clearEntries() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The list of tests or benchmarks in this run.
clearEntry() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
clearEnvironment() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
clearExecutorName() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Executor's name
clearExecutorType() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Which executor to use, the default executor will be used if it is an empty string or "DEFAULT"
clearExperimental() - Method in class org.tensorflow.framework.ConfigProto.Builder
.tensorflow.ConfigProto.Experimental experimental = 16;
clearExperimental() - Method in class org.tensorflow.framework.GPUOptions.Builder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
clearExperimental() - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.Experimental experimental = 8;
clearExperimentalDebugInfo() - Method in class org.tensorflow.framework.NodeDef.Builder
This stores debug information associated with the node.
clearExplanation() - Method in class org.tensorflow.framework.OpDeprecation.Builder
Explanation of why it was deprecated and what to use instead.
clearExtent() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
clearExternalValues() - Method in class org.tensorflow.framework.ValuesDef.Builder
 
clearExtras() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
clearF() - Method in class org.tensorflow.framework.AttrValue.Builder
"float"
clearF() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(float)"
clearFailOnOptimizerErrors() - Method in class org.tensorflow.framework.RewriterConfig.Builder
If true, any optimization pass failing will cause the MetaOptimizer to stop with an error.
clearFeature() - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
clearFeature() - Method in class org.tensorflow.example.Features.Builder
 
clearFeatureList() - Method in class org.tensorflow.example.FeatureLists.Builder
 
clearFeatureLists() - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.FeatureLists feature_lists = 2;
clearFeatureMap() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
clearFeatures() - Method in class org.tensorflow.example.Example.Builder
.tensorflow.Features features = 1;
clearFeed() - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be fed in the callable.
clearFeedDevices() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
clearFetch() - Method in class org.tensorflow.framework.CallableOptions.Builder
Fetches.
clearFetchDevices() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
clearFetchSkipSync() - Method in class org.tensorflow.framework.CallableOptions.Builder
By default, RunCallable() will synchronize the GPU stream before returning fetched tensors on a GPU device, to ensure that the values in those tensors have been produced.
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.BytesList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.Example.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.Feature.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.FeatureList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.FeatureLists.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.Features.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.FloatList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.Int64List.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.SequenceExample.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ApiDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ApiDefs.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.AttrValue.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CollectionDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CondContextDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.DebugOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GPUOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GradientDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GraphDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GraphOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.HistogramProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.KernelDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.KernelList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.LocalLinks.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.MemoryStats.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.NodeDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.NodeOutput.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.OpDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.OpList.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.RPCOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.RunMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.RunOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.SavedModel.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.StepStats.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.Summary.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.Summary.Image.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.Summary.Value.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.TensorConnection.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.TensorDescription.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.TensorInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.TensorProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.VariableDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.VersionDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.Event.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.LogMessage.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.SavedSlice.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.SaverDef.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.SessionLog.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
clearFilename() - Method in class org.tensorflow.framework.AssetFileDef.Builder
The filename within an assets directory.
clearFilenameTensorName() - Method in class org.tensorflow.util.SaverDef.Builder
The name of the tensor in which to specify the filename when saving or restoring a model checkpoint.
clearFilePath() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Path to the source code file.
clearFileVersion() - Method in class org.tensorflow.util.Event.Builder
An event file was started, with the specified version.
clearFixedLenFeature() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
clearFloatList() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.FloatList float_list = 2;
clearFloatList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.FloatList float_list = 4;
clearFloatVal() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_FLOAT.
clearForceGpuCompatible() - Method in class org.tensorflow.framework.GPUOptions.Builder
Force all tensors to be gpu_compatible.
clearFrequency() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Core Frequency in Mhz
clearFromTensor() - Method in class org.tensorflow.framework.TensorConnection.Builder
A tensor name.
clearFullName() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Name of the full variable of which this is a slice.
clearFullName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
The full name of the variable/tensor, if applicable.
clearFullShape() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of the full variable.
clearFunc() - Method in class org.tensorflow.framework.AttrValue.Builder
"func" represents a function.
clearFunc() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
clearFunction() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
clearFunctionName() - Method in class org.tensorflow.framework.GradientDef.Builder
The function name.
clearFunctionOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Function optimizations (default is ON).
clearGlobalJitLevel() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
.tensorflow.OptimizerOptions.GlobalJitLevel global_jit_level = 5;
clearGlobalName() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
The global name of the threadpool.
clearGlobalStep() - Method in class org.tensorflow.framework.DebugOptions.Builder
Caller-specified global step count.
clearGpuOptions() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all GPUs.
clearGradient() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
clearGradientFunc() - Method in class org.tensorflow.framework.GradientDef.Builder
The gradient function's name.
clearGraphDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
GraphDef.
clearGraphDef() - Method in class org.tensorflow.util.Event.Builder
An encoded version of a GraphDef.
clearGraphInputNodeInfo() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
clearGraphInputNodeName() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph input node name
clearGraphOpName() - Method in class org.tensorflow.framework.ApiDef.Builder
Name of the op (in the OpDef) to specify the API for.
clearGraphOptions() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all graphs.
clearGraphOutputNodeInfo() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
clearGraphOutputNodeName() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph output node name
clearHalfVal() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_HALF, DT_BFLOAT16.
clearHandle() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
Handle describing the feeds and fetches of the step.
clearHash() - Method in class org.tensorflow.util.testlog.CommitId.Builder
string hash = 2;
clearHashCode() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Hash code for the type of the resource.
clearHasLength() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
clearHasMinimum() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
For type == "int", this is a minimum value.
clearHasSingleReference() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Set if this tensor only has one remaining reference
clearHealthStatus() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
.tensorflow.WorkerHealth health_status = 1;
clearHeight() - Method in class org.tensorflow.framework.Summary.Image.Builder
Dimensions of the image.
clearHisto() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.HistogramProto histo = 5;
clearHost() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
The host name on which a source code file is located.
clearHostMemoryArg() - Method in class org.tensorflow.framework.KernelDef.Builder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
clearHostname() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Host name of machine that ran the benchmark.
clearHostname() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
string hostname = 3;
clearHostTempMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Deprecated.
clearI() - Method in class org.tensorflow.framework.AttrValue.Builder
"int"
clearI() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(int)"
clearId() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The id of the node.
clearImage() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Image image = 4;
clearInaccurate() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Are the costs inaccurate?
clearInArg() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
clearIncarnation() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
A device is assigned a global unique number each time it is initialized.
clearIndex() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Index of the output being set.
clearIndicesOutputTensorName() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string indices_output_tensor_name = 3;
clearIndicesTensorName() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The indices Tensor must have dtype int64 and shape [?, ?].
clearInferShapes() - Method in class org.tensorflow.framework.GraphOptions.Builder
Annotate each Node with Op output shape data, to the extent it can be statically inferred.
clearInitializerName() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the initializer op.
clearInitialValueName() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the tensor holding the variable's initial value.
clearInput() - Method in class org.tensorflow.framework.NodeDef.Builder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
clearInputArg() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
clearInputCount() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 input_count = 6;
clearInputInfo() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
clearInputs() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
clearInt64List() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.Int64List int64_list = 3;
clearInt64List() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.Int64List int64_list = 3;
clearInt64Val() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT64
clearInterOpParallelismThreads() - Method in class org.tensorflow.framework.ConfigProto.Builder
Nodes that perform blocking operations are enqueued on a pool of inter_op_parallelism_threads available in each process.
clearInterOpThreadPool() - Method in class org.tensorflow.framework.RunOptions.Builder
The thread pool to use, if session_inter_op_thread_pool is configured.
clearIntraOpParallelismThreads() - Method in class org.tensorflow.framework.ConfigProto.Builder
The execution of an individual op (for some op types) can be parallelized on a pool of intra_op_parallelism_threads.
clearIntVal() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
clearIsAggregate() - Method in class org.tensorflow.framework.OpDef.Builder
If is_aggregate is true, then this operation accepts N >= 2 inputs and produces 1 output all of the same type.
clearIsCommutative() - Method in class org.tensorflow.framework.OpDef.Builder
True if the operation is commutative ("op(a,b) == op(b,a)" for all inputs)
clearIsFinal() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
If true, the output is permanent: it can't be discarded, because this node is part of the "final output".
clearIsolateSessionState() - Method in class org.tensorflow.framework.ConfigProto.Builder
If true, any resources such as Variables used in the session will not be shared with other sessions.
clearIsRef() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
For inputs: if true, the inputs are required to be refs.
clearIsResource() - Method in class org.tensorflow.framework.VariableDef.Builder
Whether to represent this as a ResourceVariable.
clearIsStateful() - Method in class org.tensorflow.framework.OpDef.Builder
Ops are marked as stateful if their behavior depends on some state beyond their input tensors (e.g.
clearIters() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
If a benchmark, how many iterations it was run for
clearJob() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
clearJobName() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The name of the job of which this server is a member.
clearKeepCheckpointEveryNHours() - Method in class org.tensorflow.util.SaverDef.Builder
How often to keep an additional checkpoint.
clearKernel() - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
clearKernelName() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Name of the kernel making the allocation as set in GraphDef, e.g., "affine2/weights/Assign".
clearKernelName() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Name of the kernel producing an output as set in GraphDef, e.g., "affine2/weights/Assign".
clearKeys() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
Keys for tensors in the VariantTensorDataProto.
clearKind() - Method in class org.tensorflow.example.Feature.Builder
 
clearKind() - Method in class org.tensorflow.framework.CollectionDef.Builder
 
clearKind() - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
clearKind() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
clearL1CacheSize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
L1 cache size in bytes
clearL2CacheSize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
L2 cache size in bytes
clearL3CacheSize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
L3 cache size in bytes
clearLabel() - Method in class org.tensorflow.framework.KernelDef.Builder
This allows experimental kernels to be registered for an op that won't be used unless the user specifies a "_kernel" attr with value matching this.
clearLastModified() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
The timestamp at which the source code file is last modified.
clearLayoutOptimizer() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Optimize tensor layouts (default is ON) e.g.
clearLength() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
int64 length = 2;
clearLengthFrames() - Method in class org.tensorflow.framework.Summary.Audio.Builder
Length of the audio in frames (samples per channel).
clearLevel() - Method in class org.tensorflow.util.LogMessage.Builder
.tensorflow.LogMessage.Level level = 1;
clearLibrary() - Method in class org.tensorflow.framework.GraphDef.Builder
EXPERIMENTAL.
clearLines() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Line-by-line content of the source code file.
clearLink() - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
clearLinkage() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
clearLinks() - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional local interconnect links to other devices.
clearList() - Method in class org.tensorflow.framework.AttrValue.Builder
any "list(...)"
clearLiveBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The bytes that are not deallocated.
clearLocality() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Platform-specific data about device that may be useful for supporting efficient data transfers.
clearLocalName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
A user-provided name for the edge.
clearLogDevicePlacement() - Method in class org.tensorflow.framework.ConfigProto.Builder
Whether device placements should be logged.
clearLogMessage() - Method in class org.tensorflow.util.Event.Builder
The user output a log message.
clearLoopEnterNames() - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for enter tensors.
clearLoopExitNames() - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for exit tensors.
clearLoopOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Loop optimizations (default is ON).
clearMachine() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
clearMachineConfiguration() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Machine-specific parameters (Platform and CPU info)
clearMax() - Method in class org.tensorflow.framework.HistogramProto.Builder
double max = 2;
clearMaxByteSize() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
repeated int32 max_byte_size = 2;
clearMaxFoldedConstantInBytes() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
Constant folding optimization replaces tensors whose values can be predetermined, with constant nodes.
clearMaximumIterationsName() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Optional name of the maximum_iterations tensor.
clearMaxToKeep() - Method in class org.tensorflow.util.SaverDef.Builder
Maximum number of checkpoints to keep.
clearMaybeTypeName() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
For debug-only, the name of the type pointed to by this handle, if available.
clearMemory() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
clearMemoryInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
.tensorflow.MemoryInfo memory_info = 6;
clearMemoryLimit() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Memory capacity of device in bytes.
clearMemoryLimit() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Memory capacity in bytes.
clearMemoryLimitMb() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
Per "virtual" device memory limit, in MB.
clearMemoryOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures memory optimization passes through the meta-optimizer.
clearMemoryOptimizerTargetNodeNameScope() - Method in class org.tensorflow.framework.RewriterConfig.Builder
A node name scope for node names which are valid outputs of recompuations.
clearMemorySize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Memory size in bytes
clearMemoryStats() - Method in class org.tensorflow.framework.NodeExecStats.Builder
.tensorflow.MemoryStats memory_stats = 12;
clearMemoryTime() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Analytical estimate of the memory access cost of this node, in microseconds.
clearMessage() - Method in class org.tensorflow.util.LogMessage.Builder
string message = 2;
clearMeta() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
clearMetadata() - Method in class org.tensorflow.framework.Summary.Value.Builder
Contains metadata on the summary value such as which plugins may use it.
clearMetadata() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Portions of the object that are not Tensors.
clearMetaGraphDef() - Method in class org.tensorflow.util.Event.Builder
An encoded version of a MetaGraphDef.
clearMetaGraphs() - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
clearMetaGraphVersion() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User specified Version string.
clearMetaInfoDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
clearMetaOptimizerIterations() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Controls how many times we run the optimizers in meta optimizer (default is once).
clearMetaOptimizerTimeoutMs() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Maximum number of milliseconds to spend optimizing a single graph before timing out.
clearMethodName() - Method in class org.tensorflow.framework.SignatureDef.Builder
Extensible method_name information enabling third-party users to mark a SignatureDef as supporting a particular method.
clearMhzPerCpu() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
How fast are these cpus?
clearMin() - Method in class org.tensorflow.framework.HistogramProto.Builder
double min = 1;
clearMinConsumer() - Method in class org.tensorflow.framework.VersionDef.Builder
Any consumer below this version is not allowed to consume this data.
clearMinGraphNodes() - Method in class org.tensorflow.framework.RewriterConfig.Builder
The minimum number of nodes in a graph to optimizer.
clearMinimum() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
int64 minimum = 6;
clearMode() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
opt, dbg, etc
clearModel() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
e.g.
clearModel() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Model (Haswell, K40, ...)
clearMsg() - Method in class org.tensorflow.util.SessionLog.Builder
string msg = 3;
clearName() - Method in class org.tensorflow.distruntime.JobDef.Builder
The name of this job.
clearName() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
string name = 1;
clearName() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
string name = 1;
clearName() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Name should be either like "CamelCaseName" or "Package.CamelCaseName".
clearName() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The name of the node.
clearName() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Fully specified name of the device within a cluster.
clearName() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
string name = 1;
clearName() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
string name = 1;
clearName() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
string name = 1;
clearName() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
string name = 1;
clearName() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
Name of an attr from the Op.
clearName() - Method in class org.tensorflow.framework.NameAttrList.Builder
string name = 1;
clearName() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
Name of the tensor.
clearName() - Method in class org.tensorflow.framework.NodeDef.Builder
The name given to this operator.
clearName() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Name for the input/output.
clearName() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A descriptive name for the argument.
clearName() - Method in class org.tensorflow.framework.OpDef.Builder
Op names starting with an underscore are reserved for internal use.
clearName() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Unique name of this resource.
clearName() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
string name = 1;
clearName() - Method in class org.tensorflow.framework.TensorInfo.Builder
For dense `Tensor`s, the name of the tensor in the graph.
clearName() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
Optional name of the tensor dimension.
clearName() - Method in class org.tensorflow.util.SavedSlice.Builder
Name of the tensor that this slice belongs to.
clearName() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Name of the tensor.
clearName() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Device name.
clearName() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
The name of the specific benchmark or test (e.g.
clearName() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Benchmark target identifier.
clearName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
A name for the Tensor.
clearName() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
string name = 1;
clearName() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
string name = 2;
clearNestedContexts() - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
clearNestedContexts() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
clearNode() - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
clearNode() - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
clearNodeDef() - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
clearNodeId() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
int32 node_id = 2;
clearNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 node_id = 2;
clearNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
int32 node_id = 1;
clearNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
int32 node_id = 1;
clearNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
int32 node_id = 1;
clearNodeId() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
An index into `CheckpointableObjectGraph.nodes`, indicating the object being referenced.
clearNodeInfo() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
clearNodeInput() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
clearNodeInputInfo() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
clearNodeList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.NodeList node_list = 1;
clearNodeName() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name of the node to watch.
clearNodeName() - Method in class org.tensorflow.framework.NodeExecStats.Builder
TODO(tucker): Use some more compact form of node identity than the full string name.
clearNodeName() - Method in class org.tensorflow.framework.Summary.Value.Builder
This field is deprecated and will not be set.
clearNodeOutputInfo() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
clearNodes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
clearNodeStats() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
clearNum() - Method in class org.tensorflow.framework.HistogramProto.Builder
double num = 3;
clearNumaNode() - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional NUMA locality of device.
clearNumberAttr() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
if specified, attr must have type "int"
clearNumBytes() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Number of bytes in the allocation.
clearNumChannels() - Method in class org.tensorflow.framework.Summary.Audio.Builder
Number of channels of audio.
clearNumCores() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
int64 num_cores = 1;
clearNumCores() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Number of cores
clearNumCoresAllowed() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
int64 num_cores_allowed = 2;
clearNumDevToDevCopyStreams() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If > 1, the number of device-to-device copy streams to create for each GPUDevice.
clearNumRecordsProduced() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
int64 num_records_produced = 3;
clearNumRegisters() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Number of registers per core.
clearNumReplicas() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
int32 num_replicas = 2;
clearNumShards() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Number of data files in the bundle.
clearNumThreads() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
The number of threads in the pool.
clearObsoleteOldStyleHistogram() - Method in class org.tensorflow.framework.Summary.Value.Builder
bytes obsolete_old_style_histogram = 3;
clearOffset() - Method in class org.tensorflow.util.BundleEntryProto.Builder
int64 offset = 4;
clearOffset() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
uint64 offset = 1;
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.BytesList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.Example.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.Feature.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.FeatureList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.FeatureLists.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.Features.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.FloatList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.Int64List.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.SequenceExample.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ApiDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ApiDefs.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.AttrValue.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CollectionDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CondContextDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.DebugOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GPUOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GradientDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GraphDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GraphOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.HistogramProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.KernelDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.KernelList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.LocalLinks.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.MemoryStats.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.NodeDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.NodeOutput.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.OpDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.OpList.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.RPCOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.RunMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.RunOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.SavedModel.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.StepStats.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.Summary.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.Summary.Image.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.Summary.Value.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.TensorConnection.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.TensorDescription.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.TensorInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.TensorProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.VariableDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.VersionDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.Event.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.LogMessage.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.SavedSlice.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.SaverDef.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.SessionLog.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
clearOp() - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
clearOp() - Method in class org.tensorflow.framework.KernelDef.Builder
Must match the name of an Op.
clearOp() - Method in class org.tensorflow.framework.NodeDef.Builder
The operation name.
clearOp() - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
clearOpEndRelMicros() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_end_rel_micros = 4;
clearOpEndRelNanos() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_end_rel_nanos = 15;
clearOperation() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Name of the operation making the allocation.
clearOperation() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Name of the operation making the deallocation.
clearOperationTimeoutInMs() - Method in class org.tensorflow.framework.ConfigProto.Builder
Global timeout for all blocking operations in this session.
clearOpStartRelMicros() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_start_rel_micros = 3;
clearOpStartRelNanos() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_start_rel_nanos = 14;
clearOptimizerOptions() - Method in class org.tensorflow.framework.GraphOptions.Builder
Options controlling how graph is optimized.
clearOptimizers() - Method in class org.tensorflow.framework.RewriterConfig.Builder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
clearOptLevel() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
Overall optimization level.
clearOpts() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
Bazel compilation options, if known
clearOriginalNodeNames() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
Opaque string inserted into error messages created by the runtime.
clearOriginalVariableNodeId() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
An index into `CheckpointableObjectGraph.nodes`, indicating the variable object this slot was created for.
clearOutArg() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
clearOutput() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
clearOutputArg() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
clearOutputCount() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 output_count = 7;
clearOutputInfo() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
clearOutputPartitionGraphs() - Method in class org.tensorflow.framework.RunOptions.Builder
Whether the partition graph(s) executed by the executor(s) should be outputted via RunMetadata.
clearOutputPort() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
int32 output_port = 2;
clearOutputs() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
clearOutputSlot() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Output slot to watch.
clearPaddingId() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 padding_id = 5;
clearParallelIterations() - Method in class org.tensorflow.framework.WhileContextDef.Builder
The number of iterations allowed to run in parallel.
clearParameterMap() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
clearPartitionGraphs() - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
clearPeakBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
int64 peak_bytes = 3;
clearPendingChangelist() - Method in class org.tensorflow.util.testlog.CommitId.Builder
Changelist tested if the change list is not already submitted.
clearPerProcessGpuMemoryFraction() - Method in class org.tensorflow.framework.GPUOptions.Builder
Fraction of the available GPU memory to allocate for each process.
clearPersistentMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Persistent memory used by this node.
clearPersistentMemorySize() - Method in class org.tensorflow.framework.MemoryStats.Builder
int64 persistent_memory_size = 3;
clearPersistentTensorAllocIds() - Method in class org.tensorflow.framework.MemoryStats.Builder
repeated int64 persistent_tensor_alloc_ids = 5;
clearPhysicalDescription() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
The physical description of this device.
clearPhysicalDeviceDesc() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
String representation of the physical device that this device maps to.
clearPinToHostOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Force small ops onto the CPU (default is OFF).
clearPivotForBodyName() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot_for_body tensor.
clearPivotForPredName() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot_for_pred tensor.
clearPivotName() - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the pivot tensor.
clearPivotName() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot tensor.
clearPlaceholder() - Method in class org.tensorflow.framework.AttrValue.Builder
This is a placeholder only used in nodes defined inside a function.
clearPlacementPeriod() - Method in class org.tensorflow.framework.ConfigProto.Builder
Assignment of Nodes to Devices is recomputed every placement_period steps until the system warms up (at which point the recomputation typically slows down automatically).
clearPlacePrunedGraph() - Method in class org.tensorflow.framework.GraphOptions.Builder
Only place the subgraphs that are run, rather than the entire graph.
clearPlatformInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Additional platform information.
clearPluginData() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Data that associates a summary with a certain plugin.
clearPluginName() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
The name of the plugin this data pertains to.
clearPollingActiveDelayUsecs() - Method in class org.tensorflow.framework.GPUOptions.Builder
In the event polling loop sleep this many microseconds between PollEvents calls, when the queue is not empty.
clearPollingInactiveDelayMsecs() - Method in class org.tensorflow.framework.GPUOptions.Builder
This field is deprecated and ignored.
clearPrecedingNode() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
int32 preceding_node = 1;
clearPrecedingPort() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
int32 preceding_port = 2;
clearPredName() - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the pred tensor.
clearPriority() - Method in class org.tensorflow.framework.KernelDef.Builder
Prioritization of kernel amongst different devices.
clearProducer() - Method in class org.tensorflow.framework.VersionDef.Builder
The version of the code that produced this data.
clearProperties() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
.tensorflow.DeviceProperties properties = 2;
clearProtocol() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The protocol to be used by this server.
clearPtr() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Address of the allocation.
clearPtr() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Address of the allocation.
clearQueueClosedExceptionTypes() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
clearQueueName() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
Queue name.
clearRecvBufMaxChunk() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Guidance to formatting of large RecvBuf fields for transfer.
clearReferencedTensor() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
clearRelease() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
clearRemapping() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Remapping (default is ON) Remap subgraphs onto more efficient implementations.
clearRemoteGraph() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Definition of remote graph
clearRenameTo() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
Change the name used to access this arg in the API from what is used in the GraphDef.
clearRenameTo() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Change the name used to access this attr in the API from what is used in the GraphDef.
clearReportTensorAllocationsUponOom() - Method in class org.tensorflow.framework.RunOptions.Builder
When enabled, causes tensor allocation information to be included in the error message when the Run() call fails because the allocator ran out of memory (OOM).
clearRequestedBytes() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Total number of bytes requested
clearResetDiskByteUsage() - Method in class org.tensorflow.framework.DebugOptions.Builder
Whether the total disk usage of tfdbg is to be reset to zero in this Session.run call.
clearResourceHandleVal() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
clearRestoreOpName() - Method in class org.tensorflow.util.SaverDef.Builder
The operation to run when restoring a model checkpoint.
clearRet() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
clearRewriteOptions() - Method in class org.tensorflow.framework.GraphOptions.Builder
Options that control the type and amount of graph rewriting.
clearRpcOptions() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply when this session uses the distributed runtime.
clearRunConfiguration() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Run-specific parameters (arguments, etc)
clearRunMetadata() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
Byte-encoded version of the `RunMetadata` proto in order to allow lazy deserialization.
clearRunMode() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Used for differentiating between continuous and debug builds.
clearRunOptions() - Method in class org.tensorflow.framework.CallableOptions.Builder
Options that will be applied to each run.
clearRunTime() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The amount of time the total run took (wall time in seconds)
clearS() - Method in class org.tensorflow.framework.AttrValue.Builder
"string"
clearS() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(string)"
clearSampleRate() - Method in class org.tensorflow.framework.Summary.Audio.Builder
Sample rate of the audio in Hz.
clearSavedModelSchemaVersion() - Method in class org.tensorflow.framework.SavedModel.Builder
The schema version of the SavedModel instance.
clearSaverDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
SaverDef.
clearSaveSliceInfoDef() - Method in class org.tensorflow.framework.VariableDef.Builder
Support for saving variables as slices of a larger variable.
clearSaveTensorName() - Method in class org.tensorflow.util.SaverDef.Builder
The operation to run when saving a model checkpoint.
clearScheduledMicros() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 scheduled_micros = 9;
clearScheduledNanos() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 scheduled_nanos = 17;
clearScomplexVal() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX64.
clearScopedAllocatorOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Try to allocate some independent Op outputs contiguously in order to merge or eliminate downstream Ops (off by default).
clearScopedAllocatorOpts() - Method in class org.tensorflow.framework.RewriterConfig.Builder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
clearSerialIdentifier() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Unique serial number of the machine.
clearSerializedExecutorParameters() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Parameters given to the executor
clearSessionInterOpThreadPool() - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
clearSessionLog() - Method in class org.tensorflow.util.Event.Builder
The state of the session which can be used for restarting after crashes.
clearShape() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorShapeProto shape = 2;
clearShape() - Method in class org.tensorflow.framework.AttrValue.Builder
"shape"
clearShape() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
clearShape() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.TensorShapeProto shape = 3;
clearShape() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
repeated int64 shape = 3;
clearShape() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
repeated int64 shape = 2;
clearShape() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
repeated int64 shape = 2;
clearShape() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.TensorShapeProto shape = 2;
clearShape() - Method in class org.tensorflow.framework.TensorDescription.Builder
Shape of the tensor.
clearShape() - Method in class org.tensorflow.util.BundleEntryProto.Builder
.tensorflow.TensorShapeProto shape = 2;
clearShape() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Shape of the tensor
clearShapeOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Shape optimizations (default is ON) Simplify computations made on shapes.
clearShapesOutputTensorName() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string shapes_output_tensor_name = 4;
clearSharded() - Method in class org.tensorflow.util.SaverDef.Builder
Shard the save files, one per device that has Variable nodes.
clearShardId() - Method in class org.tensorflow.util.BundleEntryProto.Builder
The binary content of the tensor lies in: File "shard_id": bytes [offset, offset + size).
clearSharedMemorySizePerMultiprocessor() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Shared memory size per multiprocessor in bytes.
clearShutdownMode() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WorkerShutdownMode shutdown_mode = 1;
clearSignature() - Method in class org.tensorflow.framework.FunctionDef.Builder
The definition of the function's name, arguments, return values, attrs etc.
clearSignatureDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
clearSimpleValue() - Method in class org.tensorflow.framework.Summary.Value.Builder
float simple_value = 2;
clearSize() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
int64 size = 1;
clearSize() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
Size of the tensor in that dimension.
clearSize() - Method in class org.tensorflow.util.BundleEntryProto.Builder
int64 size = 5;
clearSlice() - Method in class org.tensorflow.util.SavedSlice.Builder
Extent of the slice.
clearSlice() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
clearSlices() - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
clearSlot() - Method in class org.tensorflow.framework.NodeOutput.Builder
int32 slot = 1;
clearSlotName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
The name of the slot (e.g.
clearSlotVariableNodeId() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
An index into `CheckpointableObjectGraph.nodes`, indicating the `Object` with the value of the slot variable.
clearSlotVariables() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
clearSnapshot() - Method in class org.tensorflow.util.testlog.CommitId.Builder
Hash of intermediate change between hash/changelist and what was tested.
clearSnapshotName() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the snapshot tensor.
clearSocOpId() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 soc_op_id = 4;
clearSourceFiles() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
clearStart() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
Start index of the slice, starting at 0.
clearStartTime() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The time the run started (in seconds of UTC time since Unix epoch)
clearStatus() - Method in class org.tensorflow.util.SessionLog.Builder
.tensorflow.SessionLog.SessionStatus status = 1;
clearStep() - Method in class org.tensorflow.util.Event.Builder
Global step of the event.
clearStepId() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Process-unique step id.
clearStepId() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Process-unique step id.
clearStepId() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
Process-unique step id.
clearStepId() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Process-unique step id.
clearStepId() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Process-unique step id.
clearStepStats() - Method in class org.tensorflow.framework.RunMetadata.Builder
Statistics traced for this step.
clearStrength() - Method in class org.tensorflow.framework.InterconnectLink.Builder
int32 strength = 3;
clearStringVal() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_STRING
clearStringValue() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
string string_value = 2;
clearStrippedDefaultAttrs() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A flag to denote whether default-valued attrs have been stripped from the nodes in this graph_def.
clearStrippedOpList() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A copy of the OpDefs used by the producer of this graph_def.
clearSum() - Method in class org.tensorflow.framework.HistogramProto.Builder
double sum = 4;
clearSummary() - Method in class org.tensorflow.framework.ApiDef.Builder
One-line human-readable description of what the Op does.
clearSummary() - Method in class org.tensorflow.framework.OpDef.Builder
One-line human-readable description of what the Op does.
clearSummary() - Method in class org.tensorflow.util.Event.Builder
A summary was generated.
clearSummaryDescription() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Longform readable description of the summary sequence.
clearSumSquares() - Method in class org.tensorflow.framework.HistogramProto.Builder
double sum_squares = 5;
clearSwapMemory() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Whether GPU-CPU memory swap is enabled for this loop.
clearSystem() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
clearTag() - Method in class org.tensorflow.framework.Summary.Value.Builder
Tag name for the data.
clearTag() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
Tag name associated with this metadata.
clearTaggedRunMetadata() - Method in class org.tensorflow.util.Event.Builder
The metadata returned by running a session.run() call.
clearTags() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User supplied tag(s) on the meta_graph and included graph_def.
clearTarget() - Method in class org.tensorflow.framework.CallableOptions.Builder
Target Nodes.
clearTarget() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The target of the run, e.g.: //tensorflow/core:kernels_adjust_contrast_op_benchmark_test
clearTaskIndex() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The task index of this server in its job.
clearTasks() - Method in class org.tensorflow.distruntime.JobDef.Builder
 
clearTempMemorySize() - Method in class org.tensorflow.framework.MemoryStats.Builder
int64 temp_memory_size = 1;
clearTemporaryMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Temporary memory used by this node.
clearTensor() - Method in class org.tensorflow.framework.AttrValue.Builder
"tensor"
clearTensor() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
clearTensor() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Allocated tensor details.
clearTensor() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Output tensor details.
clearTensor() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
clearTensor() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.TensorProto tensor = 8;
clearTensor() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
clearTensorConnection() - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
clearTensorContent() - Method in class org.tensorflow.framework.TensorProto.Builder
Serialized raw tensor content from either Tensor::AsProtoTensorContent or memcpy in tensorflow::grpc::EncodeTensorToByteBuffer.
clearTensorContent() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
repeated bytes tensor_content = 1;
clearTensorDescription() - Method in class org.tensorflow.framework.NodeOutput.Builder
.tensorflow.TensorDescription tensor_description = 3;
clearTensorflowGitVersion() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
The __git_version__ string of the tensorflow build used to write this graph.
clearTensorflowVersion() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
The __version__ string of the tensorflow build used to write this graph.
clearTensorInfo() - Method in class org.tensorflow.framework.AssetFileDef.Builder
The tensor to bind the asset filename to.
clearTensors() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
clearTensorShape() - Method in class org.tensorflow.framework.TensorInfo.Builder
The static shape should be recorded here, to the extent that it can be known in advance.
clearTensorShape() - Method in class org.tensorflow.framework.TensorProto.Builder
Shape of the tensor.
clearThreadId() - Method in class org.tensorflow.framework.NodeExecStats.Builder
uint32 thread_id = 10;
clearThroughput() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Throughput (in MB/s)
clearTimelineLabel() - Method in class org.tensorflow.framework.NodeExecStats.Builder
string timeline_label = 8;
clearTimelineStep() - Method in class org.tensorflow.framework.GraphOptions.Builder
If > 0, record a timeline every this many steps.
clearTimeoutInMs() - Method in class org.tensorflow.framework.RunOptions.Builder
Time to wait for operation to complete in milliseconds.
clearTimeoutMs() - Method in class org.tensorflow.util.WatchdogConfig.Builder
int64 timeout_ms = 1;
clearTolerateDebugOpCreationFailures() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Do not error out if debug op creation fails (e.g., due to dtype incompatibility).
clearTotal() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
Total virtual memory in bytes
clearTotalBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
These are per-node allocator memory stats.
clearToTensor() - Method in class org.tensorflow.framework.TensorConnection.Builder
A tensor name.
clearTraceLevel() - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.TraceLevel trace_level = 1;
clearTrainable() - Method in class org.tensorflow.framework.VariableDef.Builder
Whether this variable should be trained.
clearType() - Method in class org.tensorflow.framework.AttrValue.Builder
"type"
clearType() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
clearType() - Method in class org.tensorflow.framework.InterconnectLink.Builder
string type = 2;
clearType() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Describes the type of one or more tensors that are accepted/produced by this input/output arg.
clearType() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
One of the type names from attr_value.proto ("string", "list(string)", "int", etc.).
clearType() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Type of the tensor
clearType() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Device type, e.g.
clearType() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Device type (CPU, GPU, ...)
clearTypeAttr() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
if specified, attr must have type "type"
clearTypeHint() - Method in class org.tensorflow.framework.SummaryDescription.Builder
Hint on how plugins should process the data in this series.
clearTypeListAttr() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
If specified, attr must have type "list(type)", and none of type, type_attr, and number_attr may be specified.
clearTypeName() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
string type_name = 3;
clearTypeName() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Name of the type of objects being serialized.
clearUint32Val() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT32
clearUint64Val() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT64
clearUnknownRank() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
If true, the number of dimensions in the shape is unknown.
clearUseNumaAffinity() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
If true, and supported by the platform, the runtime will attempt to use NUMA affinity where applicable.
clearUsePerSessionThreads() - Method in class org.tensorflow.framework.ConfigProto.Builder
If true, use a new set of threads for this session rather than the global pool of threads.
clearUseRpcForInprocessMaster() - Method in class org.tensorflow.framework.RPCOptions.Builder
If true, always use RPC to contact the session target.
clearUseRunHandlerPool() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
If true, then operations (using the inter-op pool) across all session::run() calls will be centrally scheduled, optimizing for (median and tail) latency.
clearUseUnifiedMemory() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If true, uses CUDA unified memory for memory allocations.
clearUuid() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
Final entry in output of "nvidia-smi -L"
clearValue() - Method in class org.tensorflow.example.BytesList.Builder
repeated bytes value = 1;
clearValue() - Method in class org.tensorflow.example.FloatList.Builder
repeated float value = 1 [packed = true];
clearValue() - Method in class org.tensorflow.example.Int64List.Builder
repeated int64 value = 1 [packed = true];
clearValue() - Method in class org.tensorflow.framework.AttrValue.Builder
 
clearValue() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
clearValue() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
repeated bytes value = 1;
clearValue() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
repeated float value = 1 [packed = true];
clearValue() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
repeated int64 value = 1 [packed = true];
clearValue() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
repeated string value = 1;
clearValue() - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
clearValue() - Method in class org.tensorflow.framework.Summary.Value.Builder
 
clearValues() - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names that have been seen in this context.
clearValuesDef() - Method in class org.tensorflow.framework.CondContextDef.Builder
Values and external values in control flow context.
clearValuesDef() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Values and external values in control flow context.
clearValuesOutputTensorName() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
string values_output_tensor_name = 4;
clearValuesOutputTensorName() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string values_output_tensor_name = 2;
clearValuesTensorName() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The shape of the values Tensor is [?].
clearVariableName() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the variable tensor.
clearVariantVal() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
clearVarLenFeature() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
clearVarOffset() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Offset of this variable into the full variable.
clearVarShape() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of this variable.
clearVendor() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Vendor (Intel, nvidia, ...)
clearVersion() - Method in class org.tensorflow.framework.GraphDef.Builder
Deprecated.
clearVersion() - Method in class org.tensorflow.framework.OpDeprecation.Builder
First GraphDef version at which the op is disallowed.
clearVersion() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Versioning of the tensor bundle format.
clearVersion() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
A user-specified version string.
clearVersion() - Method in class org.tensorflow.util.SaverDef.Builder
.tensorflow.SaverDef.CheckpointFormatVersion version = 7;
clearVersion() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
clearVersionNumber() - Method in class org.tensorflow.framework.TensorProto.Builder
Version number.
clearVersions() - Method in class org.tensorflow.framework.GraphDef.Builder
Compatibility versions of the graph.
clearVersions() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Compatibility version of this checkpoint.
clearVirtualDevices() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
clearVisibility() - Method in class org.tensorflow.framework.ApiDef.Builder
.tensorflow.ApiDef.Visibility visibility = 2;
clearVisibleDeviceList() - Method in class org.tensorflow.framework.GPUOptions.Builder
A comma-separated list of GPU ids that determines the 'visible' to 'virtual' mapping of GPU devices.
clearWallTime() - Method in class org.tensorflow.util.Event.Builder
Timestamp of the event.
clearWallTime() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Total wall time used for all iterations (in seconds)
clearWatchdogConfig() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WatchdogConfig watchdog_config = 2;
clearWhat() - Method in class org.tensorflow.util.Event.Builder
 
clearWhileCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.WhileContextDef while_ctxt = 2;
clearWidth() - Method in class org.tensorflow.framework.Summary.Image.Builder
int32 width = 2;
clearWorkerLog() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
clearWorkFinished() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
int64 work_finished = 2;
clearWorkStarted() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
int64 work_started = 1;
clone() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
clone() - Method in class org.tensorflow.distruntime.JobDef.Builder
 
clone() - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
clone() - Method in class org.tensorflow.example.BytesList.Builder
 
clone() - Method in class org.tensorflow.example.Example.Builder
 
clone() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
clone() - Method in class org.tensorflow.example.Feature.Builder
 
clone() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
clone() - Method in class org.tensorflow.example.FeatureList.Builder
 
clone() - Method in class org.tensorflow.example.FeatureLists.Builder
 
clone() - Method in class org.tensorflow.example.Features.Builder
 
clone() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
clone() - Method in class org.tensorflow.example.FloatList.Builder
 
clone() - Method in class org.tensorflow.example.Int64List.Builder
 
clone() - Method in class org.tensorflow.example.SequenceExample.Builder
 
clone() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
clone() - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
clone() - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
clone() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
clone() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
clone() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
clone() - Method in class org.tensorflow.framework.ApiDef.Builder
 
clone() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
clone() - Method in class org.tensorflow.framework.ApiDefs.Builder
 
clone() - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
clone() - Method in class org.tensorflow.framework.AttrValue.Builder
 
clone() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
clone() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
clone() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
clone() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
clone() - Method in class org.tensorflow.framework.CollectionDef.Builder
 
clone() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
clone() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
clone() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
clone() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
clone() - Method in class org.tensorflow.framework.CondContextDef.Builder
 
clone() - Method in class org.tensorflow.framework.ConfigProto.Builder
 
clone() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
clone() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
clone() - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
clone() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
clone() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
clone() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
clone() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
clone() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
clone() - Method in class org.tensorflow.framework.DebugOptions.Builder
 
clone() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
clone() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
clone() - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
clone() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
clone() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
clone() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
clone() - Method in class org.tensorflow.framework.GPUOptions.Builder
 
clone() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
clone() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
clone() - Method in class org.tensorflow.framework.GradientDef.Builder
 
clone() - Method in class org.tensorflow.framework.GraphDef.Builder
 
clone() - Method in class org.tensorflow.framework.GraphOptions.Builder
 
clone() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
clone() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
clone() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
clone() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
clone() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
clone() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
clone() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
clone() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
clone() - Method in class org.tensorflow.framework.HistogramProto.Builder
 
clone() - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
clone() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
clone() - Method in class org.tensorflow.framework.KernelDef.Builder
 
clone() - Method in class org.tensorflow.framework.KernelList.Builder
 
clone() - Method in class org.tensorflow.framework.LocalLinks.Builder
 
clone() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
clone() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
clone() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
clone() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
clone() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
clone() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
clone() - Method in class org.tensorflow.framework.MemoryStats.Builder
 
clone() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
clone() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
clone() - Method in class org.tensorflow.framework.NameAttrList.Builder
 
clone() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
clone() - Method in class org.tensorflow.framework.NodeDef.Builder
 
clone() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
clone() - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
clone() - Method in class org.tensorflow.framework.NodeOutput.Builder
 
clone() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
clone() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
clone() - Method in class org.tensorflow.framework.OpDef.Builder
 
clone() - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
clone() - Method in class org.tensorflow.framework.OpList.Builder
 
clone() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
clone() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
clone() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
clone() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
clone() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
clone() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
clone() - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
clone() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
clone() - Method in class org.tensorflow.framework.RPCOptions.Builder
 
clone() - Method in class org.tensorflow.framework.RunMetadata.Builder
 
clone() - Method in class org.tensorflow.framework.RunOptions.Builder
 
clone() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
clone() - Method in class org.tensorflow.framework.SavedModel.Builder
 
clone() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
clone() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
clone() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
clone() - Method in class org.tensorflow.framework.StepStats.Builder
 
clone() - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
clone() - Method in class org.tensorflow.framework.Summary.Builder
 
clone() - Method in class org.tensorflow.framework.Summary.Image.Builder
 
clone() - Method in class org.tensorflow.framework.Summary.Value.Builder
 
clone() - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
clone() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
clone() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
clone() - Method in class org.tensorflow.framework.TensorConnection.Builder
 
clone() - Method in class org.tensorflow.framework.TensorDescription.Builder
 
clone() - Method in class org.tensorflow.framework.TensorInfo.Builder
 
clone() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
clone() - Method in class org.tensorflow.framework.TensorProto.Builder
 
clone() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
clone() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
clone() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
clone() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
clone() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
clone() - Method in class org.tensorflow.framework.ValuesDef.Builder
 
clone() - Method in class org.tensorflow.framework.VariableDef.Builder
 
clone() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
clone() - Method in class org.tensorflow.framework.VersionDef.Builder
 
clone() - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
clone() - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
clone() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
clone() - Method in class org.tensorflow.util.Event.Builder
 
clone() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
clone() - Method in class org.tensorflow.util.LogMessage.Builder
 
clone() - Method in class org.tensorflow.util.SavedSlice.Builder
 
clone() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
clone() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
clone() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
clone() - Method in class org.tensorflow.util.SaverDef.Builder
 
clone() - Method in class org.tensorflow.util.SessionLog.Builder
 
clone() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
clone() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
clone() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
clone() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
clone() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
clone() - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
clone() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
clone() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
clone() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
clone() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
clone() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
clone() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
clone() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
clone() - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
clone() - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
clone() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
clone() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
clone() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
clone() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
clone() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
clone() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
clone() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
clone() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
clone() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
clone() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
clone() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
clone() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
CLOSE_OP_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.QueueRunnerDef
 
CLUSTER_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
CLUSTER_FIELD_NUMBER - Static variable in class org.tensorflow.distruntime.ServerDef
 
ClusterDef - Class in org.tensorflow.distruntime
Defines a TensorFlow cluster as a set of jobs.
ClusterDef.Builder - Class in org.tensorflow.distruntime
Defines a TensorFlow cluster as a set of jobs.
ClusterDefOrBuilder - Interface in org.tensorflow.distruntime
 
ClusterProtos - Class in org.tensorflow.distruntime
 
Code - Enum in org.tensorflow.framework
The canonical error codes for TensorFlow APIs.
COLLECTION_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef
 
CollectionDef - Class in org.tensorflow.framework
CollectionDef should cover most collections.
CollectionDef.AnyList - Class in org.tensorflow.framework
AnyList is used for collecting Any protos.
CollectionDef.AnyList.Builder - Class in org.tensorflow.framework
AnyList is used for collecting Any protos.
CollectionDef.AnyListOrBuilder - Interface in org.tensorflow.framework
 
CollectionDef.Builder - Class in org.tensorflow.framework
CollectionDef should cover most collections.
CollectionDef.BytesList - Class in org.tensorflow.framework
BytesList is used for collecting strings and serialized protobufs.
CollectionDef.BytesList.Builder - Class in org.tensorflow.framework
BytesList is used for collecting strings and serialized protobufs.
CollectionDef.BytesListOrBuilder - Interface in org.tensorflow.framework
 
CollectionDef.FloatList - Class in org.tensorflow.framework
FloatList is used for collecting float values.
CollectionDef.FloatList.Builder - Class in org.tensorflow.framework
FloatList is used for collecting float values.
CollectionDef.FloatListOrBuilder - Interface in org.tensorflow.framework
 
CollectionDef.Int64List - Class in org.tensorflow.framework
Int64List is used for collecting int, int64 and long values.
CollectionDef.Int64List.Builder - Class in org.tensorflow.framework
Int64List is used for collecting int, int64 and long values.
CollectionDef.Int64ListOrBuilder - Interface in org.tensorflow.framework
 
CollectionDef.KindCase - Enum in org.tensorflow.framework
 
CollectionDef.NodeList - Class in org.tensorflow.framework
NodeList is used for collecting nodes in graph.
CollectionDef.NodeList.Builder - Class in org.tensorflow.framework
NodeList is used for collecting nodes in graph.
CollectionDef.NodeListOrBuilder - Interface in org.tensorflow.framework
 
CollectionDefOrBuilder - Interface in org.tensorflow.framework
 
COLLECTIVE_GRAPH_KEY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunOptions.Experimental
 
COLLECTIVE_GROUP_LEADER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto.Experimental
 
COLLECTIVE_RING_ORDER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions.Experimental
 
COLORSPACE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Image
 
COMMIT_ID_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
CommitId - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.CommitId
CommitId.Builder - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.CommitId
CommitId.KindCase - Enum in org.tensorflow.util.testlog
 
CommitIdOrBuilder - Interface in org.tensorflow.util.testlog
 
COMPRESSION_ALGORITHM_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RPCOptions
 
COMPRESSION_LEVEL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RPCOptions
 
COMPUTE_COST_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
COMPUTE_TIME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
COND_CTXT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ControlFlowContextDef
 
CondContextDef - Class in org.tensorflow.framework
Protocol buffer representing a CondContext object.
CondContextDef.Builder - Class in org.tensorflow.framework
Protocol buffer representing a CondContext object.
CondContextDefOrBuilder - Interface in org.tensorflow.framework
 
ConfigProto - Class in org.tensorflow.framework
Session configuration parameters.
ConfigProto.Builder - Class in org.tensorflow.framework
Session configuration parameters.
ConfigProto.Experimental - Class in org.tensorflow.framework
Everything inside Experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
ConfigProto.Experimental.Builder - Class in org.tensorflow.framework
Everything inside Experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
ConfigProto.ExperimentalOrBuilder - Interface in org.tensorflow.framework
 
ConfigProtoOrBuilder - Interface in org.tensorflow.framework
 
ConfigProtos - Class in org.tensorflow.framework
 
CONST_NODE_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferInfo
 
CONSTANT_FOLDING_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
CONSTRAINT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.KernelDef
 
CONTAINER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ResourceHandleProto
 
containsAttr(String) - Method in class org.tensorflow.framework.FunctionDef.Builder
Attributes specific to this function definition.
containsAttr(String) - Method in class org.tensorflow.framework.FunctionDef
Attributes specific to this function definition.
containsAttr(String) - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
Attributes specific to this function definition.
containsAttr(String) - Method in class org.tensorflow.framework.NameAttrList.Builder
map<string, .tensorflow.AttrValue> attr = 2;
containsAttr(String) - Method in class org.tensorflow.framework.NameAttrList
map<string, .tensorflow.AttrValue> attr = 2;
containsAttr(String) - Method in interface org.tensorflow.framework.NameAttrListOrBuilder
map<string, .tensorflow.AttrValue> attr = 2;
containsAttr(String) - Method in class org.tensorflow.framework.NodeDef.Builder
Operation-specific graph-construction-time configuration.
containsAttr(String) - Method in class org.tensorflow.framework.NodeDef
Operation-specific graph-construction-time configuration.
containsAttr(String) - Method in interface org.tensorflow.framework.NodeDefOrBuilder
Operation-specific graph-construction-time configuration.
containsCacheSize(String) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Cache sizes (in bytes), e.g.
containsCacheSize(String) - Method in class org.tensorflow.util.testlog.CPUInfo
Cache sizes (in bytes), e.g.
containsCacheSize(String) - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
Cache sizes (in bytes), e.g.
containsCollectionDef(String) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
collection_def: Map from collection name to collections.
containsCollectionDef(String) - Method in class org.tensorflow.framework.MetaGraphDef
collection_def: Map from collection name to collections.
containsCollectionDef(String) - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
collection_def: Map from collection name to collections.
containsDeviceCount(String) - Method in class org.tensorflow.framework.ConfigProto.Builder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
containsDeviceCount(String) - Method in class org.tensorflow.framework.ConfigProto
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
containsDeviceCount(String) - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
containsEnvironment(String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Version of the tools and libraries used with this device (e.g.
containsEnvironment(String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Version of the tools and libraries used with this device (e.g.
containsEnvironment(String) - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Version of the tools and libraries used with this device (e.g.
containsExternalValues(String) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names referenced by but external to this context.
containsExternalValues(String) - Method in class org.tensorflow.framework.ValuesDef
Value names referenced by but external to this context.
containsExternalValues(String) - Method in interface org.tensorflow.framework.ValuesDefOrBuilder
Value names referenced by but external to this context.
containsExtras(String) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Generic map from result key to value.
containsExtras(String) - Method in class org.tensorflow.util.testlog.BenchmarkEntry
Generic map from result key to value.
containsExtras(String) - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
Generic map from result key to value.
containsFeature(String) - Method in class org.tensorflow.example.Features.Builder
Map from feature name to feature.
containsFeature(String) - Method in class org.tensorflow.example.Features
Map from feature name to feature.
containsFeature(String) - Method in interface org.tensorflow.example.FeaturesOrBuilder
Map from feature name to feature.
containsFeatureList(String) - Method in class org.tensorflow.example.FeatureLists.Builder
Map from feature name to feature list.
containsFeatureList(String) - Method in class org.tensorflow.example.FeatureLists
Map from feature name to feature list.
containsFeatureList(String) - Method in interface org.tensorflow.example.FeatureListsOrBuilder
Map from feature name to feature list.
containsFeatureMap(String) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
containsFeatureMap(String) - Method in class org.tensorflow.example.ExampleParserConfiguration
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
containsFeatureMap(String) - Method in interface org.tensorflow.example.ExampleParserConfigurationOrBuilder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
containsFeedDevices(String) - Method in class org.tensorflow.framework.CallableOptions.Builder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
containsFeedDevices(String) - Method in class org.tensorflow.framework.CallableOptions
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
containsFeedDevices(String) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
containsFetchDevices(String) - Method in class org.tensorflow.framework.CallableOptions.Builder
map<string, string> fetch_devices = 7;
containsFetchDevices(String) - Method in class org.tensorflow.framework.CallableOptions
map<string, string> fetch_devices = 7;
containsFetchDevices(String) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
map<string, string> fetch_devices = 7;
containsInputs(String) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named input parameters.
containsInputs(String) - Method in class org.tensorflow.framework.SignatureDef
Named input parameters.
containsInputs(String) - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Named input parameters.
containsOutputs(String) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named output parameters.
containsOutputs(String) - Method in class org.tensorflow.framework.SignatureDef
Named output parameters.
containsOutputs(String) - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Named output parameters.
containsParameterMap(String) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
map<string, .tensorflow.AttrValue> parameter_map = 2;
containsParameterMap(String) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
map<string, .tensorflow.AttrValue> parameter_map = 2;
containsParameterMap(String) - Method in interface org.tensorflow.framework.RewriterConfig.CustomGraphOptimizerOrBuilder
map<string, .tensorflow.AttrValue> parameter_map = 2;
containsRet(String) - Method in class org.tensorflow.framework.FunctionDef.Builder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
containsRet(String) - Method in class org.tensorflow.framework.FunctionDef
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
containsRet(String) - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
containsSignatureDef(String) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
containsSignatureDef(String) - Method in class org.tensorflow.framework.MetaGraphDef
signature_def: Map from user supplied key for a signature to a single SignatureDef.
containsSignatureDef(String) - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
containsTasks(int) - Method in class org.tensorflow.distruntime.JobDef.Builder
Mapping from task ID to "hostname:port" string.
containsTasks(int) - Method in class org.tensorflow.distruntime.JobDef
Mapping from task ID to "hostname:port" string.
containsTasks(int) - Method in interface org.tensorflow.distruntime.JobDefOrBuilder
Mapping from task ID to "hostname:port" string.
CONTENT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SummaryMetadata.PluginData
 
CONTENT_TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Audio
 
CONTEXT_FIELD_NUMBER - Static variable in class org.tensorflow.example.SequenceExample
 
CONTEXT_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CondContextDef
 
CONTEXT_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
CONTROL_INPUT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
ControlFlowContextDef - Class in org.tensorflow.framework
Container for any kind of control flow context.
ControlFlowContextDef.Builder - Class in org.tensorflow.framework
Container for any kind of control flow context.
ControlFlowContextDef.CtxtCase - Enum in org.tensorflow.framework
 
ControlFlowContextDefOrBuilder - Interface in org.tensorflow.framework
 
ControlFlowProtos - Class in org.tensorflow.framework
 
COO_SPARSE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorInfo
 
COST_GRAPH_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunMetadata
 
CostGraphDef - Class in org.tensorflow.framework
Protobuf type tensorflow.CostGraphDef
CostGraphDef.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.CostGraphDef
CostGraphDef.Node - Class in org.tensorflow.framework
Protobuf type tensorflow.CostGraphDef.Node
CostGraphDef.Node.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.CostGraphDef.Node
CostGraphDef.Node.InputInfo - Class in org.tensorflow.framework
Inputs of this node.
CostGraphDef.Node.InputInfo.Builder - Class in org.tensorflow.framework
Inputs of this node.
CostGraphDef.Node.InputInfoOrBuilder - Interface in org.tensorflow.framework
 
CostGraphDef.Node.OutputInfo - Class in org.tensorflow.framework
Outputs of this node.
CostGraphDef.Node.OutputInfo.Builder - Class in org.tensorflow.framework
Outputs of this node.
CostGraphDef.Node.OutputInfoOrBuilder - Interface in org.tensorflow.framework
 
CostGraphDef.NodeOrBuilder - Interface in org.tensorflow.framework
 
CostGraphDefOrBuilder - Interface in org.tensorflow.framework
 
CostGraphProtos - Class in org.tensorflow.framework
 
CPP_MICROBENCHMARK_VALUE - Static variable in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
CPP_MICROBENCHMARK = 1;
CPU_GOVERNOR_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.CPUInfo
 
CPU_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.CPUInfo
 
CPU_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.MachineConfiguration
 
CPU_TIME_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.BenchmarkEntry
 
CPUInfo - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.CPUInfo
CPUInfo.Builder - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.CPUInfo
CPUInfoOrBuilder - Interface in org.tensorflow.util.testlog
 
CRC32C_FIELD_NUMBER - Static variable in class org.tensorflow.util.BundleEntryProto
 
CURRENT_WORK_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ReaderBaseState
 
CUSTOM_OPTIMIZERS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 

D

DATA_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
DATA_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedSlice
 
DATA_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedTensorSlices
 
DATA_LOSS_VALUE - Static variable in enum org.tensorflow.framework.Code
Unrecoverable data loss or corruption.
DataType - Enum in org.tensorflow.framework
LINT.IfChange
DCOMPLEX_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
DEADLINE_EXCEEDED_VALUE - Static variable in enum org.tensorflow.framework.Code
Deadline expired before operation could complete.
DEBUG_OPS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebugTensorWatch
 
DEBUG_OPTIONS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunOptions
 
DEBUG_STRIPPER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
DEBUG_TENSOR_WATCH_OPTS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebugOptions
 
DEBUG_URLS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebugTensorWatch
 
DebuggedSourceFile - Class in org.tensorflow.framework
Protobuf type tensorflow.DebuggedSourceFile
DebuggedSourceFile.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.DebuggedSourceFile
DebuggedSourceFileOrBuilder - Interface in org.tensorflow.framework
 
DebuggedSourceFiles - Class in org.tensorflow.framework
Protobuf type tensorflow.DebuggedSourceFiles
DebuggedSourceFiles.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.DebuggedSourceFiles
DebuggedSourceFilesOrBuilder - Interface in org.tensorflow.framework
 
DEBUGGING_VALUE - Static variable in enum org.tensorflow.util.LogMessage.Level
Note: The logging level 10 cannot be named DEBUG.
DebugOptions - Class in org.tensorflow.framework
Options for initializing DebuggerState in TensorFlow Debugger (tfdbg).
DebugOptions.Builder - Class in org.tensorflow.framework
Options for initializing DebuggerState in TensorFlow Debugger (tfdbg).
DebugOptionsOrBuilder - Interface in org.tensorflow.framework
 
DebugProtos - Class in org.tensorflow.framework
 
DebugTensorWatch - Class in org.tensorflow.framework
Option for watching a node in TensorFlow Debugger (tfdbg).
DebugTensorWatch.Builder - Class in org.tensorflow.framework
Option for watching a node in TensorFlow Debugger (tfdbg).
DebugTensorWatchOrBuilder - Interface in org.tensorflow.framework
 
DEFAULT_GRAPH_INPUT_TENSOR_SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
DEFAULT_GRAPH_OUTPUT_TENSOR_SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
DEFAULT_MEM_OPT_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.MemOptType
The default setting (SCHEDULING and SWAPPING HEURISTICS only)
DEFAULT_NUM_ITERS_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
DEFAULT_NUM_ITERS = 0;
DEFAULT_SESSION_CONFIG_FIELD_NUMBER - Static variable in class org.tensorflow.distruntime.ServerDef
 
DEFAULT_VALUE - Static variable in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
Default setting ("off" now, but later expected to be "on")
DEFAULT_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.Toggle
DEFAULT = 0;
DEFAULT_VALUE - Static variable in enum org.tensorflow.util.WorkerShutdownMode
DEFAULT = 0;
DEFAULT_VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.example.FixedLenFeatureProto
 
DEFAULT_VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef.Attr
 
DEFAULT_VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.AttrDef
 
DEFAULT_VISIBILITY_VALUE - Static variable in enum org.tensorflow.framework.ApiDef.Visibility
Normally this is "VISIBLE" unless you are inheriting a different value from another ApiDef.
DEFERRED_DELETION_BYTES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions
 
DEFERRED_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawDeallocation
 
DENSE_SHAPE_TENSOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorInfo.CooSparse
 
DEPENDENCY_OPTIMIZATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
DEPRECATED_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef.Endpoint
 
DEPRECATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
DEPRECATION_MESSAGE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
DEPRECATION_VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
DEPRECATION_VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef.Endpoint
 
DESCRIPTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef.Arg
 
DESCRIPTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef.Attr
 
DESCRIPTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
DESCRIPTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.ArgDef
 
DESCRIPTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.AttrDef
 
DESCRIPTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
DESCRIPTION_PREFIX_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
DESCRIPTION_SUFFIX_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
DESTINATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferInfo
 
DEV_STATS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.StepStats
 
DEVICE_COUNT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
DEVICE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
DEVICE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceStepStats
 
DEVICE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeDef
 
DEVICE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ResourceHandleProto
 
DEVICE_FILTERS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
DEVICE_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.InterconnectLink
 
DEVICE_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.MachineConfiguration
 
DEVICE_PERSISTENT_MEMORY_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
DEVICE_PERSISTENT_MEMORY_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryStats
 
DEVICE_PERSISTENT_TENSOR_ALLOC_IDS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryStats
 
DEVICE_TEMP_MEMORY_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
DEVICE_TEMP_MEMORY_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryStats
 
DEVICE_TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceAttributes
 
DEVICE_TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.KernelDef
 
DeviceAttributes - Class in org.tensorflow.framework
Protobuf type tensorflow.DeviceAttributes
DeviceAttributes.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.DeviceAttributes
DeviceAttributesOrBuilder - Interface in org.tensorflow.framework
 
DeviceAttributesProtos - Class in org.tensorflow.framework
 
DeviceLocality - Class in org.tensorflow.framework
Protobuf type tensorflow.DeviceLocality
DeviceLocality.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.DeviceLocality
DeviceLocalityOrBuilder - Interface in org.tensorflow.framework
 
DevicePropertiesProtos - Class in tensorflow
 
DevicePropertiesProtos.DeviceProperties - Class in tensorflow
Protobuf type tensorflow.DeviceProperties
DevicePropertiesProtos.DeviceProperties.Builder - Class in tensorflow
Protobuf type tensorflow.DeviceProperties
DevicePropertiesProtos.DevicePropertiesOrBuilder - Interface in tensorflow
 
DevicePropertiesProtos.NamedDevice - Class in tensorflow
Protobuf type tensorflow.NamedDevice
DevicePropertiesProtos.NamedDevice.Builder - Class in tensorflow
Protobuf type tensorflow.NamedDevice
DevicePropertiesProtos.NamedDeviceOrBuilder - Interface in tensorflow
 
DeviceStepStats - Class in org.tensorflow.framework
Protobuf type tensorflow.DeviceStepStats
DeviceStepStats.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.DeviceStepStats
DeviceStepStatsOrBuilder - Interface in org.tensorflow.framework
 
DIM_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorShapeProto
 
DISABLE_META_OPTIMIZER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
DISABLE_MODEL_PRUNING_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
DISPLAY_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SummaryMetadata
 
DO_COMMON_SUBEXPRESSION_ELIMINATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OptimizerOptions
 
DO_CONSTANT_FOLDING_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OptimizerOptions
 
DO_FUNCTION_INLINING_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OptimizerOptions
 
DO_NOT_USE_RESERVED_FOR_FUTURE_EXPANSION_USE_DEFAULT_IN_SWITCH_INSTEAD__VALUE - Static variable in enum org.tensorflow.framework.Code
An extra enum entry to prevent people from writing code that fails to compile when a new code is added.
DOUBLE_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
DOUBLE_VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.EntryValue
 
DT_BFLOAT16_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_BFLOAT16_REF = 114;
DT_BFLOAT16_VALUE - Static variable in enum org.tensorflow.framework.DataType
Float32 truncated to 16 bits.
DT_BOOL_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_BOOL_REF = 110;
DT_BOOL_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_BOOL = 10;
DT_COMPLEX128_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_COMPLEX128_REF = 118;
DT_COMPLEX128_VALUE - Static variable in enum org.tensorflow.framework.DataType
Double-precision complex
DT_COMPLEX64_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_COMPLEX64_REF = 108;
DT_COMPLEX64_VALUE - Static variable in enum org.tensorflow.framework.DataType
Single-precision complex
DT_DOUBLE_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_DOUBLE_REF = 102;
DT_DOUBLE_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_DOUBLE = 2;
DT_FLOAT_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
Do not use! These are only for parameters.
DT_FLOAT_VALUE - Static variable in enum org.tensorflow.framework.DataType
Data types that all computation devices are expected to be capable to support.
DT_HALF_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_HALF_REF = 119;
DT_HALF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_HALF = 19;
DT_INT16_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_INT16_REF = 105;
DT_INT16_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_INT16 = 5;
DT_INT32_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_INT32_REF = 103;
DT_INT32_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_INT32 = 3;
DT_INT64_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_INT64_REF = 109;
DT_INT64_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_INT64 = 9;
DT_INT8_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_INT8_REF = 106;
DT_INT8_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_INT8 = 6;
DT_INVALID_VALUE - Static variable in enum org.tensorflow.framework.DataType
Not a legal value for DataType.
DT_QINT16_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_QINT16_REF = 115;
DT_QINT16_VALUE - Static variable in enum org.tensorflow.framework.DataType
Quantized int16
DT_QINT32_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_QINT32_REF = 113;
DT_QINT32_VALUE - Static variable in enum org.tensorflow.framework.DataType
Quantized int32
DT_QINT8_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_QINT8_REF = 111;
DT_QINT8_VALUE - Static variable in enum org.tensorflow.framework.DataType
Quantized int8
DT_QUINT16_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_QUINT16_REF = 116;
DT_QUINT16_VALUE - Static variable in enum org.tensorflow.framework.DataType
Quantized uint16
DT_QUINT8_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_QUINT8_REF = 112;
DT_QUINT8_VALUE - Static variable in enum org.tensorflow.framework.DataType
Quantized uint8
DT_RESOURCE_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_RESOURCE_REF = 120;
DT_RESOURCE_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_RESOURCE = 20;
DT_STRING_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_STRING_REF = 107;
DT_STRING_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_STRING = 7;
DT_UINT16_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_UINT16_REF = 117;
DT_UINT16_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_UINT16 = 17;
DT_UINT32_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_UINT32_REF = 122;
DT_UINT32_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_UINT32 = 22;
DT_UINT64_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_UINT64_REF = 123;
DT_UINT64_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_UINT64 = 23;
DT_UINT8_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_UINT8_REF = 104;
DT_UINT8_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_UINT8 = 4;
DT_VARIANT_REF_VALUE - Static variable in enum org.tensorflow.framework.DataType
DT_VARIANT_REF = 121;
DT_VARIANT_VALUE - Static variable in enum org.tensorflow.framework.DataType
Arbitrary C++ data types
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.example.FixedLenFeatureProto
 
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.example.VarLenFeatureProto
 
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorDescription
 
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorInfo
 
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
DTYPE_FIELD_NUMBER - Static variable in class org.tensorflow.util.BundleEntryProto
 

E

ELEMENT_FIELD_NUMBER - Static variable in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
ENABLE_BFLOAT16_SENDRECV_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphOptions
 
ENABLE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AutoParallelOptions
 
ENABLE_OP_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ScopedAllocatorOptions
 
ENABLE_RECV_SCHEDULING_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphOptions
 
ENCODED_AUDIO_STRING_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Audio
 
ENCODED_IMAGE_STRING_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Image
 
ENDIANNESS_FIELD_NUMBER - Static variable in class org.tensorflow.util.BundleHeaderProto
 
ENDPOINT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
ENQUEUE_OP_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.QueueRunnerDef
 
ENTRIES_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
ENTRY_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.BenchmarkEntries
 
EntryValue - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.EntryValue
EntryValue.Builder - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.EntryValue
EntryValue.KindCase - Enum in org.tensorflow.util.testlog
 
EntryValueOrBuilder - Interface in org.tensorflow.util.testlog
 
ENVIRONMENT_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
equals(Object) - Method in class org.tensorflow.distruntime.ClusterDef
 
equals(Object) - Method in class org.tensorflow.distruntime.JobDef
 
equals(Object) - Method in class org.tensorflow.distruntime.ServerDef
 
equals(Object) - Method in class org.tensorflow.example.BytesList
 
equals(Object) - Method in class org.tensorflow.example.Example
 
equals(Object) - Method in class org.tensorflow.example.ExampleParserConfiguration
 
equals(Object) - Method in class org.tensorflow.example.Feature
 
equals(Object) - Method in class org.tensorflow.example.FeatureConfiguration
 
equals(Object) - Method in class org.tensorflow.example.FeatureList
 
equals(Object) - Method in class org.tensorflow.example.FeatureLists
 
equals(Object) - Method in class org.tensorflow.example.Features
 
equals(Object) - Method in class org.tensorflow.example.FixedLenFeatureProto
 
equals(Object) - Method in class org.tensorflow.example.FloatList
 
equals(Object) - Method in class org.tensorflow.example.Int64List
 
equals(Object) - Method in class org.tensorflow.example.SequenceExample
 
equals(Object) - Method in class org.tensorflow.example.VarLenFeatureProto
 
equals(Object) - Method in class org.tensorflow.framework.AllocationDescription
 
equals(Object) - Method in class org.tensorflow.framework.AllocationRecord
 
equals(Object) - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
equals(Object) - Method in class org.tensorflow.framework.ApiDef.Arg
 
equals(Object) - Method in class org.tensorflow.framework.ApiDef.Attr
 
equals(Object) - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
equals(Object) - Method in class org.tensorflow.framework.ApiDef
 
equals(Object) - Method in class org.tensorflow.framework.ApiDefs
 
equals(Object) - Method in class org.tensorflow.framework.AssetFileDef
 
equals(Object) - Method in class org.tensorflow.framework.AttrValue
 
equals(Object) - Method in class org.tensorflow.framework.AttrValue.ListValue
 
equals(Object) - Method in class org.tensorflow.framework.AutoParallelOptions
 
equals(Object) - Method in class org.tensorflow.framework.CallableOptions
 
equals(Object) - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
equals(Object) - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
equals(Object) - Method in class org.tensorflow.framework.CollectionDef
 
equals(Object) - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
equals(Object) - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
equals(Object) - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
equals(Object) - Method in class org.tensorflow.framework.CondContextDef
 
equals(Object) - Method in class org.tensorflow.framework.ConfigProto
 
equals(Object) - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
equals(Object) - Method in class org.tensorflow.framework.ControlFlowContextDef
 
equals(Object) - Method in class org.tensorflow.framework.CostGraphDef
 
equals(Object) - Method in class org.tensorflow.framework.CostGraphDef.Node
 
equals(Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
equals(Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
equals(Object) - Method in class org.tensorflow.framework.DebuggedSourceFile
 
equals(Object) - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
equals(Object) - Method in class org.tensorflow.framework.DebugOptions
 
equals(Object) - Method in class org.tensorflow.framework.DebugTensorWatch
 
equals(Object) - Method in class org.tensorflow.framework.DeviceAttributes
 
equals(Object) - Method in class org.tensorflow.framework.DeviceLocality
 
equals(Object) - Method in class org.tensorflow.framework.DeviceStepStats
 
equals(Object) - Method in class org.tensorflow.framework.FunctionDef
 
equals(Object) - Method in class org.tensorflow.framework.FunctionDefLibrary
 
equals(Object) - Method in class org.tensorflow.framework.GPUOptions
 
equals(Object) - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
equals(Object) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
equals(Object) - Method in class org.tensorflow.framework.GradientDef
 
equals(Object) - Method in class org.tensorflow.framework.GraphDef
 
equals(Object) - Method in class org.tensorflow.framework.GraphOptions
 
equals(Object) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
equals(Object) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
equals(Object) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
equals(Object) - Method in class org.tensorflow.framework.GraphTransferInfo
 
equals(Object) - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
equals(Object) - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
equals(Object) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
equals(Object) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
equals(Object) - Method in class org.tensorflow.framework.HistogramProto
 
equals(Object) - Method in class org.tensorflow.framework.InterconnectLink
 
equals(Object) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
equals(Object) - Method in class org.tensorflow.framework.KernelDef
 
equals(Object) - Method in class org.tensorflow.framework.KernelList
 
equals(Object) - Method in class org.tensorflow.framework.LocalLinks
 
equals(Object) - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
equals(Object) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
equals(Object) - Method in class org.tensorflow.framework.MemoryLogStep
 
equals(Object) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
equals(Object) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
equals(Object) - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
equals(Object) - Method in class org.tensorflow.framework.MemoryStats
 
equals(Object) - Method in class org.tensorflow.framework.MetaGraphDef
 
equals(Object) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
equals(Object) - Method in class org.tensorflow.framework.NameAttrList
 
equals(Object) - Method in class org.tensorflow.framework.NamedTensorProto
 
equals(Object) - Method in class org.tensorflow.framework.NodeDef
 
equals(Object) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
equals(Object) - Method in class org.tensorflow.framework.NodeExecStats
 
equals(Object) - Method in class org.tensorflow.framework.NodeOutput
 
equals(Object) - Method in class org.tensorflow.framework.OpDef.ArgDef
 
equals(Object) - Method in class org.tensorflow.framework.OpDef.AttrDef
 
equals(Object) - Method in class org.tensorflow.framework.OpDef
 
equals(Object) - Method in class org.tensorflow.framework.OpDeprecation
 
equals(Object) - Method in class org.tensorflow.framework.OpList
 
equals(Object) - Method in class org.tensorflow.framework.OptimizerOptions
 
equals(Object) - Method in class org.tensorflow.framework.QueueRunnerDef
 
equals(Object) - Method in class org.tensorflow.framework.ReaderBaseState
 
equals(Object) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
equals(Object) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
equals(Object) - Method in class org.tensorflow.framework.ResourceHandleProto
 
equals(Object) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
equals(Object) - Method in class org.tensorflow.framework.RewriterConfig
 
equals(Object) - Method in class org.tensorflow.framework.RPCOptions
 
equals(Object) - Method in class org.tensorflow.framework.RunMetadata
 
equals(Object) - Method in class org.tensorflow.framework.RunOptions
 
equals(Object) - Method in class org.tensorflow.framework.RunOptions.Experimental
 
equals(Object) - Method in class org.tensorflow.framework.SavedModel
 
equals(Object) - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
equals(Object) - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
equals(Object) - Method in class org.tensorflow.framework.SignatureDef
 
equals(Object) - Method in class org.tensorflow.framework.StepStats
 
equals(Object) - Method in class org.tensorflow.framework.Summary.Audio
 
equals(Object) - Method in class org.tensorflow.framework.Summary
 
equals(Object) - Method in class org.tensorflow.framework.Summary.Image
 
equals(Object) - Method in class org.tensorflow.framework.Summary.Value
 
equals(Object) - Method in class org.tensorflow.framework.SummaryDescription
 
equals(Object) - Method in class org.tensorflow.framework.SummaryMetadata
 
equals(Object) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
equals(Object) - Method in class org.tensorflow.framework.TensorConnection
 
equals(Object) - Method in class org.tensorflow.framework.TensorDescription
 
equals(Object) - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
equals(Object) - Method in class org.tensorflow.framework.TensorInfo
 
equals(Object) - Method in class org.tensorflow.framework.TensorProto
 
equals(Object) - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
equals(Object) - Method in class org.tensorflow.framework.TensorShapeProto
 
equals(Object) - Method in class org.tensorflow.framework.TensorSliceProto
 
equals(Object) - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
equals(Object) - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
equals(Object) - Method in class org.tensorflow.framework.ValuesDef
 
equals(Object) - Method in class org.tensorflow.framework.VariableDef
 
equals(Object) - Method in class org.tensorflow.framework.VariantTensorDataProto
 
equals(Object) - Method in class org.tensorflow.framework.VersionDef
 
equals(Object) - Method in class org.tensorflow.framework.WhileContextDef
 
equals(Object) - Method in class org.tensorflow.util.BundleEntryProto
 
equals(Object) - Method in class org.tensorflow.util.BundleHeaderProto
 
equals(Object) - Method in class org.tensorflow.util.Event
 
equals(Object) - Method in class org.tensorflow.util.IteratorStateMetadata
 
equals(Object) - Method in class org.tensorflow.util.LogMessage
 
equals(Object) - Method in class org.tensorflow.util.SavedSlice
 
equals(Object) - Method in class org.tensorflow.util.SavedSliceMeta
 
equals(Object) - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
equals(Object) - Method in class org.tensorflow.util.SavedTensorSlices
 
equals(Object) - Method in class org.tensorflow.util.SaverDef
 
equals(Object) - Method in class org.tensorflow.util.SessionLog
 
equals(Object) - Method in class org.tensorflow.util.TaggedRunMetadata
 
equals(Object) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
equals(Object) - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
equals(Object) - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
equals(Object) - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
equals(Object) - Method in class org.tensorflow.util.testlog.CommitId
 
equals(Object) - Method in class org.tensorflow.util.testlog.CPUInfo
 
equals(Object) - Method in class org.tensorflow.util.testlog.EntryValue
 
equals(Object) - Method in class org.tensorflow.util.testlog.GPUInfo
 
equals(Object) - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
equals(Object) - Method in class org.tensorflow.util.testlog.MemoryInfo
 
equals(Object) - Method in class org.tensorflow.util.testlog.PlatformInfo
 
equals(Object) - Method in class org.tensorflow.util.testlog.RunConfiguration
 
equals(Object) - Method in class org.tensorflow.util.testlog.TestResults
 
equals(Object) - Method in class org.tensorflow.util.WatchdogConfig
 
equals(Object) - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
equals(Object) - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
equals(Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
equals(Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
equals(Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
equals(Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
equals(Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
equals(Object) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
equals(Object) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
equals(Object) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
equals(Object) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
equals(Object) - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
ERROR_VALUE - Static variable in enum org.tensorflow.util.LogMessage.Level
ERROR = 40;
ErrorCodesProtos - Class in org.tensorflow.framework
 
Event - Class in org.tensorflow.util
Protocol buffer representing an event that happened during the execution of a Brain model.
Event.Builder - Class in org.tensorflow.util
Protocol buffer representing an event that happened during the execution of a Brain model.
Event.WhatCase - Enum in org.tensorflow.util
 
EventOrBuilder - Interface in org.tensorflow.util
 
EventProtos - Class in org.tensorflow.util
 
Example - Class in org.tensorflow.example
Protobuf type tensorflow.Example
Example.Builder - Class in org.tensorflow.example
Protobuf type tensorflow.Example
ExampleOrBuilder - Interface in org.tensorflow.example
 
ExampleParserConfiguration - Class in org.tensorflow.example
Protobuf type tensorflow.ExampleParserConfiguration
ExampleParserConfiguration.Builder - Class in org.tensorflow.example
Protobuf type tensorflow.ExampleParserConfiguration
ExampleParserConfigurationOrBuilder - Interface in org.tensorflow.example
 
ExampleParserConfigurationProtos - Class in org.tensorflow.example
 
ExampleProtos - Class in org.tensorflow.example
 
EXECUTOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
EXECUTOR_TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto.Experimental
 
EXPERIMENTAL_DEBUG_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeDef
 
EXPERIMENTAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
EXPERIMENTAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions
 
EXPERIMENTAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunOptions
 
EXPLANATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDeprecation
 
EXTENT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorSliceProto
 
EXTERNAL_VALUES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ValuesDef
 
EXTRAS_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.BenchmarkEntry
 

F

F_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue
 
F_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue.ListValue
 
FAIL_ON_OPTIMIZER_ERRORS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
FAILED_PRECONDITION_VALUE - Static variable in enum org.tensorflow.framework.Code
Operation was rejected because the system is not in a state required for the operation's execution.
FATAL_VALUE - Static variable in enum org.tensorflow.util.LogMessage.Level
FATAL = 50;
Feature - Class in org.tensorflow.example
Containers for non-sequential data.
Feature.Builder - Class in org.tensorflow.example
Containers for non-sequential data.
Feature.KindCase - Enum in org.tensorflow.example
 
FEATURE_FIELD_NUMBER - Static variable in class org.tensorflow.example.FeatureList
 
FEATURE_FIELD_NUMBER - Static variable in class org.tensorflow.example.Features
 
FEATURE_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.example.FeatureLists
 
FEATURE_LISTS_FIELD_NUMBER - Static variable in class org.tensorflow.example.SequenceExample
 
FEATURE_MAP_FIELD_NUMBER - Static variable in class org.tensorflow.example.ExampleParserConfiguration
 
FeatureConfiguration - Class in org.tensorflow.example
Protobuf type tensorflow.FeatureConfiguration
FeatureConfiguration.Builder - Class in org.tensorflow.example
Protobuf type tensorflow.FeatureConfiguration
FeatureConfiguration.ConfigCase - Enum in org.tensorflow.example
 
FeatureConfigurationOrBuilder - Interface in org.tensorflow.example
 
FeatureList - Class in org.tensorflow.example
Containers for sequential data.
FeatureList.Builder - Class in org.tensorflow.example
Containers for sequential data.
FeatureListOrBuilder - Interface in org.tensorflow.example
 
FeatureLists - Class in org.tensorflow.example
Protobuf type tensorflow.FeatureLists
FeatureLists.Builder - Class in org.tensorflow.example
Protobuf type tensorflow.FeatureLists
FeatureListsOrBuilder - Interface in org.tensorflow.example
 
FeatureOrBuilder - Interface in org.tensorflow.example
 
FeatureProtos - Class in org.tensorflow.example
 
Features - Class in org.tensorflow.example
Protobuf type tensorflow.Features
Features.Builder - Class in org.tensorflow.example
Protobuf type tensorflow.Features
FEATURES_FIELD_NUMBER - Static variable in class org.tensorflow.example.Example
 
FeaturesOrBuilder - Interface in org.tensorflow.example
 
FEED_DEVICES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CallableOptions
 
FEED_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CallableOptions
 
FETCH_DEVICES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CallableOptions
 
FETCH_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CallableOptions
 
FETCH_SKIP_SYNC_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CallableOptions
 
FILE_PATH_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebuggedSourceFile
 
FILE_VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.util.Event
 
FILENAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AssetFileDef
 
FILENAME_TENSOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.util.SaverDef
 
FIXED_LEN_FEATURE_FIELD_NUMBER - Static variable in class org.tensorflow.example.FeatureConfiguration
 
FixedLenFeatureProto - Class in org.tensorflow.example
Protobuf type tensorflow.FixedLenFeatureProto
FixedLenFeatureProto.Builder - Class in org.tensorflow.example
Protobuf type tensorflow.FixedLenFeatureProto
FixedLenFeatureProtoOrBuilder - Interface in org.tensorflow.example
 
FLOAT_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.example.Feature
 
FLOAT_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CollectionDef
 
FLOAT_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
FloatList - Class in org.tensorflow.example
Protobuf type tensorflow.FloatList
FloatList.Builder - Class in org.tensorflow.example
Protobuf type tensorflow.FloatList
FloatListOrBuilder - Interface in org.tensorflow.example
 
FORCE_GPU_COMPATIBLE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions
 
forNumber(int) - Static method in enum org.tensorflow.example.Feature.KindCase
 
forNumber(int) - Static method in enum org.tensorflow.example.FeatureConfiguration.ConfigCase
 
forNumber(int) - Static method in enum org.tensorflow.framework.ApiDef.Visibility
 
forNumber(int) - Static method in enum org.tensorflow.framework.AttrValue.ValueCase
 
forNumber(int) - Static method in enum org.tensorflow.framework.Code
 
forNumber(int) - Static method in enum org.tensorflow.framework.CollectionDef.KindCase
 
forNumber(int) - Static method in enum org.tensorflow.framework.ControlFlowContextDef.CtxtCase
 
forNumber(int) - Static method in enum org.tensorflow.framework.DataType
 
forNumber(int) - Static method in enum org.tensorflow.framework.GraphTransferInfo.Destination
 
forNumber(int) - Static method in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
 
forNumber(int) - Static method in enum org.tensorflow.framework.OptimizerOptions.Level
 
forNumber(int) - Static method in enum org.tensorflow.framework.RewriterConfig.MemOptType
 
forNumber(int) - Static method in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
 
forNumber(int) - Static method in enum org.tensorflow.framework.RewriterConfig.Toggle
 
forNumber(int) - Static method in enum org.tensorflow.framework.RunOptions.TraceLevel
 
forNumber(int) - Static method in enum org.tensorflow.framework.Summary.Value.ValueCase
 
forNumber(int) - Static method in enum org.tensorflow.framework.TensorInfo.EncodingCase
 
forNumber(int) - Static method in enum org.tensorflow.framework.TensorSliceProto.Extent.HasLengthCase
 
forNumber(int) - Static method in enum org.tensorflow.util.BundleHeaderProto.Endianness
 
forNumber(int) - Static method in enum org.tensorflow.util.Event.WhatCase
 
forNumber(int) - Static method in enum org.tensorflow.util.LogMessage.Level
 
forNumber(int) - Static method in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
 
forNumber(int) - Static method in enum org.tensorflow.util.SessionLog.SessionStatus
 
forNumber(int) - Static method in enum org.tensorflow.util.testlog.CommitId.KindCase
 
forNumber(int) - Static method in enum org.tensorflow.util.testlog.EntryValue.KindCase
 
forNumber(int) - Static method in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
 
forNumber(int) - Static method in enum org.tensorflow.util.WorkerHealth
 
forNumber(int) - Static method in enum org.tensorflow.util.WorkerShutdownMode
 
FREQUENCY_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
FROM_TENSOR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorConnection
 
FULL_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SaveSliceInfoDef
 
FULL_NAME_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
FULL_SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SaveSliceInfoDef
 
FULL_TRACE_VALUE - Static variable in enum org.tensorflow.framework.RunOptions.TraceLevel
FULL_TRACE = 3;
FUNC_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue
 
FUNC_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue.ListValue
 
FUNCTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.FunctionDefLibrary
 
FUNCTION_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GradientDef
 
FUNCTION_OPTIMIZATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
FunctionDef - Class in org.tensorflow.framework
A function can be instantiated when the runtime can bind every attr with a value.
FunctionDef.Builder - Class in org.tensorflow.framework
A function can be instantiated when the runtime can bind every attr with a value.
FunctionDefLibrary - Class in org.tensorflow.framework
A library is a set of named functions.
FunctionDefLibrary.Builder - Class in org.tensorflow.framework
A library is a set of named functions.
FunctionDefLibraryOrBuilder - Interface in org.tensorflow.framework
 
FunctionDefOrBuilder - Interface in org.tensorflow.framework
 
FunctionProtos - Class in org.tensorflow.framework
 

G

getAliasInputPort() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
If >= 0, the output is an alias of an input.
getAliasInputPort() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
If >= 0, the output is an alias of an input.
getAliasInputPort() - Method in interface org.tensorflow.framework.CostGraphDef.Node.OutputInfoOrBuilder
If >= 0, the output is an alias of an input.
getAllEndRelMicros() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_end_rel_micros = 5;
getAllEndRelMicros() - Method in class org.tensorflow.framework.NodeExecStats
int64 all_end_rel_micros = 5;
getAllEndRelMicros() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
int64 all_end_rel_micros = 5;
getAllEndRelNanos() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_end_rel_nanos = 16;
getAllEndRelNanos() - Method in class org.tensorflow.framework.NodeExecStats
int64 all_end_rel_nanos = 16;
getAllEndRelNanos() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
int64 all_end_rel_nanos = 16;
getAllocatedBytes() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Total number of bytes allocated if known
getAllocatedBytes() - Method in class org.tensorflow.framework.AllocationDescription
Total number of bytes allocated if known
getAllocatedBytes() - Method in interface org.tensorflow.framework.AllocationDescriptionOrBuilder
Total number of bytes allocated if known
getAllocationDescription() - Method in class org.tensorflow.framework.TensorDescription.Builder
Information about the size and allocator used for the data
getAllocationDescription() - Method in class org.tensorflow.framework.TensorDescription
Information about the size and allocator used for the data
getAllocationDescription() - Method in interface org.tensorflow.framework.TensorDescriptionOrBuilder
Information about the size and allocator used for the data
getAllocationDescriptionBuilder() - Method in class org.tensorflow.framework.TensorDescription.Builder
Information about the size and allocator used for the data
getAllocationDescriptionOrBuilder() - Method in class org.tensorflow.framework.TensorDescription.Builder
Information about the size and allocator used for the data
getAllocationDescriptionOrBuilder() - Method in class org.tensorflow.framework.TensorDescription
Information about the size and allocator used for the data
getAllocationDescriptionOrBuilder() - Method in interface org.tensorflow.framework.TensorDescriptionOrBuilder
Information about the size and allocator used for the data
getAllocationId() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Identifier of the allocated buffer if known
getAllocationId() - Method in class org.tensorflow.framework.AllocationDescription
Identifier of the allocated buffer if known
getAllocationId() - Method in interface org.tensorflow.framework.AllocationDescriptionOrBuilder
Identifier of the allocated buffer if known
getAllocationId() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Id of the tensor buffer being allocated, used to match to a corresponding deallocation.
getAllocationId() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
Id of the tensor buffer being allocated, used to match to a corresponding deallocation.
getAllocationId() - Method in interface org.tensorflow.framework.MemoryLogRawAllocationOrBuilder
Id of the tensor buffer being allocated, used to match to a corresponding deallocation.
getAllocationId() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Id of the tensor buffer being deallocated, used to match to a corresponding allocation.
getAllocationId() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
Id of the tensor buffer being deallocated, used to match to a corresponding allocation.
getAllocationId() - Method in interface org.tensorflow.framework.MemoryLogRawDeallocationOrBuilder
Id of the tensor buffer being deallocated, used to match to a corresponding allocation.
getAllocationId() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
Id of the tensor buffer being deallocated, used to match to a corresponding allocation.
getAllocationId() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
Id of the tensor buffer being deallocated, used to match to a corresponding allocation.
getAllocationId() - Method in interface org.tensorflow.framework.MemoryLogTensorDeallocationOrBuilder
Id of the tensor buffer being deallocated, used to match to a corresponding allocation.
getAllocationRecords(int) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
getAllocationRecords(int) - Method in class org.tensorflow.framework.AllocatorMemoryUsed
The allocation and deallocation timeline.
getAllocationRecords(int) - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
The allocation and deallocation timeline.
getAllocationRecordsBuilder(int) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
getAllocationRecordsBuilderList() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
getAllocationRecordsCount() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
getAllocationRecordsCount() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
The allocation and deallocation timeline.
getAllocationRecordsCount() - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
The allocation and deallocation timeline.
getAllocationRecordsList() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
getAllocationRecordsList() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
The allocation and deallocation timeline.
getAllocationRecordsList() - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
The allocation and deallocation timeline.
getAllocationRecordsOrBuilder(int) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
getAllocationRecordsOrBuilder(int) - Method in class org.tensorflow.framework.AllocatorMemoryUsed
The allocation and deallocation timeline.
getAllocationRecordsOrBuilder(int) - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
The allocation and deallocation timeline.
getAllocationRecordsOrBuilderList() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
getAllocationRecordsOrBuilderList() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
The allocation and deallocation timeline.
getAllocationRecordsOrBuilderList() - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
The allocation and deallocation timeline.
getAllocatorBytesInUse() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
These are snapshots of the overall allocator memory stats.
getAllocatorBytesInUse() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
These are snapshots of the overall allocator memory stats.
getAllocatorBytesInUse() - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
These are snapshots of the overall allocator memory stats.
getAllocatorName() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Name of the allocator used
getAllocatorName() - Method in class org.tensorflow.framework.AllocationDescription
Name of the allocator used
getAllocatorName() - Method in interface org.tensorflow.framework.AllocationDescriptionOrBuilder
Name of the allocator used
getAllocatorName() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
string allocator_name = 1;
getAllocatorName() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
string allocator_name = 1;
getAllocatorName() - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
string allocator_name = 1;
getAllocatorName() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Name of the allocator used.
getAllocatorName() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
Name of the allocator used.
getAllocatorName() - Method in interface org.tensorflow.framework.MemoryLogRawAllocationOrBuilder
Name of the allocator used.
getAllocatorName() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Name of the allocator used.
getAllocatorName() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
Name of the allocator used.
getAllocatorName() - Method in interface org.tensorflow.framework.MemoryLogRawDeallocationOrBuilder
Name of the allocator used.
getAllocatorName() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
Name of the allocator used.
getAllocatorName() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
Name of the allocator used.
getAllocatorName() - Method in interface org.tensorflow.framework.MemoryLogTensorDeallocationOrBuilder
Name of the allocator used.
getAllocatorNameBytes() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Name of the allocator used
getAllocatorNameBytes() - Method in class org.tensorflow.framework.AllocationDescription
Name of the allocator used
getAllocatorNameBytes() - Method in interface org.tensorflow.framework.AllocationDescriptionOrBuilder
Name of the allocator used
getAllocatorNameBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
string allocator_name = 1;
getAllocatorNameBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
string allocator_name = 1;
getAllocatorNameBytes() - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
string allocator_name = 1;
getAllocatorNameBytes() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Name of the allocator used.
getAllocatorNameBytes() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
Name of the allocator used.
getAllocatorNameBytes() - Method in interface org.tensorflow.framework.MemoryLogRawAllocationOrBuilder
Name of the allocator used.
getAllocatorNameBytes() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Name of the allocator used.
getAllocatorNameBytes() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
Name of the allocator used.
getAllocatorNameBytes() - Method in interface org.tensorflow.framework.MemoryLogRawDeallocationOrBuilder
Name of the allocator used.
getAllocatorNameBytes() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
Name of the allocator used.
getAllocatorNameBytes() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
Name of the allocator used.
getAllocatorNameBytes() - Method in interface org.tensorflow.framework.MemoryLogTensorDeallocationOrBuilder
Name of the allocator used.
getAllocatorType() - Method in class org.tensorflow.framework.GPUOptions.Builder
The type of GPU allocation strategy to use.
getAllocatorType() - Method in class org.tensorflow.framework.GPUOptions
The type of GPU allocation strategy to use.
getAllocatorType() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
The type of GPU allocation strategy to use.
getAllocatorTypeBytes() - Method in class org.tensorflow.framework.GPUOptions.Builder
The type of GPU allocation strategy to use.
getAllocatorTypeBytes() - Method in class org.tensorflow.framework.GPUOptions
The type of GPU allocation strategy to use.
getAllocatorTypeBytes() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
The type of GPU allocation strategy to use.
getAllocBytes() - Method in class org.tensorflow.framework.AllocationRecord.Builder
Number of bytes allocated, or de-allocated if negative.
getAllocBytes() - Method in class org.tensorflow.framework.AllocationRecord
Number of bytes allocated, or de-allocated if negative.
getAllocBytes() - Method in interface org.tensorflow.framework.AllocationRecordOrBuilder
Number of bytes allocated, or de-allocated if negative.
getAllocMicros() - Method in class org.tensorflow.framework.AllocationRecord.Builder
The timestamp of the operation.
getAllocMicros() - Method in class org.tensorflow.framework.AllocationRecord
The timestamp of the operation.
getAllocMicros() - Method in interface org.tensorflow.framework.AllocationRecordOrBuilder
The timestamp of the operation.
getAllowedValues() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
A list of values that this kernel supports for this attr.
getAllowedValues() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
A list of values that this kernel supports for this attr.
getAllowedValues() - Method in interface org.tensorflow.framework.KernelDef.AttrConstraintOrBuilder
A list of values that this kernel supports for this attr.
getAllowedValues() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
The set of allowed values.
getAllowedValues() - Method in class org.tensorflow.framework.OpDef.AttrDef
The set of allowed values.
getAllowedValues() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
The set of allowed values.
getAllowedValuesBuilder() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
A list of values that this kernel supports for this attr.
getAllowedValuesBuilder() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
The set of allowed values.
getAllowedValuesOrBuilder() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
A list of values that this kernel supports for this attr.
getAllowedValuesOrBuilder() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
A list of values that this kernel supports for this attr.
getAllowedValuesOrBuilder() - Method in interface org.tensorflow.framework.KernelDef.AttrConstraintOrBuilder
A list of values that this kernel supports for this attr.
getAllowedValuesOrBuilder() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
The set of allowed values.
getAllowedValuesOrBuilder() - Method in class org.tensorflow.framework.OpDef.AttrDef
The set of allowed values.
getAllowedValuesOrBuilder() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
The set of allowed values.
getAllowGrowth() - Method in class org.tensorflow.framework.GPUOptions.Builder
If true, the allocator does not pre-allocate the entire specified GPU memory region, instead starting small and growing as needed.
getAllowGrowth() - Method in class org.tensorflow.framework.GPUOptions
If true, the allocator does not pre-allocate the entire specified GPU memory region, instead starting small and growing as needed.
getAllowGrowth() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
If true, the allocator does not pre-allocate the entire specified GPU memory region, instead starting small and growing as needed.
getAllowSoftPlacement() - Method in class org.tensorflow.framework.ConfigProto.Builder
Whether soft placement is allowed.
getAllowSoftPlacement() - Method in class org.tensorflow.framework.ConfigProto
Whether soft placement is allowed.
getAllowSoftPlacement() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Whether soft placement is allowed.
getAllowsUninitializedInput() - Method in class org.tensorflow.framework.OpDef.Builder
By default, all inputs to an Op must be initialized Tensors.
getAllowsUninitializedInput() - Method in class org.tensorflow.framework.OpDef
By default, all inputs to an Op must be initialized Tensors.
getAllowsUninitializedInput() - Method in interface org.tensorflow.framework.OpDefOrBuilder
By default, all inputs to an Op must be initialized Tensors.
getAllStartMicros() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_start_micros = 2;
getAllStartMicros() - Method in class org.tensorflow.framework.NodeExecStats
int64 all_start_micros = 2;
getAllStartMicros() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
int64 all_start_micros = 2;
getAllStartNanos() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_start_nanos = 13;
getAllStartNanos() - Method in class org.tensorflow.framework.NodeExecStats
int64 all_start_nanos = 13;
getAllStartNanos() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
int64 all_start_nanos = 13;
getAnyInfo() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A serialized protobuf.
getAnyInfo() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
A serialized protobuf.
getAnyInfo() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
A serialized protobuf.
getAnyInfoBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A serialized protobuf.
getAnyInfoOrBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A serialized protobuf.
getAnyInfoOrBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
A serialized protobuf.
getAnyInfoOrBuilder() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
A serialized protobuf.
getAnyList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.AnyList any_list = 5;
getAnyList() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.AnyList any_list = 5;
getAnyList() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.AnyList any_list = 5;
getAnyListBuilder() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.AnyList any_list = 5;
getAnyListOrBuilder() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.AnyList any_list = 5;
getAnyListOrBuilder() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.AnyList any_list = 5;
getAnyListOrBuilder() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.AnyList any_list = 5;
getArgOrder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
List of original in_arg names to specify new argument order.
getArgOrder(int) - Method in class org.tensorflow.framework.ApiDef
List of original in_arg names to specify new argument order.
getArgOrder(int) - Method in interface org.tensorflow.framework.ApiDefOrBuilder
List of original in_arg names to specify new argument order.
getArgOrderBytes(int) - Method in class org.tensorflow.framework.ApiDef.Builder
List of original in_arg names to specify new argument order.
getArgOrderBytes(int) - Method in class org.tensorflow.framework.ApiDef
List of original in_arg names to specify new argument order.
getArgOrderBytes(int) - Method in interface org.tensorflow.framework.ApiDefOrBuilder
List of original in_arg names to specify new argument order.
getArgOrderCount() - Method in class org.tensorflow.framework.ApiDef.Builder
List of original in_arg names to specify new argument order.
getArgOrderCount() - Method in class org.tensorflow.framework.ApiDef
List of original in_arg names to specify new argument order.
getArgOrderCount() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
List of original in_arg names to specify new argument order.
getArgOrderList() - Method in class org.tensorflow.framework.ApiDef.Builder
List of original in_arg names to specify new argument order.
getArgOrderList() - Method in class org.tensorflow.framework.ApiDef
List of original in_arg names to specify new argument order.
getArgOrderList() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
List of original in_arg names to specify new argument order.
getArgument(int) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
repeated string argument = 1;
getArgument(int) - Method in class org.tensorflow.util.testlog.RunConfiguration
repeated string argument = 1;
getArgument(int) - Method in interface org.tensorflow.util.testlog.RunConfigurationOrBuilder
repeated string argument = 1;
getArgumentBytes(int) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
repeated string argument = 1;
getArgumentBytes(int) - Method in class org.tensorflow.util.testlog.RunConfiguration
repeated string argument = 1;
getArgumentBytes(int) - Method in interface org.tensorflow.util.testlog.RunConfigurationOrBuilder
repeated string argument = 1;
getArgumentCount() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
repeated string argument = 1;
getArgumentCount() - Method in class org.tensorflow.util.testlog.RunConfiguration
repeated string argument = 1;
getArgumentCount() - Method in interface org.tensorflow.util.testlog.RunConfigurationOrBuilder
repeated string argument = 1;
getArgumentList() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
repeated string argument = 1;
getArgumentList() - Method in class org.tensorflow.util.testlog.RunConfiguration
repeated string argument = 1;
getArgumentList() - Method in interface org.tensorflow.util.testlog.RunConfigurationOrBuilder
repeated string argument = 1;
getArithmeticOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Arithmetic optimizations (default is ON) e.g.
getArithmeticOptimization() - Method in class org.tensorflow.framework.RewriterConfig
Arithmetic optimizations (default is ON) e.g.
getArithmeticOptimization() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Arithmetic optimizations (default is ON) e.g.
getArithmeticOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Arithmetic optimizations (default is ON) e.g.
getArithmeticOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig
Arithmetic optimizations (default is ON) e.g.
getArithmeticOptimizationValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Arithmetic optimizations (default is ON) e.g.
getAssetFileDef(int) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
getAssetFileDef(int) - Method in class org.tensorflow.framework.MetaGraphDef
Asset file def to be used with the defined graph.
getAssetFileDef(int) - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
Asset file def to be used with the defined graph.
getAssetFileDefBuilder(int) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
getAssetFileDefBuilderList() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
getAssetFileDefCount() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
getAssetFileDefCount() - Method in class org.tensorflow.framework.MetaGraphDef
Asset file def to be used with the defined graph.
getAssetFileDefCount() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
Asset file def to be used with the defined graph.
getAssetFileDefList() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
getAssetFileDefList() - Method in class org.tensorflow.framework.MetaGraphDef
Asset file def to be used with the defined graph.
getAssetFileDefList() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
Asset file def to be used with the defined graph.
getAssetFileDefOrBuilder(int) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
getAssetFileDefOrBuilder(int) - Method in class org.tensorflow.framework.MetaGraphDef
Asset file def to be used with the defined graph.
getAssetFileDefOrBuilder(int) - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
Asset file def to be used with the defined graph.
getAssetFileDefOrBuilderList() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
getAssetFileDefOrBuilderList() - Method in class org.tensorflow.framework.MetaGraphDef
Asset file def to be used with the defined graph.
getAssetFileDefOrBuilderList() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
Asset file def to be used with the defined graph.
getAttr(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttr(int) - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttr(int) - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttr() - Method in class org.tensorflow.framework.FunctionDef.Builder
Deprecated.
getAttr() - Method in class org.tensorflow.framework.FunctionDef
Deprecated.
getAttr() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
Deprecated.
getAttr() - Method in class org.tensorflow.framework.NameAttrList.Builder
Deprecated.
getAttr() - Method in class org.tensorflow.framework.NameAttrList
Deprecated.
getAttr() - Method in interface org.tensorflow.framework.NameAttrListOrBuilder
Deprecated.
getAttr() - Method in class org.tensorflow.framework.NodeDef.Builder
Deprecated.
getAttr() - Method in class org.tensorflow.framework.NodeDef
Deprecated.
getAttr() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
Deprecated.
getAttr(int) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttr(int) - Method in class org.tensorflow.framework.OpDef
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttr(int) - Method in interface org.tensorflow.framework.OpDefOrBuilder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrBuilder(int) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrBuilderList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrBuilderList() - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrCount() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrCount() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrCount() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrCount() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
getAttrCount() - Method in class org.tensorflow.framework.FunctionDef
 
getAttrCount() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
Attributes specific to this function definition.
getAttrCount() - Method in class org.tensorflow.framework.NameAttrList.Builder
 
getAttrCount() - Method in class org.tensorflow.framework.NameAttrList
 
getAttrCount() - Method in interface org.tensorflow.framework.NameAttrListOrBuilder
map<string, .tensorflow.AttrValue> attr = 2;
getAttrCount() - Method in class org.tensorflow.framework.NodeDef.Builder
 
getAttrCount() - Method in class org.tensorflow.framework.NodeDef
 
getAttrCount() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
Operation-specific graph-construction-time configuration.
getAttrCount() - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrCount() - Method in class org.tensorflow.framework.OpDef
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrCount() - Method in interface org.tensorflow.framework.OpDefOrBuilder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttributes(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
getAttributes(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Serialized data specific to this object.
getAttributes(int) - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Serialized data specific to this object.
getAttributesBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
getAttributesBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
getAttributesCount() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
getAttributesCount() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Serialized data specific to this object.
getAttributesCount() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Serialized data specific to this object.
getAttributesList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
getAttributesList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Serialized data specific to this object.
getAttributesList() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Serialized data specific to this object.
getAttributesOrBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
getAttributesOrBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Serialized data specific to this object.
getAttributesOrBuilder(int) - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Serialized data specific to this object.
getAttributesOrBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
getAttributesOrBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Serialized data specific to this object.
getAttributesOrBuilderList() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Serialized data specific to this object.
getAttrList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrList() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrList() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrList() - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrList() - Method in class org.tensorflow.framework.OpDef
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrList() - Method in interface org.tensorflow.framework.OpDefOrBuilder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrMap() - Method in class org.tensorflow.framework.FunctionDef.Builder
Attributes specific to this function definition.
getAttrMap() - Method in class org.tensorflow.framework.FunctionDef
Attributes specific to this function definition.
getAttrMap() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
Attributes specific to this function definition.
getAttrMap() - Method in class org.tensorflow.framework.NameAttrList.Builder
map<string, .tensorflow.AttrValue> attr = 2;
getAttrMap() - Method in class org.tensorflow.framework.NameAttrList
map<string, .tensorflow.AttrValue> attr = 2;
getAttrMap() - Method in interface org.tensorflow.framework.NameAttrListOrBuilder
map<string, .tensorflow.AttrValue> attr = 2;
getAttrMap() - Method in class org.tensorflow.framework.NodeDef.Builder
Operation-specific graph-construction-time configuration.
getAttrMap() - Method in class org.tensorflow.framework.NodeDef
Operation-specific graph-construction-time configuration.
getAttrMap() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
Operation-specific graph-construction-time configuration.
getAttrOrBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrOrBuilder(int) - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrOrBuilder(int) - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrOrBuilder(int) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrOrBuilder(int) - Method in class org.tensorflow.framework.OpDef
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrOrBuilder(int) - Method in interface org.tensorflow.framework.OpDefOrBuilder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrOrBuilderList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrOrBuilderList() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrOrBuilderList() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Attr attr = 6;
getAttrOrBuilderList() - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrOrBuilderList() - Method in class org.tensorflow.framework.OpDef
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrOrBuilderList() - Method in interface org.tensorflow.framework.OpDefOrBuilder
repeated .tensorflow.OpDef.AttrDef attr = 4;
getAttrOrDefault(String, AttrValue) - Method in class org.tensorflow.framework.FunctionDef.Builder
Attributes specific to this function definition.
getAttrOrDefault(String, AttrValue) - Method in class org.tensorflow.framework.FunctionDef
Attributes specific to this function definition.
getAttrOrDefault(String, AttrValue) - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
Attributes specific to this function definition.
getAttrOrDefault(String, AttrValue) - Method in class org.tensorflow.framework.NameAttrList.Builder
map<string, .tensorflow.AttrValue> attr = 2;
getAttrOrDefault(String, AttrValue) - Method in class org.tensorflow.framework.NameAttrList
map<string, .tensorflow.AttrValue> attr = 2;
getAttrOrDefault(String, AttrValue) - Method in interface org.tensorflow.framework.NameAttrListOrBuilder
map<string, .tensorflow.AttrValue> attr = 2;
getAttrOrDefault(String, AttrValue) - Method in class org.tensorflow.framework.NodeDef.Builder
Operation-specific graph-construction-time configuration.
getAttrOrDefault(String, AttrValue) - Method in class org.tensorflow.framework.NodeDef
Operation-specific graph-construction-time configuration.
getAttrOrDefault(String, AttrValue) - Method in interface org.tensorflow.framework.NodeDefOrBuilder
Operation-specific graph-construction-time configuration.
getAttrOrThrow(String) - Method in class org.tensorflow.framework.FunctionDef.Builder
Attributes specific to this function definition.
getAttrOrThrow(String) - Method in class org.tensorflow.framework.FunctionDef
Attributes specific to this function definition.
getAttrOrThrow(String) - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
Attributes specific to this function definition.
getAttrOrThrow(String) - Method in class org.tensorflow.framework.NameAttrList.Builder
map<string, .tensorflow.AttrValue> attr = 2;
getAttrOrThrow(String) - Method in class org.tensorflow.framework.NameAttrList
map<string, .tensorflow.AttrValue> attr = 2;
getAttrOrThrow(String) - Method in interface org.tensorflow.framework.NameAttrListOrBuilder
map<string, .tensorflow.AttrValue> attr = 2;
getAttrOrThrow(String) - Method in class org.tensorflow.framework.NodeDef.Builder
Operation-specific graph-construction-time configuration.
getAttrOrThrow(String) - Method in class org.tensorflow.framework.NodeDef
Operation-specific graph-construction-time configuration.
getAttrOrThrow(String) - Method in interface org.tensorflow.framework.NodeDefOrBuilder
Operation-specific graph-construction-time configuration.
getAudio() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Audio audio = 6;
getAudio() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.Summary.Audio audio = 6;
getAudio() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.Summary.Audio audio = 6;
getAudioBuilder() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Audio audio = 6;
getAudioOrBuilder() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Audio audio = 6;
getAudioOrBuilder() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.Summary.Audio audio = 6;
getAudioOrBuilder() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.Summary.Audio audio = 6;
getAutoParallel() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
getAutoParallel() - Method in class org.tensorflow.framework.RewriterConfig
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
getAutoParallel() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
getAutoParallelBuilder() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
getAutoParallelOrBuilder() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
getAutoParallelOrBuilder() - Method in class org.tensorflow.framework.RewriterConfig
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
getAutoParallelOrBuilder() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
getAvailable() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
Immediately available memory in bytes
getAvailable() - Method in class org.tensorflow.util.testlog.MemoryInfo
Immediately available memory in bytes
getAvailable() - Method in interface org.tensorflow.util.testlog.MemoryInfoOrBuilder
Immediately available memory in bytes
getAvailableDeviceInfo(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
getAvailableDeviceInfo(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration
Devices accessible to the test (e.g.
getAvailableDeviceInfo(int) - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Devices accessible to the test (e.g.
getAvailableDeviceInfoBuilder(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
getAvailableDeviceInfoBuilderList() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
getAvailableDeviceInfoCount() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
getAvailableDeviceInfoCount() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Devices accessible to the test (e.g.
getAvailableDeviceInfoCount() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Devices accessible to the test (e.g.
getAvailableDeviceInfoList() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
getAvailableDeviceInfoList() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Devices accessible to the test (e.g.
getAvailableDeviceInfoList() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Devices accessible to the test (e.g.
getAvailableDeviceInfoOrBuilder(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
getAvailableDeviceInfoOrBuilder(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration
Devices accessible to the test (e.g.
getAvailableDeviceInfoOrBuilder(int) - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Devices accessible to the test (e.g.
getAvailableDeviceInfoOrBuilderList() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
getAvailableDeviceInfoOrBuilderList() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Devices accessible to the test (e.g.
getAvailableDeviceInfoOrBuilderList() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Devices accessible to the test (e.g.
getB() - Method in class org.tensorflow.framework.AttrValue.Builder
"bool"
getB() - Method in class org.tensorflow.framework.AttrValue
"bool"
getB(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(bool)"
getB(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(bool)"
getB(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(bool)"
getB() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"bool"
getBackProp() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Whether backprop is enabled for this while loop.
getBackProp() - Method in class org.tensorflow.framework.WhileContextDef
Whether backprop is enabled for this while loop.
getBackProp() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Whether backprop is enabled for this while loop.
getBadConsumers(int) - Method in class org.tensorflow.framework.VersionDef.Builder
Specific consumer versions which are disallowed (e.g.
getBadConsumers(int) - Method in class org.tensorflow.framework.VersionDef
Specific consumer versions which are disallowed (e.g.
getBadConsumers(int) - Method in interface org.tensorflow.framework.VersionDefOrBuilder
Specific consumer versions which are disallowed (e.g.
getBadConsumersCount() - Method in class org.tensorflow.framework.VersionDef.Builder
Specific consumer versions which are disallowed (e.g.
getBadConsumersCount() - Method in class org.tensorflow.framework.VersionDef
Specific consumer versions which are disallowed (e.g.
getBadConsumersCount() - Method in interface org.tensorflow.framework.VersionDefOrBuilder
Specific consumer versions which are disallowed (e.g.
getBadConsumersList() - Method in class org.tensorflow.framework.VersionDef.Builder
Specific consumer versions which are disallowed (e.g.
getBadConsumersList() - Method in class org.tensorflow.framework.VersionDef
Specific consumer versions which are disallowed (e.g.
getBadConsumersList() - Method in interface org.tensorflow.framework.VersionDefOrBuilder
Specific consumer versions which are disallowed (e.g.
getBandwidth() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Memory bandwidth in KB/s
getBandwidth() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Memory bandwidth in KB/s
getBandwidth() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Memory bandwidth in KB/s
getBCount() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(bool)"
getBCount() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(bool)"
getBCount() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(bool)"
getBenchmarkType() - Method in class org.tensorflow.util.testlog.TestResults.Builder
.tensorflow.TestResults.BenchmarkType benchmark_type = 10;
getBenchmarkType() - Method in class org.tensorflow.util.testlog.TestResults
.tensorflow.TestResults.BenchmarkType benchmark_type = 10;
getBenchmarkType() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
.tensorflow.TestResults.BenchmarkType benchmark_type = 10;
getBenchmarkTypeValue() - Method in class org.tensorflow.util.testlog.TestResults.Builder
.tensorflow.TestResults.BenchmarkType benchmark_type = 10;
getBenchmarkTypeValue() - Method in class org.tensorflow.util.testlog.TestResults
.tensorflow.TestResults.BenchmarkType benchmark_type = 10;
getBenchmarkTypeValue() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
.tensorflow.TestResults.BenchmarkType benchmark_type = 10;
getBits() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getBits() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getBits() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getBitsBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getBitsBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getBitsBytes() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getBList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(bool)"
getBList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(bool)"
getBList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(bool)"
getBoolVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_BOOL
getBoolVal(int) - Method in class org.tensorflow.framework.TensorProto
DT_BOOL
getBoolVal(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_BOOL
getBoolValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_BOOL
getBoolValCount() - Method in class org.tensorflow.framework.TensorProto
DT_BOOL
getBoolValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_BOOL
getBoolValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_BOOL
getBoolValList() - Method in class org.tensorflow.framework.TensorProto
DT_BOOL
getBoolValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_BOOL
getBranch() - Method in class org.tensorflow.framework.CondContextDef.Builder
Branch prediction.
getBranch() - Method in class org.tensorflow.framework.CondContextDef
Branch prediction.
getBranch() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Branch prediction.
getBucket(int) - Method in class org.tensorflow.framework.HistogramProto.Builder
repeated double bucket = 7 [packed = true];
getBucket(int) - Method in class org.tensorflow.framework.HistogramProto
repeated double bucket = 7 [packed = true];
getBucket(int) - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
repeated double bucket = 7 [packed = true];
getBucketCount() - Method in class org.tensorflow.framework.HistogramProto.Builder
repeated double bucket = 7 [packed = true];
getBucketCount() - Method in class org.tensorflow.framework.HistogramProto
repeated double bucket = 7 [packed = true];
getBucketCount() - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
repeated double bucket = 7 [packed = true];
getBucketLimit(int) - Method in class org.tensorflow.framework.HistogramProto.Builder
Parallel arrays encoding the bucket boundaries and the bucket values.
getBucketLimit(int) - Method in class org.tensorflow.framework.HistogramProto
Parallel arrays encoding the bucket boundaries and the bucket values.
getBucketLimit(int) - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
Parallel arrays encoding the bucket boundaries and the bucket values.
getBucketLimitCount() - Method in class org.tensorflow.framework.HistogramProto.Builder
Parallel arrays encoding the bucket boundaries and the bucket values.
getBucketLimitCount() - Method in class org.tensorflow.framework.HistogramProto
Parallel arrays encoding the bucket boundaries and the bucket values.
getBucketLimitCount() - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
Parallel arrays encoding the bucket boundaries and the bucket values.
getBucketLimitList() - Method in class org.tensorflow.framework.HistogramProto.Builder
Parallel arrays encoding the bucket boundaries and the bucket values.
getBucketLimitList() - Method in class org.tensorflow.framework.HistogramProto
Parallel arrays encoding the bucket boundaries and the bucket values.
getBucketLimitList() - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
Parallel arrays encoding the bucket boundaries and the bucket values.
getBucketList() - Method in class org.tensorflow.framework.HistogramProto.Builder
repeated double bucket = 7 [packed = true];
getBucketList() - Method in class org.tensorflow.framework.HistogramProto
repeated double bucket = 7 [packed = true];
getBucketList() - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
repeated double bucket = 7 [packed = true];
getBuildConfiguration() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The configuration of the build (compiled opt? with cuda? any copts?)
getBuildConfiguration() - Method in class org.tensorflow.util.testlog.TestResults
The configuration of the build (compiled opt? with cuda? any copts?)
getBuildConfiguration() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The configuration of the build (compiled opt? with cuda? any copts?)
getBuildConfigurationBuilder() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The configuration of the build (compiled opt? with cuda? any copts?)
getBuildConfigurationOrBuilder() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The configuration of the build (compiled opt? with cuda? any copts?)
getBuildConfigurationOrBuilder() - Method in class org.tensorflow.util.testlog.TestResults
The configuration of the build (compiled opt? with cuda? any copts?)
getBuildConfigurationOrBuilder() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The configuration of the build (compiled opt? with cuda? any copts?)
getBuildCostModel() - Method in class org.tensorflow.framework.GraphOptions.Builder
The number of steps to run before returning a cost model detailing the memory usage and performance of each node of the graph.
getBuildCostModel() - Method in class org.tensorflow.framework.GraphOptions
The number of steps to run before returning a cost model detailing the memory usage and performance of each node of the graph.
getBuildCostModel() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
The number of steps to run before returning a cost model detailing the memory usage and performance of each node of the graph.
getBuildCostModelAfter() - Method in class org.tensorflow.framework.GraphOptions.Builder
The number of steps to skip before collecting statistics for the cost model.
getBuildCostModelAfter() - Method in class org.tensorflow.framework.GraphOptions
The number of steps to skip before collecting statistics for the cost model.
getBuildCostModelAfter() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
The number of steps to skip before collecting statistics for the cost model.
getBusId() - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional bus locality of device.
getBusId() - Method in class org.tensorflow.framework.DeviceLocality
Optional bus locality of device.
getBusId() - Method in interface org.tensorflow.framework.DeviceLocalityOrBuilder
Optional bus locality of device.
getBusId() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
e.g.
getBusId() - Method in class org.tensorflow.util.testlog.GPUInfo
e.g.
getBusId() - Method in interface org.tensorflow.util.testlog.GPUInfoOrBuilder
e.g.
getBusIdBytes() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
e.g.
getBusIdBytes() - Method in class org.tensorflow.util.testlog.GPUInfo
e.g.
getBusIdBytes() - Method in interface org.tensorflow.util.testlog.GPUInfoOrBuilder
e.g.
getBytes() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Byte size of the file.
getBytes() - Method in class org.tensorflow.framework.DebuggedSourceFile
Byte size of the file.
getBytes() - Method in interface org.tensorflow.framework.DebuggedSourceFileOrBuilder
Byte size of the file.
getBytesList() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.BytesList bytes_list = 1;
getBytesList() - Method in class org.tensorflow.example.Feature
.tensorflow.BytesList bytes_list = 1;
getBytesList() - Method in interface org.tensorflow.example.FeatureOrBuilder
.tensorflow.BytesList bytes_list = 1;
getBytesList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
getBytesList() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.BytesList bytes_list = 2;
getBytesList() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
getBytesListBuilder() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.BytesList bytes_list = 1;
getBytesListBuilder() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
getBytesListOrBuilder() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.BytesList bytes_list = 1;
getBytesListOrBuilder() - Method in class org.tensorflow.example.Feature
.tensorflow.BytesList bytes_list = 1;
getBytesListOrBuilder() - Method in interface org.tensorflow.example.FeatureOrBuilder
.tensorflow.BytesList bytes_list = 1;
getBytesListOrBuilder() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
getBytesListOrBuilder() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.BytesList bytes_list = 2;
getBytesListOrBuilder() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
getCacheSize() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Deprecated.
getCacheSize() - Method in class org.tensorflow.util.testlog.CPUInfo
Deprecated.
getCacheSize() - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
Deprecated.
getCacheSizeCount() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
getCacheSizeCount() - Method in class org.tensorflow.util.testlog.CPUInfo
 
getCacheSizeCount() - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
Cache sizes (in bytes), e.g.
getCacheSizeMap() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Cache sizes (in bytes), e.g.
getCacheSizeMap() - Method in class org.tensorflow.util.testlog.CPUInfo
Cache sizes (in bytes), e.g.
getCacheSizeMap() - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
Cache sizes (in bytes), e.g.
getCacheSizeOrDefault(String, long) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Cache sizes (in bytes), e.g.
getCacheSizeOrDefault(String, long) - Method in class org.tensorflow.util.testlog.CPUInfo
Cache sizes (in bytes), e.g.
getCacheSizeOrDefault(String, long) - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
Cache sizes (in bytes), e.g.
getCacheSizeOrThrow(String) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Cache sizes (in bytes), e.g.
getCacheSizeOrThrow(String) - Method in class org.tensorflow.util.testlog.CPUInfo
Cache sizes (in bytes), e.g.
getCacheSizeOrThrow(String) - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
Cache sizes (in bytes), e.g.
getCancelOpName() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
The operation to run to cancel the queue.
getCancelOpName() - Method in class org.tensorflow.framework.QueueRunnerDef
The operation to run to cancel the queue.
getCancelOpName() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
The operation to run to cancel the queue.
getCancelOpNameBytes() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
The operation to run to cancel the queue.
getCancelOpNameBytes() - Method in class org.tensorflow.framework.QueueRunnerDef
The operation to run to cancel the queue.
getCancelOpNameBytes() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
The operation to run to cancel the queue.
getCcFlags(int) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
CC compiler flags, if known
getCcFlags(int) - Method in class org.tensorflow.util.testlog.BuildConfiguration
CC compiler flags, if known
getCcFlags(int) - Method in interface org.tensorflow.util.testlog.BuildConfigurationOrBuilder
CC compiler flags, if known
getCcFlagsBytes(int) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
CC compiler flags, if known
getCcFlagsBytes(int) - Method in class org.tensorflow.util.testlog.BuildConfiguration
CC compiler flags, if known
getCcFlagsBytes(int) - Method in interface org.tensorflow.util.testlog.BuildConfigurationOrBuilder
CC compiler flags, if known
getCcFlagsCount() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
CC compiler flags, if known
getCcFlagsCount() - Method in class org.tensorflow.util.testlog.BuildConfiguration
CC compiler flags, if known
getCcFlagsCount() - Method in interface org.tensorflow.util.testlog.BuildConfigurationOrBuilder
CC compiler flags, if known
getCcFlagsList() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
CC compiler flags, if known
getCcFlagsList() - Method in class org.tensorflow.util.testlog.BuildConfiguration
CC compiler flags, if known
getCcFlagsList() - Method in interface org.tensorflow.util.testlog.BuildConfigurationOrBuilder
CC compiler flags, if known
getChangelist() - Method in class org.tensorflow.util.testlog.CommitId.Builder
Submitted changelist.
getChangelist() - Method in class org.tensorflow.util.testlog.CommitId
Submitted changelist.
getChangelist() - Method in interface org.tensorflow.util.testlog.CommitIdOrBuilder
Submitted changelist.
getCheckpointKey() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
The generated name of the Tensor in the checkpoint.
getCheckpointKey() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
The generated name of the Tensor in the checkpoint.
getCheckpointKey() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensorOrBuilder
The generated name of the Tensor in the checkpoint.
getCheckpointKeyBytes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
The generated name of the Tensor in the checkpoint.
getCheckpointKeyBytes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
The generated name of the Tensor in the checkpoint.
getCheckpointKeyBytes() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensorOrBuilder
The generated name of the Tensor in the checkpoint.
getCheckpointPath() - Method in class org.tensorflow.util.SessionLog.Builder
This checkpoint_path contains both the path and filename.
getCheckpointPath() - Method in class org.tensorflow.util.SessionLog
This checkpoint_path contains both the path and filename.
getCheckpointPath() - Method in interface org.tensorflow.util.SessionLogOrBuilder
This checkpoint_path contains both the path and filename.
getCheckpointPathBytes() - Method in class org.tensorflow.util.SessionLog.Builder
This checkpoint_path contains both the path and filename.
getCheckpointPathBytes() - Method in class org.tensorflow.util.SessionLog
This checkpoint_path contains both the path and filename.
getCheckpointPathBytes() - Method in interface org.tensorflow.util.SessionLogOrBuilder
This checkpoint_path contains both the path and filename.
getChildren(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
getChildren(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Objects which this object depends on.
getChildren(int) - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Objects which this object depends on.
getChildrenBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
getChildrenBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
getChildrenCount() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
getChildrenCount() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Objects which this object depends on.
getChildrenCount() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Objects which this object depends on.
getChildrenList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
getChildrenList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Objects which this object depends on.
getChildrenList() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Objects which this object depends on.
getChildrenOrBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
getChildrenOrBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Objects which this object depends on.
getChildrenOrBuilder(int) - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Objects which this object depends on.
getChildrenOrBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
getChildrenOrBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Objects which this object depends on.
getChildrenOrBuilderList() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Objects which this object depends on.
getCloseOpName() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
The operation to run to close the queue.
getCloseOpName() - Method in class org.tensorflow.framework.QueueRunnerDef
The operation to run to close the queue.
getCloseOpName() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
The operation to run to close the queue.
getCloseOpNameBytes() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
The operation to run to close the queue.
getCloseOpNameBytes() - Method in class org.tensorflow.framework.QueueRunnerDef
The operation to run to close the queue.
getCloseOpNameBytes() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
The operation to run to close the queue.
getCluster() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The cluster of which this server is a member.
getCluster() - Method in class org.tensorflow.distruntime.ServerDef
The cluster of which this server is a member.
getCluster() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The cluster of which this server is a member.
getClusterBuilder() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The cluster of which this server is a member.
getClusterDef() - Method in class org.tensorflow.framework.ConfigProto.Builder
Optional list of all workers to use in this session.
getClusterDef() - Method in class org.tensorflow.framework.ConfigProto
Optional list of all workers to use in this session.
getClusterDef() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Optional list of all workers to use in this session.
getClusterDefBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
Optional list of all workers to use in this session.
getClusterDefOrBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
Optional list of all workers to use in this session.
getClusterDefOrBuilder() - Method in class org.tensorflow.framework.ConfigProto
Optional list of all workers to use in this session.
getClusterDefOrBuilder() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Optional list of all workers to use in this session.
getClusterOrBuilder() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The cluster of which this server is a member.
getClusterOrBuilder() - Method in class org.tensorflow.distruntime.ServerDef
The cluster of which this server is a member.
getClusterOrBuilder() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The cluster of which this server is a member.
getCollectionDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Deprecated.
getCollectionDef() - Method in class org.tensorflow.framework.MetaGraphDef
Deprecated.
getCollectionDef() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
Deprecated.
getCollectionDefCount() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
getCollectionDefCount() - Method in class org.tensorflow.framework.MetaGraphDef
 
getCollectionDefCount() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
collection_def: Map from collection name to collections.
getCollectionDefMap() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
collection_def: Map from collection name to collections.
getCollectionDefMap() - Method in class org.tensorflow.framework.MetaGraphDef
collection_def: Map from collection name to collections.
getCollectionDefMap() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
collection_def: Map from collection name to collections.
getCollectionDefOrDefault(String, CollectionDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
collection_def: Map from collection name to collections.
getCollectionDefOrDefault(String, CollectionDef) - Method in class org.tensorflow.framework.MetaGraphDef
collection_def: Map from collection name to collections.
getCollectionDefOrDefault(String, CollectionDef) - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
collection_def: Map from collection name to collections.
getCollectionDefOrThrow(String) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
collection_def: Map from collection name to collections.
getCollectionDefOrThrow(String) - Method in class org.tensorflow.framework.MetaGraphDef
collection_def: Map from collection name to collections.
getCollectionDefOrThrow(String) - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
collection_def: Map from collection name to collections.
getCollectiveGraphKey() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
If non-zero, declares that this graph is going to use collective ops and must synchronize step_ids with any other graph with this same group_key value (in a distributed computation where tasks run disjoint graphs).
getCollectiveGraphKey() - Method in class org.tensorflow.framework.RunOptions.Experimental
If non-zero, declares that this graph is going to use collective ops and must synchronize step_ids with any other graph with this same group_key value (in a distributed computation where tasks run disjoint graphs).
getCollectiveGraphKey() - Method in interface org.tensorflow.framework.RunOptions.ExperimentalOrBuilder
If non-zero, declares that this graph is going to use collective ops and must synchronize step_ids with any other graph with this same group_key value (in a distributed computation where tasks run disjoint graphs).
getCollectiveGroupLeader() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Task name for group resolution.
getCollectiveGroupLeader() - Method in class org.tensorflow.framework.ConfigProto.Experimental
Task name for group resolution.
getCollectiveGroupLeader() - Method in interface org.tensorflow.framework.ConfigProto.ExperimentalOrBuilder
Task name for group resolution.
getCollectiveGroupLeaderBytes() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Task name for group resolution.
getCollectiveGroupLeaderBytes() - Method in class org.tensorflow.framework.ConfigProto.Experimental
Task name for group resolution.
getCollectiveGroupLeaderBytes() - Method in interface org.tensorflow.framework.ConfigProto.ExperimentalOrBuilder
Task name for group resolution.
getCollectiveRingOrder() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If non-empty, defines a good GPU ring order on a single worker based on device interconnect.
getCollectiveRingOrder() - Method in class org.tensorflow.framework.GPUOptions.Experimental
If non-empty, defines a good GPU ring order on a single worker based on device interconnect.
getCollectiveRingOrder() - Method in interface org.tensorflow.framework.GPUOptions.ExperimentalOrBuilder
If non-empty, defines a good GPU ring order on a single worker based on device interconnect.
getCollectiveRingOrderBytes() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If non-empty, defines a good GPU ring order on a single worker based on device interconnect.
getCollectiveRingOrderBytes() - Method in class org.tensorflow.framework.GPUOptions.Experimental
If non-empty, defines a good GPU ring order on a single worker based on device interconnect.
getCollectiveRingOrderBytes() - Method in interface org.tensorflow.framework.GPUOptions.ExperimentalOrBuilder
If non-empty, defines a good GPU ring order on a single worker based on device interconnect.
getColorspace() - Method in class org.tensorflow.framework.Summary.Image.Builder
Valid colorspace values are 1 - grayscale 2 - grayscale + alpha 3 - RGB 4 - RGBA 5 - DIGITAL_YUV 6 - BGRA
getColorspace() - Method in class org.tensorflow.framework.Summary.Image
Valid colorspace values are 1 - grayscale 2 - grayscale + alpha 3 - RGB 4 - RGBA 5 - DIGITAL_YUV 6 - BGRA
getColorspace() - Method in interface org.tensorflow.framework.Summary.ImageOrBuilder
Valid colorspace values are 1 - grayscale 2 - grayscale + alpha 3 - RGB 4 - RGBA 5 - DIGITAL_YUV 6 - BGRA
getCommitId() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The commit id (git hash or changelist)
getCommitId() - Method in class org.tensorflow.util.testlog.TestResults
The commit id (git hash or changelist)
getCommitId() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The commit id (git hash or changelist)
getCommitIdBuilder() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The commit id (git hash or changelist)
getCommitIdOrBuilder() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The commit id (git hash or changelist)
getCommitIdOrBuilder() - Method in class org.tensorflow.util.testlog.TestResults
The commit id (git hash or changelist)
getCommitIdOrBuilder() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The commit id (git hash or changelist)
getCompressionAlgorithm() - Method in class org.tensorflow.framework.RPCOptions.Builder
The compression algorithm to be used.
getCompressionAlgorithm() - Method in class org.tensorflow.framework.RPCOptions
The compression algorithm to be used.
getCompressionAlgorithm() - Method in interface org.tensorflow.framework.RPCOptionsOrBuilder
The compression algorithm to be used.
getCompressionAlgorithmBytes() - Method in class org.tensorflow.framework.RPCOptions.Builder
The compression algorithm to be used.
getCompressionAlgorithmBytes() - Method in class org.tensorflow.framework.RPCOptions
The compression algorithm to be used.
getCompressionAlgorithmBytes() - Method in interface org.tensorflow.framework.RPCOptionsOrBuilder
The compression algorithm to be used.
getCompressionLevel() - Method in class org.tensorflow.framework.RPCOptions.Builder
If compression_algorithm is set, the compression level to be used.
getCompressionLevel() - Method in class org.tensorflow.framework.RPCOptions
If compression_algorithm is set, the compression level to be used.
getCompressionLevel() - Method in interface org.tensorflow.framework.RPCOptionsOrBuilder
If compression_algorithm is set, the compression level to be used.
getComputeCost() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Estimate of the computational cost of this node, in microseconds.
getComputeCost() - Method in class org.tensorflow.framework.CostGraphDef.Node
Estimate of the computational cost of this node, in microseconds.
getComputeCost() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Estimate of the computational cost of this node, in microseconds.
getComputeTime() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Analytical estimate of the computational cost of this node, in microseconds.
getComputeTime() - Method in class org.tensorflow.framework.CostGraphDef.Node
Analytical estimate of the computational cost of this node, in microseconds.
getComputeTime() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Analytical estimate of the computational cost of this node, in microseconds.
getCondCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.CondContextDef cond_ctxt = 1;
getCondCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef
.tensorflow.CondContextDef cond_ctxt = 1;
getCondCtxt() - Method in interface org.tensorflow.framework.ControlFlowContextDefOrBuilder
.tensorflow.CondContextDef cond_ctxt = 1;
getCondCtxtBuilder() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.CondContextDef cond_ctxt = 1;
getCondCtxtOrBuilder() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.CondContextDef cond_ctxt = 1;
getCondCtxtOrBuilder() - Method in class org.tensorflow.framework.ControlFlowContextDef
.tensorflow.CondContextDef cond_ctxt = 1;
getCondCtxtOrBuilder() - Method in interface org.tensorflow.framework.ControlFlowContextDefOrBuilder
.tensorflow.CondContextDef cond_ctxt = 1;
getConfigCase() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
getConfigCase() - Method in class org.tensorflow.example.FeatureConfiguration
 
getConfigCase() - Method in interface org.tensorflow.example.FeatureConfigurationOrBuilder
 
getConstantFolding() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Fold constants (default is ON) Statically infer the value of tensors when possible, and materialize the result using constants.
getConstantFolding() - Method in class org.tensorflow.framework.RewriterConfig
Fold constants (default is ON) Statically infer the value of tensors when possible, and materialize the result using constants.
getConstantFolding() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Fold constants (default is ON) Statically infer the value of tensors when possible, and materialize the result using constants.
getConstantFoldingValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Fold constants (default is ON) Statically infer the value of tensors when possible, and materialize the result using constants.
getConstantFoldingValue() - Method in class org.tensorflow.framework.RewriterConfig
Fold constants (default is ON) Statically infer the value of tensors when possible, and materialize the result using constants.
getConstantFoldingValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Fold constants (default is ON) Statically infer the value of tensors when possible, and materialize the result using constants.
getConstNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfo(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoCount() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoOrBuilder(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstNodeInfoOrBuilderList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
getConstraint(int) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraint(int) - Method in class org.tensorflow.framework.KernelDef
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraint(int) - Method in interface org.tensorflow.framework.KernelDefOrBuilder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintBuilder(int) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintBuilderList() - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintCount() - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintCount() - Method in class org.tensorflow.framework.KernelDef
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintCount() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintList() - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintList() - Method in class org.tensorflow.framework.KernelDef
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintList() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintOrBuilder(int) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintOrBuilder(int) - Method in class org.tensorflow.framework.KernelDef
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintOrBuilder(int) - Method in interface org.tensorflow.framework.KernelDefOrBuilder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintOrBuilderList() - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintOrBuilderList() - Method in class org.tensorflow.framework.KernelDef
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getConstraintOrBuilderList() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
getContainer() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Container in which this resource is placed.
getContainer() - Method in class org.tensorflow.framework.ResourceHandleProto
Container in which this resource is placed.
getContainer() - Method in interface org.tensorflow.framework.ResourceHandleProtoOrBuilder
Container in which this resource is placed.
getContainerBytes() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Container in which this resource is placed.
getContainerBytes() - Method in class org.tensorflow.framework.ResourceHandleProto
Container in which this resource is placed.
getContainerBytes() - Method in interface org.tensorflow.framework.ResourceHandleProtoOrBuilder
Container in which this resource is placed.
getContent() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
The content to store for the plugin.
getContent() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
The content to store for the plugin.
getContent() - Method in interface org.tensorflow.framework.SummaryMetadata.PluginDataOrBuilder
The content to store for the plugin.
getContentType() - Method in class org.tensorflow.framework.Summary.Audio.Builder
string content_type = 5;
getContentType() - Method in class org.tensorflow.framework.Summary.Audio
string content_type = 5;
getContentType() - Method in interface org.tensorflow.framework.Summary.AudioOrBuilder
string content_type = 5;
getContentTypeBytes() - Method in class org.tensorflow.framework.Summary.Audio.Builder
string content_type = 5;
getContentTypeBytes() - Method in class org.tensorflow.framework.Summary.Audio
string content_type = 5;
getContentTypeBytes() - Method in interface org.tensorflow.framework.Summary.AudioOrBuilder
string content_type = 5;
getContext() - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.Features context = 1;
getContext() - Method in class org.tensorflow.example.SequenceExample
.tensorflow.Features context = 1;
getContext() - Method in interface org.tensorflow.example.SequenceExampleOrBuilder
.tensorflow.Features context = 1;
getContextBuilder() - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.Features context = 1;
getContextName() - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the context.
getContextName() - Method in class org.tensorflow.framework.CondContextDef
Name of the context.
getContextName() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Name of the context.
getContextName() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the context.
getContextName() - Method in class org.tensorflow.framework.WhileContextDef
Name of the context.
getContextName() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Name of the context.
getContextNameBytes() - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the context.
getContextNameBytes() - Method in class org.tensorflow.framework.CondContextDef
Name of the context.
getContextNameBytes() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Name of the context.
getContextNameBytes() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the context.
getContextNameBytes() - Method in class org.tensorflow.framework.WhileContextDef
Name of the context.
getContextNameBytes() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Name of the context.
getContextOrBuilder() - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.Features context = 1;
getContextOrBuilder() - Method in class org.tensorflow.example.SequenceExample
.tensorflow.Features context = 1;
getContextOrBuilder() - Method in interface org.tensorflow.example.SequenceExampleOrBuilder
.tensorflow.Features context = 1;
getControlInput(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Ids of the control inputs for this node.
getControlInput(int) - Method in class org.tensorflow.framework.CostGraphDef.Node
Ids of the control inputs for this node.
getControlInput(int) - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Ids of the control inputs for this node.
getControlInputCount() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Ids of the control inputs for this node.
getControlInputCount() - Method in class org.tensorflow.framework.CostGraphDef.Node
Ids of the control inputs for this node.
getControlInputCount() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Ids of the control inputs for this node.
getControlInputList() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Ids of the control inputs for this node.
getControlInputList() - Method in class org.tensorflow.framework.CostGraphDef.Node
Ids of the control inputs for this node.
getControlInputList() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Ids of the control inputs for this node.
getCooSparse() - Method in class org.tensorflow.framework.TensorInfo.Builder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
getCooSparse() - Method in class org.tensorflow.framework.TensorInfo
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
getCooSparse() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
getCooSparseBuilder() - Method in class org.tensorflow.framework.TensorInfo.Builder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
getCooSparseOrBuilder() - Method in class org.tensorflow.framework.TensorInfo.Builder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
getCooSparseOrBuilder() - Method in class org.tensorflow.framework.TensorInfo
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
getCooSparseOrBuilder() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
getCostGraph() - Method in class org.tensorflow.framework.RunMetadata.Builder
The cost graph for the computation defined by the run call.
getCostGraph() - Method in class org.tensorflow.framework.RunMetadata
The cost graph for the computation defined by the run call.
getCostGraph() - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
The cost graph for the computation defined by the run call.
getCostGraphBuilder() - Method in class org.tensorflow.framework.RunMetadata.Builder
The cost graph for the computation defined by the run call.
getCostGraphOrBuilder() - Method in class org.tensorflow.framework.RunMetadata.Builder
The cost graph for the computation defined by the run call.
getCostGraphOrBuilder() - Method in class org.tensorflow.framework.RunMetadata
The cost graph for the computation defined by the run call.
getCostGraphOrBuilder() - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
The cost graph for the computation defined by the run call.
getCpuGovernor() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
What kind of cpu scaling is enabled on the host.
getCpuGovernor() - Method in class org.tensorflow.util.testlog.CPUInfo
What kind of cpu scaling is enabled on the host.
getCpuGovernor() - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
What kind of cpu scaling is enabled on the host.
getCpuGovernorBytes() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
What kind of cpu scaling is enabled on the host.
getCpuGovernorBytes() - Method in class org.tensorflow.util.testlog.CPUInfo
What kind of cpu scaling is enabled on the host.
getCpuGovernorBytes() - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
What kind of cpu scaling is enabled on the host.
getCpuInfo() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Additional cpu information.
getCpuInfo() - Method in class org.tensorflow.util.testlog.CPUInfo
Additional cpu information.
getCpuInfo() - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
Additional cpu information.
getCpuInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
CPU Information.
getCpuInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration
CPU Information.
getCpuInfo() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
CPU Information.
getCpuInfoBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
CPU Information.
getCpuInfoBytes() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Additional cpu information.
getCpuInfoBytes() - Method in class org.tensorflow.util.testlog.CPUInfo
Additional cpu information.
getCpuInfoBytes() - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
Additional cpu information.
getCpuInfoOrBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
CPU Information.
getCpuInfoOrBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration
CPU Information.
getCpuInfoOrBuilder() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
CPU Information.
getCpuTime() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Total cpu time used for all iterations (in seconds)
getCpuTime() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
Total cpu time used for all iterations (in seconds)
getCpuTime() - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
Total cpu time used for all iterations (in seconds)
getCrc32C() - Method in class org.tensorflow.util.BundleEntryProto.Builder
The CRC32C checksum of the tensor bytes.
getCrc32C() - Method in class org.tensorflow.util.BundleEntryProto
The CRC32C checksum of the tensor bytes.
getCrc32C() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
The CRC32C checksum of the tensor bytes.
getCtxtCase() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
getCtxtCase() - Method in class org.tensorflow.framework.ControlFlowContextDef
 
getCtxtCase() - Method in interface org.tensorflow.framework.ControlFlowContextDefOrBuilder
 
getCurrentWork() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
bytes current_work = 4;
getCurrentWork() - Method in class org.tensorflow.framework.ReaderBaseState
bytes current_work = 4;
getCurrentWork() - Method in interface org.tensorflow.framework.ReaderBaseStateOrBuilder
bytes current_work = 4;
getCustomOptimizers(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
getCustomOptimizers(int) - Method in class org.tensorflow.framework.RewriterConfig
list of CustomGraphOptimizers to apply.
getCustomOptimizers(int) - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
list of CustomGraphOptimizers to apply.
getCustomOptimizersBuilder(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
getCustomOptimizersBuilderList() - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
getCustomOptimizersCount() - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
getCustomOptimizersCount() - Method in class org.tensorflow.framework.RewriterConfig
list of CustomGraphOptimizers to apply.
getCustomOptimizersCount() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
list of CustomGraphOptimizers to apply.
getCustomOptimizersList() - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
getCustomOptimizersList() - Method in class org.tensorflow.framework.RewriterConfig
list of CustomGraphOptimizers to apply.
getCustomOptimizersList() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
list of CustomGraphOptimizers to apply.
getCustomOptimizersOrBuilder(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
getCustomOptimizersOrBuilder(int) - Method in class org.tensorflow.framework.RewriterConfig
list of CustomGraphOptimizers to apply.
getCustomOptimizersOrBuilder(int) - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
list of CustomGraphOptimizers to apply.
getCustomOptimizersOrBuilderList() - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
getCustomOptimizersOrBuilderList() - Method in class org.tensorflow.framework.RewriterConfig
list of CustomGraphOptimizers to apply.
getCustomOptimizersOrBuilderList() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
list of CustomGraphOptimizers to apply.
getData() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
bytes data = 4;
getData() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
bytes data = 4;
getData() - Method in interface org.tensorflow.framework.GraphTransferConstNodeInfoOrBuilder
bytes data = 4;
getData() - Method in class org.tensorflow.util.SavedSlice.Builder
The raw data of the slice is stored as a TensorProto.
getData() - Method in class org.tensorflow.util.SavedSlice
The raw data of the slice is stored as a TensorProto.
getData() - Method in interface org.tensorflow.util.SavedSliceOrBuilder
The raw data of the slice is stored as a TensorProto.
getData() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This exists in all but the first item of each checkpoint file.
getData() - Method in class org.tensorflow.util.SavedTensorSlices
This exists in all but the first item of each checkpoint file.
getData() - Method in interface org.tensorflow.util.SavedTensorSlicesOrBuilder
This exists in all but the first item of each checkpoint file.
getDataBuilder() - Method in class org.tensorflow.util.SavedSlice.Builder
The raw data of the slice is stored as a TensorProto.
getDataBuilder() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This exists in all but the first item of each checkpoint file.
getDataOrBuilder() - Method in class org.tensorflow.util.SavedSlice.Builder
The raw data of the slice is stored as a TensorProto.
getDataOrBuilder() - Method in class org.tensorflow.util.SavedSlice
The raw data of the slice is stored as a TensorProto.
getDataOrBuilder() - Method in interface org.tensorflow.util.SavedSliceOrBuilder
The raw data of the slice is stored as a TensorProto.
getDataOrBuilder() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This exists in all but the first item of each checkpoint file.
getDataOrBuilder() - Method in class org.tensorflow.util.SavedTensorSlices
This exists in all but the first item of each checkpoint file.
getDataOrBuilder() - Method in interface org.tensorflow.util.SavedTensorSlicesOrBuilder
This exists in all but the first item of each checkpoint file.
getDcomplexVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX128.
getDcomplexVal(int) - Method in class org.tensorflow.framework.TensorProto
DT_COMPLEX128.
getDcomplexVal(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_COMPLEX128.
getDcomplexValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX128.
getDcomplexValCount() - Method in class org.tensorflow.framework.TensorProto
DT_COMPLEX128.
getDcomplexValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_COMPLEX128.
getDcomplexValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX128.
getDcomplexValList() - Method in class org.tensorflow.framework.TensorProto
DT_COMPLEX128.
getDcomplexValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_COMPLEX128.
getDebugOps(int) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name(s) of the debugging op(s).
getDebugOps(int) - Method in class org.tensorflow.framework.DebugTensorWatch
Name(s) of the debugging op(s).
getDebugOps(int) - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
Name(s) of the debugging op(s).
getDebugOpsBytes(int) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name(s) of the debugging op(s).
getDebugOpsBytes(int) - Method in class org.tensorflow.framework.DebugTensorWatch
Name(s) of the debugging op(s).
getDebugOpsBytes(int) - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
Name(s) of the debugging op(s).
getDebugOpsCount() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name(s) of the debugging op(s).
getDebugOpsCount() - Method in class org.tensorflow.framework.DebugTensorWatch
Name(s) of the debugging op(s).
getDebugOpsCount() - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
Name(s) of the debugging op(s).
getDebugOpsList() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name(s) of the debugging op(s).
getDebugOpsList() - Method in class org.tensorflow.framework.DebugTensorWatch
Name(s) of the debugging op(s).
getDebugOpsList() - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
Name(s) of the debugging op(s).
getDebugOptions() - Method in class org.tensorflow.framework.RunOptions.Builder
EXPERIMENTAL.
getDebugOptions() - Method in class org.tensorflow.framework.RunOptions
EXPERIMENTAL.
getDebugOptions() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
EXPERIMENTAL.
getDebugOptionsBuilder() - Method in class org.tensorflow.framework.RunOptions.Builder
EXPERIMENTAL.
getDebugOptionsOrBuilder() - Method in class org.tensorflow.framework.RunOptions.Builder
EXPERIMENTAL.
getDebugOptionsOrBuilder() - Method in class org.tensorflow.framework.RunOptions
EXPERIMENTAL.
getDebugOptionsOrBuilder() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
EXPERIMENTAL.
getDebugStripper() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Strips debug-related nodes from the graph (off by default).
getDebugStripper() - Method in class org.tensorflow.framework.RewriterConfig
Strips debug-related nodes from the graph (off by default).
getDebugStripper() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Strips debug-related nodes from the graph (off by default).
getDebugStripperValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Strips debug-related nodes from the graph (off by default).
getDebugStripperValue() - Method in class org.tensorflow.framework.RewriterConfig
Strips debug-related nodes from the graph (off by default).
getDebugStripperValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Strips debug-related nodes from the graph (off by default).
getDebugTensorWatchOpts(int) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
getDebugTensorWatchOpts(int) - Method in class org.tensorflow.framework.DebugOptions
Debugging options
getDebugTensorWatchOpts(int) - Method in interface org.tensorflow.framework.DebugOptionsOrBuilder
Debugging options
getDebugTensorWatchOptsBuilder(int) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
getDebugTensorWatchOptsBuilderList() - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
getDebugTensorWatchOptsCount() - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
getDebugTensorWatchOptsCount() - Method in class org.tensorflow.framework.DebugOptions
Debugging options
getDebugTensorWatchOptsCount() - Method in interface org.tensorflow.framework.DebugOptionsOrBuilder
Debugging options
getDebugTensorWatchOptsList() - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
getDebugTensorWatchOptsList() - Method in class org.tensorflow.framework.DebugOptions
Debugging options
getDebugTensorWatchOptsList() - Method in interface org.tensorflow.framework.DebugOptionsOrBuilder
Debugging options
getDebugTensorWatchOptsOrBuilder(int) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
getDebugTensorWatchOptsOrBuilder(int) - Method in class org.tensorflow.framework.DebugOptions
Debugging options
getDebugTensorWatchOptsOrBuilder(int) - Method in interface org.tensorflow.framework.DebugOptionsOrBuilder
Debugging options
getDebugTensorWatchOptsOrBuilderList() - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
getDebugTensorWatchOptsOrBuilderList() - Method in class org.tensorflow.framework.DebugOptions
Debugging options
getDebugTensorWatchOptsOrBuilderList() - Method in interface org.tensorflow.framework.DebugOptionsOrBuilder
Debugging options
getDebugUrls(int) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
URL(s) for debug targets(s).
getDebugUrls(int) - Method in class org.tensorflow.framework.DebugTensorWatch
URL(s) for debug targets(s).
getDebugUrls(int) - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
URL(s) for debug targets(s).
getDebugUrlsBytes(int) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
URL(s) for debug targets(s).
getDebugUrlsBytes(int) - Method in class org.tensorflow.framework.DebugTensorWatch
URL(s) for debug targets(s).
getDebugUrlsBytes(int) - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
URL(s) for debug targets(s).
getDebugUrlsCount() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
URL(s) for debug targets(s).
getDebugUrlsCount() - Method in class org.tensorflow.framework.DebugTensorWatch
URL(s) for debug targets(s).
getDebugUrlsCount() - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
URL(s) for debug targets(s).
getDebugUrlsList() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
URL(s) for debug targets(s).
getDebugUrlsList() - Method in class org.tensorflow.framework.DebugTensorWatch
URL(s) for debug targets(s).
getDebugUrlsList() - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
URL(s) for debug targets(s).
getDefaultGraphInputTensorShape(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShape(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShape(int) - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeBuilder(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeBuilderList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeCount() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeCount() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeCount() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeList() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeOrBuilder(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeOrBuilder(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeOrBuilder(int) - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeOrBuilderList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeOrBuilderList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphInputTensorShapeOrBuilderList() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Default graph input tensor shape used to allocate memory before executing op
getDefaultGraphOutputTensorShape(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShape(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShape(int) - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeBuilder(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeBuilderList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeCount() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeCount() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeCount() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeList() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeOrBuilder(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeOrBuilder(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeOrBuilder(int) - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeOrBuilderList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeOrBuilderList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultGraphOutputTensorShapeOrBuilderList() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
getDefaultInstance() - Static method in class org.tensorflow.distruntime.ClusterDef
 
getDefaultInstance() - Static method in class org.tensorflow.distruntime.JobDef
 
getDefaultInstance() - Static method in class org.tensorflow.distruntime.ServerDef
 
getDefaultInstance() - Static method in class org.tensorflow.example.BytesList
 
getDefaultInstance() - Static method in class org.tensorflow.example.Example
 
getDefaultInstance() - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
getDefaultInstance() - Static method in class org.tensorflow.example.Feature
 
getDefaultInstance() - Static method in class org.tensorflow.example.FeatureConfiguration
 
getDefaultInstance() - Static method in class org.tensorflow.example.FeatureList
 
getDefaultInstance() - Static method in class org.tensorflow.example.FeatureLists
 
getDefaultInstance() - Static method in class org.tensorflow.example.Features
 
getDefaultInstance() - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
getDefaultInstance() - Static method in class org.tensorflow.example.FloatList
 
getDefaultInstance() - Static method in class org.tensorflow.example.Int64List
 
getDefaultInstance() - Static method in class org.tensorflow.example.SequenceExample
 
getDefaultInstance() - Static method in class org.tensorflow.example.VarLenFeatureProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.AllocationDescription
 
getDefaultInstance() - Static method in class org.tensorflow.framework.AllocationRecord
 
getDefaultInstance() - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ApiDef.Arg
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ApiDef.Attr
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ApiDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ApiDefs
 
getDefaultInstance() - Static method in class org.tensorflow.framework.AssetFileDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.AttrValue
 
getDefaultInstance() - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
getDefaultInstance() - Static method in class org.tensorflow.framework.AutoParallelOptions
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CallableOptions
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CollectionDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CondContextDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ConfigProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CostGraphDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
getDefaultInstance() - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
getDefaultInstance() - Static method in class org.tensorflow.framework.DebugOptions
 
getDefaultInstance() - Static method in class org.tensorflow.framework.DebugTensorWatch
 
getDefaultInstance() - Static method in class org.tensorflow.framework.DeviceAttributes
 
getDefaultInstance() - Static method in class org.tensorflow.framework.DeviceLocality
 
getDefaultInstance() - Static method in class org.tensorflow.framework.DeviceStepStats
 
getDefaultInstance() - Static method in class org.tensorflow.framework.FunctionDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GPUOptions
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GradientDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GraphDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GraphOptions
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GraphTransferInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.HistogramProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.InterconnectLink
 
getDefaultInstance() - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
getDefaultInstance() - Static method in class org.tensorflow.framework.KernelDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.KernelList
 
getDefaultInstance() - Static method in class org.tensorflow.framework.LocalLinks
 
getDefaultInstance() - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
getDefaultInstance() - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
getDefaultInstance() - Static method in class org.tensorflow.framework.MemoryLogStep
 
getDefaultInstance() - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
getDefaultInstance() - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
getDefaultInstance() - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
getDefaultInstance() - Static method in class org.tensorflow.framework.MemoryStats
 
getDefaultInstance() - Static method in class org.tensorflow.framework.MetaGraphDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.NameAttrList
 
getDefaultInstance() - Static method in class org.tensorflow.framework.NamedTensorProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.NodeDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.NodeExecStats
 
getDefaultInstance() - Static method in class org.tensorflow.framework.NodeOutput
 
getDefaultInstance() - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.OpDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.OpDeprecation
 
getDefaultInstance() - Static method in class org.tensorflow.framework.OpList
 
getDefaultInstance() - Static method in class org.tensorflow.framework.OptimizerOptions
 
getDefaultInstance() - Static method in class org.tensorflow.framework.QueueRunnerDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ReaderBaseState
 
getDefaultInstance() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ResourceHandleProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
getDefaultInstance() - Static method in class org.tensorflow.framework.RewriterConfig
 
getDefaultInstance() - Static method in class org.tensorflow.framework.RPCOptions
 
getDefaultInstance() - Static method in class org.tensorflow.framework.RunMetadata
 
getDefaultInstance() - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
getDefaultInstance() - Static method in class org.tensorflow.framework.RunOptions
 
getDefaultInstance() - Static method in class org.tensorflow.framework.SavedModel
 
getDefaultInstance() - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
getDefaultInstance() - Static method in class org.tensorflow.framework.SignatureDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.StepStats
 
getDefaultInstance() - Static method in class org.tensorflow.framework.Summary.Audio
 
getDefaultInstance() - Static method in class org.tensorflow.framework.Summary
 
getDefaultInstance() - Static method in class org.tensorflow.framework.Summary.Image
 
getDefaultInstance() - Static method in class org.tensorflow.framework.Summary.Value
 
getDefaultInstance() - Static method in class org.tensorflow.framework.SummaryDescription
 
getDefaultInstance() - Static method in class org.tensorflow.framework.SummaryMetadata
 
getDefaultInstance() - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
getDefaultInstance() - Static method in class org.tensorflow.framework.TensorConnection
 
getDefaultInstance() - Static method in class org.tensorflow.framework.TensorDescription
 
getDefaultInstance() - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
getDefaultInstance() - Static method in class org.tensorflow.framework.TensorInfo
 
getDefaultInstance() - Static method in class org.tensorflow.framework.TensorProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
getDefaultInstance() - Static method in class org.tensorflow.framework.TensorShapeProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
getDefaultInstance() - Static method in class org.tensorflow.framework.TensorSliceProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.ValuesDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.VariableDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
getDefaultInstance() - Static method in class org.tensorflow.framework.VersionDef
 
getDefaultInstance() - Static method in class org.tensorflow.framework.WhileContextDef
 
getDefaultInstance() - Static method in class org.tensorflow.util.BundleEntryProto
 
getDefaultInstance() - Static method in class org.tensorflow.util.BundleHeaderProto
 
getDefaultInstance() - Static method in class org.tensorflow.util.Event
 
getDefaultInstance() - Static method in class org.tensorflow.util.IteratorStateMetadata
 
getDefaultInstance() - Static method in class org.tensorflow.util.LogMessage
 
getDefaultInstance() - Static method in class org.tensorflow.util.SavedSlice
 
getDefaultInstance() - Static method in class org.tensorflow.util.SavedSliceMeta
 
getDefaultInstance() - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
getDefaultInstance() - Static method in class org.tensorflow.util.SavedTensorSlices
 
getDefaultInstance() - Static method in class org.tensorflow.util.SaverDef
 
getDefaultInstance() - Static method in class org.tensorflow.util.SessionLog
 
getDefaultInstance() - Static method in class org.tensorflow.util.TaggedRunMetadata
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.CommitId
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.CPUInfo
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.EntryValue
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.GPUInfo
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
getDefaultInstance() - Static method in class org.tensorflow.util.testlog.TestResults
 
getDefaultInstance() - Static method in class org.tensorflow.util.WatchdogConfig
 
getDefaultInstance() - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
getDefaultInstance() - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
getDefaultInstance() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
getDefaultInstance() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
getDefaultInstance() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
getDefaultInstance() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
getDefaultInstance() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
getDefaultInstance() - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
getDefaultInstance() - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
getDefaultInstance() - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
getDefaultInstance() - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
getDefaultInstance() - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
getDefaultInstanceForType() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.distruntime.ClusterDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.distruntime.JobDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.distruntime.JobDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.distruntime.ServerDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.BytesList.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.BytesList
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.Example.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.Example
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.ExampleParserConfiguration
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.Feature.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.Feature
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.FeatureConfiguration
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.FeatureList.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.FeatureList
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.FeatureLists.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.FeatureLists
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.Features.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.Features
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.FixedLenFeatureProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.FloatList.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.FloatList
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.Int64List.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.Int64List
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.SequenceExample.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.SequenceExample
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.example.VarLenFeatureProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AllocationDescription
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AllocationRecord
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ApiDef.Arg
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ApiDef.Attr
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ApiDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ApiDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ApiDefs.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ApiDefs
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AssetFileDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AttrValue.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AttrValue
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AttrValue.ListValue
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.AutoParallelOptions
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CallableOptions
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CondContextDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CondContextDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ConfigProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ConfigProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ControlFlowContextDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CostGraphDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CostGraphDef.Node
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DebuggedSourceFile
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DebugOptions.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DebugOptions
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DebugTensorWatch
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DeviceAttributes
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DeviceLocality
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.DeviceStepStats
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.FunctionDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.FunctionDefLibrary
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GPUOptions.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GPUOptions
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GradientDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GradientDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphOptions.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphOptions
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.HistogramProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.HistogramProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.InterconnectLink
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.KernelDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.KernelDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.KernelList.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.KernelList
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.LocalLinks.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.LocalLinks
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogStep
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryStats.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MemoryStats
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MetaGraphDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NameAttrList.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NameAttrList
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NamedTensorProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NodeDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NodeDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NodeExecStats
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NodeOutput.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.NodeOutput
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OpDef.ArgDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OpDef.AttrDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OpDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OpDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OpDeprecation
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OpList.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OpList
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.OptimizerOptions
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.QueueRunnerDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ReaderBaseState
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ResourceHandleProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RewriterConfig
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RPCOptions.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RPCOptions
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RunMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RunMetadata
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RunOptions.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RunOptions.Experimental
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.RunOptions
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SavedModel.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SavedModel
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SignatureDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.StepStats.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.StepStats
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.Summary.Audio
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.Summary.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.Summary
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.Summary.Image.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.Summary.Image
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.Summary.Value.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.Summary.Value
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SummaryDescription
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SummaryMetadata
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorConnection.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorConnection
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorDescription.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorDescription
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorShapeProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.TensorSliceProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ValuesDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.ValuesDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.VariableDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.VariableDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.VariantTensorDataProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.VersionDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.VersionDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.framework.WhileContextDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.BundleEntryProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.BundleHeaderProto
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.Event.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.Event
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.IteratorStateMetadata
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.LogMessage.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.LogMessage
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SavedSlice.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SavedSlice
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SavedSliceMeta
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SavedTensorSlices
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SaverDef.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SaverDef
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SessionLog.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.SessionLog
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.TaggedRunMetadata
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.CommitId
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.CPUInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.EntryValue
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.GPUInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.MemoryInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.PlatformInfo
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.RunConfiguration
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.testlog.TestResults
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.WatchdogConfig
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
getDefaultInstanceForType() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
getDefaultInstanceForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
getDefaultInstanceForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
getDefaultInstanceForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
getDefaultInstanceForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
getDefaultInstanceForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
getDefaultInstanceForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
getDefaultInstanceForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
getDefaultInstanceForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
getDefaultInstanceForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
getDefaultInstanceForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
getDefaultInstanceForType() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
getDefaultInstanceForType() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
getDefaultInstanceForType() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
getDefaultInstanceForType() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
getDefaultInstanceForType() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
getDefaultInstanceForType() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
getDefaultInstanceForType() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
getDefaultInstanceForType() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
getDefaultInstanceForType() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
getDefaultInstanceForType() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
getDefaultSessionConfig() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The default configuration for sessions that run on this server.
getDefaultSessionConfig() - Method in class org.tensorflow.distruntime.ServerDef
The default configuration for sessions that run on this server.
getDefaultSessionConfig() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The default configuration for sessions that run on this server.
getDefaultSessionConfigBuilder() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The default configuration for sessions that run on this server.
getDefaultSessionConfigOrBuilder() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The default configuration for sessions that run on this server.
getDefaultSessionConfigOrBuilder() - Method in class org.tensorflow.distruntime.ServerDef
The default configuration for sessions that run on this server.
getDefaultSessionConfigOrBuilder() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The default configuration for sessions that run on this server.
getDefaultValue() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorProto default_value = 3;
getDefaultValue() - Method in class org.tensorflow.example.FixedLenFeatureProto
.tensorflow.TensorProto default_value = 3;
getDefaultValue() - Method in interface org.tensorflow.example.FixedLenFeatureProtoOrBuilder
.tensorflow.TensorProto default_value = 3;
getDefaultValue() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Specify a new default value to use for this attr.
getDefaultValue() - Method in class org.tensorflow.framework.ApiDef.Attr
Specify a new default value to use for this attr.
getDefaultValue() - Method in interface org.tensorflow.framework.ApiDef.AttrOrBuilder
Specify a new default value to use for this attr.
getDefaultValue() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A reasonable default for this attribute if the user does not supply a value.
getDefaultValue() - Method in class org.tensorflow.framework.OpDef.AttrDef
A reasonable default for this attribute if the user does not supply a value.
getDefaultValue() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
A reasonable default for this attribute if the user does not supply a value.
getDefaultValueBuilder() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorProto default_value = 3;
getDefaultValueBuilder() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Specify a new default value to use for this attr.
getDefaultValueBuilder() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A reasonable default for this attribute if the user does not supply a value.
getDefaultValueOrBuilder() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorProto default_value = 3;
getDefaultValueOrBuilder() - Method in class org.tensorflow.example.FixedLenFeatureProto
.tensorflow.TensorProto default_value = 3;
getDefaultValueOrBuilder() - Method in interface org.tensorflow.example.FixedLenFeatureProtoOrBuilder
.tensorflow.TensorProto default_value = 3;
getDefaultValueOrBuilder() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Specify a new default value to use for this attr.
getDefaultValueOrBuilder() - Method in class org.tensorflow.framework.ApiDef.Attr
Specify a new default value to use for this attr.
getDefaultValueOrBuilder() - Method in interface org.tensorflow.framework.ApiDef.AttrOrBuilder
Specify a new default value to use for this attr.
getDefaultValueOrBuilder() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A reasonable default for this attribute if the user does not supply a value.
getDefaultValueOrBuilder() - Method in class org.tensorflow.framework.OpDef.AttrDef
A reasonable default for this attribute if the user does not supply a value.
getDefaultValueOrBuilder() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
A reasonable default for this attribute if the user does not supply a value.
getDeferred() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
True if the deallocation is queued and will be performed later, e.g.
getDeferred() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
True if the deallocation is queued and will be performed later, e.g.
getDeferred() - Method in interface org.tensorflow.framework.MemoryLogRawDeallocationOrBuilder
True if the deallocation is queued and will be performed later, e.g.
getDeferredDeletionBytes() - Method in class org.tensorflow.framework.GPUOptions.Builder
Delay deletion of up to this many bytes to reduce the number of interactions with gpu driver code.
getDeferredDeletionBytes() - Method in class org.tensorflow.framework.GPUOptions
Delay deletion of up to this many bytes to reduce the number of interactions with gpu driver code.
getDeferredDeletionBytes() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
Delay deletion of up to this many bytes to reduce the number of interactions with gpu driver code.
getDenseShapeTensorName() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The dynamic logical shape represented by the SparseTensor is recorded in the Tensor referenced here.
getDenseShapeTensorName() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
The dynamic logical shape represented by the SparseTensor is recorded in the Tensor referenced here.
getDenseShapeTensorName() - Method in interface org.tensorflow.framework.TensorInfo.CooSparseOrBuilder
The dynamic logical shape represented by the SparseTensor is recorded in the Tensor referenced here.
getDenseShapeTensorNameBytes() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The dynamic logical shape represented by the SparseTensor is recorded in the Tensor referenced here.
getDenseShapeTensorNameBytes() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
The dynamic logical shape represented by the SparseTensor is recorded in the Tensor referenced here.
getDenseShapeTensorNameBytes() - Method in interface org.tensorflow.framework.TensorInfo.CooSparseOrBuilder
The dynamic logical shape represented by the SparseTensor is recorded in the Tensor referenced here.
getDependencyOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Control dependency optimizations (default is ON).
getDependencyOptimization() - Method in class org.tensorflow.framework.RewriterConfig
Control dependency optimizations (default is ON).
getDependencyOptimization() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Control dependency optimizations (default is ON).
getDependencyOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Control dependency optimizations (default is ON).
getDependencyOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig
Control dependency optimizations (default is ON).
getDependencyOptimizationValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Control dependency optimizations (default is ON).
getDeprecated() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Set if this endpoint is deprecated.
getDeprecated() - Method in class org.tensorflow.framework.ApiDef.Endpoint
Set if this endpoint is deprecated.
getDeprecated() - Method in interface org.tensorflow.framework.ApiDef.EndpointOrBuilder
Set if this endpoint is deprecated.
getDeprecation() - Method in class org.tensorflow.framework.OpDef.Builder
Optional deprecation based on GraphDef versions.
getDeprecation() - Method in class org.tensorflow.framework.OpDef
Optional deprecation based on GraphDef versions.
getDeprecation() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Optional deprecation based on GraphDef versions.
getDeprecationBuilder() - Method in class org.tensorflow.framework.OpDef.Builder
Optional deprecation based on GraphDef versions.
getDeprecationMessage() - Method in class org.tensorflow.framework.ApiDef.Builder
If this op is deprecated, set deprecation message to the message that should be logged when this op is used.
getDeprecationMessage() - Method in class org.tensorflow.framework.ApiDef
If this op is deprecated, set deprecation message to the message that should be logged when this op is used.
getDeprecationMessage() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
If this op is deprecated, set deprecation message to the message that should be logged when this op is used.
getDeprecationMessageBytes() - Method in class org.tensorflow.framework.ApiDef.Builder
If this op is deprecated, set deprecation message to the message that should be logged when this op is used.
getDeprecationMessageBytes() - Method in class org.tensorflow.framework.ApiDef
If this op is deprecated, set deprecation message to the message that should be logged when this op is used.
getDeprecationMessageBytes() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
If this op is deprecated, set deprecation message to the message that should be logged when this op is used.
getDeprecationOrBuilder() - Method in class org.tensorflow.framework.OpDef.Builder
Optional deprecation based on GraphDef versions.
getDeprecationOrBuilder() - Method in class org.tensorflow.framework.OpDef
Optional deprecation based on GraphDef versions.
getDeprecationOrBuilder() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Optional deprecation based on GraphDef versions.
getDeprecationVersion() - Method in class org.tensorflow.framework.ApiDef.Builder
Major version when the op will be deleted.
getDeprecationVersion() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Major version when an endpoint will be deleted.
getDeprecationVersion() - Method in class org.tensorflow.framework.ApiDef.Endpoint
Major version when an endpoint will be deleted.
getDeprecationVersion() - Method in interface org.tensorflow.framework.ApiDef.EndpointOrBuilder
Major version when an endpoint will be deleted.
getDeprecationVersion() - Method in class org.tensorflow.framework.ApiDef
Major version when the op will be deleted.
getDeprecationVersion() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
Major version when the op will be deleted.
getDescription() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
Note: this will replace any inherited arg doc.
getDescription() - Method in class org.tensorflow.framework.ApiDef.Arg
Note: this will replace any inherited arg doc.
getDescription() - Method in interface org.tensorflow.framework.ApiDef.ArgOrBuilder
Note: this will replace any inherited arg doc.
getDescription() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Note: this will replace any inherited attr doc, there is no current way of modifying attr descriptions as can be done with op descriptions.
getDescription() - Method in class org.tensorflow.framework.ApiDef.Attr
Note: this will replace any inherited attr doc, there is no current way of modifying attr descriptions as can be done with op descriptions.
getDescription() - Method in interface org.tensorflow.framework.ApiDef.AttrOrBuilder
Note: this will replace any inherited attr doc, there is no current way of modifying attr descriptions as can be done with op descriptions.
getDescription() - Method in class org.tensorflow.framework.ApiDef.Builder
Additional, longer human-readable description of what the Op does.
getDescription() - Method in class org.tensorflow.framework.ApiDef
Additional, longer human-readable description of what the Op does.
getDescription() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
Additional, longer human-readable description of what the Op does.
getDescription() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Human readable description.
getDescription() - Method in class org.tensorflow.framework.OpDef.ArgDef
Human readable description.
getDescription() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
Human readable description.
getDescription() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
Human-readable description.
getDescription() - Method in class org.tensorflow.framework.OpDef.AttrDef
Human-readable description.
getDescription() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
Human-readable description.
getDescription() - Method in class org.tensorflow.framework.OpDef.Builder
Additional, longer human-readable description of what the Op does.
getDescription() - Method in class org.tensorflow.framework.OpDef
Additional, longer human-readable description of what the Op does.
getDescription() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Additional, longer human-readable description of what the Op does.
getDescriptionBytes() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
Note: this will replace any inherited arg doc.
getDescriptionBytes() - Method in class org.tensorflow.framework.ApiDef.Arg
Note: this will replace any inherited arg doc.
getDescriptionBytes() - Method in interface org.tensorflow.framework.ApiDef.ArgOrBuilder
Note: this will replace any inherited arg doc.
getDescriptionBytes() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Note: this will replace any inherited attr doc, there is no current way of modifying attr descriptions as can be done with op descriptions.
getDescriptionBytes() - Method in class org.tensorflow.framework.ApiDef.Attr
Note: this will replace any inherited attr doc, there is no current way of modifying attr descriptions as can be done with op descriptions.
getDescriptionBytes() - Method in interface org.tensorflow.framework.ApiDef.AttrOrBuilder
Note: this will replace any inherited attr doc, there is no current way of modifying attr descriptions as can be done with op descriptions.
getDescriptionBytes() - Method in class org.tensorflow.framework.ApiDef.Builder
Additional, longer human-readable description of what the Op does.
getDescriptionBytes() - Method in class org.tensorflow.framework.ApiDef
Additional, longer human-readable description of what the Op does.
getDescriptionBytes() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
Additional, longer human-readable description of what the Op does.
getDescriptionBytes() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Human readable description.
getDescriptionBytes() - Method in class org.tensorflow.framework.OpDef.ArgDef
Human readable description.
getDescriptionBytes() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
Human readable description.
getDescriptionBytes() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
Human-readable description.
getDescriptionBytes() - Method in class org.tensorflow.framework.OpDef.AttrDef
Human-readable description.
getDescriptionBytes() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
Human-readable description.
getDescriptionBytes() - Method in class org.tensorflow.framework.OpDef.Builder
Additional, longer human-readable description of what the Op does.
getDescriptionBytes() - Method in class org.tensorflow.framework.OpDef
Additional, longer human-readable description of what the Op does.
getDescriptionBytes() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Additional, longer human-readable description of what the Op does.
getDescriptionPrefix() - Method in class org.tensorflow.framework.ApiDef.Builder
Modify an existing/inherited description by adding text to the beginning or end.
getDescriptionPrefix() - Method in class org.tensorflow.framework.ApiDef
Modify an existing/inherited description by adding text to the beginning or end.
getDescriptionPrefix() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
Modify an existing/inherited description by adding text to the beginning or end.
getDescriptionPrefixBytes() - Method in class org.tensorflow.framework.ApiDef.Builder
Modify an existing/inherited description by adding text to the beginning or end.
getDescriptionPrefixBytes() - Method in class org.tensorflow.framework.ApiDef
Modify an existing/inherited description by adding text to the beginning or end.
getDescriptionPrefixBytes() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
Modify an existing/inherited description by adding text to the beginning or end.
getDescriptionSuffix() - Method in class org.tensorflow.framework.ApiDef.Builder
string description_suffix = 10;
getDescriptionSuffix() - Method in class org.tensorflow.framework.ApiDef
string description_suffix = 10;
getDescriptionSuffix() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
string description_suffix = 10;
getDescriptionSuffixBytes() - Method in class org.tensorflow.framework.ApiDef.Builder
string description_suffix = 10;
getDescriptionSuffixBytes() - Method in class org.tensorflow.framework.ApiDef
string description_suffix = 10;
getDescriptionSuffixBytes() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
string description_suffix = 10;
getDescriptor() - Static method in class org.tensorflow.distruntime.ClusterDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.distruntime.ClusterDef
 
getDescriptor() - Static method in class org.tensorflow.distruntime.ClusterProtos
 
getDescriptor() - Static method in class org.tensorflow.distruntime.JobDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.distruntime.JobDef
 
getDescriptor() - Static method in class org.tensorflow.distruntime.ServerDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.distruntime.ServerDef
 
getDescriptor() - Static method in class org.tensorflow.distruntime.ServerProtos
 
getDescriptor() - Static method in class org.tensorflow.example.BytesList.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.BytesList
 
getDescriptor() - Static method in class org.tensorflow.example.Example.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.Example
 
getDescriptor() - Static method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
getDescriptor() - Static method in class org.tensorflow.example.ExampleParserConfigurationProtos
 
getDescriptor() - Static method in class org.tensorflow.example.ExampleProtos
 
getDescriptor() - Static method in class org.tensorflow.example.Feature.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.Feature
 
getDescriptor() - Static method in class org.tensorflow.example.FeatureConfiguration.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.FeatureConfiguration
 
getDescriptor() - Static method in class org.tensorflow.example.FeatureList.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.FeatureList
 
getDescriptor() - Static method in class org.tensorflow.example.FeatureLists.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.FeatureLists
 
getDescriptor() - Static method in class org.tensorflow.example.FeatureProtos
 
getDescriptor() - Static method in class org.tensorflow.example.Features.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.Features
 
getDescriptor() - Static method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
getDescriptor() - Static method in class org.tensorflow.example.FloatList.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.FloatList
 
getDescriptor() - Static method in class org.tensorflow.example.Int64List.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.Int64List
 
getDescriptor() - Static method in class org.tensorflow.example.SequenceExample.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.SequenceExample
 
getDescriptor() - Static method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.example.VarLenFeatureProto
 
getDescriptor() - Static method in class org.tensorflow.framework.AllocationDescription.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.AllocationDescription
 
getDescriptor() - Static method in class org.tensorflow.framework.AllocationDescriptionProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.AllocationRecord.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.AllocationRecord
 
getDescriptor() - Static method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDef.Arg
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDef.Attr
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDef
 
getDescriptor() - Static method in enum org.tensorflow.framework.ApiDef.Visibility
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDefProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDefs.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ApiDefs
 
getDescriptor() - Static method in class org.tensorflow.framework.AssetFileDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.AssetFileDef
 
getDescriptor() - Static method in class org.tensorflow.framework.AttrValue.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.AttrValue
 
getDescriptor() - Static method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
getDescriptor() - Static method in class org.tensorflow.framework.AttrValueProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.AutoParallelOptions
 
getDescriptor() - Static method in class org.tensorflow.framework.CallableOptions.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CallableOptions
 
getDescriptor() - Static method in enum org.tensorflow.framework.Code
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
getDescriptor() - Static method in class org.tensorflow.framework.CondContextDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CondContextDef
 
getDescriptor() - Static method in class org.tensorflow.framework.ConfigProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
getDescriptor() - Static method in class org.tensorflow.framework.ConfigProto
 
getDescriptor() - Static method in class org.tensorflow.framework.ConfigProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
getDescriptor() - Static method in class org.tensorflow.framework.ControlFlowProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.CostGraphDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CostGraphDef
 
getDescriptor() - Static method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
getDescriptor() - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.CostGraphProtos
 
getDescriptor() - Static method in enum org.tensorflow.framework.DataType
 
getDescriptor() - Static method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
getDescriptor() - Static method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
getDescriptor() - Static method in class org.tensorflow.framework.DebugOptions.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.DebugOptions
 
getDescriptor() - Static method in class org.tensorflow.framework.DebugProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.DebugTensorWatch
 
getDescriptor() - Static method in class org.tensorflow.framework.DeviceAttributes.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.DeviceAttributes
 
getDescriptor() - Static method in class org.tensorflow.framework.DeviceAttributesProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.DeviceLocality.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.DeviceLocality
 
getDescriptor() - Static method in class org.tensorflow.framework.DeviceStepStats.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.DeviceStepStats
 
getDescriptor() - Static method in class org.tensorflow.framework.ErrorCodesProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.FunctionDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.FunctionDef
 
getDescriptor() - Static method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
getDescriptor() - Static method in class org.tensorflow.framework.FunctionProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.GPUOptions.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
getDescriptor() - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
getDescriptor() - Static method in class org.tensorflow.framework.GPUOptions
 
getDescriptor() - Static method in class org.tensorflow.framework.GradientDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GradientDef
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphDef
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphOptions.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphOptions
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
getDescriptor() - Static method in enum org.tensorflow.framework.GraphTransferInfo.Destination
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferInfoProto
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.HistogramProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.HistogramProto
 
getDescriptor() - Static method in class org.tensorflow.framework.InterconnectLink.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.InterconnectLink
 
getDescriptor() - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
getDescriptor() - Static method in class org.tensorflow.framework.KernelDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.KernelDef
 
getDescriptor() - Static method in class org.tensorflow.framework.KernelDefProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.KernelList.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.KernelList
 
getDescriptor() - Static method in class org.tensorflow.framework.LocalLinks.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.LocalLinks
 
getDescriptor() - Static method in class org.tensorflow.framework.LogMemoryProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogStep.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogStep
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryStats.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.MemoryStats
 
getDescriptor() - Static method in class org.tensorflow.framework.MetaGraphDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.MetaGraphDef
 
getDescriptor() - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
getDescriptor() - Static method in class org.tensorflow.framework.MetaGraphProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.NameAttrList.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.NameAttrList
 
getDescriptor() - Static method in class org.tensorflow.framework.NamedTensorProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.NamedTensorProto
 
getDescriptor() - Static method in class org.tensorflow.framework.NamedTensorProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.NodeDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.NodeDef
 
getDescriptor() - Static method in class org.tensorflow.framework.NodeExecStats.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.NodeExecStats
 
getDescriptor() - Static method in class org.tensorflow.framework.NodeOutput.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.NodeOutput
 
getDescriptor() - Static method in class org.tensorflow.framework.NodeProto
 
getDescriptor() - Static method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
getDescriptor() - Static method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
getDescriptor() - Static method in class org.tensorflow.framework.OpDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.OpDef
 
getDescriptor() - Static method in class org.tensorflow.framework.OpDefProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.OpDeprecation.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.OpDeprecation
 
getDescriptor() - Static method in class org.tensorflow.framework.OpList.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.OpList
 
getDescriptor() - Static method in class org.tensorflow.framework.OptimizerOptions.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.OptimizerOptions
 
getDescriptor() - Static method in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
 
getDescriptor() - Static method in enum org.tensorflow.framework.OptimizerOptions.Level
 
getDescriptor() - Static method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.QueueRunnerDef
 
getDescriptor() - Static method in class org.tensorflow.framework.QueueRunnerProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.ReaderBaseProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.ReaderBaseState.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ReaderBaseState
 
getDescriptor() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
getDescriptor() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfoProto
 
getDescriptor() - Static method in class org.tensorflow.framework.ResourceHandle
 
getDescriptor() - Static method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ResourceHandleProto
 
getDescriptor() - Static method in class org.tensorflow.framework.RewriterConfig.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
getDescriptor() - Static method in class org.tensorflow.framework.RewriterConfig
 
getDescriptor() - Static method in enum org.tensorflow.framework.RewriterConfig.MemOptType
 
getDescriptor() - Static method in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
 
getDescriptor() - Static method in enum org.tensorflow.framework.RewriterConfig.Toggle
 
getDescriptor() - Static method in class org.tensorflow.framework.RewriterConfigProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.RPCOptions.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.RPCOptions
 
getDescriptor() - Static method in class org.tensorflow.framework.RunMetadata.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.RunMetadata
 
getDescriptor() - Static method in class org.tensorflow.framework.RunOptions.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
getDescriptor() - Static method in class org.tensorflow.framework.RunOptions
 
getDescriptor() - Static method in enum org.tensorflow.framework.RunOptions.TraceLevel
 
getDescriptor() - Static method in class org.tensorflow.framework.SavedModel.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.SavedModel
 
getDescriptor() - Static method in class org.tensorflow.framework.SavedModelProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
getDescriptor() - Static method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
getDescriptor() - Static method in class org.tensorflow.framework.SignatureDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.SignatureDef
 
getDescriptor() - Static method in class org.tensorflow.framework.StepStats.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.StepStats
 
getDescriptor() - Static method in class org.tensorflow.framework.StepStatsProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.Summary.Audio.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.Summary.Audio
 
getDescriptor() - Static method in class org.tensorflow.framework.Summary.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.Summary
 
getDescriptor() - Static method in class org.tensorflow.framework.Summary.Image.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.Summary.Image
 
getDescriptor() - Static method in class org.tensorflow.framework.Summary.Value.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.Summary.Value
 
getDescriptor() - Static method in class org.tensorflow.framework.SummaryDescription.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.SummaryDescription
 
getDescriptor() - Static method in class org.tensorflow.framework.SummaryMetadata.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.SummaryMetadata
 
getDescriptor() - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
getDescriptor() - Static method in class org.tensorflow.framework.SummaryProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorConnection.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorConnection
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorDescription.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorDescription
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorDescriptionProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorInfo
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorProto
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorShapeProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorShapeProto
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorShapeProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorSliceProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorSliceProto
 
getDescriptor() - Static method in class org.tensorflow.framework.TensorSliceProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
getDescriptor() - Static method in class org.tensorflow.framework.TypesProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.ValuesDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.ValuesDef
 
getDescriptor() - Static method in class org.tensorflow.framework.VariableDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.VariableDef
 
getDescriptor() - Static method in class org.tensorflow.framework.VariableProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
getDescriptor() - Static method in class org.tensorflow.framework.VersionDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.VersionDef
 
getDescriptor() - Static method in class org.tensorflow.framework.VersionsProtos
 
getDescriptor() - Static method in class org.tensorflow.framework.WhileContextDef.Builder
 
getDescriptor() - Static method in class org.tensorflow.framework.WhileContextDef
 
getDescriptor() - Static method in class org.tensorflow.util.BundleEntryProto.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.BundleEntryProto
 
getDescriptor() - Static method in class org.tensorflow.util.BundleHeaderProto.Builder
 
getDescriptor() - Static method in enum org.tensorflow.util.BundleHeaderProto.Endianness
 
getDescriptor() - Static method in class org.tensorflow.util.BundleHeaderProto
 
getDescriptor() - Static method in class org.tensorflow.util.Event.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.Event
 
getDescriptor() - Static method in class org.tensorflow.util.EventProtos
 
getDescriptor() - Static method in class org.tensorflow.util.IteratorProtos
 
getDescriptor() - Static method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.IteratorStateMetadata
 
getDescriptor() - Static method in class org.tensorflow.util.LogMessage.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.LogMessage
 
getDescriptor() - Static method in enum org.tensorflow.util.LogMessage.Level
 
getDescriptor() - Static method in class org.tensorflow.util.SavedSlice.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.SavedSlice
 
getDescriptor() - Static method in class org.tensorflow.util.SavedSliceMeta.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.SavedSliceMeta
 
getDescriptor() - Static method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
getDescriptor() - Static method in class org.tensorflow.util.SavedTensorSliceProtos
 
getDescriptor() - Static method in class org.tensorflow.util.SavedTensorSlices.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.SavedTensorSlices
 
getDescriptor() - Static method in class org.tensorflow.util.SaverDef.Builder
 
getDescriptor() - Static method in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
 
getDescriptor() - Static method in class org.tensorflow.util.SaverDef
 
getDescriptor() - Static method in class org.tensorflow.util.SaverProtos
 
getDescriptor() - Static method in class org.tensorflow.util.SessionLog.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.SessionLog
 
getDescriptor() - Static method in enum org.tensorflow.util.SessionLog.SessionStatus
 
getDescriptor() - Static method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.TaggedRunMetadata
 
getDescriptor() - Static method in class org.tensorflow.util.TensorBundleProtos
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.CommitId.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.CommitId
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.CPUInfo
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.EntryValue.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.EntryValue
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.GPUInfo
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.TestLogProtos
 
getDescriptor() - Static method in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.TestResults.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.testlog.TestResults
 
getDescriptor() - Static method in class org.tensorflow.util.WatchdogConfig.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.WatchdogConfig
 
getDescriptor() - Static method in enum org.tensorflow.util.WorkerHealth
 
getDescriptor() - Static method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
getDescriptor() - Static method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
getDescriptor() - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
getDescriptor() - Static method in enum org.tensorflow.util.WorkerShutdownMode
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
getDescriptor() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass
 
getDescriptor() - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
getDescriptor() - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
getDescriptor() - Static method in class tensorflow.DevicePropertiesProtos
 
getDescriptor() - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
getDescriptor() - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
getDescriptor() - Static method in class tensorflow.MemmappedFileSystem
 
getDescriptor() - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
getDescriptor() - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
getDescriptor() - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
getDescriptor() - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
getDescriptor() - Static method in class tensorflow.TransportOptions
 
getDescriptor() - Static method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
getDescriptor() - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
getDescriptorForType() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.distruntime.JobDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.BytesList.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.Example.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.Feature.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.FeatureList.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.FeatureLists.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.Features.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.FloatList.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.Int64List.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.SequenceExample.Builder
 
getDescriptorForType() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ApiDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.framework.ApiDef.Visibility
 
getDescriptorForType() - Method in class org.tensorflow.framework.ApiDefs.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.AttrValue.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.framework.Code
 
getDescriptorForType() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CollectionDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CondContextDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ConfigProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.framework.DataType
 
getDescriptorForType() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.DebugOptions.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GPUOptions.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GradientDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GraphDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GraphOptions.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.framework.GraphTransferInfo.Destination
 
getDescriptorForType() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.HistogramProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.KernelDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.KernelList.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.LocalLinks.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.MemoryStats.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.NameAttrList.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.NodeDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.NodeOutput.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.OpDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.OpList.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
 
getDescriptorForType() - Method in enum org.tensorflow.framework.OptimizerOptions.Level
 
getDescriptorForType() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.framework.RewriterConfig.MemOptType
 
getDescriptorForType() - Method in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
 
getDescriptorForType() - Method in enum org.tensorflow.framework.RewriterConfig.Toggle
 
getDescriptorForType() - Method in class org.tensorflow.framework.RPCOptions.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.RunMetadata.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.RunOptions.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.framework.RunOptions.TraceLevel
 
getDescriptorForType() - Method in class org.tensorflow.framework.SavedModel.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.StepStats.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.Summary.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.Summary.Image.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.Summary.Value.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.TensorConnection.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.TensorDescription.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.TensorInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.TensorProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.ValuesDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.VariableDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.VersionDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.util.BundleHeaderProto.Endianness
 
getDescriptorForType() - Method in class org.tensorflow.util.Event.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.LogMessage.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.util.LogMessage.Level
 
getDescriptorForType() - Method in class org.tensorflow.util.SavedSlice.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.SaverDef.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
 
getDescriptorForType() - Method in class org.tensorflow.util.SessionLog.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.util.SessionLog.SessionStatus
 
getDescriptorForType() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
 
getDescriptorForType() - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.util.WorkerHealth
 
getDescriptorForType() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
getDescriptorForType() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
getDescriptorForType() - Method in enum org.tensorflow.util.WorkerShutdownMode
 
getDescriptorForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
getDescriptorForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
getDescriptorForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
getDescriptorForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
getDescriptorForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
getDescriptorForType() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
getDescriptorForType() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
getDescriptorForType() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
getDescriptorForType() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
getDescriptorForType() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
getDestination() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Destination of graph transfer
getDestination() - Method in class org.tensorflow.framework.GraphTransferInfo
Destination of graph transfer
getDestination() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
Destination of graph transfer
getDestinationValue() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Destination of graph transfer
getDestinationValue() - Method in class org.tensorflow.framework.GraphTransferInfo
Destination of graph transfer
getDestinationValue() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
Destination of graph transfer
getDevice() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The device of the node.
getDevice() - Method in class org.tensorflow.framework.CostGraphDef.Node
The device of the node.
getDevice() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
The device of the node.
getDevice() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
string device = 1;
getDevice() - Method in class org.tensorflow.framework.DeviceStepStats
string device = 1;
getDevice() - Method in interface org.tensorflow.framework.DeviceStepStatsOrBuilder
string device = 1;
getDevice() - Method in class org.tensorflow.framework.NodeDef.Builder
A (possibly partial) specification for the device on which this node should be placed.
getDevice() - Method in class org.tensorflow.framework.NodeDef
A (possibly partial) specification for the device on which this node should be placed.
getDevice() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
A (possibly partial) specification for the device on which this node should be placed.
getDevice() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Unique name for the device containing the resource.
getDevice() - Method in class org.tensorflow.framework.ResourceHandleProto
Unique name for the device containing the resource.
getDevice() - Method in interface org.tensorflow.framework.ResourceHandleProtoOrBuilder
Unique name for the device containing the resource.
getDeviceBytes() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The device of the node.
getDeviceBytes() - Method in class org.tensorflow.framework.CostGraphDef.Node
The device of the node.
getDeviceBytes() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
The device of the node.
getDeviceBytes() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
string device = 1;
getDeviceBytes() - Method in class org.tensorflow.framework.DeviceStepStats
string device = 1;
getDeviceBytes() - Method in interface org.tensorflow.framework.DeviceStepStatsOrBuilder
string device = 1;
getDeviceBytes() - Method in class org.tensorflow.framework.NodeDef.Builder
A (possibly partial) specification for the device on which this node should be placed.
getDeviceBytes() - Method in class org.tensorflow.framework.NodeDef
A (possibly partial) specification for the device on which this node should be placed.
getDeviceBytes() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
A (possibly partial) specification for the device on which this node should be placed.
getDeviceBytes() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Unique name for the device containing the resource.
getDeviceBytes() - Method in class org.tensorflow.framework.ResourceHandleProto
Unique name for the device containing the resource.
getDeviceBytes() - Method in interface org.tensorflow.framework.ResourceHandleProtoOrBuilder
Unique name for the device containing the resource.
getDeviceCount() - Method in class org.tensorflow.framework.ConfigProto.Builder
Deprecated.
getDeviceCount() - Method in class org.tensorflow.framework.ConfigProto
Deprecated.
getDeviceCount() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Deprecated.
getDeviceCountCount() - Method in class org.tensorflow.framework.ConfigProto.Builder
 
getDeviceCountCount() - Method in class org.tensorflow.framework.ConfigProto
 
getDeviceCountCount() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
getDeviceCountMap() - Method in class org.tensorflow.framework.ConfigProto.Builder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
getDeviceCountMap() - Method in class org.tensorflow.framework.ConfigProto
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
getDeviceCountMap() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
getDeviceCountOrDefault(String, int) - Method in class org.tensorflow.framework.ConfigProto.Builder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
getDeviceCountOrDefault(String, int) - Method in class org.tensorflow.framework.ConfigProto
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
getDeviceCountOrDefault(String, int) - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
getDeviceCountOrThrow(String) - Method in class org.tensorflow.framework.ConfigProto.Builder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
getDeviceCountOrThrow(String) - Method in class org.tensorflow.framework.ConfigProto
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
getDeviceCountOrThrow(String) - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
getDeviceFilters(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFilters(int) - Method in class org.tensorflow.framework.ConfigProto
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFilters(int) - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFiltersBytes(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFiltersBytes(int) - Method in class org.tensorflow.framework.ConfigProto
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFiltersBytes(int) - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFiltersCount() - Method in class org.tensorflow.framework.ConfigProto.Builder
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFiltersCount() - Method in class org.tensorflow.framework.ConfigProto
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFiltersCount() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFiltersList() - Method in class org.tensorflow.framework.ConfigProto.Builder
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFiltersList() - Method in class org.tensorflow.framework.ConfigProto
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceFiltersList() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
When any filters are present sessions will ignore all devices which do not match the filters.
getDeviceId() - Method in class org.tensorflow.framework.InterconnectLink.Builder
int32 device_id = 1;
getDeviceId() - Method in class org.tensorflow.framework.InterconnectLink
int32 device_id = 1;
getDeviceId() - Method in interface org.tensorflow.framework.InterconnectLinkOrBuilder
int32 device_id = 1;
getDeviceInfo(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
getDeviceInfo(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration
Other devices that are attached and relevant (e.g.
getDeviceInfo(int) - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Other devices that are attached and relevant (e.g.
getDeviceInfoBuilder(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
getDeviceInfoBuilderList() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
getDeviceInfoCount() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
getDeviceInfoCount() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Other devices that are attached and relevant (e.g.
getDeviceInfoCount() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Other devices that are attached and relevant (e.g.
getDeviceInfoList() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
getDeviceInfoList() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Other devices that are attached and relevant (e.g.
getDeviceInfoList() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Other devices that are attached and relevant (e.g.
getDeviceInfoOrBuilder(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
getDeviceInfoOrBuilder(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration
Other devices that are attached and relevant (e.g.
getDeviceInfoOrBuilder(int) - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Other devices that are attached and relevant (e.g.
getDeviceInfoOrBuilderList() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
getDeviceInfoOrBuilderList() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Other devices that are attached and relevant (e.g.
getDeviceInfoOrBuilderList() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Other devices that are attached and relevant (e.g.
getDevicePersistentMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Deprecated.
getDevicePersistentMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node
Deprecated.
getDevicePersistentMemorySize() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Deprecated.
getDevicePersistentMemorySize() - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
getDevicePersistentMemorySize() - Method in class org.tensorflow.framework.MemoryStats
Deprecated.
getDevicePersistentMemorySize() - Method in interface org.tensorflow.framework.MemoryStatsOrBuilder
Deprecated.
getDevicePersistentTensorAllocIds(int) - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
getDevicePersistentTensorAllocIds(int) - Method in class org.tensorflow.framework.MemoryStats
Deprecated.
getDevicePersistentTensorAllocIds(int) - Method in interface org.tensorflow.framework.MemoryStatsOrBuilder
Deprecated.
getDevicePersistentTensorAllocIdsCount() - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
getDevicePersistentTensorAllocIdsCount() - Method in class org.tensorflow.framework.MemoryStats
Deprecated.
getDevicePersistentTensorAllocIdsCount() - Method in interface org.tensorflow.framework.MemoryStatsOrBuilder
Deprecated.
getDevicePersistentTensorAllocIdsList() - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
getDevicePersistentTensorAllocIdsList() - Method in class org.tensorflow.framework.MemoryStats
Deprecated.
getDevicePersistentTensorAllocIdsList() - Method in interface org.tensorflow.framework.MemoryStatsOrBuilder
Deprecated.
getDeviceTempMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Deprecated.
getDeviceTempMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node
Deprecated.
getDeviceTempMemorySize() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Deprecated.
getDeviceTempMemorySize() - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
getDeviceTempMemorySize() - Method in class org.tensorflow.framework.MemoryStats
Deprecated.
getDeviceTempMemorySize() - Method in interface org.tensorflow.framework.MemoryStatsOrBuilder
Deprecated.
getDeviceType() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
String representation of device_type.
getDeviceType() - Method in class org.tensorflow.framework.DeviceAttributes
String representation of device_type.
getDeviceType() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
String representation of device_type.
getDeviceType() - Method in class org.tensorflow.framework.KernelDef.Builder
Type of device this kernel runs on.
getDeviceType() - Method in class org.tensorflow.framework.KernelDef
Type of device this kernel runs on.
getDeviceType() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
Type of device this kernel runs on.
getDeviceTypeBytes() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
String representation of device_type.
getDeviceTypeBytes() - Method in class org.tensorflow.framework.DeviceAttributes
String representation of device_type.
getDeviceTypeBytes() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
String representation of device_type.
getDeviceTypeBytes() - Method in class org.tensorflow.framework.KernelDef.Builder
Type of device this kernel runs on.
getDeviceTypeBytes() - Method in class org.tensorflow.framework.KernelDef
Type of device this kernel runs on.
getDeviceTypeBytes() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
Type of device this kernel runs on.
getDevStats(int) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStats(int) - Method in class org.tensorflow.framework.StepStats
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStats(int) - Method in interface org.tensorflow.framework.StepStatsOrBuilder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsBuilder(int) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsBuilderList() - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsCount() - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsCount() - Method in class org.tensorflow.framework.StepStats
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsCount() - Method in interface org.tensorflow.framework.StepStatsOrBuilder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsList() - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsList() - Method in class org.tensorflow.framework.StepStats
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsList() - Method in interface org.tensorflow.framework.StepStatsOrBuilder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsOrBuilder(int) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsOrBuilder(int) - Method in class org.tensorflow.framework.StepStats
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsOrBuilder(int) - Method in interface org.tensorflow.framework.StepStatsOrBuilder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsOrBuilderList() - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsOrBuilderList() - Method in class org.tensorflow.framework.StepStats
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDevStatsOrBuilderList() - Method in interface org.tensorflow.framework.StepStatsOrBuilder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
getDim(int) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDim(int) - Method in class org.tensorflow.framework.TensorShapeProto
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDim(int) - Method in interface org.tensorflow.framework.TensorShapeProtoOrBuilder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimBuilder(int) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimBuilderList() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimCount() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimCount() - Method in class org.tensorflow.framework.TensorShapeProto
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimCount() - Method in interface org.tensorflow.framework.TensorShapeProtoOrBuilder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimList() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimList() - Method in class org.tensorflow.framework.TensorShapeProto
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimList() - Method in interface org.tensorflow.framework.TensorShapeProtoOrBuilder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimOrBuilder(int) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimOrBuilder(int) - Method in class org.tensorflow.framework.TensorShapeProto
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimOrBuilder(int) - Method in interface org.tensorflow.framework.TensorShapeProtoOrBuilder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimOrBuilderList() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimOrBuilderList() - Method in class org.tensorflow.framework.TensorShapeProto
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDimOrBuilderList() - Method in interface org.tensorflow.framework.TensorShapeProtoOrBuilder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
getDisableMetaOptimizer() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Disable the entire meta optimizer (off by default).
getDisableMetaOptimizer() - Method in class org.tensorflow.framework.RewriterConfig
Disable the entire meta optimizer (off by default).
getDisableMetaOptimizer() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Disable the entire meta optimizer (off by default).
getDisableModelPruning() - Method in class org.tensorflow.framework.RewriterConfig.Builder
If true, don't remove unnecessary ops from the graph
getDisableModelPruning() - Method in class org.tensorflow.framework.RewriterConfig
If true, don't remove unnecessary ops from the graph
getDisableModelPruning() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
If true, don't remove unnecessary ops from the graph
getDisplayName() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Display name for viewing in TensorBoard.
getDisplayName() - Method in class org.tensorflow.framework.SummaryMetadata
Display name for viewing in TensorBoard.
getDisplayName() - Method in interface org.tensorflow.framework.SummaryMetadataOrBuilder
Display name for viewing in TensorBoard.
getDisplayNameBytes() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Display name for viewing in TensorBoard.
getDisplayNameBytes() - Method in class org.tensorflow.framework.SummaryMetadata
Display name for viewing in TensorBoard.
getDisplayNameBytes() - Method in interface org.tensorflow.framework.SummaryMetadataOrBuilder
Display name for viewing in TensorBoard.
getDoCommonSubexpressionElimination() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
If true, optimize the graph using common subexpression elimination.
getDoCommonSubexpressionElimination() - Method in class org.tensorflow.framework.OptimizerOptions
If true, optimize the graph using common subexpression elimination.
getDoCommonSubexpressionElimination() - Method in interface org.tensorflow.framework.OptimizerOptionsOrBuilder
If true, optimize the graph using common subexpression elimination.
getDoConstantFolding() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
If true, perform constant folding optimization on the graph.
getDoConstantFolding() - Method in class org.tensorflow.framework.OptimizerOptions
If true, perform constant folding optimization on the graph.
getDoConstantFolding() - Method in interface org.tensorflow.framework.OptimizerOptionsOrBuilder
If true, perform constant folding optimization on the graph.
getDoFunctionInlining() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
If true, perform function inlining on the graph.
getDoFunctionInlining() - Method in class org.tensorflow.framework.OptimizerOptions
If true, perform function inlining on the graph.
getDoFunctionInlining() - Method in interface org.tensorflow.framework.OptimizerOptionsOrBuilder
If true, perform function inlining on the graph.
getDoubleVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_DOUBLE.
getDoubleVal(int) - Method in class org.tensorflow.framework.TensorProto
DT_DOUBLE.
getDoubleVal(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_DOUBLE.
getDoubleValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_DOUBLE.
getDoubleValCount() - Method in class org.tensorflow.framework.TensorProto
DT_DOUBLE.
getDoubleValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_DOUBLE.
getDoubleValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_DOUBLE.
getDoubleValList() - Method in class org.tensorflow.framework.TensorProto
DT_DOUBLE.
getDoubleValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_DOUBLE.
getDoubleValue() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
double double_value = 1;
getDoubleValue() - Method in class org.tensorflow.util.testlog.EntryValue
double double_value = 1;
getDoubleValue() - Method in interface org.tensorflow.util.testlog.EntryValueOrBuilder
double double_value = 1;
getDtype() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.DataType dtype = 1;
getDtype() - Method in class org.tensorflow.example.FixedLenFeatureProto
.tensorflow.DataType dtype = 1;
getDtype() - Method in interface org.tensorflow.example.FixedLenFeatureProtoOrBuilder
.tensorflow.DataType dtype = 1;
getDtype() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
.tensorflow.DataType dtype = 1;
getDtype() - Method in class org.tensorflow.example.VarLenFeatureProto
.tensorflow.DataType dtype = 1;
getDtype() - Method in interface org.tensorflow.example.VarLenFeatureProtoOrBuilder
.tensorflow.DataType dtype = 1;
getDtype() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.DataType dtype = 4;
getDtype() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
.tensorflow.DataType dtype = 4;
getDtype() - Method in interface org.tensorflow.framework.CostGraphDef.Node.OutputInfoOrBuilder
.tensorflow.DataType dtype = 4;
getDtype() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
.tensorflow.DataType dtype = 5;
getDtype() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
.tensorflow.DataType dtype = 5;
getDtype() - Method in interface org.tensorflow.framework.GraphTransferConstNodeInfoOrBuilder
.tensorflow.DataType dtype = 5;
getDtype() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
.tensorflow.DataType dtype = 3;
getDtype() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
.tensorflow.DataType dtype = 3;
getDtype() - Method in interface org.tensorflow.framework.GraphTransferGraphInputNodeInfoOrBuilder
.tensorflow.DataType dtype = 3;
getDtype() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
.tensorflow.DataType dtype = 3;
getDtype() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
.tensorflow.DataType dtype = 3;
getDtype() - Method in interface org.tensorflow.framework.GraphTransferGraphOutputNodeInfoOrBuilder
.tensorflow.DataType dtype = 3;
getDtype() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.DataType dtype = 1;
getDtype() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
.tensorflow.DataType dtype = 1;
getDtype() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProtoOrBuilder
.tensorflow.DataType dtype = 1;
getDtype() - Method in class org.tensorflow.framework.TensorDescription.Builder
Data type of tensor elements
getDtype() - Method in class org.tensorflow.framework.TensorDescription
Data type of tensor elements
getDtype() - Method in interface org.tensorflow.framework.TensorDescriptionOrBuilder
Data type of tensor elements
getDtype() - Method in class org.tensorflow.framework.TensorInfo.Builder
.tensorflow.DataType dtype = 2;
getDtype() - Method in class org.tensorflow.framework.TensorInfo
.tensorflow.DataType dtype = 2;
getDtype() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
.tensorflow.DataType dtype = 2;
getDtype() - Method in class org.tensorflow.framework.TensorProto.Builder
.tensorflow.DataType dtype = 1;
getDtype() - Method in class org.tensorflow.framework.TensorProto
.tensorflow.DataType dtype = 1;
getDtype() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
.tensorflow.DataType dtype = 1;
getDtype() - Method in class org.tensorflow.util.BundleEntryProto.Builder
The tensor dtype and shape.
getDtype() - Method in class org.tensorflow.util.BundleEntryProto
The tensor dtype and shape.
getDtype() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
The tensor dtype and shape.
getDtypeValue() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in class org.tensorflow.example.FixedLenFeatureProto
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in interface org.tensorflow.example.FixedLenFeatureProtoOrBuilder
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in class org.tensorflow.example.VarLenFeatureProto
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in interface org.tensorflow.example.VarLenFeatureProtoOrBuilder
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.DataType dtype = 4;
getDtypeValue() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
.tensorflow.DataType dtype = 4;
getDtypeValue() - Method in interface org.tensorflow.framework.CostGraphDef.Node.OutputInfoOrBuilder
.tensorflow.DataType dtype = 4;
getDtypeValue() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
.tensorflow.DataType dtype = 5;
getDtypeValue() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
.tensorflow.DataType dtype = 5;
getDtypeValue() - Method in interface org.tensorflow.framework.GraphTransferConstNodeInfoOrBuilder
.tensorflow.DataType dtype = 5;
getDtypeValue() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
.tensorflow.DataType dtype = 3;
getDtypeValue() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
.tensorflow.DataType dtype = 3;
getDtypeValue() - Method in interface org.tensorflow.framework.GraphTransferGraphInputNodeInfoOrBuilder
.tensorflow.DataType dtype = 3;
getDtypeValue() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
.tensorflow.DataType dtype = 3;
getDtypeValue() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
.tensorflow.DataType dtype = 3;
getDtypeValue() - Method in interface org.tensorflow.framework.GraphTransferGraphOutputNodeInfoOrBuilder
.tensorflow.DataType dtype = 3;
getDtypeValue() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProtoOrBuilder
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in class org.tensorflow.framework.TensorDescription.Builder
Data type of tensor elements
getDtypeValue() - Method in class org.tensorflow.framework.TensorDescription
Data type of tensor elements
getDtypeValue() - Method in interface org.tensorflow.framework.TensorDescriptionOrBuilder
Data type of tensor elements
getDtypeValue() - Method in class org.tensorflow.framework.TensorInfo.Builder
.tensorflow.DataType dtype = 2;
getDtypeValue() - Method in class org.tensorflow.framework.TensorInfo
.tensorflow.DataType dtype = 2;
getDtypeValue() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
.tensorflow.DataType dtype = 2;
getDtypeValue() - Method in class org.tensorflow.framework.TensorProto.Builder
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in class org.tensorflow.framework.TensorProto
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
.tensorflow.DataType dtype = 1;
getDtypeValue() - Method in class org.tensorflow.util.BundleEntryProto.Builder
The tensor dtype and shape.
getDtypeValue() - Method in class org.tensorflow.util.BundleEntryProto
The tensor dtype and shape.
getDtypeValue() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
The tensor dtype and shape.
getElement(int) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElement(int) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElement(int) - Method in interface tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryOrBuilder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementBuilder(int) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementBuilderList() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementCount() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementCount() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementCount() - Method in interface tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryOrBuilder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementList() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementList() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementList() - Method in interface tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryOrBuilder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementOrBuilder(int) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementOrBuilder(int) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementOrBuilder(int) - Method in interface tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryOrBuilder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementOrBuilderList() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementOrBuilderList() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getElementOrBuilderList() - Method in interface tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryOrBuilder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
getEnable() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
bool enable = 1;
getEnable() - Method in class org.tensorflow.framework.AutoParallelOptions
bool enable = 1;
getEnable() - Method in interface org.tensorflow.framework.AutoParallelOptionsOrBuilder
bool enable = 1;
getEnableBfloat16Sendrecv() - Method in class org.tensorflow.framework.GraphOptions.Builder
If true, transfer float values between processes as bfloat16.
getEnableBfloat16Sendrecv() - Method in class org.tensorflow.framework.GraphOptions
If true, transfer float values between processes as bfloat16.
getEnableBfloat16Sendrecv() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
If true, transfer float values between processes as bfloat16.
getEnableOp(int) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
If present, only perform optimization for these ops.
getEnableOp(int) - Method in class org.tensorflow.framework.ScopedAllocatorOptions
If present, only perform optimization for these ops.
getEnableOp(int) - Method in interface org.tensorflow.framework.ScopedAllocatorOptionsOrBuilder
If present, only perform optimization for these ops.
getEnableOpBytes(int) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
If present, only perform optimization for these ops.
getEnableOpBytes(int) - Method in class org.tensorflow.framework.ScopedAllocatorOptions
If present, only perform optimization for these ops.
getEnableOpBytes(int) - Method in interface org.tensorflow.framework.ScopedAllocatorOptionsOrBuilder
If present, only perform optimization for these ops.
getEnableOpCount() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
If present, only perform optimization for these ops.
getEnableOpCount() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
If present, only perform optimization for these ops.
getEnableOpCount() - Method in interface org.tensorflow.framework.ScopedAllocatorOptionsOrBuilder
If present, only perform optimization for these ops.
getEnableOpList() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
If present, only perform optimization for these ops.
getEnableOpList() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
If present, only perform optimization for these ops.
getEnableOpList() - Method in interface org.tensorflow.framework.ScopedAllocatorOptionsOrBuilder
If present, only perform optimization for these ops.
getEnableRecvScheduling() - Method in class org.tensorflow.framework.GraphOptions.Builder
If true, use control flow to schedule the activation of Recv nodes.
getEnableRecvScheduling() - Method in class org.tensorflow.framework.GraphOptions
If true, use control flow to schedule the activation of Recv nodes.
getEnableRecvScheduling() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
If true, use control flow to schedule the activation of Recv nodes.
getEncodedAudioString() - Method in class org.tensorflow.framework.Summary.Audio.Builder
Encoded audio data and its associated RFC 2045 content type (e.g.
getEncodedAudioString() - Method in class org.tensorflow.framework.Summary.Audio
Encoded audio data and its associated RFC 2045 content type (e.g.
getEncodedAudioString() - Method in interface org.tensorflow.framework.Summary.AudioOrBuilder
Encoded audio data and its associated RFC 2045 content type (e.g.
getEncodedImageString() - Method in class org.tensorflow.framework.Summary.Image.Builder
Image data in encoded format.
getEncodedImageString() - Method in class org.tensorflow.framework.Summary.Image
Image data in encoded format.
getEncodedImageString() - Method in interface org.tensorflow.framework.Summary.ImageOrBuilder
Image data in encoded format.
getEncodingCase() - Method in class org.tensorflow.framework.TensorInfo.Builder
 
getEncodingCase() - Method in class org.tensorflow.framework.TensorInfo
 
getEncodingCase() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
 
getEndianness() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
.tensorflow.BundleHeaderProto.Endianness endianness = 2;
getEndianness() - Method in class org.tensorflow.util.BundleHeaderProto
.tensorflow.BundleHeaderProto.Endianness endianness = 2;
getEndianness() - Method in interface org.tensorflow.util.BundleHeaderProtoOrBuilder
.tensorflow.BundleHeaderProto.Endianness endianness = 2;
getEndiannessValue() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
.tensorflow.BundleHeaderProto.Endianness endianness = 2;
getEndiannessValue() - Method in class org.tensorflow.util.BundleHeaderProto
.tensorflow.BundleHeaderProto.Endianness endianness = 2;
getEndiannessValue() - Method in interface org.tensorflow.util.BundleHeaderProtoOrBuilder
.tensorflow.BundleHeaderProto.Endianness endianness = 2;
getEndpoint(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpoint(int) - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpoint(int) - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointBuilderList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointCount() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointCount() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointCount() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointList() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointList() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointOrBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointOrBuilder(int) - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointOrBuilder(int) - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointOrBuilderList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointOrBuilderList() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEndpointOrBuilderList() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
getEnqueueOpName(int) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of enqueue operations.
getEnqueueOpName(int) - Method in class org.tensorflow.framework.QueueRunnerDef
A list of enqueue operations.
getEnqueueOpName(int) - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
A list of enqueue operations.
getEnqueueOpNameBytes(int) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of enqueue operations.
getEnqueueOpNameBytes(int) - Method in class org.tensorflow.framework.QueueRunnerDef
A list of enqueue operations.
getEnqueueOpNameBytes(int) - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
A list of enqueue operations.
getEnqueueOpNameCount() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of enqueue operations.
getEnqueueOpNameCount() - Method in class org.tensorflow.framework.QueueRunnerDef
A list of enqueue operations.
getEnqueueOpNameCount() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
A list of enqueue operations.
getEnqueueOpNameList() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of enqueue operations.
getEnqueueOpNameList() - Method in class org.tensorflow.framework.QueueRunnerDef
A list of enqueue operations.
getEnqueueOpNameList() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
A list of enqueue operations.
getEntries() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The list of tests or benchmarks in this run.
getEntries() - Method in class org.tensorflow.util.testlog.TestResults
The list of tests or benchmarks in this run.
getEntries() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The list of tests or benchmarks in this run.
getEntriesBuilder() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The list of tests or benchmarks in this run.
getEntriesOrBuilder() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The list of tests or benchmarks in this run.
getEntriesOrBuilder() - Method in class org.tensorflow.util.testlog.TestResults
The list of tests or benchmarks in this run.
getEntriesOrBuilder() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The list of tests or benchmarks in this run.
getEntry(int) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntry(int) - Method in class org.tensorflow.util.testlog.BenchmarkEntries
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntry(int) - Method in interface org.tensorflow.util.testlog.BenchmarkEntriesOrBuilder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryBuilder(int) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryBuilderList() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryCount() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryCount() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryCount() - Method in interface org.tensorflow.util.testlog.BenchmarkEntriesOrBuilder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryList() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryList() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryList() - Method in interface org.tensorflow.util.testlog.BenchmarkEntriesOrBuilder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryOrBuilder(int) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryOrBuilder(int) - Method in class org.tensorflow.util.testlog.BenchmarkEntries
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryOrBuilder(int) - Method in interface org.tensorflow.util.testlog.BenchmarkEntriesOrBuilder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryOrBuilderList() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryOrBuilderList() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
repeated .tensorflow.BenchmarkEntry entry = 1;
getEntryOrBuilderList() - Method in interface org.tensorflow.util.testlog.BenchmarkEntriesOrBuilder
repeated .tensorflow.BenchmarkEntry entry = 1;
getEnvironment() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Deprecated.
getEnvironment() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Deprecated.
getEnvironment() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Deprecated.
getEnvironmentCount() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
getEnvironmentCount() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
getEnvironmentCount() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Version of the tools and libraries used with this device (e.g.
getEnvironmentMap() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Version of the tools and libraries used with this device (e.g.
getEnvironmentMap() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Version of the tools and libraries used with this device (e.g.
getEnvironmentMap() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Version of the tools and libraries used with this device (e.g.
getEnvironmentOrDefault(String, String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Version of the tools and libraries used with this device (e.g.
getEnvironmentOrDefault(String, String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Version of the tools and libraries used with this device (e.g.
getEnvironmentOrDefault(String, String) - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Version of the tools and libraries used with this device (e.g.
getEnvironmentOrThrow(String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Version of the tools and libraries used with this device (e.g.
getEnvironmentOrThrow(String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Version of the tools and libraries used with this device (e.g.
getEnvironmentOrThrow(String) - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Version of the tools and libraries used with this device (e.g.
getExecutorName() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Executor's name
getExecutorName() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Executor's name
getExecutorName() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Executor's name
getExecutorNameBytes() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Executor's name
getExecutorNameBytes() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Executor's name
getExecutorNameBytes() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Executor's name
getExecutorType() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Which executor to use, the default executor will be used if it is an empty string or "DEFAULT"
getExecutorType() - Method in class org.tensorflow.framework.ConfigProto.Experimental
Which executor to use, the default executor will be used if it is an empty string or "DEFAULT"
getExecutorType() - Method in interface org.tensorflow.framework.ConfigProto.ExperimentalOrBuilder
Which executor to use, the default executor will be used if it is an empty string or "DEFAULT"
getExecutorTypeBytes() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Which executor to use, the default executor will be used if it is an empty string or "DEFAULT"
getExecutorTypeBytes() - Method in class org.tensorflow.framework.ConfigProto.Experimental
Which executor to use, the default executor will be used if it is an empty string or "DEFAULT"
getExecutorTypeBytes() - Method in interface org.tensorflow.framework.ConfigProto.ExperimentalOrBuilder
Which executor to use, the default executor will be used if it is an empty string or "DEFAULT"
getExperimental() - Method in class org.tensorflow.framework.ConfigProto.Builder
.tensorflow.ConfigProto.Experimental experimental = 16;
getExperimental() - Method in class org.tensorflow.framework.ConfigProto
.tensorflow.ConfigProto.Experimental experimental = 16;
getExperimental() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
.tensorflow.ConfigProto.Experimental experimental = 16;
getExperimental() - Method in class org.tensorflow.framework.GPUOptions.Builder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
getExperimental() - Method in class org.tensorflow.framework.GPUOptions
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
getExperimental() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
getExperimental() - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.Experimental experimental = 8;
getExperimental() - Method in class org.tensorflow.framework.RunOptions
.tensorflow.RunOptions.Experimental experimental = 8;
getExperimental() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
.tensorflow.RunOptions.Experimental experimental = 8;
getExperimentalBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
.tensorflow.ConfigProto.Experimental experimental = 16;
getExperimentalBuilder() - Method in class org.tensorflow.framework.GPUOptions.Builder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
getExperimentalBuilder() - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.Experimental experimental = 8;
getExperimentalDebugInfo() - Method in class org.tensorflow.framework.NodeDef.Builder
This stores debug information associated with the node.
getExperimentalDebugInfo() - Method in class org.tensorflow.framework.NodeDef
This stores debug information associated with the node.
getExperimentalDebugInfo() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
This stores debug information associated with the node.
getExperimentalDebugInfoBuilder() - Method in class org.tensorflow.framework.NodeDef.Builder
This stores debug information associated with the node.
getExperimentalDebugInfoOrBuilder() - Method in class org.tensorflow.framework.NodeDef.Builder
This stores debug information associated with the node.
getExperimentalDebugInfoOrBuilder() - Method in class org.tensorflow.framework.NodeDef
This stores debug information associated with the node.
getExperimentalDebugInfoOrBuilder() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
This stores debug information associated with the node.
getExperimentalOrBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
.tensorflow.ConfigProto.Experimental experimental = 16;
getExperimentalOrBuilder() - Method in class org.tensorflow.framework.ConfigProto
.tensorflow.ConfigProto.Experimental experimental = 16;
getExperimentalOrBuilder() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
.tensorflow.ConfigProto.Experimental experimental = 16;
getExperimentalOrBuilder() - Method in class org.tensorflow.framework.GPUOptions.Builder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
getExperimentalOrBuilder() - Method in class org.tensorflow.framework.GPUOptions
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
getExperimentalOrBuilder() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
getExperimentalOrBuilder() - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.Experimental experimental = 8;
getExperimentalOrBuilder() - Method in class org.tensorflow.framework.RunOptions
.tensorflow.RunOptions.Experimental experimental = 8;
getExperimentalOrBuilder() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
.tensorflow.RunOptions.Experimental experimental = 8;
getExplanation() - Method in class org.tensorflow.framework.OpDeprecation.Builder
Explanation of why it was deprecated and what to use instead.
getExplanation() - Method in class org.tensorflow.framework.OpDeprecation
Explanation of why it was deprecated and what to use instead.
getExplanation() - Method in interface org.tensorflow.framework.OpDeprecationOrBuilder
Explanation of why it was deprecated and what to use instead.
getExplanationBytes() - Method in class org.tensorflow.framework.OpDeprecation.Builder
Explanation of why it was deprecated and what to use instead.
getExplanationBytes() - Method in class org.tensorflow.framework.OpDeprecation
Explanation of why it was deprecated and what to use instead.
getExplanationBytes() - Method in interface org.tensorflow.framework.OpDeprecationOrBuilder
Explanation of why it was deprecated and what to use instead.
getExtent(int) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
getExtent(int) - Method in class org.tensorflow.framework.TensorSliceProto
Extent of the slice in all tensor dimensions.
getExtent(int) - Method in interface org.tensorflow.framework.TensorSliceProtoOrBuilder
Extent of the slice in all tensor dimensions.
getExtentBuilder(int) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
getExtentBuilderList() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
getExtentCount() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
getExtentCount() - Method in class org.tensorflow.framework.TensorSliceProto
Extent of the slice in all tensor dimensions.
getExtentCount() - Method in interface org.tensorflow.framework.TensorSliceProtoOrBuilder
Extent of the slice in all tensor dimensions.
getExtentList() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
getExtentList() - Method in class org.tensorflow.framework.TensorSliceProto
Extent of the slice in all tensor dimensions.
getExtentList() - Method in interface org.tensorflow.framework.TensorSliceProtoOrBuilder
Extent of the slice in all tensor dimensions.
getExtentOrBuilder(int) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
getExtentOrBuilder(int) - Method in class org.tensorflow.framework.TensorSliceProto
Extent of the slice in all tensor dimensions.
getExtentOrBuilder(int) - Method in interface org.tensorflow.framework.TensorSliceProtoOrBuilder
Extent of the slice in all tensor dimensions.
getExtentOrBuilderList() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
getExtentOrBuilderList() - Method in class org.tensorflow.framework.TensorSliceProto
Extent of the slice in all tensor dimensions.
getExtentOrBuilderList() - Method in interface org.tensorflow.framework.TensorSliceProtoOrBuilder
Extent of the slice in all tensor dimensions.
getExternalValues() - Method in class org.tensorflow.framework.ValuesDef.Builder
Deprecated.
getExternalValues() - Method in class org.tensorflow.framework.ValuesDef
Deprecated.
getExternalValues() - Method in interface org.tensorflow.framework.ValuesDefOrBuilder
Deprecated.
getExternalValuesCount() - Method in class org.tensorflow.framework.ValuesDef.Builder
 
getExternalValuesCount() - Method in class org.tensorflow.framework.ValuesDef
 
getExternalValuesCount() - Method in interface org.tensorflow.framework.ValuesDefOrBuilder
Value names referenced by but external to this context.
getExternalValuesMap() - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names referenced by but external to this context.
getExternalValuesMap() - Method in class org.tensorflow.framework.ValuesDef
Value names referenced by but external to this context.
getExternalValuesMap() - Method in interface org.tensorflow.framework.ValuesDefOrBuilder
Value names referenced by but external to this context.
getExternalValuesOrDefault(String, String) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names referenced by but external to this context.
getExternalValuesOrDefault(String, String) - Method in class org.tensorflow.framework.ValuesDef
Value names referenced by but external to this context.
getExternalValuesOrDefault(String, String) - Method in interface org.tensorflow.framework.ValuesDefOrBuilder
Value names referenced by but external to this context.
getExternalValuesOrThrow(String) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names referenced by but external to this context.
getExternalValuesOrThrow(String) - Method in class org.tensorflow.framework.ValuesDef
Value names referenced by but external to this context.
getExternalValuesOrThrow(String) - Method in interface org.tensorflow.framework.ValuesDefOrBuilder
Value names referenced by but external to this context.
getExtras() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Deprecated.
getExtras() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
Deprecated.
getExtras() - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
Deprecated.
getExtrasCount() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
getExtrasCount() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
getExtrasCount() - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
Generic map from result key to value.
getExtrasMap() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Generic map from result key to value.
getExtrasMap() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
Generic map from result key to value.
getExtrasMap() - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
Generic map from result key to value.
getExtrasOrDefault(String, EntryValue) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Generic map from result key to value.
getExtrasOrDefault(String, EntryValue) - Method in class org.tensorflow.util.testlog.BenchmarkEntry
Generic map from result key to value.
getExtrasOrDefault(String, EntryValue) - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
Generic map from result key to value.
getExtrasOrThrow(String) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Generic map from result key to value.
getExtrasOrThrow(String) - Method in class org.tensorflow.util.testlog.BenchmarkEntry
Generic map from result key to value.
getExtrasOrThrow(String) - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
Generic map from result key to value.
getF() - Method in class org.tensorflow.framework.AttrValue.Builder
"float"
getF() - Method in class org.tensorflow.framework.AttrValue
"float"
getF(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(float)"
getF(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(float)"
getF(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(float)"
getF() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"float"
getFailOnOptimizerErrors() - Method in class org.tensorflow.framework.RewriterConfig.Builder
If true, any optimization pass failing will cause the MetaOptimizer to stop with an error.
getFailOnOptimizerErrors() - Method in class org.tensorflow.framework.RewriterConfig
If true, any optimization pass failing will cause the MetaOptimizer to stop with an error.
getFailOnOptimizerErrors() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
If true, any optimization pass failing will cause the MetaOptimizer to stop with an error.
getFCount() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(float)"
getFCount() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(float)"
getFCount() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(float)"
getFeature(int) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
getFeature(int) - Method in class org.tensorflow.example.FeatureList
repeated .tensorflow.Feature feature = 1;
getFeature(int) - Method in interface org.tensorflow.example.FeatureListOrBuilder
repeated .tensorflow.Feature feature = 1;
getFeature() - Method in class org.tensorflow.example.Features.Builder
Deprecated.
getFeature() - Method in class org.tensorflow.example.Features
Deprecated.
getFeature() - Method in interface org.tensorflow.example.FeaturesOrBuilder
Deprecated.
getFeatureBuilder(int) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
getFeatureBuilderList() - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
getFeatureCount() - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
getFeatureCount() - Method in class org.tensorflow.example.FeatureList
repeated .tensorflow.Feature feature = 1;
getFeatureCount() - Method in interface org.tensorflow.example.FeatureListOrBuilder
repeated .tensorflow.Feature feature = 1;
getFeatureCount() - Method in class org.tensorflow.example.Features.Builder
 
getFeatureCount() - Method in class org.tensorflow.example.Features
 
getFeatureCount() - Method in interface org.tensorflow.example.FeaturesOrBuilder
Map from feature name to feature.
getFeatureList() - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
getFeatureList() - Method in class org.tensorflow.example.FeatureList
repeated .tensorflow.Feature feature = 1;
getFeatureList() - Method in interface org.tensorflow.example.FeatureListOrBuilder
repeated .tensorflow.Feature feature = 1;
getFeatureList() - Method in class org.tensorflow.example.FeatureLists.Builder
Deprecated.
getFeatureList() - Method in class org.tensorflow.example.FeatureLists
Deprecated.
getFeatureList() - Method in interface org.tensorflow.example.FeatureListsOrBuilder
Deprecated.
getFeatureListCount() - Method in class org.tensorflow.example.FeatureLists.Builder
 
getFeatureListCount() - Method in class org.tensorflow.example.FeatureLists
 
getFeatureListCount() - Method in interface org.tensorflow.example.FeatureListsOrBuilder
Map from feature name to feature list.
getFeatureListMap() - Method in class org.tensorflow.example.FeatureLists.Builder
Map from feature name to feature list.
getFeatureListMap() - Method in class org.tensorflow.example.FeatureLists
Map from feature name to feature list.
getFeatureListMap() - Method in interface org.tensorflow.example.FeatureListsOrBuilder
Map from feature name to feature list.
getFeatureListOrDefault(String, FeatureList) - Method in class org.tensorflow.example.FeatureLists.Builder
Map from feature name to feature list.
getFeatureListOrDefault(String, FeatureList) - Method in class org.tensorflow.example.FeatureLists
Map from feature name to feature list.
getFeatureListOrDefault(String, FeatureList) - Method in interface org.tensorflow.example.FeatureListsOrBuilder
Map from feature name to feature list.
getFeatureListOrThrow(String) - Method in class org.tensorflow.example.FeatureLists.Builder
Map from feature name to feature list.
getFeatureListOrThrow(String) - Method in class org.tensorflow.example.FeatureLists
Map from feature name to feature list.
getFeatureListOrThrow(String) - Method in interface org.tensorflow.example.FeatureListsOrBuilder
Map from feature name to feature list.
getFeatureLists() - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.FeatureLists feature_lists = 2;
getFeatureLists() - Method in class org.tensorflow.example.SequenceExample
.tensorflow.FeatureLists feature_lists = 2;
getFeatureLists() - Method in interface org.tensorflow.example.SequenceExampleOrBuilder
.tensorflow.FeatureLists feature_lists = 2;
getFeatureListsBuilder() - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.FeatureLists feature_lists = 2;
getFeatureListsOrBuilder() - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.FeatureLists feature_lists = 2;
getFeatureListsOrBuilder() - Method in class org.tensorflow.example.SequenceExample
.tensorflow.FeatureLists feature_lists = 2;
getFeatureListsOrBuilder() - Method in interface org.tensorflow.example.SequenceExampleOrBuilder
.tensorflow.FeatureLists feature_lists = 2;
getFeatureMap() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
Deprecated.
getFeatureMap() - Method in class org.tensorflow.example.ExampleParserConfiguration
Deprecated.
getFeatureMap() - Method in interface org.tensorflow.example.ExampleParserConfigurationOrBuilder
Deprecated.
getFeatureMap() - Method in class org.tensorflow.example.Features.Builder
Map from feature name to feature.
getFeatureMap() - Method in class org.tensorflow.example.Features
Map from feature name to feature.
getFeatureMap() - Method in interface org.tensorflow.example.FeaturesOrBuilder
Map from feature name to feature.
getFeatureMapCount() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
getFeatureMapCount() - Method in class org.tensorflow.example.ExampleParserConfiguration
 
getFeatureMapCount() - Method in interface org.tensorflow.example.ExampleParserConfigurationOrBuilder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
getFeatureMapMap() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
getFeatureMapMap() - Method in class org.tensorflow.example.ExampleParserConfiguration
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
getFeatureMapMap() - Method in interface org.tensorflow.example.ExampleParserConfigurationOrBuilder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
getFeatureMapOrDefault(String, FeatureConfiguration) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
getFeatureMapOrDefault(String, FeatureConfiguration) - Method in class org.tensorflow.example.ExampleParserConfiguration
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
getFeatureMapOrDefault(String, FeatureConfiguration) - Method in interface org.tensorflow.example.ExampleParserConfigurationOrBuilder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
getFeatureMapOrThrow(String) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
getFeatureMapOrThrow(String) - Method in class org.tensorflow.example.ExampleParserConfiguration
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
getFeatureMapOrThrow(String) - Method in interface org.tensorflow.example.ExampleParserConfigurationOrBuilder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
getFeatureOrBuilder(int) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
getFeatureOrBuilder(int) - Method in class org.tensorflow.example.FeatureList
repeated .tensorflow.Feature feature = 1;
getFeatureOrBuilder(int) - Method in interface org.tensorflow.example.FeatureListOrBuilder
repeated .tensorflow.Feature feature = 1;
getFeatureOrBuilderList() - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
getFeatureOrBuilderList() - Method in class org.tensorflow.example.FeatureList
repeated .tensorflow.Feature feature = 1;
getFeatureOrBuilderList() - Method in interface org.tensorflow.example.FeatureListOrBuilder
repeated .tensorflow.Feature feature = 1;
getFeatureOrDefault(String, Feature) - Method in class org.tensorflow.example.Features.Builder
Map from feature name to feature.
getFeatureOrDefault(String, Feature) - Method in class org.tensorflow.example.Features
Map from feature name to feature.
getFeatureOrDefault(String, Feature) - Method in interface org.tensorflow.example.FeaturesOrBuilder
Map from feature name to feature.
getFeatureOrThrow(String) - Method in class org.tensorflow.example.Features.Builder
Map from feature name to feature.
getFeatureOrThrow(String) - Method in class org.tensorflow.example.Features
Map from feature name to feature.
getFeatureOrThrow(String) - Method in interface org.tensorflow.example.FeaturesOrBuilder
Map from feature name to feature.
getFeatures() - Method in class org.tensorflow.example.Example.Builder
.tensorflow.Features features = 1;
getFeatures() - Method in class org.tensorflow.example.Example
.tensorflow.Features features = 1;
getFeatures() - Method in interface org.tensorflow.example.ExampleOrBuilder
.tensorflow.Features features = 1;
getFeaturesBuilder() - Method in class org.tensorflow.example.Example.Builder
.tensorflow.Features features = 1;
getFeaturesOrBuilder() - Method in class org.tensorflow.example.Example.Builder
.tensorflow.Features features = 1;
getFeaturesOrBuilder() - Method in class org.tensorflow.example.Example
.tensorflow.Features features = 1;
getFeaturesOrBuilder() - Method in interface org.tensorflow.example.ExampleOrBuilder
.tensorflow.Features features = 1;
getFeed(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be fed in the callable.
getFeed(int) - Method in class org.tensorflow.framework.CallableOptions
Tensors to be fed in the callable.
getFeed(int) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Tensors to be fed in the callable.
getFeedBytes(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be fed in the callable.
getFeedBytes(int) - Method in class org.tensorflow.framework.CallableOptions
Tensors to be fed in the callable.
getFeedBytes(int) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Tensors to be fed in the callable.
getFeedCount() - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be fed in the callable.
getFeedCount() - Method in class org.tensorflow.framework.CallableOptions
Tensors to be fed in the callable.
getFeedCount() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Tensors to be fed in the callable.
getFeedDevices() - Method in class org.tensorflow.framework.CallableOptions.Builder
Deprecated.
getFeedDevices() - Method in class org.tensorflow.framework.CallableOptions
Deprecated.
getFeedDevices() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Deprecated.
getFeedDevicesCount() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
getFeedDevicesCount() - Method in class org.tensorflow.framework.CallableOptions
 
getFeedDevicesCount() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
getFeedDevicesMap() - Method in class org.tensorflow.framework.CallableOptions.Builder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
getFeedDevicesMap() - Method in class org.tensorflow.framework.CallableOptions
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
getFeedDevicesMap() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
getFeedDevicesOrDefault(String, String) - Method in class org.tensorflow.framework.CallableOptions.Builder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
getFeedDevicesOrDefault(String, String) - Method in class org.tensorflow.framework.CallableOptions
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
getFeedDevicesOrDefault(String, String) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
getFeedDevicesOrThrow(String) - Method in class org.tensorflow.framework.CallableOptions.Builder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
getFeedDevicesOrThrow(String) - Method in class org.tensorflow.framework.CallableOptions
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
getFeedDevicesOrThrow(String) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
getFeedList() - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be fed in the callable.
getFeedList() - Method in class org.tensorflow.framework.CallableOptions
Tensors to be fed in the callable.
getFeedList() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Tensors to be fed in the callable.
getFetch(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Fetches.
getFetch(int) - Method in class org.tensorflow.framework.CallableOptions
Fetches.
getFetch(int) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Fetches.
getFetchBytes(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Fetches.
getFetchBytes(int) - Method in class org.tensorflow.framework.CallableOptions
Fetches.
getFetchBytes(int) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Fetches.
getFetchCount() - Method in class org.tensorflow.framework.CallableOptions.Builder
Fetches.
getFetchCount() - Method in class org.tensorflow.framework.CallableOptions
Fetches.
getFetchCount() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Fetches.
getFetchDevices() - Method in class org.tensorflow.framework.CallableOptions.Builder
Deprecated.
getFetchDevices() - Method in class org.tensorflow.framework.CallableOptions
Deprecated.
getFetchDevices() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Deprecated.
getFetchDevicesCount() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
getFetchDevicesCount() - Method in class org.tensorflow.framework.CallableOptions
 
getFetchDevicesCount() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
map<string, string> fetch_devices = 7;
getFetchDevicesMap() - Method in class org.tensorflow.framework.CallableOptions.Builder
map<string, string> fetch_devices = 7;
getFetchDevicesMap() - Method in class org.tensorflow.framework.CallableOptions
map<string, string> fetch_devices = 7;
getFetchDevicesMap() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
map<string, string> fetch_devices = 7;
getFetchDevicesOrDefault(String, String) - Method in class org.tensorflow.framework.CallableOptions.Builder
map<string, string> fetch_devices = 7;
getFetchDevicesOrDefault(String, String) - Method in class org.tensorflow.framework.CallableOptions
map<string, string> fetch_devices = 7;
getFetchDevicesOrDefault(String, String) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
map<string, string> fetch_devices = 7;
getFetchDevicesOrThrow(String) - Method in class org.tensorflow.framework.CallableOptions.Builder
map<string, string> fetch_devices = 7;
getFetchDevicesOrThrow(String) - Method in class org.tensorflow.framework.CallableOptions
map<string, string> fetch_devices = 7;
getFetchDevicesOrThrow(String) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
map<string, string> fetch_devices = 7;
getFetchList() - Method in class org.tensorflow.framework.CallableOptions.Builder
Fetches.
getFetchList() - Method in class org.tensorflow.framework.CallableOptions
Fetches.
getFetchList() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Fetches.
getFetchSkipSync() - Method in class org.tensorflow.framework.CallableOptions.Builder
By default, RunCallable() will synchronize the GPU stream before returning fetched tensors on a GPU device, to ensure that the values in those tensors have been produced.
getFetchSkipSync() - Method in class org.tensorflow.framework.CallableOptions
By default, RunCallable() will synchronize the GPU stream before returning fetched tensors on a GPU device, to ensure that the values in those tensors have been produced.
getFetchSkipSync() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
By default, RunCallable() will synchronize the GPU stream before returning fetched tensors on a GPU device, to ensure that the values in those tensors have been produced.
getFilename() - Method in class org.tensorflow.framework.AssetFileDef.Builder
The filename within an assets directory.
getFilename() - Method in class org.tensorflow.framework.AssetFileDef
The filename within an assets directory.
getFilename() - Method in interface org.tensorflow.framework.AssetFileDefOrBuilder
The filename within an assets directory.
getFilenameBytes() - Method in class org.tensorflow.framework.AssetFileDef.Builder
The filename within an assets directory.
getFilenameBytes() - Method in class org.tensorflow.framework.AssetFileDef
The filename within an assets directory.
getFilenameBytes() - Method in interface org.tensorflow.framework.AssetFileDefOrBuilder
The filename within an assets directory.
getFilenameTensorName() - Method in class org.tensorflow.util.SaverDef.Builder
The name of the tensor in which to specify the filename when saving or restoring a model checkpoint.
getFilenameTensorName() - Method in class org.tensorflow.util.SaverDef
The name of the tensor in which to specify the filename when saving or restoring a model checkpoint.
getFilenameTensorName() - Method in interface org.tensorflow.util.SaverDefOrBuilder
The name of the tensor in which to specify the filename when saving or restoring a model checkpoint.
getFilenameTensorNameBytes() - Method in class org.tensorflow.util.SaverDef.Builder
The name of the tensor in which to specify the filename when saving or restoring a model checkpoint.
getFilenameTensorNameBytes() - Method in class org.tensorflow.util.SaverDef
The name of the tensor in which to specify the filename when saving or restoring a model checkpoint.
getFilenameTensorNameBytes() - Method in interface org.tensorflow.util.SaverDefOrBuilder
The name of the tensor in which to specify the filename when saving or restoring a model checkpoint.
getFilePath() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Path to the source code file.
getFilePath() - Method in class org.tensorflow.framework.DebuggedSourceFile
Path to the source code file.
getFilePath() - Method in interface org.tensorflow.framework.DebuggedSourceFileOrBuilder
Path to the source code file.
getFilePathBytes() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Path to the source code file.
getFilePathBytes() - Method in class org.tensorflow.framework.DebuggedSourceFile
Path to the source code file.
getFilePathBytes() - Method in interface org.tensorflow.framework.DebuggedSourceFileOrBuilder
Path to the source code file.
getFileVersion() - Method in class org.tensorflow.util.Event.Builder
An event file was started, with the specified version.
getFileVersion() - Method in class org.tensorflow.util.Event
An event file was started, with the specified version.
getFileVersion() - Method in interface org.tensorflow.util.EventOrBuilder
An event file was started, with the specified version.
getFileVersionBytes() - Method in class org.tensorflow.util.Event.Builder
An event file was started, with the specified version.
getFileVersionBytes() - Method in class org.tensorflow.util.Event
An event file was started, with the specified version.
getFileVersionBytes() - Method in interface org.tensorflow.util.EventOrBuilder
An event file was started, with the specified version.
getFixedLenFeature() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
getFixedLenFeature() - Method in class org.tensorflow.example.FeatureConfiguration
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
getFixedLenFeature() - Method in interface org.tensorflow.example.FeatureConfigurationOrBuilder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
getFixedLenFeatureBuilder() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
getFixedLenFeatureOrBuilder() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
getFixedLenFeatureOrBuilder() - Method in class org.tensorflow.example.FeatureConfiguration
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
getFixedLenFeatureOrBuilder() - Method in interface org.tensorflow.example.FeatureConfigurationOrBuilder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
getFList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(float)"
getFList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(float)"
getFList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(float)"
getFloatList() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.FloatList float_list = 2;
getFloatList() - Method in class org.tensorflow.example.Feature
.tensorflow.FloatList float_list = 2;
getFloatList() - Method in interface org.tensorflow.example.FeatureOrBuilder
.tensorflow.FloatList float_list = 2;
getFloatList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.FloatList float_list = 4;
getFloatList() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.FloatList float_list = 4;
getFloatList() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.FloatList float_list = 4;
getFloatListBuilder() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.FloatList float_list = 2;
getFloatListBuilder() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.FloatList float_list = 4;
getFloatListOrBuilder() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.FloatList float_list = 2;
getFloatListOrBuilder() - Method in class org.tensorflow.example.Feature
.tensorflow.FloatList float_list = 2;
getFloatListOrBuilder() - Method in interface org.tensorflow.example.FeatureOrBuilder
.tensorflow.FloatList float_list = 2;
getFloatListOrBuilder() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.FloatList float_list = 4;
getFloatListOrBuilder() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.FloatList float_list = 4;
getFloatListOrBuilder() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.FloatList float_list = 4;
getFloatVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_FLOAT.
getFloatVal(int) - Method in class org.tensorflow.framework.TensorProto
DT_FLOAT.
getFloatVal(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_FLOAT.
getFloatValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_FLOAT.
getFloatValCount() - Method in class org.tensorflow.framework.TensorProto
DT_FLOAT.
getFloatValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_FLOAT.
getFloatValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_FLOAT.
getFloatValList() - Method in class org.tensorflow.framework.TensorProto
DT_FLOAT.
getFloatValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_FLOAT.
getForceGpuCompatible() - Method in class org.tensorflow.framework.GPUOptions.Builder
Force all tensors to be gpu_compatible.
getForceGpuCompatible() - Method in class org.tensorflow.framework.GPUOptions
Force all tensors to be gpu_compatible.
getForceGpuCompatible() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
Force all tensors to be gpu_compatible.
getFrequency() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Core Frequency in Mhz
getFrequency() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Core Frequency in Mhz
getFrequency() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Core Frequency in Mhz
getFromTensor() - Method in class org.tensorflow.framework.TensorConnection.Builder
A tensor name.
getFromTensor() - Method in class org.tensorflow.framework.TensorConnection
A tensor name.
getFromTensor() - Method in interface org.tensorflow.framework.TensorConnectionOrBuilder
A tensor name.
getFromTensorBytes() - Method in class org.tensorflow.framework.TensorConnection.Builder
A tensor name.
getFromTensorBytes() - Method in class org.tensorflow.framework.TensorConnection
A tensor name.
getFromTensorBytes() - Method in interface org.tensorflow.framework.TensorConnectionOrBuilder
A tensor name.
getFullName() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Name of the full variable of which this is a slice.
getFullName() - Method in class org.tensorflow.framework.SaveSliceInfoDef
Name of the full variable of which this is a slice.
getFullName() - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Name of the full variable of which this is a slice.
getFullName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
The full name of the variable/tensor, if applicable.
getFullName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
The full name of the variable/tensor, if applicable.
getFullName() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensorOrBuilder
The full name of the variable/tensor, if applicable.
getFullNameBytes() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Name of the full variable of which this is a slice.
getFullNameBytes() - Method in class org.tensorflow.framework.SaveSliceInfoDef
Name of the full variable of which this is a slice.
getFullNameBytes() - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Name of the full variable of which this is a slice.
getFullNameBytes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
The full name of the variable/tensor, if applicable.
getFullNameBytes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
The full name of the variable/tensor, if applicable.
getFullNameBytes() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensorOrBuilder
The full name of the variable/tensor, if applicable.
getFullShape(int) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of the full variable.
getFullShape(int) - Method in class org.tensorflow.framework.SaveSliceInfoDef
Shape of the full variable.
getFullShape(int) - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Shape of the full variable.
getFullShapeCount() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of the full variable.
getFullShapeCount() - Method in class org.tensorflow.framework.SaveSliceInfoDef
Shape of the full variable.
getFullShapeCount() - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Shape of the full variable.
getFullShapeList() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of the full variable.
getFullShapeList() - Method in class org.tensorflow.framework.SaveSliceInfoDef
Shape of the full variable.
getFullShapeList() - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Shape of the full variable.
getFunc() - Method in class org.tensorflow.framework.AttrValue.Builder
"func" represents a function.
getFunc() - Method in class org.tensorflow.framework.AttrValue
"func" represents a function.
getFunc(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
getFunc(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(attr)"
getFunc(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(attr)"
getFunc() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"func" represents a function.
getFuncBuilder() - Method in class org.tensorflow.framework.AttrValue.Builder
"func" represents a function.
getFuncBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
getFuncBuilderList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
getFuncCount() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
getFuncCount() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(attr)"
getFuncCount() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(attr)"
getFuncList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
getFuncList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(attr)"
getFuncList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(attr)"
getFuncOrBuilder() - Method in class org.tensorflow.framework.AttrValue.Builder
"func" represents a function.
getFuncOrBuilder() - Method in class org.tensorflow.framework.AttrValue
"func" represents a function.
getFuncOrBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
getFuncOrBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(attr)"
getFuncOrBuilder(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(attr)"
getFuncOrBuilder() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"func" represents a function.
getFuncOrBuilderList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
getFuncOrBuilderList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(attr)"
getFuncOrBuilderList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(attr)"
getFunction(int) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
getFunction(int) - Method in class org.tensorflow.framework.FunctionDefLibrary
repeated .tensorflow.FunctionDef function = 1;
getFunction(int) - Method in interface org.tensorflow.framework.FunctionDefLibraryOrBuilder
repeated .tensorflow.FunctionDef function = 1;
getFunctionBuilder(int) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
getFunctionBuilderList() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
getFunctionCount() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
getFunctionCount() - Method in class org.tensorflow.framework.FunctionDefLibrary
repeated .tensorflow.FunctionDef function = 1;
getFunctionCount() - Method in interface org.tensorflow.framework.FunctionDefLibraryOrBuilder
repeated .tensorflow.FunctionDef function = 1;
getFunctionList() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
getFunctionList() - Method in class org.tensorflow.framework.FunctionDefLibrary
repeated .tensorflow.FunctionDef function = 1;
getFunctionList() - Method in interface org.tensorflow.framework.FunctionDefLibraryOrBuilder
repeated .tensorflow.FunctionDef function = 1;
getFunctionName() - Method in class org.tensorflow.framework.GradientDef.Builder
The function name.
getFunctionName() - Method in class org.tensorflow.framework.GradientDef
The function name.
getFunctionName() - Method in interface org.tensorflow.framework.GradientDefOrBuilder
The function name.
getFunctionNameBytes() - Method in class org.tensorflow.framework.GradientDef.Builder
The function name.
getFunctionNameBytes() - Method in class org.tensorflow.framework.GradientDef
The function name.
getFunctionNameBytes() - Method in interface org.tensorflow.framework.GradientDefOrBuilder
The function name.
getFunctionOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Function optimizations (default is ON).
getFunctionOptimization() - Method in class org.tensorflow.framework.RewriterConfig
Function optimizations (default is ON).
getFunctionOptimization() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Function optimizations (default is ON).
getFunctionOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Function optimizations (default is ON).
getFunctionOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig
Function optimizations (default is ON).
getFunctionOptimizationValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Function optimizations (default is ON).
getFunctionOrBuilder(int) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
getFunctionOrBuilder(int) - Method in class org.tensorflow.framework.FunctionDefLibrary
repeated .tensorflow.FunctionDef function = 1;
getFunctionOrBuilder(int) - Method in interface org.tensorflow.framework.FunctionDefLibraryOrBuilder
repeated .tensorflow.FunctionDef function = 1;
getFunctionOrBuilderList() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
getFunctionOrBuilderList() - Method in class org.tensorflow.framework.FunctionDefLibrary
repeated .tensorflow.FunctionDef function = 1;
getFunctionOrBuilderList() - Method in interface org.tensorflow.framework.FunctionDefLibraryOrBuilder
repeated .tensorflow.FunctionDef function = 1;
getGlobalJitLevel() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
.tensorflow.OptimizerOptions.GlobalJitLevel global_jit_level = 5;
getGlobalJitLevel() - Method in class org.tensorflow.framework.OptimizerOptions
.tensorflow.OptimizerOptions.GlobalJitLevel global_jit_level = 5;
getGlobalJitLevel() - Method in interface org.tensorflow.framework.OptimizerOptionsOrBuilder
.tensorflow.OptimizerOptions.GlobalJitLevel global_jit_level = 5;
getGlobalJitLevelValue() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
.tensorflow.OptimizerOptions.GlobalJitLevel global_jit_level = 5;
getGlobalJitLevelValue() - Method in class org.tensorflow.framework.OptimizerOptions
.tensorflow.OptimizerOptions.GlobalJitLevel global_jit_level = 5;
getGlobalJitLevelValue() - Method in interface org.tensorflow.framework.OptimizerOptionsOrBuilder
.tensorflow.OptimizerOptions.GlobalJitLevel global_jit_level = 5;
getGlobalName() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
The global name of the threadpool.
getGlobalName() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
The global name of the threadpool.
getGlobalName() - Method in interface org.tensorflow.framework.ThreadPoolOptionProtoOrBuilder
The global name of the threadpool.
getGlobalNameBytes() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
The global name of the threadpool.
getGlobalNameBytes() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
The global name of the threadpool.
getGlobalNameBytes() - Method in interface org.tensorflow.framework.ThreadPoolOptionProtoOrBuilder
The global name of the threadpool.
getGlobalStep() - Method in class org.tensorflow.framework.DebugOptions.Builder
Caller-specified global step count.
getGlobalStep() - Method in class org.tensorflow.framework.DebugOptions
Caller-specified global step count.
getGlobalStep() - Method in interface org.tensorflow.framework.DebugOptionsOrBuilder
Caller-specified global step count.
getGpuOptions() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all GPUs.
getGpuOptions() - Method in class org.tensorflow.framework.ConfigProto
Options that apply to all GPUs.
getGpuOptions() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Options that apply to all GPUs.
getGpuOptionsBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all GPUs.
getGpuOptionsOrBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all GPUs.
getGpuOptionsOrBuilder() - Method in class org.tensorflow.framework.ConfigProto
Options that apply to all GPUs.
getGpuOptionsOrBuilder() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Options that apply to all GPUs.
getGradient(int) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
getGradient(int) - Method in class org.tensorflow.framework.FunctionDefLibrary
repeated .tensorflow.GradientDef gradient = 2;
getGradient(int) - Method in interface org.tensorflow.framework.FunctionDefLibraryOrBuilder
repeated .tensorflow.GradientDef gradient = 2;
getGradientBuilder(int) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
getGradientBuilderList() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
getGradientCount() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
getGradientCount() - Method in class org.tensorflow.framework.FunctionDefLibrary
repeated .tensorflow.GradientDef gradient = 2;
getGradientCount() - Method in interface org.tensorflow.framework.FunctionDefLibraryOrBuilder
repeated .tensorflow.GradientDef gradient = 2;
getGradientFunc() - Method in class org.tensorflow.framework.GradientDef.Builder
The gradient function's name.
getGradientFunc() - Method in class org.tensorflow.framework.GradientDef
The gradient function's name.
getGradientFunc() - Method in interface org.tensorflow.framework.GradientDefOrBuilder
The gradient function's name.
getGradientFuncBytes() - Method in class org.tensorflow.framework.GradientDef.Builder
The gradient function's name.
getGradientFuncBytes() - Method in class org.tensorflow.framework.GradientDef
The gradient function's name.
getGradientFuncBytes() - Method in interface org.tensorflow.framework.GradientDefOrBuilder
The gradient function's name.
getGradientList() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
getGradientList() - Method in class org.tensorflow.framework.FunctionDefLibrary
repeated .tensorflow.GradientDef gradient = 2;
getGradientList() - Method in interface org.tensorflow.framework.FunctionDefLibraryOrBuilder
repeated .tensorflow.GradientDef gradient = 2;
getGradientOrBuilder(int) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
getGradientOrBuilder(int) - Method in class org.tensorflow.framework.FunctionDefLibrary
repeated .tensorflow.GradientDef gradient = 2;
getGradientOrBuilder(int) - Method in interface org.tensorflow.framework.FunctionDefLibraryOrBuilder
repeated .tensorflow.GradientDef gradient = 2;
getGradientOrBuilderList() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
getGradientOrBuilderList() - Method in class org.tensorflow.framework.FunctionDefLibrary
repeated .tensorflow.GradientDef gradient = 2;
getGradientOrBuilderList() - Method in interface org.tensorflow.framework.FunctionDefLibraryOrBuilder
repeated .tensorflow.GradientDef gradient = 2;
getGraphDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
GraphDef.
getGraphDef() - Method in class org.tensorflow.framework.MetaGraphDef
GraphDef.
getGraphDef() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
GraphDef.
getGraphDef() - Method in class org.tensorflow.util.Event.Builder
An encoded version of a GraphDef.
getGraphDef() - Method in class org.tensorflow.util.Event
An encoded version of a GraphDef.
getGraphDef() - Method in interface org.tensorflow.util.EventOrBuilder
An encoded version of a GraphDef.
getGraphDefBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
GraphDef.
getGraphDefOrBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
GraphDef.
getGraphDefOrBuilder() - Method in class org.tensorflow.framework.MetaGraphDef
GraphDef.
getGraphDefOrBuilder() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
GraphDef.
getGraphInputNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
getGraphInputNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo
Input Node parameters of transferred graph
getGraphInputNodeInfo(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
Input Node parameters of transferred graph
getGraphInputNodeInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
getGraphInputNodeInfoBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
getGraphInputNodeInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
getGraphInputNodeInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo
Input Node parameters of transferred graph
getGraphInputNodeInfoCount() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
Input Node parameters of transferred graph
getGraphInputNodeInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
getGraphInputNodeInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo
Input Node parameters of transferred graph
getGraphInputNodeInfoList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
Input Node parameters of transferred graph
getGraphInputNodeInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
getGraphInputNodeInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo
Input Node parameters of transferred graph
getGraphInputNodeInfoOrBuilder(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
Input Node parameters of transferred graph
getGraphInputNodeInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
getGraphInputNodeInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo
Input Node parameters of transferred graph
getGraphInputNodeInfoOrBuilderList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
Input Node parameters of transferred graph
getGraphInputNodeName(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph input node name
getGraphInputNodeName(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Remote fused graph input node name
getGraphInputNodeName(int) - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Remote fused graph input node name
getGraphInputNodeNameBytes(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph input node name
getGraphInputNodeNameBytes(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Remote fused graph input node name
getGraphInputNodeNameBytes(int) - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Remote fused graph input node name
getGraphInputNodeNameCount() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph input node name
getGraphInputNodeNameCount() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Remote fused graph input node name
getGraphInputNodeNameCount() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Remote fused graph input node name
getGraphInputNodeNameList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph input node name
getGraphInputNodeNameList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Remote fused graph input node name
getGraphInputNodeNameList() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Remote fused graph input node name
getGraphOpName() - Method in class org.tensorflow.framework.ApiDef.Builder
Name of the op (in the OpDef) to specify the API for.
getGraphOpName() - Method in class org.tensorflow.framework.ApiDef
Name of the op (in the OpDef) to specify the API for.
getGraphOpName() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
Name of the op (in the OpDef) to specify the API for.
getGraphOpNameBytes() - Method in class org.tensorflow.framework.ApiDef.Builder
Name of the op (in the OpDef) to specify the API for.
getGraphOpNameBytes() - Method in class org.tensorflow.framework.ApiDef
Name of the op (in the OpDef) to specify the API for.
getGraphOpNameBytes() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
Name of the op (in the OpDef) to specify the API for.
getGraphOptions() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all graphs.
getGraphOptions() - Method in class org.tensorflow.framework.ConfigProto
Options that apply to all graphs.
getGraphOptions() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Options that apply to all graphs.
getGraphOptionsBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all graphs.
getGraphOptionsOrBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all graphs.
getGraphOptionsOrBuilder() - Method in class org.tensorflow.framework.ConfigProto
Options that apply to all graphs.
getGraphOptionsOrBuilder() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Options that apply to all graphs.
getGraphOutputNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfo(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoCount() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoOrBuilder(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeInfoOrBuilderList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
getGraphOutputNodeName(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph output node name
getGraphOutputNodeName(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Remote fused graph output node name
getGraphOutputNodeName(int) - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Remote fused graph output node name
getGraphOutputNodeNameBytes(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph output node name
getGraphOutputNodeNameBytes(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Remote fused graph output node name
getGraphOutputNodeNameBytes(int) - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Remote fused graph output node name
getGraphOutputNodeNameCount() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph output node name
getGraphOutputNodeNameCount() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Remote fused graph output node name
getGraphOutputNodeNameCount() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Remote fused graph output node name
getGraphOutputNodeNameList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph output node name
getGraphOutputNodeNameList() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Remote fused graph output node name
getGraphOutputNodeNameList() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Remote fused graph output node name
getHalfVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_HALF, DT_BFLOAT16.
getHalfVal(int) - Method in class org.tensorflow.framework.TensorProto
DT_HALF, DT_BFLOAT16.
getHalfVal(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_HALF, DT_BFLOAT16.
getHalfValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_HALF, DT_BFLOAT16.
getHalfValCount() - Method in class org.tensorflow.framework.TensorProto
DT_HALF, DT_BFLOAT16.
getHalfValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_HALF, DT_BFLOAT16.
getHalfValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_HALF, DT_BFLOAT16.
getHalfValList() - Method in class org.tensorflow.framework.TensorProto
DT_HALF, DT_BFLOAT16.
getHalfValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_HALF, DT_BFLOAT16.
getHandle() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
Handle describing the feeds and fetches of the step.
getHandle() - Method in class org.tensorflow.framework.MemoryLogStep
Handle describing the feeds and fetches of the step.
getHandle() - Method in interface org.tensorflow.framework.MemoryLogStepOrBuilder
Handle describing the feeds and fetches of the step.
getHandleBytes() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
Handle describing the feeds and fetches of the step.
getHandleBytes() - Method in class org.tensorflow.framework.MemoryLogStep
Handle describing the feeds and fetches of the step.
getHandleBytes() - Method in interface org.tensorflow.framework.MemoryLogStepOrBuilder
Handle describing the feeds and fetches of the step.
getHash() - Method in class org.tensorflow.util.testlog.CommitId.Builder
string hash = 2;
getHash() - Method in class org.tensorflow.util.testlog.CommitId
string hash = 2;
getHash() - Method in interface org.tensorflow.util.testlog.CommitIdOrBuilder
string hash = 2;
getHashBytes() - Method in class org.tensorflow.util.testlog.CommitId.Builder
string hash = 2;
getHashBytes() - Method in class org.tensorflow.util.testlog.CommitId
string hash = 2;
getHashBytes() - Method in interface org.tensorflow.util.testlog.CommitIdOrBuilder
string hash = 2;
getHashCode() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Hash code for the type of the resource.
getHashCode() - Method in class org.tensorflow.framework.ResourceHandleProto
Hash code for the type of the resource.
getHashCode() - Method in interface org.tensorflow.framework.ResourceHandleProtoOrBuilder
Hash code for the type of the resource.
getHasLengthCase() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
getHasLengthCase() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
getHasLengthCase() - Method in interface org.tensorflow.framework.TensorSliceProto.ExtentOrBuilder
 
getHasMinimum() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
For type == "int", this is a minimum value.
getHasMinimum() - Method in class org.tensorflow.framework.OpDef.AttrDef
For type == "int", this is a minimum value.
getHasMinimum() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
For type == "int", this is a minimum value.
getHasSingleReference() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Set if this tensor only has one remaining reference
getHasSingleReference() - Method in class org.tensorflow.framework.AllocationDescription
Set if this tensor only has one remaining reference
getHasSingleReference() - Method in interface org.tensorflow.framework.AllocationDescriptionOrBuilder
Set if this tensor only has one remaining reference
getHealthStatus() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
.tensorflow.WorkerHealth health_status = 1;
getHealthStatus() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
.tensorflow.WorkerHealth health_status = 1;
getHealthStatus() - Method in interface org.tensorflow.util.WorkerHeartbeatResponseOrBuilder
.tensorflow.WorkerHealth health_status = 1;
getHealthStatusValue() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
.tensorflow.WorkerHealth health_status = 1;
getHealthStatusValue() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
.tensorflow.WorkerHealth health_status = 1;
getHealthStatusValue() - Method in interface org.tensorflow.util.WorkerHeartbeatResponseOrBuilder
.tensorflow.WorkerHealth health_status = 1;
getHeight() - Method in class org.tensorflow.framework.Summary.Image.Builder
Dimensions of the image.
getHeight() - Method in class org.tensorflow.framework.Summary.Image
Dimensions of the image.
getHeight() - Method in interface org.tensorflow.framework.Summary.ImageOrBuilder
Dimensions of the image.
getHisto() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.HistogramProto histo = 5;
getHisto() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.HistogramProto histo = 5;
getHisto() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.HistogramProto histo = 5;
getHistoBuilder() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.HistogramProto histo = 5;
getHistoOrBuilder() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.HistogramProto histo = 5;
getHistoOrBuilder() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.HistogramProto histo = 5;
getHistoOrBuilder() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.HistogramProto histo = 5;
getHost() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
The host name on which a source code file is located.
getHost() - Method in class org.tensorflow.framework.DebuggedSourceFile
The host name on which a source code file is located.
getHost() - Method in interface org.tensorflow.framework.DebuggedSourceFileOrBuilder
The host name on which a source code file is located.
getHostBytes() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
The host name on which a source code file is located.
getHostBytes() - Method in class org.tensorflow.framework.DebuggedSourceFile
The host name on which a source code file is located.
getHostBytes() - Method in interface org.tensorflow.framework.DebuggedSourceFileOrBuilder
The host name on which a source code file is located.
getHostMemoryArg(int) - Method in class org.tensorflow.framework.KernelDef.Builder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArg(int) - Method in class org.tensorflow.framework.KernelDef
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArg(int) - Method in interface org.tensorflow.framework.KernelDefOrBuilder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArgBytes(int) - Method in class org.tensorflow.framework.KernelDef.Builder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArgBytes(int) - Method in class org.tensorflow.framework.KernelDef
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArgBytes(int) - Method in interface org.tensorflow.framework.KernelDefOrBuilder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArgCount() - Method in class org.tensorflow.framework.KernelDef.Builder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArgCount() - Method in class org.tensorflow.framework.KernelDef
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArgCount() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArgList() - Method in class org.tensorflow.framework.KernelDef.Builder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArgList() - Method in class org.tensorflow.framework.KernelDef
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostMemoryArgList() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
getHostname() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Host name of machine that ran the benchmark.
getHostname() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Host name of machine that ran the benchmark.
getHostname() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Host name of machine that ran the benchmark.
getHostname() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
string hostname = 3;
getHostname() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
string hostname = 3;
getHostname() - Method in interface org.tensorflow.util.WorkerHeartbeatResponseOrBuilder
string hostname = 3;
getHostnameBytes() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Host name of machine that ran the benchmark.
getHostnameBytes() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Host name of machine that ran the benchmark.
getHostnameBytes() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Host name of machine that ran the benchmark.
getHostnameBytes() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
string hostname = 3;
getHostnameBytes() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
string hostname = 3;
getHostnameBytes() - Method in interface org.tensorflow.util.WorkerHeartbeatResponseOrBuilder
string hostname = 3;
getHostTempMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Deprecated.
getHostTempMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node
Deprecated.
getHostTempMemorySize() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Deprecated.
getI() - Method in class org.tensorflow.framework.AttrValue.Builder
"int"
getI() - Method in class org.tensorflow.framework.AttrValue
"int"
getI(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(int)"
getI(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(int)"
getI(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(int)"
getI() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"int"
getICount() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(int)"
getICount() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(int)"
getICount() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(int)"
getId() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The id of the node.
getId() - Method in class org.tensorflow.framework.CostGraphDef.Node
The id of the node.
getId() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
The id of the node.
getIList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(int)"
getIList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(int)"
getIList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(int)"
getImage() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Image image = 4;
getImage() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.Summary.Image image = 4;
getImage() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.Summary.Image image = 4;
getImageBuilder() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Image image = 4;
getImageOrBuilder() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Image image = 4;
getImageOrBuilder() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.Summary.Image image = 4;
getImageOrBuilder() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.Summary.Image image = 4;
getInaccurate() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Are the costs inaccurate?
getInaccurate() - Method in class org.tensorflow.framework.CostGraphDef.Node
Are the costs inaccurate?
getInaccurate() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Are the costs inaccurate?
getInArg(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArg(int) - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArg(int) - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgBuilderList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgCount() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgCount() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgCount() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgList() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgList() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgOrBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgOrBuilder(int) - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgOrBuilder(int) - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgOrBuilderList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgOrBuilderList() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getInArgOrBuilderList() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
getIncarnation() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
A device is assigned a global unique number each time it is initialized.
getIncarnation() - Method in class org.tensorflow.framework.DeviceAttributes
A device is assigned a global unique number each time it is initialized.
getIncarnation() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
A device is assigned a global unique number each time it is initialized.
getIndex() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Index of the output being set.
getIndex() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
Index of the output being set.
getIndex() - Method in interface org.tensorflow.framework.MemoryLogTensorOutputOrBuilder
Index of the output being set.
getIndicesOutputTensorName() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string indices_output_tensor_name = 3;
getIndicesOutputTensorName() - Method in class org.tensorflow.example.VarLenFeatureProto
string indices_output_tensor_name = 3;
getIndicesOutputTensorName() - Method in interface org.tensorflow.example.VarLenFeatureProtoOrBuilder
string indices_output_tensor_name = 3;
getIndicesOutputTensorNameBytes() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string indices_output_tensor_name = 3;
getIndicesOutputTensorNameBytes() - Method in class org.tensorflow.example.VarLenFeatureProto
string indices_output_tensor_name = 3;
getIndicesOutputTensorNameBytes() - Method in interface org.tensorflow.example.VarLenFeatureProtoOrBuilder
string indices_output_tensor_name = 3;
getIndicesTensorName() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The indices Tensor must have dtype int64 and shape [?, ?].
getIndicesTensorName() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
The indices Tensor must have dtype int64 and shape [?, ?].
getIndicesTensorName() - Method in interface org.tensorflow.framework.TensorInfo.CooSparseOrBuilder
The indices Tensor must have dtype int64 and shape [?, ?].
getIndicesTensorNameBytes() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The indices Tensor must have dtype int64 and shape [?, ?].
getIndicesTensorNameBytes() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
The indices Tensor must have dtype int64 and shape [?, ?].
getIndicesTensorNameBytes() - Method in interface org.tensorflow.framework.TensorInfo.CooSparseOrBuilder
The indices Tensor must have dtype int64 and shape [?, ?].
getInferShapes() - Method in class org.tensorflow.framework.GraphOptions.Builder
Annotate each Node with Op output shape data, to the extent it can be statically inferred.
getInferShapes() - Method in class org.tensorflow.framework.GraphOptions
Annotate each Node with Op output shape data, to the extent it can be statically inferred.
getInferShapes() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
Annotate each Node with Op output shape data, to the extent it can be statically inferred.
getInitializerName() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the initializer op.
getInitializerName() - Method in class org.tensorflow.framework.VariableDef
Name of the initializer op.
getInitializerName() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Name of the initializer op.
getInitializerNameBytes() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the initializer op.
getInitializerNameBytes() - Method in class org.tensorflow.framework.VariableDef
Name of the initializer op.
getInitializerNameBytes() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Name of the initializer op.
getInitialValueName() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the tensor holding the variable's initial value.
getInitialValueName() - Method in class org.tensorflow.framework.VariableDef
Name of the tensor holding the variable's initial value.
getInitialValueName() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Name of the tensor holding the variable's initial value.
getInitialValueNameBytes() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the tensor holding the variable's initial value.
getInitialValueNameBytes() - Method in class org.tensorflow.framework.VariableDef
Name of the tensor holding the variable's initial value.
getInitialValueNameBytes() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Name of the tensor holding the variable's initial value.
getInput(int) - Method in class org.tensorflow.framework.NodeDef.Builder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInput(int) - Method in class org.tensorflow.framework.NodeDef
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInput(int) - Method in interface org.tensorflow.framework.NodeDefOrBuilder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInputArg(int) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
getInputArg(int) - Method in class org.tensorflow.framework.OpDef
Description of the input(s).
getInputArg(int) - Method in interface org.tensorflow.framework.OpDefOrBuilder
Description of the input(s).
getInputArgBuilder(int) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
getInputArgBuilderList() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
getInputArgCount() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
getInputArgCount() - Method in class org.tensorflow.framework.OpDef
Description of the input(s).
getInputArgCount() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Description of the input(s).
getInputArgList() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
getInputArgList() - Method in class org.tensorflow.framework.OpDef
Description of the input(s).
getInputArgList() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Description of the input(s).
getInputArgOrBuilder(int) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
getInputArgOrBuilder(int) - Method in class org.tensorflow.framework.OpDef
Description of the input(s).
getInputArgOrBuilder(int) - Method in interface org.tensorflow.framework.OpDefOrBuilder
Description of the input(s).
getInputArgOrBuilderList() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
getInputArgOrBuilderList() - Method in class org.tensorflow.framework.OpDef
Description of the input(s).
getInputArgOrBuilderList() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Description of the input(s).
getInputBytes(int) - Method in class org.tensorflow.framework.NodeDef.Builder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInputBytes(int) - Method in class org.tensorflow.framework.NodeDef
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInputBytes(int) - Method in interface org.tensorflow.framework.NodeDefOrBuilder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInputCount() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 input_count = 6;
getInputCount() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
int32 input_count = 6;
getInputCount() - Method in interface org.tensorflow.framework.GraphTransferNodeInfoOrBuilder
int32 input_count = 6;
getInputCount() - Method in class org.tensorflow.framework.NodeDef.Builder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInputCount() - Method in class org.tensorflow.framework.NodeDef
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInputCount() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInputInfo(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfo(int) - Method in class org.tensorflow.framework.CostGraphDef.Node
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfo(int) - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoBuilderList() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoCount() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoCount() - Method in class org.tensorflow.framework.CostGraphDef.Node
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoCount() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoList() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoList() - Method in class org.tensorflow.framework.CostGraphDef.Node
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoList() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoOrBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoOrBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Node
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoOrBuilder(int) - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoOrBuilderList() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoOrBuilderList() - Method in class org.tensorflow.framework.CostGraphDef.Node
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputInfoOrBuilderList() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
getInputList() - Method in class org.tensorflow.framework.NodeDef.Builder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInputList() - Method in class org.tensorflow.framework.NodeDef
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInputList() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
getInputs() - Method in class org.tensorflow.framework.SignatureDef.Builder
Deprecated.
getInputs() - Method in class org.tensorflow.framework.SignatureDef
Deprecated.
getInputs() - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Deprecated.
getInputsCount() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
getInputsCount() - Method in class org.tensorflow.framework.SignatureDef
 
getInputsCount() - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Named input parameters.
getInputsMap() - Method in class org.tensorflow.framework.SignatureDef.Builder
Named input parameters.
getInputsMap() - Method in class org.tensorflow.framework.SignatureDef
Named input parameters.
getInputsMap() - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Named input parameters.
getInputsOrDefault(String, TensorInfo) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named input parameters.
getInputsOrDefault(String, TensorInfo) - Method in class org.tensorflow.framework.SignatureDef
Named input parameters.
getInputsOrDefault(String, TensorInfo) - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Named input parameters.
getInputsOrThrow(String) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named input parameters.
getInputsOrThrow(String) - Method in class org.tensorflow.framework.SignatureDef
Named input parameters.
getInputsOrThrow(String) - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Named input parameters.
getInt64List() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.Int64List int64_list = 3;
getInt64List() - Method in class org.tensorflow.example.Feature
.tensorflow.Int64List int64_list = 3;
getInt64List() - Method in interface org.tensorflow.example.FeatureOrBuilder
.tensorflow.Int64List int64_list = 3;
getInt64List() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.Int64List int64_list = 3;
getInt64List() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.Int64List int64_list = 3;
getInt64List() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.Int64List int64_list = 3;
getInt64ListBuilder() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.Int64List int64_list = 3;
getInt64ListBuilder() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.Int64List int64_list = 3;
getInt64ListOrBuilder() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.Int64List int64_list = 3;
getInt64ListOrBuilder() - Method in class org.tensorflow.example.Feature
.tensorflow.Int64List int64_list = 3;
getInt64ListOrBuilder() - Method in interface org.tensorflow.example.FeatureOrBuilder
.tensorflow.Int64List int64_list = 3;
getInt64ListOrBuilder() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.Int64List int64_list = 3;
getInt64ListOrBuilder() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.Int64List int64_list = 3;
getInt64ListOrBuilder() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.Int64List int64_list = 3;
getInt64Val(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT64
getInt64Val(int) - Method in class org.tensorflow.framework.TensorProto
DT_INT64
getInt64Val(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_INT64
getInt64ValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT64
getInt64ValCount() - Method in class org.tensorflow.framework.TensorProto
DT_INT64
getInt64ValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_INT64
getInt64ValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT64
getInt64ValList() - Method in class org.tensorflow.framework.TensorProto
DT_INT64
getInt64ValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_INT64
getInterOpParallelismThreads() - Method in class org.tensorflow.framework.ConfigProto.Builder
Nodes that perform blocking operations are enqueued on a pool of inter_op_parallelism_threads available in each process.
getInterOpParallelismThreads() - Method in class org.tensorflow.framework.ConfigProto
Nodes that perform blocking operations are enqueued on a pool of inter_op_parallelism_threads available in each process.
getInterOpParallelismThreads() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Nodes that perform blocking operations are enqueued on a pool of inter_op_parallelism_threads available in each process.
getInterOpThreadPool() - Method in class org.tensorflow.framework.RunOptions.Builder
The thread pool to use, if session_inter_op_thread_pool is configured.
getInterOpThreadPool() - Method in class org.tensorflow.framework.RunOptions
The thread pool to use, if session_inter_op_thread_pool is configured.
getInterOpThreadPool() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
The thread pool to use, if session_inter_op_thread_pool is configured.
getIntraOpParallelismThreads() - Method in class org.tensorflow.framework.ConfigProto.Builder
The execution of an individual op (for some op types) can be parallelized on a pool of intra_op_parallelism_threads.
getIntraOpParallelismThreads() - Method in class org.tensorflow.framework.ConfigProto
The execution of an individual op (for some op types) can be parallelized on a pool of intra_op_parallelism_threads.
getIntraOpParallelismThreads() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
The execution of an individual op (for some op types) can be parallelized on a pool of intra_op_parallelism_threads.
getIntVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
getIntVal(int) - Method in class org.tensorflow.framework.TensorProto
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
getIntVal(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
getIntValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
getIntValCount() - Method in class org.tensorflow.framework.TensorProto
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
getIntValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
getIntValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
getIntValList() - Method in class org.tensorflow.framework.TensorProto
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
getIntValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
getIsAggregate() - Method in class org.tensorflow.framework.OpDef.Builder
If is_aggregate is true, then this operation accepts N >= 2 inputs and produces 1 output all of the same type.
getIsAggregate() - Method in class org.tensorflow.framework.OpDef
If is_aggregate is true, then this operation accepts N >= 2 inputs and produces 1 output all of the same type.
getIsAggregate() - Method in interface org.tensorflow.framework.OpDefOrBuilder
If is_aggregate is true, then this operation accepts N >= 2 inputs and produces 1 output all of the same type.
getIsCommutative() - Method in class org.tensorflow.framework.OpDef.Builder
True if the operation is commutative ("op(a,b) == op(b,a)" for all inputs)
getIsCommutative() - Method in class org.tensorflow.framework.OpDef
True if the operation is commutative ("op(a,b) == op(b,a)" for all inputs)
getIsCommutative() - Method in interface org.tensorflow.framework.OpDefOrBuilder
True if the operation is commutative ("op(a,b) == op(b,a)" for all inputs)
getIsFinal() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
If true, the output is permanent: it can't be discarded, because this node is part of the "final output".
getIsFinal() - Method in class org.tensorflow.framework.CostGraphDef.Node
If true, the output is permanent: it can't be discarded, because this node is part of the "final output".
getIsFinal() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
If true, the output is permanent: it can't be discarded, because this node is part of the "final output".
getIsolateSessionState() - Method in class org.tensorflow.framework.ConfigProto.Builder
If true, any resources such as Variables used in the session will not be shared with other sessions.
getIsolateSessionState() - Method in class org.tensorflow.framework.ConfigProto
If true, any resources such as Variables used in the session will not be shared with other sessions.
getIsolateSessionState() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
If true, any resources such as Variables used in the session will not be shared with other sessions.
getIsRef() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
For inputs: if true, the inputs are required to be refs.
getIsRef() - Method in class org.tensorflow.framework.OpDef.ArgDef
For inputs: if true, the inputs are required to be refs.
getIsRef() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
For inputs: if true, the inputs are required to be refs.
getIsResource() - Method in class org.tensorflow.framework.VariableDef.Builder
Whether to represent this as a ResourceVariable.
getIsResource() - Method in class org.tensorflow.framework.VariableDef
Whether to represent this as a ResourceVariable.
getIsResource() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Whether to represent this as a ResourceVariable.
getIsStateful() - Method in class org.tensorflow.framework.OpDef.Builder
Ops are marked as stateful if their behavior depends on some state beyond their input tensors (e.g.
getIsStateful() - Method in class org.tensorflow.framework.OpDef
Ops are marked as stateful if their behavior depends on some state beyond their input tensors (e.g.
getIsStateful() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Ops are marked as stateful if their behavior depends on some state beyond their input tensors (e.g.
getIters() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
If a benchmark, how many iterations it was run for
getIters() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
If a benchmark, how many iterations it was run for
getIters() - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
If a benchmark, how many iterations it was run for
getJob(int) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
getJob(int) - Method in class org.tensorflow.distruntime.ClusterDef
The jobs that comprise the cluster.
getJob(int) - Method in interface org.tensorflow.distruntime.ClusterDefOrBuilder
The jobs that comprise the cluster.
getJobBuilder(int) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
getJobBuilderList() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
getJobCount() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
getJobCount() - Method in class org.tensorflow.distruntime.ClusterDef
The jobs that comprise the cluster.
getJobCount() - Method in interface org.tensorflow.distruntime.ClusterDefOrBuilder
The jobs that comprise the cluster.
getJobList() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
getJobList() - Method in class org.tensorflow.distruntime.ClusterDef
The jobs that comprise the cluster.
getJobList() - Method in interface org.tensorflow.distruntime.ClusterDefOrBuilder
The jobs that comprise the cluster.
getJobName() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The name of the job of which this server is a member.
getJobName() - Method in class org.tensorflow.distruntime.ServerDef
The name of the job of which this server is a member.
getJobName() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The name of the job of which this server is a member.
getJobNameBytes() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The name of the job of which this server is a member.
getJobNameBytes() - Method in class org.tensorflow.distruntime.ServerDef
The name of the job of which this server is a member.
getJobNameBytes() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The name of the job of which this server is a member.
getJobOrBuilder(int) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
getJobOrBuilder(int) - Method in class org.tensorflow.distruntime.ClusterDef
The jobs that comprise the cluster.
getJobOrBuilder(int) - Method in interface org.tensorflow.distruntime.ClusterDefOrBuilder
The jobs that comprise the cluster.
getJobOrBuilderList() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
getJobOrBuilderList() - Method in class org.tensorflow.distruntime.ClusterDef
The jobs that comprise the cluster.
getJobOrBuilderList() - Method in interface org.tensorflow.distruntime.ClusterDefOrBuilder
The jobs that comprise the cluster.
getKeepCheckpointEveryNHours() - Method in class org.tensorflow.util.SaverDef.Builder
How often to keep an additional checkpoint.
getKeepCheckpointEveryNHours() - Method in class org.tensorflow.util.SaverDef
How often to keep an additional checkpoint.
getKeepCheckpointEveryNHours() - Method in interface org.tensorflow.util.SaverDefOrBuilder
How often to keep an additional checkpoint.
getKernel(int) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
getKernel(int) - Method in class org.tensorflow.framework.KernelList
repeated .tensorflow.KernelDef kernel = 1;
getKernel(int) - Method in interface org.tensorflow.framework.KernelListOrBuilder
repeated .tensorflow.KernelDef kernel = 1;
getKernelBuilder(int) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
getKernelBuilderList() - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
getKernelCount() - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
getKernelCount() - Method in class org.tensorflow.framework.KernelList
repeated .tensorflow.KernelDef kernel = 1;
getKernelCount() - Method in interface org.tensorflow.framework.KernelListOrBuilder
repeated .tensorflow.KernelDef kernel = 1;
getKernelList() - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
getKernelList() - Method in class org.tensorflow.framework.KernelList
repeated .tensorflow.KernelDef kernel = 1;
getKernelList() - Method in interface org.tensorflow.framework.KernelListOrBuilder
repeated .tensorflow.KernelDef kernel = 1;
getKernelName() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Name of the kernel making the allocation as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelName() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
Name of the kernel making the allocation as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelName() - Method in interface org.tensorflow.framework.MemoryLogTensorAllocationOrBuilder
Name of the kernel making the allocation as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelName() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Name of the kernel producing an output as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelName() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
Name of the kernel producing an output as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelName() - Method in interface org.tensorflow.framework.MemoryLogTensorOutputOrBuilder
Name of the kernel producing an output as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelNameBytes() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Name of the kernel making the allocation as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelNameBytes() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
Name of the kernel making the allocation as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelNameBytes() - Method in interface org.tensorflow.framework.MemoryLogTensorAllocationOrBuilder
Name of the kernel making the allocation as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelNameBytes() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Name of the kernel producing an output as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelNameBytes() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
Name of the kernel producing an output as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelNameBytes() - Method in interface org.tensorflow.framework.MemoryLogTensorOutputOrBuilder
Name of the kernel producing an output as set in GraphDef, e.g., "affine2/weights/Assign".
getKernelOrBuilder(int) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
getKernelOrBuilder(int) - Method in class org.tensorflow.framework.KernelList
repeated .tensorflow.KernelDef kernel = 1;
getKernelOrBuilder(int) - Method in interface org.tensorflow.framework.KernelListOrBuilder
repeated .tensorflow.KernelDef kernel = 1;
getKernelOrBuilderList() - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
getKernelOrBuilderList() - Method in class org.tensorflow.framework.KernelList
repeated .tensorflow.KernelDef kernel = 1;
getKernelOrBuilderList() - Method in interface org.tensorflow.framework.KernelListOrBuilder
repeated .tensorflow.KernelDef kernel = 1;
getKeys(int) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
Keys for tensors in the VariantTensorDataProto.
getKeys(int) - Method in class org.tensorflow.util.IteratorStateMetadata
Keys for tensors in the VariantTensorDataProto.
getKeys(int) - Method in interface org.tensorflow.util.IteratorStateMetadataOrBuilder
Keys for tensors in the VariantTensorDataProto.
getKeysBytes(int) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
Keys for tensors in the VariantTensorDataProto.
getKeysBytes(int) - Method in class org.tensorflow.util.IteratorStateMetadata
Keys for tensors in the VariantTensorDataProto.
getKeysBytes(int) - Method in interface org.tensorflow.util.IteratorStateMetadataOrBuilder
Keys for tensors in the VariantTensorDataProto.
getKeysCount() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
Keys for tensors in the VariantTensorDataProto.
getKeysCount() - Method in class org.tensorflow.util.IteratorStateMetadata
Keys for tensors in the VariantTensorDataProto.
getKeysCount() - Method in interface org.tensorflow.util.IteratorStateMetadataOrBuilder
Keys for tensors in the VariantTensorDataProto.
getKeysList() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
Keys for tensors in the VariantTensorDataProto.
getKeysList() - Method in class org.tensorflow.util.IteratorStateMetadata
Keys for tensors in the VariantTensorDataProto.
getKeysList() - Method in interface org.tensorflow.util.IteratorStateMetadataOrBuilder
Keys for tensors in the VariantTensorDataProto.
getKindCase() - Method in class org.tensorflow.example.Feature.Builder
 
getKindCase() - Method in class org.tensorflow.example.Feature
 
getKindCase() - Method in interface org.tensorflow.example.FeatureOrBuilder
 
getKindCase() - Method in class org.tensorflow.framework.CollectionDef.Builder
 
getKindCase() - Method in class org.tensorflow.framework.CollectionDef
 
getKindCase() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
 
getKindCase() - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
getKindCase() - Method in class org.tensorflow.util.testlog.CommitId
 
getKindCase() - Method in interface org.tensorflow.util.testlog.CommitIdOrBuilder
 
getKindCase() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
getKindCase() - Method in class org.tensorflow.util.testlog.EntryValue
 
getKindCase() - Method in interface org.tensorflow.util.testlog.EntryValueOrBuilder
 
getL1CacheSize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
L1 cache size in bytes
getL1CacheSize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
L1 cache size in bytes
getL1CacheSize() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
L1 cache size in bytes
getL2CacheSize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
L2 cache size in bytes
getL2CacheSize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
L2 cache size in bytes
getL2CacheSize() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
L2 cache size in bytes
getL3CacheSize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
L3 cache size in bytes
getL3CacheSize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
L3 cache size in bytes
getL3CacheSize() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
L3 cache size in bytes
getLabel() - Method in class org.tensorflow.framework.KernelDef.Builder
This allows experimental kernels to be registered for an op that won't be used unless the user specifies a "_kernel" attr with value matching this.
getLabel() - Method in class org.tensorflow.framework.KernelDef
This allows experimental kernels to be registered for an op that won't be used unless the user specifies a "_kernel" attr with value matching this.
getLabel() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
This allows experimental kernels to be registered for an op that won't be used unless the user specifies a "_kernel" attr with value matching this.
getLabelBytes() - Method in class org.tensorflow.framework.KernelDef.Builder
This allows experimental kernels to be registered for an op that won't be used unless the user specifies a "_kernel" attr with value matching this.
getLabelBytes() - Method in class org.tensorflow.framework.KernelDef
This allows experimental kernels to be registered for an op that won't be used unless the user specifies a "_kernel" attr with value matching this.
getLabelBytes() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
This allows experimental kernels to be registered for an op that won't be used unless the user specifies a "_kernel" attr with value matching this.
getLastModified() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
The timestamp at which the source code file is last modified.
getLastModified() - Method in class org.tensorflow.framework.DebuggedSourceFile
The timestamp at which the source code file is last modified.
getLastModified() - Method in interface org.tensorflow.framework.DebuggedSourceFileOrBuilder
The timestamp at which the source code file is last modified.
getLayoutOptimizer() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Optimize tensor layouts (default is ON) e.g.
getLayoutOptimizer() - Method in class org.tensorflow.framework.RewriterConfig
Optimize tensor layouts (default is ON) e.g.
getLayoutOptimizer() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Optimize tensor layouts (default is ON) e.g.
getLayoutOptimizerValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Optimize tensor layouts (default is ON) e.g.
getLayoutOptimizerValue() - Method in class org.tensorflow.framework.RewriterConfig
Optimize tensor layouts (default is ON) e.g.
getLayoutOptimizerValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Optimize tensor layouts (default is ON) e.g.
getLength() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
int64 length = 2;
getLength() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
int64 length = 2;
getLength() - Method in interface org.tensorflow.framework.TensorSliceProto.ExtentOrBuilder
int64 length = 2;
getLengthFrames() - Method in class org.tensorflow.framework.Summary.Audio.Builder
Length of the audio in frames (samples per channel).
getLengthFrames() - Method in class org.tensorflow.framework.Summary.Audio
Length of the audio in frames (samples per channel).
getLengthFrames() - Method in interface org.tensorflow.framework.Summary.AudioOrBuilder
Length of the audio in frames (samples per channel).
getLevel() - Method in class org.tensorflow.util.LogMessage.Builder
.tensorflow.LogMessage.Level level = 1;
getLevel() - Method in class org.tensorflow.util.LogMessage
.tensorflow.LogMessage.Level level = 1;
getLevel() - Method in interface org.tensorflow.util.LogMessageOrBuilder
.tensorflow.LogMessage.Level level = 1;
getLevelValue() - Method in class org.tensorflow.util.LogMessage.Builder
.tensorflow.LogMessage.Level level = 1;
getLevelValue() - Method in class org.tensorflow.util.LogMessage
.tensorflow.LogMessage.Level level = 1;
getLevelValue() - Method in interface org.tensorflow.util.LogMessageOrBuilder
.tensorflow.LogMessage.Level level = 1;
getLibrary() - Method in class org.tensorflow.framework.GraphDef.Builder
EXPERIMENTAL.
getLibrary() - Method in class org.tensorflow.framework.GraphDef
EXPERIMENTAL.
getLibrary() - Method in interface org.tensorflow.framework.GraphDefOrBuilder
EXPERIMENTAL.
getLibraryBuilder() - Method in class org.tensorflow.framework.GraphDef.Builder
EXPERIMENTAL.
getLibraryOrBuilder() - Method in class org.tensorflow.framework.GraphDef.Builder
EXPERIMENTAL.
getLibraryOrBuilder() - Method in class org.tensorflow.framework.GraphDef
EXPERIMENTAL.
getLibraryOrBuilder() - Method in interface org.tensorflow.framework.GraphDefOrBuilder
EXPERIMENTAL.
getLines(int) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Line-by-line content of the source code file.
getLines(int) - Method in class org.tensorflow.framework.DebuggedSourceFile
Line-by-line content of the source code file.
getLines(int) - Method in interface org.tensorflow.framework.DebuggedSourceFileOrBuilder
Line-by-line content of the source code file.
getLinesBytes(int) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Line-by-line content of the source code file.
getLinesBytes(int) - Method in class org.tensorflow.framework.DebuggedSourceFile
Line-by-line content of the source code file.
getLinesBytes(int) - Method in interface org.tensorflow.framework.DebuggedSourceFileOrBuilder
Line-by-line content of the source code file.
getLinesCount() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Line-by-line content of the source code file.
getLinesCount() - Method in class org.tensorflow.framework.DebuggedSourceFile
Line-by-line content of the source code file.
getLinesCount() - Method in interface org.tensorflow.framework.DebuggedSourceFileOrBuilder
Line-by-line content of the source code file.
getLinesList() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Line-by-line content of the source code file.
getLinesList() - Method in class org.tensorflow.framework.DebuggedSourceFile
Line-by-line content of the source code file.
getLinesList() - Method in interface org.tensorflow.framework.DebuggedSourceFileOrBuilder
Line-by-line content of the source code file.
getLink(int) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
getLink(int) - Method in class org.tensorflow.framework.LocalLinks
repeated .tensorflow.InterconnectLink link = 1;
getLink(int) - Method in interface org.tensorflow.framework.LocalLinksOrBuilder
repeated .tensorflow.InterconnectLink link = 1;
getLinkage() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getLinkage() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getLinkage() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getLinkageBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getLinkageBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getLinkageBytes() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getLinkBuilder(int) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
getLinkBuilderList() - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
getLinkCount() - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
getLinkCount() - Method in class org.tensorflow.framework.LocalLinks
repeated .tensorflow.InterconnectLink link = 1;
getLinkCount() - Method in interface org.tensorflow.framework.LocalLinksOrBuilder
repeated .tensorflow.InterconnectLink link = 1;
getLinkList() - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
getLinkList() - Method in class org.tensorflow.framework.LocalLinks
repeated .tensorflow.InterconnectLink link = 1;
getLinkList() - Method in interface org.tensorflow.framework.LocalLinksOrBuilder
repeated .tensorflow.InterconnectLink link = 1;
getLinkOrBuilder(int) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
getLinkOrBuilder(int) - Method in class org.tensorflow.framework.LocalLinks
repeated .tensorflow.InterconnectLink link = 1;
getLinkOrBuilder(int) - Method in interface org.tensorflow.framework.LocalLinksOrBuilder
repeated .tensorflow.InterconnectLink link = 1;
getLinkOrBuilderList() - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
getLinkOrBuilderList() - Method in class org.tensorflow.framework.LocalLinks
repeated .tensorflow.InterconnectLink link = 1;
getLinkOrBuilderList() - Method in interface org.tensorflow.framework.LocalLinksOrBuilder
repeated .tensorflow.InterconnectLink link = 1;
getLinks() - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional local interconnect links to other devices.
getLinks() - Method in class org.tensorflow.framework.DeviceLocality
Optional local interconnect links to other devices.
getLinks() - Method in interface org.tensorflow.framework.DeviceLocalityOrBuilder
Optional local interconnect links to other devices.
getLinksBuilder() - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional local interconnect links to other devices.
getLinksOrBuilder() - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional local interconnect links to other devices.
getLinksOrBuilder() - Method in class org.tensorflow.framework.DeviceLocality
Optional local interconnect links to other devices.
getLinksOrBuilder() - Method in interface org.tensorflow.framework.DeviceLocalityOrBuilder
Optional local interconnect links to other devices.
getList() - Method in class org.tensorflow.framework.AttrValue.Builder
any "list(...)"
getList() - Method in class org.tensorflow.framework.AttrValue
any "list(...)"
getList() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
any "list(...)"
getListBuilder() - Method in class org.tensorflow.framework.AttrValue.Builder
any "list(...)"
getListOrBuilder() - Method in class org.tensorflow.framework.AttrValue.Builder
any "list(...)"
getListOrBuilder() - Method in class org.tensorflow.framework.AttrValue
any "list(...)"
getListOrBuilder() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
any "list(...)"
getLiveBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The bytes that are not deallocated.
getLiveBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
The bytes that are not deallocated.
getLiveBytes() - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
The bytes that are not deallocated.
getLocality() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Platform-specific data about device that may be useful for supporting efficient data transfers.
getLocality() - Method in class org.tensorflow.framework.DeviceAttributes
Platform-specific data about device that may be useful for supporting efficient data transfers.
getLocality() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
Platform-specific data about device that may be useful for supporting efficient data transfers.
getLocalityBuilder() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Platform-specific data about device that may be useful for supporting efficient data transfers.
getLocalityOrBuilder() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Platform-specific data about device that may be useful for supporting efficient data transfers.
getLocalityOrBuilder() - Method in class org.tensorflow.framework.DeviceAttributes
Platform-specific data about device that may be useful for supporting efficient data transfers.
getLocalityOrBuilder() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
Platform-specific data about device that may be useful for supporting efficient data transfers.
getLocalName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
A user-provided name for the edge.
getLocalName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
A user-provided name for the edge.
getLocalName() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReferenceOrBuilder
A user-provided name for the edge.
getLocalNameBytes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
A user-provided name for the edge.
getLocalNameBytes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
A user-provided name for the edge.
getLocalNameBytes() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReferenceOrBuilder
A user-provided name for the edge.
getLogDevicePlacement() - Method in class org.tensorflow.framework.ConfigProto.Builder
Whether device placements should be logged.
getLogDevicePlacement() - Method in class org.tensorflow.framework.ConfigProto
Whether device placements should be logged.
getLogDevicePlacement() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Whether device placements should be logged.
getLogMessage() - Method in class org.tensorflow.util.Event.Builder
The user output a log message.
getLogMessage() - Method in class org.tensorflow.util.Event
The user output a log message.
getLogMessage() - Method in interface org.tensorflow.util.EventOrBuilder
The user output a log message.
getLogMessageBuilder() - Method in class org.tensorflow.util.Event.Builder
The user output a log message.
getLogMessageOrBuilder() - Method in class org.tensorflow.util.Event.Builder
The user output a log message.
getLogMessageOrBuilder() - Method in class org.tensorflow.util.Event
The user output a log message.
getLogMessageOrBuilder() - Method in interface org.tensorflow.util.EventOrBuilder
The user output a log message.
getLoopEnterNames(int) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for enter tensors.
getLoopEnterNames(int) - Method in class org.tensorflow.framework.WhileContextDef
List of names for enter tensors.
getLoopEnterNames(int) - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
List of names for enter tensors.
getLoopEnterNamesBytes(int) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for enter tensors.
getLoopEnterNamesBytes(int) - Method in class org.tensorflow.framework.WhileContextDef
List of names for enter tensors.
getLoopEnterNamesBytes(int) - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
List of names for enter tensors.
getLoopEnterNamesCount() - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for enter tensors.
getLoopEnterNamesCount() - Method in class org.tensorflow.framework.WhileContextDef
List of names for enter tensors.
getLoopEnterNamesCount() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
List of names for enter tensors.
getLoopEnterNamesList() - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for enter tensors.
getLoopEnterNamesList() - Method in class org.tensorflow.framework.WhileContextDef
List of names for enter tensors.
getLoopEnterNamesList() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
List of names for enter tensors.
getLoopExitNames(int) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for exit tensors.
getLoopExitNames(int) - Method in class org.tensorflow.framework.WhileContextDef
List of names for exit tensors.
getLoopExitNames(int) - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
List of names for exit tensors.
getLoopExitNamesBytes(int) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for exit tensors.
getLoopExitNamesBytes(int) - Method in class org.tensorflow.framework.WhileContextDef
List of names for exit tensors.
getLoopExitNamesBytes(int) - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
List of names for exit tensors.
getLoopExitNamesCount() - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for exit tensors.
getLoopExitNamesCount() - Method in class org.tensorflow.framework.WhileContextDef
List of names for exit tensors.
getLoopExitNamesCount() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
List of names for exit tensors.
getLoopExitNamesList() - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for exit tensors.
getLoopExitNamesList() - Method in class org.tensorflow.framework.WhileContextDef
List of names for exit tensors.
getLoopExitNamesList() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
List of names for exit tensors.
getLoopOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Loop optimizations (default is ON).
getLoopOptimization() - Method in class org.tensorflow.framework.RewriterConfig
Loop optimizations (default is ON).
getLoopOptimization() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Loop optimizations (default is ON).
getLoopOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Loop optimizations (default is ON).
getLoopOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig
Loop optimizations (default is ON).
getLoopOptimizationValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Loop optimizations (default is ON).
getMachine() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getMachine() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getMachine() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getMachineBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getMachineBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getMachineBytes() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getMachineConfiguration() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Machine-specific parameters (Platform and CPU info)
getMachineConfiguration() - Method in class org.tensorflow.util.testlog.TestResults
Machine-specific parameters (Platform and CPU info)
getMachineConfiguration() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
Machine-specific parameters (Platform and CPU info)
getMachineConfigurationBuilder() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Machine-specific parameters (Platform and CPU info)
getMachineConfigurationOrBuilder() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Machine-specific parameters (Platform and CPU info)
getMachineConfigurationOrBuilder() - Method in class org.tensorflow.util.testlog.TestResults
Machine-specific parameters (Platform and CPU info)
getMachineConfigurationOrBuilder() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
Machine-specific parameters (Platform and CPU info)
getMax() - Method in class org.tensorflow.framework.HistogramProto.Builder
double max = 2;
getMax() - Method in class org.tensorflow.framework.HistogramProto
double max = 2;
getMax() - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
double max = 2;
getMaxByteSize(int) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
repeated int32 max_byte_size = 2;
getMaxByteSize(int) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
repeated int32 max_byte_size = 2;
getMaxByteSize(int) - Method in interface org.tensorflow.framework.GraphTransferNodeOutputInfoOrBuilder
repeated int32 max_byte_size = 2;
getMaxByteSizeCount() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
repeated int32 max_byte_size = 2;
getMaxByteSizeCount() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
repeated int32 max_byte_size = 2;
getMaxByteSizeCount() - Method in interface org.tensorflow.framework.GraphTransferNodeOutputInfoOrBuilder
repeated int32 max_byte_size = 2;
getMaxByteSizeList() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
repeated int32 max_byte_size = 2;
getMaxByteSizeList() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
repeated int32 max_byte_size = 2;
getMaxByteSizeList() - Method in interface org.tensorflow.framework.GraphTransferNodeOutputInfoOrBuilder
repeated int32 max_byte_size = 2;
getMaxFoldedConstantInBytes() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
Constant folding optimization replaces tensors whose values can be predetermined, with constant nodes.
getMaxFoldedConstantInBytes() - Method in class org.tensorflow.framework.OptimizerOptions
Constant folding optimization replaces tensors whose values can be predetermined, with constant nodes.
getMaxFoldedConstantInBytes() - Method in interface org.tensorflow.framework.OptimizerOptionsOrBuilder
Constant folding optimization replaces tensors whose values can be predetermined, with constant nodes.
getMaximumIterationsName() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Optional name of the maximum_iterations tensor.
getMaximumIterationsName() - Method in class org.tensorflow.framework.WhileContextDef
Optional name of the maximum_iterations tensor.
getMaximumIterationsName() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Optional name of the maximum_iterations tensor.
getMaximumIterationsNameBytes() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Optional name of the maximum_iterations tensor.
getMaximumIterationsNameBytes() - Method in class org.tensorflow.framework.WhileContextDef
Optional name of the maximum_iterations tensor.
getMaximumIterationsNameBytes() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Optional name of the maximum_iterations tensor.
getMaxToKeep() - Method in class org.tensorflow.util.SaverDef.Builder
Maximum number of checkpoints to keep.
getMaxToKeep() - Method in class org.tensorflow.util.SaverDef
Maximum number of checkpoints to keep.
getMaxToKeep() - Method in interface org.tensorflow.util.SaverDefOrBuilder
Maximum number of checkpoints to keep.
getMaybeTypeName() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
For debug-only, the name of the type pointed to by this handle, if available.
getMaybeTypeName() - Method in class org.tensorflow.framework.ResourceHandleProto
For debug-only, the name of the type pointed to by this handle, if available.
getMaybeTypeName() - Method in interface org.tensorflow.framework.ResourceHandleProtoOrBuilder
For debug-only, the name of the type pointed to by this handle, if available.
getMaybeTypeNameBytes() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
For debug-only, the name of the type pointed to by this handle, if available.
getMaybeTypeNameBytes() - Method in class org.tensorflow.framework.ResourceHandleProto
For debug-only, the name of the type pointed to by this handle, if available.
getMaybeTypeNameBytes() - Method in interface org.tensorflow.framework.ResourceHandleProtoOrBuilder
For debug-only, the name of the type pointed to by this handle, if available.
getMemory(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemory(int) - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemory(int) - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryBuilderList() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryCount() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryCount() - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryCount() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
.tensorflow.MemoryInfo memory_info = 6;
getMemoryInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration
.tensorflow.MemoryInfo memory_info = 6;
getMemoryInfo() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
.tensorflow.MemoryInfo memory_info = 6;
getMemoryInfoBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
.tensorflow.MemoryInfo memory_info = 6;
getMemoryInfoOrBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
.tensorflow.MemoryInfo memory_info = 6;
getMemoryInfoOrBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration
.tensorflow.MemoryInfo memory_info = 6;
getMemoryInfoOrBuilder() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
.tensorflow.MemoryInfo memory_info = 6;
getMemoryLimit() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Memory capacity of device in bytes.
getMemoryLimit() - Method in class org.tensorflow.framework.DeviceAttributes
Memory capacity of device in bytes.
getMemoryLimit() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
Memory capacity of device in bytes.
getMemoryLimit() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Memory capacity in bytes.
getMemoryLimit() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
Memory capacity in bytes.
getMemoryLimit() - Method in interface org.tensorflow.util.testlog.AvailableDeviceInfoOrBuilder
Memory capacity in bytes.
getMemoryLimitMb(int) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
Per "virtual" device memory limit, in MB.
getMemoryLimitMb(int) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
Per "virtual" device memory limit, in MB.
getMemoryLimitMb(int) - Method in interface org.tensorflow.framework.GPUOptions.Experimental.VirtualDevicesOrBuilder
Per "virtual" device memory limit, in MB.
getMemoryLimitMbCount() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
Per "virtual" device memory limit, in MB.
getMemoryLimitMbCount() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
Per "virtual" device memory limit, in MB.
getMemoryLimitMbCount() - Method in interface org.tensorflow.framework.GPUOptions.Experimental.VirtualDevicesOrBuilder
Per "virtual" device memory limit, in MB.
getMemoryLimitMbList() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
Per "virtual" device memory limit, in MB.
getMemoryLimitMbList() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
Per "virtual" device memory limit, in MB.
getMemoryLimitMbList() - Method in interface org.tensorflow.framework.GPUOptions.Experimental.VirtualDevicesOrBuilder
Per "virtual" device memory limit, in MB.
getMemoryList() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryList() - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryList() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures memory optimization passes through the meta-optimizer.
getMemoryOptimization() - Method in class org.tensorflow.framework.RewriterConfig
Configures memory optimization passes through the meta-optimizer.
getMemoryOptimization() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Configures memory optimization passes through the meta-optimizer.
getMemoryOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures memory optimization passes through the meta-optimizer.
getMemoryOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig
Configures memory optimization passes through the meta-optimizer.
getMemoryOptimizationValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Configures memory optimization passes through the meta-optimizer.
getMemoryOptimizerTargetNodeNameScope() - Method in class org.tensorflow.framework.RewriterConfig.Builder
A node name scope for node names which are valid outputs of recompuations.
getMemoryOptimizerTargetNodeNameScope() - Method in class org.tensorflow.framework.RewriterConfig
A node name scope for node names which are valid outputs of recompuations.
getMemoryOptimizerTargetNodeNameScope() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
A node name scope for node names which are valid outputs of recompuations.
getMemoryOptimizerTargetNodeNameScopeBytes() - Method in class org.tensorflow.framework.RewriterConfig.Builder
A node name scope for node names which are valid outputs of recompuations.
getMemoryOptimizerTargetNodeNameScopeBytes() - Method in class org.tensorflow.framework.RewriterConfig
A node name scope for node names which are valid outputs of recompuations.
getMemoryOptimizerTargetNodeNameScopeBytes() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
A node name scope for node names which are valid outputs of recompuations.
getMemoryOrBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryOrBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryOrBuilder(int) - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryOrBuilderList() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryOrBuilderList() - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemoryOrBuilderList() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
getMemorySize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Memory size in bytes
getMemorySize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Memory size in bytes
getMemorySize() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Memory size in bytes
getMemoryStats() - Method in class org.tensorflow.framework.NodeExecStats.Builder
.tensorflow.MemoryStats memory_stats = 12;
getMemoryStats() - Method in class org.tensorflow.framework.NodeExecStats
.tensorflow.MemoryStats memory_stats = 12;
getMemoryStats() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
.tensorflow.MemoryStats memory_stats = 12;
getMemoryStatsBuilder() - Method in class org.tensorflow.framework.NodeExecStats.Builder
.tensorflow.MemoryStats memory_stats = 12;
getMemoryStatsOrBuilder() - Method in class org.tensorflow.framework.NodeExecStats.Builder
.tensorflow.MemoryStats memory_stats = 12;
getMemoryStatsOrBuilder() - Method in class org.tensorflow.framework.NodeExecStats
.tensorflow.MemoryStats memory_stats = 12;
getMemoryStatsOrBuilder() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
.tensorflow.MemoryStats memory_stats = 12;
getMemoryTime() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Analytical estimate of the memory access cost of this node, in microseconds.
getMemoryTime() - Method in class org.tensorflow.framework.CostGraphDef.Node
Analytical estimate of the memory access cost of this node, in microseconds.
getMemoryTime() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Analytical estimate of the memory access cost of this node, in microseconds.
getMessage() - Method in class org.tensorflow.util.LogMessage.Builder
string message = 2;
getMessage() - Method in class org.tensorflow.util.LogMessage
string message = 2;
getMessage() - Method in interface org.tensorflow.util.LogMessageOrBuilder
string message = 2;
getMessageBytes() - Method in class org.tensorflow.util.LogMessage.Builder
string message = 2;
getMessageBytes() - Method in class org.tensorflow.util.LogMessage
string message = 2;
getMessageBytes() - Method in interface org.tensorflow.util.LogMessageOrBuilder
string message = 2;
getMeta() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
getMeta() - Method in class org.tensorflow.util.SavedTensorSlices
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
getMeta() - Method in interface org.tensorflow.util.SavedTensorSlicesOrBuilder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
getMetaBuilder() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
getMetadata() - Method in class org.tensorflow.framework.Summary.Value.Builder
Contains metadata on the summary value such as which plugins may use it.
getMetadata() - Method in class org.tensorflow.framework.Summary.Value
Contains metadata on the summary value such as which plugins may use it.
getMetadata() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
Contains metadata on the summary value such as which plugins may use it.
getMetadata() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Portions of the object that are not Tensors.
getMetadata() - Method in class org.tensorflow.framework.VariantTensorDataProto
Portions of the object that are not Tensors.
getMetadata() - Method in interface org.tensorflow.framework.VariantTensorDataProtoOrBuilder
Portions of the object that are not Tensors.
getMetadataBuilder() - Method in class org.tensorflow.framework.Summary.Value.Builder
Contains metadata on the summary value such as which plugins may use it.
getMetadataOrBuilder() - Method in class org.tensorflow.framework.Summary.Value.Builder
Contains metadata on the summary value such as which plugins may use it.
getMetadataOrBuilder() - Method in class org.tensorflow.framework.Summary.Value
Contains metadata on the summary value such as which plugins may use it.
getMetadataOrBuilder() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
Contains metadata on the summary value such as which plugins may use it.
getMetaGraphDef() - Method in class org.tensorflow.util.Event.Builder
An encoded version of a MetaGraphDef.
getMetaGraphDef() - Method in class org.tensorflow.util.Event
An encoded version of a MetaGraphDef.
getMetaGraphDef() - Method in interface org.tensorflow.util.EventOrBuilder
An encoded version of a MetaGraphDef.
getMetaGraphs(int) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
getMetaGraphs(int) - Method in class org.tensorflow.framework.SavedModel
One or more MetaGraphs.
getMetaGraphs(int) - Method in interface org.tensorflow.framework.SavedModelOrBuilder
One or more MetaGraphs.
getMetaGraphsBuilder(int) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
getMetaGraphsBuilderList() - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
getMetaGraphsCount() - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
getMetaGraphsCount() - Method in class org.tensorflow.framework.SavedModel
One or more MetaGraphs.
getMetaGraphsCount() - Method in interface org.tensorflow.framework.SavedModelOrBuilder
One or more MetaGraphs.
getMetaGraphsList() - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
getMetaGraphsList() - Method in class org.tensorflow.framework.SavedModel
One or more MetaGraphs.
getMetaGraphsList() - Method in interface org.tensorflow.framework.SavedModelOrBuilder
One or more MetaGraphs.
getMetaGraphsOrBuilder(int) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
getMetaGraphsOrBuilder(int) - Method in class org.tensorflow.framework.SavedModel
One or more MetaGraphs.
getMetaGraphsOrBuilder(int) - Method in interface org.tensorflow.framework.SavedModelOrBuilder
One or more MetaGraphs.
getMetaGraphsOrBuilderList() - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
getMetaGraphsOrBuilderList() - Method in class org.tensorflow.framework.SavedModel
One or more MetaGraphs.
getMetaGraphsOrBuilderList() - Method in interface org.tensorflow.framework.SavedModelOrBuilder
One or more MetaGraphs.
getMetaGraphVersion() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User specified Version string.
getMetaGraphVersion() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
User specified Version string.
getMetaGraphVersion() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
User specified Version string.
getMetaGraphVersionBytes() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User specified Version string.
getMetaGraphVersionBytes() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
User specified Version string.
getMetaGraphVersionBytes() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
User specified Version string.
getMetaInfoDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
getMetaInfoDef() - Method in class org.tensorflow.framework.MetaGraphDef
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
getMetaInfoDef() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
getMetaInfoDefBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
getMetaInfoDefOrBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
getMetaInfoDefOrBuilder() - Method in class org.tensorflow.framework.MetaGraphDef
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
getMetaInfoDefOrBuilder() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
getMetaOptimizerIterations() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Controls how many times we run the optimizers in meta optimizer (default is once).
getMetaOptimizerIterations() - Method in class org.tensorflow.framework.RewriterConfig
Controls how many times we run the optimizers in meta optimizer (default is once).
getMetaOptimizerIterations() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Controls how many times we run the optimizers in meta optimizer (default is once).
getMetaOptimizerIterationsValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Controls how many times we run the optimizers in meta optimizer (default is once).
getMetaOptimizerIterationsValue() - Method in class org.tensorflow.framework.RewriterConfig
Controls how many times we run the optimizers in meta optimizer (default is once).
getMetaOptimizerIterationsValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Controls how many times we run the optimizers in meta optimizer (default is once).
getMetaOptimizerTimeoutMs() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Maximum number of milliseconds to spend optimizing a single graph before timing out.
getMetaOptimizerTimeoutMs() - Method in class org.tensorflow.framework.RewriterConfig
Maximum number of milliseconds to spend optimizing a single graph before timing out.
getMetaOptimizerTimeoutMs() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Maximum number of milliseconds to spend optimizing a single graph before timing out.
getMetaOrBuilder() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
getMetaOrBuilder() - Method in class org.tensorflow.util.SavedTensorSlices
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
getMetaOrBuilder() - Method in interface org.tensorflow.util.SavedTensorSlicesOrBuilder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
getMethodName() - Method in class org.tensorflow.framework.SignatureDef.Builder
Extensible method_name information enabling third-party users to mark a SignatureDef as supporting a particular method.
getMethodName() - Method in class org.tensorflow.framework.SignatureDef
Extensible method_name information enabling third-party users to mark a SignatureDef as supporting a particular method.
getMethodName() - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Extensible method_name information enabling third-party users to mark a SignatureDef as supporting a particular method.
getMethodNameBytes() - Method in class org.tensorflow.framework.SignatureDef.Builder
Extensible method_name information enabling third-party users to mark a SignatureDef as supporting a particular method.
getMethodNameBytes() - Method in class org.tensorflow.framework.SignatureDef
Extensible method_name information enabling third-party users to mark a SignatureDef as supporting a particular method.
getMethodNameBytes() - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Extensible method_name information enabling third-party users to mark a SignatureDef as supporting a particular method.
getMhzPerCpu() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
How fast are these cpus?
getMhzPerCpu() - Method in class org.tensorflow.util.testlog.CPUInfo
How fast are these cpus?
getMhzPerCpu() - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
How fast are these cpus?
getMin() - Method in class org.tensorflow.framework.HistogramProto.Builder
double min = 1;
getMin() - Method in class org.tensorflow.framework.HistogramProto
double min = 1;
getMin() - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
double min = 1;
getMinConsumer() - Method in class org.tensorflow.framework.VersionDef.Builder
Any consumer below this version is not allowed to consume this data.
getMinConsumer() - Method in class org.tensorflow.framework.VersionDef
Any consumer below this version is not allowed to consume this data.
getMinConsumer() - Method in interface org.tensorflow.framework.VersionDefOrBuilder
Any consumer below this version is not allowed to consume this data.
getMinGraphNodes() - Method in class org.tensorflow.framework.RewriterConfig.Builder
The minimum number of nodes in a graph to optimizer.
getMinGraphNodes() - Method in class org.tensorflow.framework.RewriterConfig
The minimum number of nodes in a graph to optimizer.
getMinGraphNodes() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
The minimum number of nodes in a graph to optimizer.
getMinimum() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
int64 minimum = 6;
getMinimum() - Method in class org.tensorflow.framework.OpDef.AttrDef
int64 minimum = 6;
getMinimum() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
int64 minimum = 6;
getMode() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
opt, dbg, etc
getMode() - Method in class org.tensorflow.util.testlog.BuildConfiguration
opt, dbg, etc
getMode() - Method in interface org.tensorflow.util.testlog.BuildConfigurationOrBuilder
opt, dbg, etc
getModeBytes() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
opt, dbg, etc
getModeBytes() - Method in class org.tensorflow.util.testlog.BuildConfiguration
opt, dbg, etc
getModeBytes() - Method in interface org.tensorflow.util.testlog.BuildConfigurationOrBuilder
opt, dbg, etc
getModel() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
e.g.
getModel() - Method in class org.tensorflow.util.testlog.GPUInfo
e.g.
getModel() - Method in interface org.tensorflow.util.testlog.GPUInfoOrBuilder
e.g.
getModel() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Model (Haswell, K40, ...)
getModel() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Model (Haswell, K40, ...)
getModel() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Model (Haswell, K40, ...)
getModelBytes() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
e.g.
getModelBytes() - Method in class org.tensorflow.util.testlog.GPUInfo
e.g.
getModelBytes() - Method in interface org.tensorflow.util.testlog.GPUInfoOrBuilder
e.g.
getModelBytes() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Model (Haswell, K40, ...)
getModelBytes() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Model (Haswell, K40, ...)
getModelBytes() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Model (Haswell, K40, ...)
getMsg() - Method in class org.tensorflow.util.SessionLog.Builder
string msg = 3;
getMsg() - Method in class org.tensorflow.util.SessionLog
string msg = 3;
getMsg() - Method in interface org.tensorflow.util.SessionLogOrBuilder
string msg = 3;
getMsgBytes() - Method in class org.tensorflow.util.SessionLog.Builder
string msg = 3;
getMsgBytes() - Method in class org.tensorflow.util.SessionLog
string msg = 3;
getMsgBytes() - Method in interface org.tensorflow.util.SessionLogOrBuilder
string msg = 3;
getMutableAttr() - Method in class org.tensorflow.framework.FunctionDef.Builder
Deprecated.
getMutableAttr() - Method in class org.tensorflow.framework.NameAttrList.Builder
Deprecated.
getMutableAttr() - Method in class org.tensorflow.framework.NodeDef.Builder
Deprecated.
getMutableCacheSize() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Deprecated.
getMutableCollectionDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Deprecated.
getMutableDeviceCount() - Method in class org.tensorflow.framework.ConfigProto.Builder
Deprecated.
getMutableEnvironment() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Deprecated.
getMutableExternalValues() - Method in class org.tensorflow.framework.ValuesDef.Builder
Deprecated.
getMutableExtras() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Deprecated.
getMutableFeature() - Method in class org.tensorflow.example.Features.Builder
Deprecated.
getMutableFeatureList() - Method in class org.tensorflow.example.FeatureLists.Builder
Deprecated.
getMutableFeatureMap() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
Deprecated.
getMutableFeedDevices() - Method in class org.tensorflow.framework.CallableOptions.Builder
Deprecated.
getMutableFetchDevices() - Method in class org.tensorflow.framework.CallableOptions.Builder
Deprecated.
getMutableInputs() - Method in class org.tensorflow.framework.SignatureDef.Builder
Deprecated.
getMutableOutputs() - Method in class org.tensorflow.framework.SignatureDef.Builder
Deprecated.
getMutableParameterMap() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
Deprecated.
getMutableRet() - Method in class org.tensorflow.framework.FunctionDef.Builder
Deprecated.
getMutableSignatureDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Deprecated.
getMutableTasks() - Method in class org.tensorflow.distruntime.JobDef.Builder
Deprecated.
getName() - Method in class org.tensorflow.distruntime.JobDef.Builder
The name of this job.
getName() - Method in class org.tensorflow.distruntime.JobDef
The name of this job.
getName() - Method in interface org.tensorflow.distruntime.JobDefOrBuilder
The name of this job.
getName() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
string name = 1;
getName() - Method in class org.tensorflow.framework.ApiDef.Arg
string name = 1;
getName() - Method in interface org.tensorflow.framework.ApiDef.ArgOrBuilder
string name = 1;
getName() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
string name = 1;
getName() - Method in class org.tensorflow.framework.ApiDef.Attr
string name = 1;
getName() - Method in interface org.tensorflow.framework.ApiDef.AttrOrBuilder
string name = 1;
getName() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Name should be either like "CamelCaseName" or "Package.CamelCaseName".
getName() - Method in class org.tensorflow.framework.ApiDef.Endpoint
Name should be either like "CamelCaseName" or "Package.CamelCaseName".
getName() - Method in interface org.tensorflow.framework.ApiDef.EndpointOrBuilder
Name should be either like "CamelCaseName" or "Package.CamelCaseName".
getName() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The name of the node.
getName() - Method in class org.tensorflow.framework.CostGraphDef.Node
The name of the node.
getName() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
The name of the node.
getName() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Fully specified name of the device within a cluster.
getName() - Method in class org.tensorflow.framework.DeviceAttributes
Fully specified name of the device within a cluster.
getName() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
Fully specified name of the device within a cluster.
getName() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
string name = 1;
getName() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
string name = 1;
getName() - Method in interface org.tensorflow.framework.GraphTransferConstNodeInfoOrBuilder
string name = 1;
getName() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
string name = 1;
getName() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
string name = 1;
getName() - Method in interface org.tensorflow.framework.GraphTransferGraphInputNodeInfoOrBuilder
string name = 1;
getName() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
string name = 1;
getName() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
string name = 1;
getName() - Method in interface org.tensorflow.framework.GraphTransferGraphOutputNodeInfoOrBuilder
string name = 1;
getName() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
string name = 1;
getName() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
string name = 1;
getName() - Method in interface org.tensorflow.framework.GraphTransferNodeInfoOrBuilder
string name = 1;
getName() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
Name of an attr from the Op.
getName() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
Name of an attr from the Op.
getName() - Method in interface org.tensorflow.framework.KernelDef.AttrConstraintOrBuilder
Name of an attr from the Op.
getName() - Method in class org.tensorflow.framework.NameAttrList.Builder
string name = 1;
getName() - Method in class org.tensorflow.framework.NameAttrList
string name = 1;
getName() - Method in interface org.tensorflow.framework.NameAttrListOrBuilder
string name = 1;
getName() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
Name of the tensor.
getName() - Method in class org.tensorflow.framework.NamedTensorProto
Name of the tensor.
getName() - Method in interface org.tensorflow.framework.NamedTensorProtoOrBuilder
Name of the tensor.
getName() - Method in class org.tensorflow.framework.NodeDef.Builder
The name given to this operator.
getName() - Method in class org.tensorflow.framework.NodeDef
The name given to this operator.
getName() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
The name given to this operator.
getName() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Name for the input/output.
getName() - Method in class org.tensorflow.framework.OpDef.ArgDef
Name for the input/output.
getName() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
Name for the input/output.
getName() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A descriptive name for the argument.
getName() - Method in class org.tensorflow.framework.OpDef.AttrDef
A descriptive name for the argument.
getName() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
A descriptive name for the argument.
getName() - Method in class org.tensorflow.framework.OpDef.Builder
Op names starting with an underscore are reserved for internal use.
getName() - Method in class org.tensorflow.framework.OpDef
Op names starting with an underscore are reserved for internal use.
getName() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Op names starting with an underscore are reserved for internal use.
getName() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Unique name of this resource.
getName() - Method in class org.tensorflow.framework.ResourceHandleProto
Unique name of this resource.
getName() - Method in interface org.tensorflow.framework.ResourceHandleProtoOrBuilder
Unique name of this resource.
getName() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
string name = 1;
getName() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
string name = 1;
getName() - Method in interface org.tensorflow.framework.RewriterConfig.CustomGraphOptimizerOrBuilder
string name = 1;
getName() - Method in class org.tensorflow.framework.TensorInfo.Builder
For dense `Tensor`s, the name of the tensor in the graph.
getName() - Method in class org.tensorflow.framework.TensorInfo
For dense `Tensor`s, the name of the tensor in the graph.
getName() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
For dense `Tensor`s, the name of the tensor in the graph.
getName() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
Optional name of the tensor dimension.
getName() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
Optional name of the tensor dimension.
getName() - Method in interface org.tensorflow.framework.TensorShapeProto.DimOrBuilder
Optional name of the tensor dimension.
getName() - Method in class org.tensorflow.util.SavedSlice.Builder
Name of the tensor that this slice belongs to.
getName() - Method in class org.tensorflow.util.SavedSlice
Name of the tensor that this slice belongs to.
getName() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Name of the tensor.
getName() - Method in class org.tensorflow.util.SavedSliceMeta
Name of the tensor.
getName() - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Name of the tensor.
getName() - Method in interface org.tensorflow.util.SavedSliceOrBuilder
Name of the tensor that this slice belongs to.
getName() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Device name.
getName() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
Device name.
getName() - Method in interface org.tensorflow.util.testlog.AvailableDeviceInfoOrBuilder
Device name.
getName() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
The name of the specific benchmark or test (e.g.
getName() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
The name of the specific benchmark or test (e.g.
getName() - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
The name of the specific benchmark or test (e.g.
getName() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Benchmark target identifier.
getName() - Method in class org.tensorflow.util.testlog.TestResults
Benchmark target identifier.
getName() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
Benchmark target identifier.
getName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
A name for the Tensor.
getName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
A name for the Tensor.
getName() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensorOrBuilder
A name for the Tensor.
getName() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
string name = 1;
getName() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
string name = 1;
getName() - Method in interface tensorflow.DevicePropertiesProtos.NamedDeviceOrBuilder
string name = 1;
getName() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
string name = 2;
getName() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
string name = 2;
getName() - Method in interface tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElementOrBuilder
string name = 2;
getNameBytes() - Method in class org.tensorflow.distruntime.JobDef.Builder
The name of this job.
getNameBytes() - Method in class org.tensorflow.distruntime.JobDef
The name of this job.
getNameBytes() - Method in interface org.tensorflow.distruntime.JobDefOrBuilder
The name of this job.
getNameBytes() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.ApiDef.Arg
string name = 1;
getNameBytes() - Method in interface org.tensorflow.framework.ApiDef.ArgOrBuilder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.ApiDef.Attr
string name = 1;
getNameBytes() - Method in interface org.tensorflow.framework.ApiDef.AttrOrBuilder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Name should be either like "CamelCaseName" or "Package.CamelCaseName".
getNameBytes() - Method in class org.tensorflow.framework.ApiDef.Endpoint
Name should be either like "CamelCaseName" or "Package.CamelCaseName".
getNameBytes() - Method in interface org.tensorflow.framework.ApiDef.EndpointOrBuilder
Name should be either like "CamelCaseName" or "Package.CamelCaseName".
getNameBytes() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The name of the node.
getNameBytes() - Method in class org.tensorflow.framework.CostGraphDef.Node
The name of the node.
getNameBytes() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
The name of the node.
getNameBytes() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Fully specified name of the device within a cluster.
getNameBytes() - Method in class org.tensorflow.framework.DeviceAttributes
Fully specified name of the device within a cluster.
getNameBytes() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
Fully specified name of the device within a cluster.
getNameBytes() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
string name = 1;
getNameBytes() - Method in interface org.tensorflow.framework.GraphTransferConstNodeInfoOrBuilder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
string name = 1;
getNameBytes() - Method in interface org.tensorflow.framework.GraphTransferGraphInputNodeInfoOrBuilder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
string name = 1;
getNameBytes() - Method in interface org.tensorflow.framework.GraphTransferGraphOutputNodeInfoOrBuilder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
string name = 1;
getNameBytes() - Method in interface org.tensorflow.framework.GraphTransferNodeInfoOrBuilder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
Name of an attr from the Op.
getNameBytes() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
Name of an attr from the Op.
getNameBytes() - Method in interface org.tensorflow.framework.KernelDef.AttrConstraintOrBuilder
Name of an attr from the Op.
getNameBytes() - Method in class org.tensorflow.framework.NameAttrList.Builder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.NameAttrList
string name = 1;
getNameBytes() - Method in interface org.tensorflow.framework.NameAttrListOrBuilder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
Name of the tensor.
getNameBytes() - Method in class org.tensorflow.framework.NamedTensorProto
Name of the tensor.
getNameBytes() - Method in interface org.tensorflow.framework.NamedTensorProtoOrBuilder
Name of the tensor.
getNameBytes() - Method in class org.tensorflow.framework.NodeDef.Builder
The name given to this operator.
getNameBytes() - Method in class org.tensorflow.framework.NodeDef
The name given to this operator.
getNameBytes() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
The name given to this operator.
getNameBytes() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Name for the input/output.
getNameBytes() - Method in class org.tensorflow.framework.OpDef.ArgDef
Name for the input/output.
getNameBytes() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
Name for the input/output.
getNameBytes() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A descriptive name for the argument.
getNameBytes() - Method in class org.tensorflow.framework.OpDef.AttrDef
A descriptive name for the argument.
getNameBytes() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
A descriptive name for the argument.
getNameBytes() - Method in class org.tensorflow.framework.OpDef.Builder
Op names starting with an underscore are reserved for internal use.
getNameBytes() - Method in class org.tensorflow.framework.OpDef
Op names starting with an underscore are reserved for internal use.
getNameBytes() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Op names starting with an underscore are reserved for internal use.
getNameBytes() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Unique name of this resource.
getNameBytes() - Method in class org.tensorflow.framework.ResourceHandleProto
Unique name of this resource.
getNameBytes() - Method in interface org.tensorflow.framework.ResourceHandleProtoOrBuilder
Unique name of this resource.
getNameBytes() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
string name = 1;
getNameBytes() - Method in interface org.tensorflow.framework.RewriterConfig.CustomGraphOptimizerOrBuilder
string name = 1;
getNameBytes() - Method in class org.tensorflow.framework.TensorInfo.Builder
For dense `Tensor`s, the name of the tensor in the graph.
getNameBytes() - Method in class org.tensorflow.framework.TensorInfo
For dense `Tensor`s, the name of the tensor in the graph.
getNameBytes() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
For dense `Tensor`s, the name of the tensor in the graph.
getNameBytes() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
Optional name of the tensor dimension.
getNameBytes() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
Optional name of the tensor dimension.
getNameBytes() - Method in interface org.tensorflow.framework.TensorShapeProto.DimOrBuilder
Optional name of the tensor dimension.
getNameBytes() - Method in class org.tensorflow.util.SavedSlice.Builder
Name of the tensor that this slice belongs to.
getNameBytes() - Method in class org.tensorflow.util.SavedSlice
Name of the tensor that this slice belongs to.
getNameBytes() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Name of the tensor.
getNameBytes() - Method in class org.tensorflow.util.SavedSliceMeta
Name of the tensor.
getNameBytes() - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Name of the tensor.
getNameBytes() - Method in interface org.tensorflow.util.SavedSliceOrBuilder
Name of the tensor that this slice belongs to.
getNameBytes() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Device name.
getNameBytes() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
Device name.
getNameBytes() - Method in interface org.tensorflow.util.testlog.AvailableDeviceInfoOrBuilder
Device name.
getNameBytes() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
The name of the specific benchmark or test (e.g.
getNameBytes() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
The name of the specific benchmark or test (e.g.
getNameBytes() - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
The name of the specific benchmark or test (e.g.
getNameBytes() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Benchmark target identifier.
getNameBytes() - Method in class org.tensorflow.util.testlog.TestResults
Benchmark target identifier.
getNameBytes() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
Benchmark target identifier.
getNameBytes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
A name for the Tensor.
getNameBytes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
A name for the Tensor.
getNameBytes() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensorOrBuilder
A name for the Tensor.
getNameBytes() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
string name = 1;
getNameBytes() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
string name = 1;
getNameBytes() - Method in interface tensorflow.DevicePropertiesProtos.NamedDeviceOrBuilder
string name = 1;
getNameBytes() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
string name = 2;
getNameBytes() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
string name = 2;
getNameBytes() - Method in interface tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElementOrBuilder
string name = 2;
getNestedContexts(int) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContexts(int) - Method in class org.tensorflow.framework.CondContextDef
Contexts contained inside this context (e.g.
getNestedContexts(int) - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Contexts contained inside this context (e.g.
getNestedContexts(int) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContexts(int) - Method in class org.tensorflow.framework.WhileContextDef
Contexts contained inside this context (e.g.
getNestedContexts(int) - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Contexts contained inside this context (e.g.
getNestedContextsBuilder(int) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsBuilder(int) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsBuilderList() - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsBuilderList() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsCount() - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsCount() - Method in class org.tensorflow.framework.CondContextDef
Contexts contained inside this context (e.g.
getNestedContextsCount() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Contexts contained inside this context (e.g.
getNestedContextsCount() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsCount() - Method in class org.tensorflow.framework.WhileContextDef
Contexts contained inside this context (e.g.
getNestedContextsCount() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Contexts contained inside this context (e.g.
getNestedContextsList() - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsList() - Method in class org.tensorflow.framework.CondContextDef
Contexts contained inside this context (e.g.
getNestedContextsList() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Contexts contained inside this context (e.g.
getNestedContextsList() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsList() - Method in class org.tensorflow.framework.WhileContextDef
Contexts contained inside this context (e.g.
getNestedContextsList() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Contexts contained inside this context (e.g.
getNestedContextsOrBuilder(int) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsOrBuilder(int) - Method in class org.tensorflow.framework.CondContextDef
Contexts contained inside this context (e.g.
getNestedContextsOrBuilder(int) - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Contexts contained inside this context (e.g.
getNestedContextsOrBuilder(int) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsOrBuilder(int) - Method in class org.tensorflow.framework.WhileContextDef
Contexts contained inside this context (e.g.
getNestedContextsOrBuilder(int) - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Contexts contained inside this context (e.g.
getNestedContextsOrBuilderList() - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsOrBuilderList() - Method in class org.tensorflow.framework.CondContextDef
Contexts contained inside this context (e.g.
getNestedContextsOrBuilderList() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Contexts contained inside this context (e.g.
getNestedContextsOrBuilderList() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
getNestedContextsOrBuilderList() - Method in class org.tensorflow.framework.WhileContextDef
Contexts contained inside this context (e.g.
getNestedContextsOrBuilderList() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Contexts contained inside this context (e.g.
getNode(int) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNode(int) - Method in class org.tensorflow.framework.CostGraphDef
repeated .tensorflow.CostGraphDef.Node node = 1;
getNode(int) - Method in interface org.tensorflow.framework.CostGraphDefOrBuilder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNode(int) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
getNode(int) - Method in class org.tensorflow.framework.GraphDef
repeated .tensorflow.NodeDef node = 1;
getNode(int) - Method in interface org.tensorflow.framework.GraphDefOrBuilder
repeated .tensorflow.NodeDef node = 1;
getNodeBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeBuilder(int) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
getNodeBuilderList() - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeBuilderList() - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
getNodeCount() - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeCount() - Method in class org.tensorflow.framework.CostGraphDef
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeCount() - Method in interface org.tensorflow.framework.CostGraphDefOrBuilder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeCount() - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
getNodeCount() - Method in class org.tensorflow.framework.GraphDef
repeated .tensorflow.NodeDef node = 1;
getNodeCount() - Method in interface org.tensorflow.framework.GraphDefOrBuilder
repeated .tensorflow.NodeDef node = 1;
getNodeDef(int) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDef(int) - Method in class org.tensorflow.framework.FunctionDef
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDef(int) - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefBuilder(int) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefBuilderList() - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefCount() - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefCount() - Method in class org.tensorflow.framework.FunctionDef
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefCount() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefList() - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefList() - Method in class org.tensorflow.framework.FunctionDef
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefList() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefOrBuilder(int) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefOrBuilder(int) - Method in class org.tensorflow.framework.FunctionDef
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefOrBuilder(int) - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefOrBuilderList() - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefOrBuilderList() - Method in class org.tensorflow.framework.FunctionDef
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeDefOrBuilderList() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
getNodeId() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
int32 node_id = 2;
getNodeId() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
int32 node_id = 2;
getNodeId() - Method in interface org.tensorflow.framework.GraphTransferConstNodeInfoOrBuilder
int32 node_id = 2;
getNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 node_id = 2;
getNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
int32 node_id = 2;
getNodeId() - Method in interface org.tensorflow.framework.GraphTransferNodeInfoOrBuilder
int32 node_id = 2;
getNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
int32 node_id = 1;
getNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeInput
int32 node_id = 1;
getNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
int32 node_id = 1;
getNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
int32 node_id = 1;
getNodeId() - Method in interface org.tensorflow.framework.GraphTransferNodeInputInfoOrBuilder
int32 node_id = 1;
getNodeId() - Method in interface org.tensorflow.framework.GraphTransferNodeInputOrBuilder
int32 node_id = 1;
getNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
int32 node_id = 1;
getNodeId() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
int32 node_id = 1;
getNodeId() - Method in interface org.tensorflow.framework.GraphTransferNodeOutputInfoOrBuilder
int32 node_id = 1;
getNodeId() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
An index into `CheckpointableObjectGraph.nodes`, indicating the object being referenced.
getNodeId() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
An index into `CheckpointableObjectGraph.nodes`, indicating the object being referenced.
getNodeId() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReferenceOrBuilder
An index into `CheckpointableObjectGraph.nodes`, indicating the object being referenced.
getNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfo(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoCount() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoOrBuilder(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInfoOrBuilderList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
getNodeInput(int) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInput(int) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInput(int) - Method in interface org.tensorflow.framework.GraphTransferNodeInputInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputBuilder(int) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputBuilderList() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputCount() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputCount() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputCount() - Method in interface org.tensorflow.framework.GraphTransferNodeInputInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfo(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoCount() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoOrBuilder(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputInfoOrBuilderList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
getNodeInputList() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputList() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputList() - Method in interface org.tensorflow.framework.GraphTransferNodeInputInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputOrBuilder(int) - Method in interface org.tensorflow.framework.GraphTransferNodeInputInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeInputOrBuilderList() - Method in interface org.tensorflow.framework.GraphTransferNodeInputInfoOrBuilder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
getNodeList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.NodeList node_list = 1;
getNodeList() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.NodeList node_list = 1;
getNodeList() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.NodeList node_list = 1;
getNodeList() - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeList() - Method in class org.tensorflow.framework.CostGraphDef
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeList() - Method in interface org.tensorflow.framework.CostGraphDefOrBuilder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeList() - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
getNodeList() - Method in class org.tensorflow.framework.GraphDef
repeated .tensorflow.NodeDef node = 1;
getNodeList() - Method in interface org.tensorflow.framework.GraphDefOrBuilder
repeated .tensorflow.NodeDef node = 1;
getNodeListBuilder() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.NodeList node_list = 1;
getNodeListOrBuilder() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.NodeList node_list = 1;
getNodeListOrBuilder() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.NodeList node_list = 1;
getNodeListOrBuilder() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.NodeList node_list = 1;
getNodeName() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name of the node to watch.
getNodeName() - Method in class org.tensorflow.framework.DebugTensorWatch
Name of the node to watch.
getNodeName() - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
Name of the node to watch.
getNodeName() - Method in class org.tensorflow.framework.NodeExecStats.Builder
TODO(tucker): Use some more compact form of node identity than the full string name.
getNodeName() - Method in class org.tensorflow.framework.NodeExecStats
TODO(tucker): Use some more compact form of node identity than the full string name.
getNodeName() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
TODO(tucker): Use some more compact form of node identity than the full string name.
getNodeName() - Method in class org.tensorflow.framework.Summary.Value.Builder
This field is deprecated and will not be set.
getNodeName() - Method in class org.tensorflow.framework.Summary.Value
This field is deprecated and will not be set.
getNodeName() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
This field is deprecated and will not be set.
getNodeNameBytes() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name of the node to watch.
getNodeNameBytes() - Method in class org.tensorflow.framework.DebugTensorWatch
Name of the node to watch.
getNodeNameBytes() - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
Name of the node to watch.
getNodeNameBytes() - Method in class org.tensorflow.framework.NodeExecStats.Builder
TODO(tucker): Use some more compact form of node identity than the full string name.
getNodeNameBytes() - Method in class org.tensorflow.framework.NodeExecStats
TODO(tucker): Use some more compact form of node identity than the full string name.
getNodeNameBytes() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
TODO(tucker): Use some more compact form of node identity than the full string name.
getNodeNameBytes() - Method in class org.tensorflow.framework.Summary.Value.Builder
This field is deprecated and will not be set.
getNodeNameBytes() - Method in class org.tensorflow.framework.Summary.Value
This field is deprecated and will not be set.
getNodeNameBytes() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
This field is deprecated and will not be set.
getNodeOrBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeOrBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeOrBuilder(int) - Method in interface org.tensorflow.framework.CostGraphDefOrBuilder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeOrBuilder(int) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
getNodeOrBuilder(int) - Method in class org.tensorflow.framework.GraphDef
repeated .tensorflow.NodeDef node = 1;
getNodeOrBuilder(int) - Method in interface org.tensorflow.framework.GraphDefOrBuilder
repeated .tensorflow.NodeDef node = 1;
getNodeOrBuilderList() - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeOrBuilderList() - Method in class org.tensorflow.framework.CostGraphDef
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeOrBuilderList() - Method in interface org.tensorflow.framework.CostGraphDefOrBuilder
repeated .tensorflow.CostGraphDef.Node node = 1;
getNodeOrBuilderList() - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
getNodeOrBuilderList() - Method in class org.tensorflow.framework.GraphDef
repeated .tensorflow.NodeDef node = 1;
getNodeOrBuilderList() - Method in interface org.tensorflow.framework.GraphDefOrBuilder
repeated .tensorflow.NodeDef node = 1;
getNodeOutputInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfo(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoCount() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoCount() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoList() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoOrBuilder(int) - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoOrBuilder(int) - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoOrBuilderList() - Method in class org.tensorflow.framework.GraphTransferInfo
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodeOutputInfoOrBuilderList() - Method in interface org.tensorflow.framework.GraphTransferInfoOrBuilder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
getNodes(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodes(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodes(int) - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraphOrBuilder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesCount() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesCount() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesCount() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraphOrBuilder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesList() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraphOrBuilder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesOrBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesOrBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesOrBuilder(int) - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraphOrBuilder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesOrBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesOrBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodesOrBuilderList() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraphOrBuilder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
getNodeStats(int) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStats(int) - Method in class org.tensorflow.framework.DeviceStepStats
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStats(int) - Method in interface org.tensorflow.framework.DeviceStepStatsOrBuilder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsBuilder(int) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsBuilderList() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsCount() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsCount() - Method in class org.tensorflow.framework.DeviceStepStats
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsCount() - Method in interface org.tensorflow.framework.DeviceStepStatsOrBuilder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsList() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsList() - Method in class org.tensorflow.framework.DeviceStepStats
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsList() - Method in interface org.tensorflow.framework.DeviceStepStatsOrBuilder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsOrBuilder(int) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsOrBuilder(int) - Method in class org.tensorflow.framework.DeviceStepStats
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsOrBuilder(int) - Method in interface org.tensorflow.framework.DeviceStepStatsOrBuilder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsOrBuilderList() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsOrBuilderList() - Method in class org.tensorflow.framework.DeviceStepStats
repeated .tensorflow.NodeExecStats node_stats = 2;
getNodeStatsOrBuilderList() - Method in interface org.tensorflow.framework.DeviceStepStatsOrBuilder
repeated .tensorflow.NodeExecStats node_stats = 2;
getNum() - Method in class org.tensorflow.framework.HistogramProto.Builder
double num = 3;
getNum() - Method in class org.tensorflow.framework.HistogramProto
double num = 3;
getNum() - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
double num = 3;
getNumaNode() - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional NUMA locality of device.
getNumaNode() - Method in class org.tensorflow.framework.DeviceLocality
Optional NUMA locality of device.
getNumaNode() - Method in interface org.tensorflow.framework.DeviceLocalityOrBuilder
Optional NUMA locality of device.
getNumber() - Method in enum org.tensorflow.example.Feature.KindCase
 
getNumber() - Method in enum org.tensorflow.example.FeatureConfiguration.ConfigCase
 
getNumber() - Method in enum org.tensorflow.framework.ApiDef.Visibility
 
getNumber() - Method in enum org.tensorflow.framework.AttrValue.ValueCase
 
getNumber() - Method in enum org.tensorflow.framework.Code
 
getNumber() - Method in enum org.tensorflow.framework.CollectionDef.KindCase
 
getNumber() - Method in enum org.tensorflow.framework.ControlFlowContextDef.CtxtCase
 
getNumber() - Method in enum org.tensorflow.framework.DataType
 
getNumber() - Method in enum org.tensorflow.framework.GraphTransferInfo.Destination
 
getNumber() - Method in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
 
getNumber() - Method in enum org.tensorflow.framework.OptimizerOptions.Level
 
getNumber() - Method in enum org.tensorflow.framework.RewriterConfig.MemOptType
 
getNumber() - Method in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
 
getNumber() - Method in enum org.tensorflow.framework.RewriterConfig.Toggle
 
getNumber() - Method in enum org.tensorflow.framework.RunOptions.TraceLevel
 
getNumber() - Method in enum org.tensorflow.framework.Summary.Value.ValueCase
 
getNumber() - Method in enum org.tensorflow.framework.TensorInfo.EncodingCase
 
getNumber() - Method in enum org.tensorflow.framework.TensorSliceProto.Extent.HasLengthCase
 
getNumber() - Method in enum org.tensorflow.util.BundleHeaderProto.Endianness
 
getNumber() - Method in enum org.tensorflow.util.Event.WhatCase
 
getNumber() - Method in enum org.tensorflow.util.LogMessage.Level
 
getNumber() - Method in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
 
getNumber() - Method in enum org.tensorflow.util.SessionLog.SessionStatus
 
getNumber() - Method in enum org.tensorflow.util.testlog.CommitId.KindCase
 
getNumber() - Method in enum org.tensorflow.util.testlog.EntryValue.KindCase
 
getNumber() - Method in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
 
getNumber() - Method in enum org.tensorflow.util.WorkerHealth
 
getNumber() - Method in enum org.tensorflow.util.WorkerShutdownMode
 
getNumberAttr() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
if specified, attr must have type "int"
getNumberAttr() - Method in class org.tensorflow.framework.OpDef.ArgDef
if specified, attr must have type "int"
getNumberAttr() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
if specified, attr must have type "int"
getNumberAttrBytes() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
if specified, attr must have type "int"
getNumberAttrBytes() - Method in class org.tensorflow.framework.OpDef.ArgDef
if specified, attr must have type "int"
getNumberAttrBytes() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
if specified, attr must have type "int"
getNumBytes() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Number of bytes in the allocation.
getNumBytes() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
Number of bytes in the allocation.
getNumBytes() - Method in interface org.tensorflow.framework.MemoryLogRawAllocationOrBuilder
Number of bytes in the allocation.
getNumChannels() - Method in class org.tensorflow.framework.Summary.Audio.Builder
Number of channels of audio.
getNumChannels() - Method in class org.tensorflow.framework.Summary.Audio
Number of channels of audio.
getNumChannels() - Method in interface org.tensorflow.framework.Summary.AudioOrBuilder
Number of channels of audio.
getNumCores() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
int64 num_cores = 1;
getNumCores() - Method in class org.tensorflow.util.testlog.CPUInfo
int64 num_cores = 1;
getNumCores() - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
int64 num_cores = 1;
getNumCores() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Number of cores
getNumCores() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Number of cores
getNumCores() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Number of cores
getNumCoresAllowed() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
int64 num_cores_allowed = 2;
getNumCoresAllowed() - Method in class org.tensorflow.util.testlog.CPUInfo
int64 num_cores_allowed = 2;
getNumCoresAllowed() - Method in interface org.tensorflow.util.testlog.CPUInfoOrBuilder
int64 num_cores_allowed = 2;
getNumDevToDevCopyStreams() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If > 1, the number of device-to-device copy streams to create for each GPUDevice.
getNumDevToDevCopyStreams() - Method in class org.tensorflow.framework.GPUOptions.Experimental
If > 1, the number of device-to-device copy streams to create for each GPUDevice.
getNumDevToDevCopyStreams() - Method in interface org.tensorflow.framework.GPUOptions.ExperimentalOrBuilder
If > 1, the number of device-to-device copy streams to create for each GPUDevice.
getNumRecordsProduced() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
int64 num_records_produced = 3;
getNumRecordsProduced() - Method in class org.tensorflow.framework.ReaderBaseState
int64 num_records_produced = 3;
getNumRecordsProduced() - Method in interface org.tensorflow.framework.ReaderBaseStateOrBuilder
int64 num_records_produced = 3;
getNumRegisters() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Number of registers per core.
getNumRegisters() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Number of registers per core.
getNumRegisters() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Number of registers per core.
getNumReplicas() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
int32 num_replicas = 2;
getNumReplicas() - Method in class org.tensorflow.framework.AutoParallelOptions
int32 num_replicas = 2;
getNumReplicas() - Method in interface org.tensorflow.framework.AutoParallelOptionsOrBuilder
int32 num_replicas = 2;
getNumShards() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Number of data files in the bundle.
getNumShards() - Method in class org.tensorflow.util.BundleHeaderProto
Number of data files in the bundle.
getNumShards() - Method in interface org.tensorflow.util.BundleHeaderProtoOrBuilder
Number of data files in the bundle.
getNumThreads() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
The number of threads in the pool.
getNumThreads() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
The number of threads in the pool.
getNumThreads() - Method in interface org.tensorflow.framework.ThreadPoolOptionProtoOrBuilder
The number of threads in the pool.
getObsoleteOldStyleHistogram() - Method in class org.tensorflow.framework.Summary.Value.Builder
bytes obsolete_old_style_histogram = 3;
getObsoleteOldStyleHistogram() - Method in class org.tensorflow.framework.Summary.Value
bytes obsolete_old_style_histogram = 3;
getObsoleteOldStyleHistogram() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
bytes obsolete_old_style_histogram = 3;
getOffset() - Method in class org.tensorflow.util.BundleEntryProto.Builder
int64 offset = 4;
getOffset() - Method in class org.tensorflow.util.BundleEntryProto
int64 offset = 4;
getOffset() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
int64 offset = 4;
getOffset() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
uint64 offset = 1;
getOffset() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
uint64 offset = 1;
getOffset() - Method in interface tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElementOrBuilder
uint64 offset = 1;
getOp(int) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
getOp(int) - Method in class org.tensorflow.framework.ApiDefs
repeated .tensorflow.ApiDef op = 1;
getOp(int) - Method in interface org.tensorflow.framework.ApiDefsOrBuilder
repeated .tensorflow.ApiDef op = 1;
getOp() - Method in class org.tensorflow.framework.KernelDef.Builder
Must match the name of an Op.
getOp() - Method in class org.tensorflow.framework.KernelDef
Must match the name of an Op.
getOp() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
Must match the name of an Op.
getOp() - Method in class org.tensorflow.framework.NodeDef.Builder
The operation name.
getOp() - Method in class org.tensorflow.framework.NodeDef
The operation name.
getOp() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
The operation name.
getOp(int) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
getOp(int) - Method in class org.tensorflow.framework.OpList
repeated .tensorflow.OpDef op = 1;
getOp(int) - Method in interface org.tensorflow.framework.OpListOrBuilder
repeated .tensorflow.OpDef op = 1;
getOpBuilder(int) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
getOpBuilder(int) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
getOpBuilderList() - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
getOpBuilderList() - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
getOpBytes() - Method in class org.tensorflow.framework.KernelDef.Builder
Must match the name of an Op.
getOpBytes() - Method in class org.tensorflow.framework.KernelDef
Must match the name of an Op.
getOpBytes() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
Must match the name of an Op.
getOpBytes() - Method in class org.tensorflow.framework.NodeDef.Builder
The operation name.
getOpBytes() - Method in class org.tensorflow.framework.NodeDef
The operation name.
getOpBytes() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
The operation name.
getOpCount() - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
getOpCount() - Method in class org.tensorflow.framework.ApiDefs
repeated .tensorflow.ApiDef op = 1;
getOpCount() - Method in interface org.tensorflow.framework.ApiDefsOrBuilder
repeated .tensorflow.ApiDef op = 1;
getOpCount() - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
getOpCount() - Method in class org.tensorflow.framework.OpList
repeated .tensorflow.OpDef op = 1;
getOpCount() - Method in interface org.tensorflow.framework.OpListOrBuilder
repeated .tensorflow.OpDef op = 1;
getOpEndRelMicros() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_end_rel_micros = 4;
getOpEndRelMicros() - Method in class org.tensorflow.framework.NodeExecStats
int64 op_end_rel_micros = 4;
getOpEndRelMicros() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
int64 op_end_rel_micros = 4;
getOpEndRelNanos() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_end_rel_nanos = 15;
getOpEndRelNanos() - Method in class org.tensorflow.framework.NodeExecStats
int64 op_end_rel_nanos = 15;
getOpEndRelNanos() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
int64 op_end_rel_nanos = 15;
getOperation() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Name of the operation making the allocation.
getOperation() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
Name of the operation making the allocation.
getOperation() - Method in interface org.tensorflow.framework.MemoryLogRawAllocationOrBuilder
Name of the operation making the allocation.
getOperation() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Name of the operation making the deallocation.
getOperation() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
Name of the operation making the deallocation.
getOperation() - Method in interface org.tensorflow.framework.MemoryLogRawDeallocationOrBuilder
Name of the operation making the deallocation.
getOperationBytes() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Name of the operation making the allocation.
getOperationBytes() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
Name of the operation making the allocation.
getOperationBytes() - Method in interface org.tensorflow.framework.MemoryLogRawAllocationOrBuilder
Name of the operation making the allocation.
getOperationBytes() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Name of the operation making the deallocation.
getOperationBytes() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
Name of the operation making the deallocation.
getOperationBytes() - Method in interface org.tensorflow.framework.MemoryLogRawDeallocationOrBuilder
Name of the operation making the deallocation.
getOperationTimeoutInMs() - Method in class org.tensorflow.framework.ConfigProto.Builder
Global timeout for all blocking operations in this session.
getOperationTimeoutInMs() - Method in class org.tensorflow.framework.ConfigProto
Global timeout for all blocking operations in this session.
getOperationTimeoutInMs() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Global timeout for all blocking operations in this session.
getOpList() - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
getOpList() - Method in class org.tensorflow.framework.ApiDefs
repeated .tensorflow.ApiDef op = 1;
getOpList() - Method in interface org.tensorflow.framework.ApiDefsOrBuilder
repeated .tensorflow.ApiDef op = 1;
getOpList() - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
getOpList() - Method in class org.tensorflow.framework.OpList
repeated .tensorflow.OpDef op = 1;
getOpList() - Method in interface org.tensorflow.framework.OpListOrBuilder
repeated .tensorflow.OpDef op = 1;
getOpOrBuilder(int) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
getOpOrBuilder(int) - Method in class org.tensorflow.framework.ApiDefs
repeated .tensorflow.ApiDef op = 1;
getOpOrBuilder(int) - Method in interface org.tensorflow.framework.ApiDefsOrBuilder
repeated .tensorflow.ApiDef op = 1;
getOpOrBuilder(int) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
getOpOrBuilder(int) - Method in class org.tensorflow.framework.OpList
repeated .tensorflow.OpDef op = 1;
getOpOrBuilder(int) - Method in interface org.tensorflow.framework.OpListOrBuilder
repeated .tensorflow.OpDef op = 1;
getOpOrBuilderList() - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
getOpOrBuilderList() - Method in class org.tensorflow.framework.ApiDefs
repeated .tensorflow.ApiDef op = 1;
getOpOrBuilderList() - Method in interface org.tensorflow.framework.ApiDefsOrBuilder
repeated .tensorflow.ApiDef op = 1;
getOpOrBuilderList() - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
getOpOrBuilderList() - Method in class org.tensorflow.framework.OpList
repeated .tensorflow.OpDef op = 1;
getOpOrBuilderList() - Method in interface org.tensorflow.framework.OpListOrBuilder
repeated .tensorflow.OpDef op = 1;
getOpStartRelMicros() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_start_rel_micros = 3;
getOpStartRelMicros() - Method in class org.tensorflow.framework.NodeExecStats
int64 op_start_rel_micros = 3;
getOpStartRelMicros() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
int64 op_start_rel_micros = 3;
getOpStartRelNanos() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_start_rel_nanos = 14;
getOpStartRelNanos() - Method in class org.tensorflow.framework.NodeExecStats
int64 op_start_rel_nanos = 14;
getOpStartRelNanos() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
int64 op_start_rel_nanos = 14;
getOptimizerOptions() - Method in class org.tensorflow.framework.GraphOptions.Builder
Options controlling how graph is optimized.
getOptimizerOptions() - Method in class org.tensorflow.framework.GraphOptions
Options controlling how graph is optimized.
getOptimizerOptions() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
Options controlling how graph is optimized.
getOptimizerOptionsBuilder() - Method in class org.tensorflow.framework.GraphOptions.Builder
Options controlling how graph is optimized.
getOptimizerOptionsOrBuilder() - Method in class org.tensorflow.framework.GraphOptions.Builder
Options controlling how graph is optimized.
getOptimizerOptionsOrBuilder() - Method in class org.tensorflow.framework.GraphOptions
Options controlling how graph is optimized.
getOptimizerOptionsOrBuilder() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
Options controlling how graph is optimized.
getOptimizers(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizers(int) - Method in class org.tensorflow.framework.RewriterConfig
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizers(int) - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizersBytes(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizersBytes(int) - Method in class org.tensorflow.framework.RewriterConfig
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizersBytes(int) - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizersCount() - Method in class org.tensorflow.framework.RewriterConfig.Builder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizersCount() - Method in class org.tensorflow.framework.RewriterConfig
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizersCount() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizersList() - Method in class org.tensorflow.framework.RewriterConfig.Builder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizersList() - Method in class org.tensorflow.framework.RewriterConfig
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptimizersList() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
getOptLevel() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
Overall optimization level.
getOptLevel() - Method in class org.tensorflow.framework.OptimizerOptions
Overall optimization level.
getOptLevel() - Method in interface org.tensorflow.framework.OptimizerOptionsOrBuilder
Overall optimization level.
getOptLevelValue() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
Overall optimization level.
getOptLevelValue() - Method in class org.tensorflow.framework.OptimizerOptions
Overall optimization level.
getOptLevelValue() - Method in interface org.tensorflow.framework.OptimizerOptionsOrBuilder
Overall optimization level.
getOpts(int) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
Bazel compilation options, if known
getOpts(int) - Method in class org.tensorflow.util.testlog.BuildConfiguration
Bazel compilation options, if known
getOpts(int) - Method in interface org.tensorflow.util.testlog.BuildConfigurationOrBuilder
Bazel compilation options, if known
getOptsBytes(int) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
Bazel compilation options, if known
getOptsBytes(int) - Method in class org.tensorflow.util.testlog.BuildConfiguration
Bazel compilation options, if known
getOptsBytes(int) - Method in interface org.tensorflow.util.testlog.BuildConfigurationOrBuilder
Bazel compilation options, if known
getOptsCount() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
Bazel compilation options, if known
getOptsCount() - Method in class org.tensorflow.util.testlog.BuildConfiguration
Bazel compilation options, if known
getOptsCount() - Method in interface org.tensorflow.util.testlog.BuildConfigurationOrBuilder
Bazel compilation options, if known
getOptsList() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
Bazel compilation options, if known
getOptsList() - Method in class org.tensorflow.util.testlog.BuildConfiguration
Bazel compilation options, if known
getOptsList() - Method in interface org.tensorflow.util.testlog.BuildConfigurationOrBuilder
Bazel compilation options, if known
getOriginalNodeNames(int) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNames(int) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNames(int) - Method in interface org.tensorflow.framework.NodeDef.ExperimentalDebugInfoOrBuilder
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNamesBytes(int) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNamesBytes(int) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNamesBytes(int) - Method in interface org.tensorflow.framework.NodeDef.ExperimentalDebugInfoOrBuilder
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNamesCount() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNamesCount() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNamesCount() - Method in interface org.tensorflow.framework.NodeDef.ExperimentalDebugInfoOrBuilder
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNamesList() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNamesList() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
Opaque string inserted into error messages created by the runtime.
getOriginalNodeNamesList() - Method in interface org.tensorflow.framework.NodeDef.ExperimentalDebugInfoOrBuilder
Opaque string inserted into error messages created by the runtime.
getOriginalVariableNodeId() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
An index into `CheckpointableObjectGraph.nodes`, indicating the variable object this slot was created for.
getOriginalVariableNodeId() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
An index into `CheckpointableObjectGraph.nodes`, indicating the variable object this slot was created for.
getOriginalVariableNodeId() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReferenceOrBuilder
An index into `CheckpointableObjectGraph.nodes`, indicating the variable object this slot was created for.
getOutArg(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArg(int) - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArg(int) - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgBuilderList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgCount() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgCount() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgCount() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgList() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgList() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgOrBuilder(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgOrBuilder(int) - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgOrBuilder(int) - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgOrBuilderList() - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgOrBuilderList() - Method in class org.tensorflow.framework.ApiDef
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutArgOrBuilderList() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
getOutput(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
getOutput(int) - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.NodeOutput output = 7;
getOutput(int) - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.NodeOutput output = 7;
getOutputArg(int) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
getOutputArg(int) - Method in class org.tensorflow.framework.OpDef
Description of the output(s).
getOutputArg(int) - Method in interface org.tensorflow.framework.OpDefOrBuilder
Description of the output(s).
getOutputArgBuilder(int) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
getOutputArgBuilderList() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
getOutputArgCount() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
getOutputArgCount() - Method in class org.tensorflow.framework.OpDef
Description of the output(s).
getOutputArgCount() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Description of the output(s).
getOutputArgList() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
getOutputArgList() - Method in class org.tensorflow.framework.OpDef
Description of the output(s).
getOutputArgList() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Description of the output(s).
getOutputArgOrBuilder(int) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
getOutputArgOrBuilder(int) - Method in class org.tensorflow.framework.OpDef
Description of the output(s).
getOutputArgOrBuilder(int) - Method in interface org.tensorflow.framework.OpDefOrBuilder
Description of the output(s).
getOutputArgOrBuilderList() - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
getOutputArgOrBuilderList() - Method in class org.tensorflow.framework.OpDef
Description of the output(s).
getOutputArgOrBuilderList() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Description of the output(s).
getOutputBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
getOutputBuilderList() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
getOutputCount() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 output_count = 7;
getOutputCount() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
int32 output_count = 7;
getOutputCount() - Method in interface org.tensorflow.framework.GraphTransferNodeInfoOrBuilder
int32 output_count = 7;
getOutputCount() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
getOutputCount() - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.NodeOutput output = 7;
getOutputCount() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.NodeOutput output = 7;
getOutputInfo(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfo(int) - Method in class org.tensorflow.framework.CostGraphDef.Node
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfo(int) - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoBuilderList() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoCount() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoCount() - Method in class org.tensorflow.framework.CostGraphDef.Node
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoCount() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoList() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoList() - Method in class org.tensorflow.framework.CostGraphDef.Node
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoList() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoOrBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoOrBuilder(int) - Method in class org.tensorflow.framework.CostGraphDef.Node
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoOrBuilder(int) - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoOrBuilderList() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoOrBuilderList() - Method in class org.tensorflow.framework.CostGraphDef.Node
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputInfoOrBuilderList() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
getOutputList() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
getOutputList() - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.NodeOutput output = 7;
getOutputList() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.NodeOutput output = 7;
getOutputOrBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
getOutputOrBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.NodeOutput output = 7;
getOutputOrBuilder(int) - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.NodeOutput output = 7;
getOutputOrBuilderList() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
getOutputOrBuilderList() - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.NodeOutput output = 7;
getOutputOrBuilderList() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.NodeOutput output = 7;
getOutputPartitionGraphs() - Method in class org.tensorflow.framework.RunOptions.Builder
Whether the partition graph(s) executed by the executor(s) should be outputted via RunMetadata.
getOutputPartitionGraphs() - Method in class org.tensorflow.framework.RunOptions
Whether the partition graph(s) executed by the executor(s) should be outputted via RunMetadata.
getOutputPartitionGraphs() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
Whether the partition graph(s) executed by the executor(s) should be outputted via RunMetadata.
getOutputPort() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
int32 output_port = 2;
getOutputPort() - Method in class org.tensorflow.framework.GraphTransferNodeInput
int32 output_port = 2;
getOutputPort() - Method in interface org.tensorflow.framework.GraphTransferNodeInputOrBuilder
int32 output_port = 2;
getOutputs() - Method in class org.tensorflow.framework.SignatureDef.Builder
Deprecated.
getOutputs() - Method in class org.tensorflow.framework.SignatureDef
Deprecated.
getOutputs() - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Deprecated.
getOutputsCount() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
getOutputsCount() - Method in class org.tensorflow.framework.SignatureDef
 
getOutputsCount() - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Named output parameters.
getOutputSlot() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Output slot to watch.
getOutputSlot() - Method in class org.tensorflow.framework.DebugTensorWatch
Output slot to watch.
getOutputSlot() - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
Output slot to watch.
getOutputsMap() - Method in class org.tensorflow.framework.SignatureDef.Builder
Named output parameters.
getOutputsMap() - Method in class org.tensorflow.framework.SignatureDef
Named output parameters.
getOutputsMap() - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Named output parameters.
getOutputsOrDefault(String, TensorInfo) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named output parameters.
getOutputsOrDefault(String, TensorInfo) - Method in class org.tensorflow.framework.SignatureDef
Named output parameters.
getOutputsOrDefault(String, TensorInfo) - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Named output parameters.
getOutputsOrThrow(String) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named output parameters.
getOutputsOrThrow(String) - Method in class org.tensorflow.framework.SignatureDef
Named output parameters.
getOutputsOrThrow(String) - Method in interface org.tensorflow.framework.SignatureDefOrBuilder
Named output parameters.
getPaddingId() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 padding_id = 5;
getPaddingId() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
int32 padding_id = 5;
getPaddingId() - Method in interface org.tensorflow.framework.GraphTransferNodeInfoOrBuilder
int32 padding_id = 5;
getParallelIterations() - Method in class org.tensorflow.framework.WhileContextDef.Builder
The number of iterations allowed to run in parallel.
getParallelIterations() - Method in class org.tensorflow.framework.WhileContextDef
The number of iterations allowed to run in parallel.
getParallelIterations() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
The number of iterations allowed to run in parallel.
getParameterMap() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
Deprecated.
getParameterMap() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
Deprecated.
getParameterMap() - Method in interface org.tensorflow.framework.RewriterConfig.CustomGraphOptimizerOrBuilder
Deprecated.
getParameterMapCount() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
getParameterMapCount() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
getParameterMapCount() - Method in interface org.tensorflow.framework.RewriterConfig.CustomGraphOptimizerOrBuilder
map<string, .tensorflow.AttrValue> parameter_map = 2;
getParameterMapMap() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
map<string, .tensorflow.AttrValue> parameter_map = 2;
getParameterMapMap() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
map<string, .tensorflow.AttrValue> parameter_map = 2;
getParameterMapMap() - Method in interface org.tensorflow.framework.RewriterConfig.CustomGraphOptimizerOrBuilder
map<string, .tensorflow.AttrValue> parameter_map = 2;
getParameterMapOrDefault(String, AttrValue) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
map<string, .tensorflow.AttrValue> parameter_map = 2;
getParameterMapOrDefault(String, AttrValue) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
map<string, .tensorflow.AttrValue> parameter_map = 2;
getParameterMapOrDefault(String, AttrValue) - Method in interface org.tensorflow.framework.RewriterConfig.CustomGraphOptimizerOrBuilder
map<string, .tensorflow.AttrValue> parameter_map = 2;
getParameterMapOrThrow(String) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
map<string, .tensorflow.AttrValue> parameter_map = 2;
getParameterMapOrThrow(String) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
map<string, .tensorflow.AttrValue> parameter_map = 2;
getParameterMapOrThrow(String) - Method in interface org.tensorflow.framework.RewriterConfig.CustomGraphOptimizerOrBuilder
map<string, .tensorflow.AttrValue> parameter_map = 2;
getParserForType() - Method in class org.tensorflow.distruntime.ClusterDef
 
getParserForType() - Method in class org.tensorflow.distruntime.JobDef
 
getParserForType() - Method in class org.tensorflow.distruntime.ServerDef
 
getParserForType() - Method in class org.tensorflow.example.BytesList
 
getParserForType() - Method in class org.tensorflow.example.Example
 
getParserForType() - Method in class org.tensorflow.example.ExampleParserConfiguration
 
getParserForType() - Method in class org.tensorflow.example.Feature
 
getParserForType() - Method in class org.tensorflow.example.FeatureConfiguration
 
getParserForType() - Method in class org.tensorflow.example.FeatureList
 
getParserForType() - Method in class org.tensorflow.example.FeatureLists
 
getParserForType() - Method in class org.tensorflow.example.Features
 
getParserForType() - Method in class org.tensorflow.example.FixedLenFeatureProto
 
getParserForType() - Method in class org.tensorflow.example.FloatList
 
getParserForType() - Method in class org.tensorflow.example.Int64List
 
getParserForType() - Method in class org.tensorflow.example.SequenceExample
 
getParserForType() - Method in class org.tensorflow.example.VarLenFeatureProto
 
getParserForType() - Method in class org.tensorflow.framework.AllocationDescription
 
getParserForType() - Method in class org.tensorflow.framework.AllocationRecord
 
getParserForType() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
getParserForType() - Method in class org.tensorflow.framework.ApiDef.Arg
 
getParserForType() - Method in class org.tensorflow.framework.ApiDef.Attr
 
getParserForType() - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
getParserForType() - Method in class org.tensorflow.framework.ApiDef
 
getParserForType() - Method in class org.tensorflow.framework.ApiDefs
 
getParserForType() - Method in class org.tensorflow.framework.AssetFileDef
 
getParserForType() - Method in class org.tensorflow.framework.AttrValue
 
getParserForType() - Method in class org.tensorflow.framework.AttrValue.ListValue
 
getParserForType() - Method in class org.tensorflow.framework.AutoParallelOptions
 
getParserForType() - Method in class org.tensorflow.framework.CallableOptions
 
getParserForType() - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
getParserForType() - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
getParserForType() - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
getParserForType() - Method in class org.tensorflow.framework.CollectionDef
 
getParserForType() - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
getParserForType() - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
getParserForType() - Method in class org.tensorflow.framework.CondContextDef
 
getParserForType() - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
getParserForType() - Method in class org.tensorflow.framework.ConfigProto
 
getParserForType() - Method in class org.tensorflow.framework.ControlFlowContextDef
 
getParserForType() - Method in class org.tensorflow.framework.CostGraphDef
 
getParserForType() - Method in class org.tensorflow.framework.CostGraphDef.Node
 
getParserForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
getParserForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
getParserForType() - Method in class org.tensorflow.framework.DebuggedSourceFile
 
getParserForType() - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
getParserForType() - Method in class org.tensorflow.framework.DebugOptions
 
getParserForType() - Method in class org.tensorflow.framework.DebugTensorWatch
 
getParserForType() - Method in class org.tensorflow.framework.DeviceAttributes
 
getParserForType() - Method in class org.tensorflow.framework.DeviceLocality
 
getParserForType() - Method in class org.tensorflow.framework.DeviceStepStats
 
getParserForType() - Method in class org.tensorflow.framework.FunctionDef
 
getParserForType() - Method in class org.tensorflow.framework.FunctionDefLibrary
 
getParserForType() - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
getParserForType() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
getParserForType() - Method in class org.tensorflow.framework.GPUOptions
 
getParserForType() - Method in class org.tensorflow.framework.GradientDef
 
getParserForType() - Method in class org.tensorflow.framework.GraphDef
 
getParserForType() - Method in class org.tensorflow.framework.GraphOptions
 
getParserForType() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
getParserForType() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
getParserForType() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
getParserForType() - Method in class org.tensorflow.framework.GraphTransferInfo
 
getParserForType() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
getParserForType() - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
getParserForType() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
getParserForType() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
getParserForType() - Method in class org.tensorflow.framework.HistogramProto
 
getParserForType() - Method in class org.tensorflow.framework.InterconnectLink
 
getParserForType() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
getParserForType() - Method in class org.tensorflow.framework.KernelDef
 
getParserForType() - Method in class org.tensorflow.framework.KernelList
 
getParserForType() - Method in class org.tensorflow.framework.LocalLinks
 
getParserForType() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
getParserForType() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
getParserForType() - Method in class org.tensorflow.framework.MemoryLogStep
 
getParserForType() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
getParserForType() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
getParserForType() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
getParserForType() - Method in class org.tensorflow.framework.MemoryStats
 
getParserForType() - Method in class org.tensorflow.framework.MetaGraphDef
 
getParserForType() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
getParserForType() - Method in class org.tensorflow.framework.NameAttrList
 
getParserForType() - Method in class org.tensorflow.framework.NamedTensorProto
 
getParserForType() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
getParserForType() - Method in class org.tensorflow.framework.NodeDef
 
getParserForType() - Method in class org.tensorflow.framework.NodeExecStats
 
getParserForType() - Method in class org.tensorflow.framework.NodeOutput
 
getParserForType() - Method in class org.tensorflow.framework.OpDef.ArgDef
 
getParserForType() - Method in class org.tensorflow.framework.OpDef.AttrDef
 
getParserForType() - Method in class org.tensorflow.framework.OpDef
 
getParserForType() - Method in class org.tensorflow.framework.OpDeprecation
 
getParserForType() - Method in class org.tensorflow.framework.OpList
 
getParserForType() - Method in class org.tensorflow.framework.OptimizerOptions
 
getParserForType() - Method in class org.tensorflow.framework.QueueRunnerDef
 
getParserForType() - Method in class org.tensorflow.framework.ReaderBaseState
 
getParserForType() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
getParserForType() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
getParserForType() - Method in class org.tensorflow.framework.ResourceHandleProto
 
getParserForType() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
getParserForType() - Method in class org.tensorflow.framework.RewriterConfig
 
getParserForType() - Method in class org.tensorflow.framework.RPCOptions
 
getParserForType() - Method in class org.tensorflow.framework.RunMetadata
 
getParserForType() - Method in class org.tensorflow.framework.RunOptions.Experimental
 
getParserForType() - Method in class org.tensorflow.framework.RunOptions
 
getParserForType() - Method in class org.tensorflow.framework.SavedModel
 
getParserForType() - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
getParserForType() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
getParserForType() - Method in class org.tensorflow.framework.SignatureDef
 
getParserForType() - Method in class org.tensorflow.framework.StepStats
 
getParserForType() - Method in class org.tensorflow.framework.Summary.Audio
 
getParserForType() - Method in class org.tensorflow.framework.Summary
 
getParserForType() - Method in class org.tensorflow.framework.Summary.Image
 
getParserForType() - Method in class org.tensorflow.framework.Summary.Value
 
getParserForType() - Method in class org.tensorflow.framework.SummaryDescription
 
getParserForType() - Method in class org.tensorflow.framework.SummaryMetadata
 
getParserForType() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
getParserForType() - Method in class org.tensorflow.framework.TensorConnection
 
getParserForType() - Method in class org.tensorflow.framework.TensorDescription
 
getParserForType() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
getParserForType() - Method in class org.tensorflow.framework.TensorInfo
 
getParserForType() - Method in class org.tensorflow.framework.TensorProto
 
getParserForType() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
getParserForType() - Method in class org.tensorflow.framework.TensorShapeProto
 
getParserForType() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
getParserForType() - Method in class org.tensorflow.framework.TensorSliceProto
 
getParserForType() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
getParserForType() - Method in class org.tensorflow.framework.ValuesDef
 
getParserForType() - Method in class org.tensorflow.framework.VariableDef
 
getParserForType() - Method in class org.tensorflow.framework.VariantTensorDataProto
 
getParserForType() - Method in class org.tensorflow.framework.VersionDef
 
getParserForType() - Method in class org.tensorflow.framework.WhileContextDef
 
getParserForType() - Method in class org.tensorflow.util.BundleEntryProto
 
getParserForType() - Method in class org.tensorflow.util.BundleHeaderProto
 
getParserForType() - Method in class org.tensorflow.util.Event
 
getParserForType() - Method in class org.tensorflow.util.IteratorStateMetadata
 
getParserForType() - Method in class org.tensorflow.util.LogMessage
 
getParserForType() - Method in class org.tensorflow.util.SavedSlice
 
getParserForType() - Method in class org.tensorflow.util.SavedSliceMeta
 
getParserForType() - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
getParserForType() - Method in class org.tensorflow.util.SavedTensorSlices
 
getParserForType() - Method in class org.tensorflow.util.SaverDef
 
getParserForType() - Method in class org.tensorflow.util.SessionLog
 
getParserForType() - Method in class org.tensorflow.util.TaggedRunMetadata
 
getParserForType() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
getParserForType() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
getParserForType() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
getParserForType() - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
getParserForType() - Method in class org.tensorflow.util.testlog.CommitId
 
getParserForType() - Method in class org.tensorflow.util.testlog.CPUInfo
 
getParserForType() - Method in class org.tensorflow.util.testlog.EntryValue
 
getParserForType() - Method in class org.tensorflow.util.testlog.GPUInfo
 
getParserForType() - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
getParserForType() - Method in class org.tensorflow.util.testlog.MemoryInfo
 
getParserForType() - Method in class org.tensorflow.util.testlog.PlatformInfo
 
getParserForType() - Method in class org.tensorflow.util.testlog.RunConfiguration
 
getParserForType() - Method in class org.tensorflow.util.testlog.TestResults
 
getParserForType() - Method in class org.tensorflow.util.WatchdogConfig
 
getParserForType() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
getParserForType() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
getParserForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
getParserForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
getParserForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
getParserForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
getParserForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
getParserForType() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
getParserForType() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
getParserForType() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
getParserForType() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
getParserForType() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
getPartitionGraphs(int) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
getPartitionGraphs(int) - Method in class org.tensorflow.framework.RunMetadata
Graphs of the partitions executed by executors.
getPartitionGraphs(int) - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
Graphs of the partitions executed by executors.
getPartitionGraphsBuilder(int) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
getPartitionGraphsBuilderList() - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
getPartitionGraphsCount() - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
getPartitionGraphsCount() - Method in class org.tensorflow.framework.RunMetadata
Graphs of the partitions executed by executors.
getPartitionGraphsCount() - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
Graphs of the partitions executed by executors.
getPartitionGraphsList() - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
getPartitionGraphsList() - Method in class org.tensorflow.framework.RunMetadata
Graphs of the partitions executed by executors.
getPartitionGraphsList() - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
Graphs of the partitions executed by executors.
getPartitionGraphsOrBuilder(int) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
getPartitionGraphsOrBuilder(int) - Method in class org.tensorflow.framework.RunMetadata
Graphs of the partitions executed by executors.
getPartitionGraphsOrBuilder(int) - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
Graphs of the partitions executed by executors.
getPartitionGraphsOrBuilderList() - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
getPartitionGraphsOrBuilderList() - Method in class org.tensorflow.framework.RunMetadata
Graphs of the partitions executed by executors.
getPartitionGraphsOrBuilderList() - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
Graphs of the partitions executed by executors.
getPeakBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
int64 peak_bytes = 3;
getPeakBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
int64 peak_bytes = 3;
getPeakBytes() - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
int64 peak_bytes = 3;
getPendingChangelist() - Method in class org.tensorflow.util.testlog.CommitId.Builder
Changelist tested if the change list is not already submitted.
getPendingChangelist() - Method in class org.tensorflow.util.testlog.CommitId
Changelist tested if the change list is not already submitted.
getPendingChangelist() - Method in interface org.tensorflow.util.testlog.CommitIdOrBuilder
Changelist tested if the change list is not already submitted.
getPerProcessGpuMemoryFraction() - Method in class org.tensorflow.framework.GPUOptions.Builder
Fraction of the available GPU memory to allocate for each process.
getPerProcessGpuMemoryFraction() - Method in class org.tensorflow.framework.GPUOptions
Fraction of the available GPU memory to allocate for each process.
getPerProcessGpuMemoryFraction() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
Fraction of the available GPU memory to allocate for each process.
getPersistentMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Persistent memory used by this node.
getPersistentMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node
Persistent memory used by this node.
getPersistentMemorySize() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Persistent memory used by this node.
getPersistentMemorySize() - Method in class org.tensorflow.framework.MemoryStats.Builder
int64 persistent_memory_size = 3;
getPersistentMemorySize() - Method in class org.tensorflow.framework.MemoryStats
int64 persistent_memory_size = 3;
getPersistentMemorySize() - Method in interface org.tensorflow.framework.MemoryStatsOrBuilder
int64 persistent_memory_size = 3;
getPersistentTensorAllocIds(int) - Method in class org.tensorflow.framework.MemoryStats.Builder
repeated int64 persistent_tensor_alloc_ids = 5;
getPersistentTensorAllocIds(int) - Method in class org.tensorflow.framework.MemoryStats
repeated int64 persistent_tensor_alloc_ids = 5;
getPersistentTensorAllocIds(int) - Method in interface org.tensorflow.framework.MemoryStatsOrBuilder
repeated int64 persistent_tensor_alloc_ids = 5;
getPersistentTensorAllocIdsCount() - Method in class org.tensorflow.framework.MemoryStats.Builder
repeated int64 persistent_tensor_alloc_ids = 5;
getPersistentTensorAllocIdsCount() - Method in class org.tensorflow.framework.MemoryStats
repeated int64 persistent_tensor_alloc_ids = 5;
getPersistentTensorAllocIdsCount() - Method in interface org.tensorflow.framework.MemoryStatsOrBuilder
repeated int64 persistent_tensor_alloc_ids = 5;
getPersistentTensorAllocIdsList() - Method in class org.tensorflow.framework.MemoryStats.Builder
repeated int64 persistent_tensor_alloc_ids = 5;
getPersistentTensorAllocIdsList() - Method in class org.tensorflow.framework.MemoryStats
repeated int64 persistent_tensor_alloc_ids = 5;
getPersistentTensorAllocIdsList() - Method in interface org.tensorflow.framework.MemoryStatsOrBuilder
repeated int64 persistent_tensor_alloc_ids = 5;
getPhysicalDescription() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
The physical description of this device.
getPhysicalDescription() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
The physical description of this device.
getPhysicalDescription() - Method in interface org.tensorflow.util.testlog.AvailableDeviceInfoOrBuilder
The physical description of this device.
getPhysicalDescriptionBytes() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
The physical description of this device.
getPhysicalDescriptionBytes() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
The physical description of this device.
getPhysicalDescriptionBytes() - Method in interface org.tensorflow.util.testlog.AvailableDeviceInfoOrBuilder
The physical description of this device.
getPhysicalDeviceDesc() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
String representation of the physical device that this device maps to.
getPhysicalDeviceDesc() - Method in class org.tensorflow.framework.DeviceAttributes
String representation of the physical device that this device maps to.
getPhysicalDeviceDesc() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
String representation of the physical device that this device maps to.
getPhysicalDeviceDescBytes() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
String representation of the physical device that this device maps to.
getPhysicalDeviceDescBytes() - Method in class org.tensorflow.framework.DeviceAttributes
String representation of the physical device that this device maps to.
getPhysicalDeviceDescBytes() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
String representation of the physical device that this device maps to.
getPinToHostOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Force small ops onto the CPU (default is OFF).
getPinToHostOptimization() - Method in class org.tensorflow.framework.RewriterConfig
Force small ops onto the CPU (default is OFF).
getPinToHostOptimization() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Force small ops onto the CPU (default is OFF).
getPinToHostOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Force small ops onto the CPU (default is OFF).
getPinToHostOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig
Force small ops onto the CPU (default is OFF).
getPinToHostOptimizationValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Force small ops onto the CPU (default is OFF).
getPivotForBodyName() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot_for_body tensor.
getPivotForBodyName() - Method in class org.tensorflow.framework.WhileContextDef
Name of the pivot_for_body tensor.
getPivotForBodyName() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Name of the pivot_for_body tensor.
getPivotForBodyNameBytes() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot_for_body tensor.
getPivotForBodyNameBytes() - Method in class org.tensorflow.framework.WhileContextDef
Name of the pivot_for_body tensor.
getPivotForBodyNameBytes() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Name of the pivot_for_body tensor.
getPivotForPredName() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot_for_pred tensor.
getPivotForPredName() - Method in class org.tensorflow.framework.WhileContextDef
Name of the pivot_for_pred tensor.
getPivotForPredName() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Name of the pivot_for_pred tensor.
getPivotForPredNameBytes() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot_for_pred tensor.
getPivotForPredNameBytes() - Method in class org.tensorflow.framework.WhileContextDef
Name of the pivot_for_pred tensor.
getPivotForPredNameBytes() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Name of the pivot_for_pred tensor.
getPivotName() - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the pivot tensor.
getPivotName() - Method in class org.tensorflow.framework.CondContextDef
Name of the pivot tensor.
getPivotName() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Name of the pivot tensor.
getPivotName() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot tensor.
getPivotName() - Method in class org.tensorflow.framework.WhileContextDef
Name of the pivot tensor.
getPivotName() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Name of the pivot tensor.
getPivotNameBytes() - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the pivot tensor.
getPivotNameBytes() - Method in class org.tensorflow.framework.CondContextDef
Name of the pivot tensor.
getPivotNameBytes() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Name of the pivot tensor.
getPivotNameBytes() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot tensor.
getPivotNameBytes() - Method in class org.tensorflow.framework.WhileContextDef
Name of the pivot tensor.
getPivotNameBytes() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Name of the pivot tensor.
getPlaceholder() - Method in class org.tensorflow.framework.AttrValue.Builder
This is a placeholder only used in nodes defined inside a function.
getPlaceholder() - Method in class org.tensorflow.framework.AttrValue
This is a placeholder only used in nodes defined inside a function.
getPlaceholder() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
This is a placeholder only used in nodes defined inside a function.
getPlaceholderBytes() - Method in class org.tensorflow.framework.AttrValue.Builder
This is a placeholder only used in nodes defined inside a function.
getPlaceholderBytes() - Method in class org.tensorflow.framework.AttrValue
This is a placeholder only used in nodes defined inside a function.
getPlaceholderBytes() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
This is a placeholder only used in nodes defined inside a function.
getPlacementPeriod() - Method in class org.tensorflow.framework.ConfigProto.Builder
Assignment of Nodes to Devices is recomputed every placement_period steps until the system warms up (at which point the recomputation typically slows down automatically).
getPlacementPeriod() - Method in class org.tensorflow.framework.ConfigProto
Assignment of Nodes to Devices is recomputed every placement_period steps until the system warms up (at which point the recomputation typically slows down automatically).
getPlacementPeriod() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Assignment of Nodes to Devices is recomputed every placement_period steps until the system warms up (at which point the recomputation typically slows down automatically).
getPlacePrunedGraph() - Method in class org.tensorflow.framework.GraphOptions.Builder
Only place the subgraphs that are run, rather than the entire graph.
getPlacePrunedGraph() - Method in class org.tensorflow.framework.GraphOptions
Only place the subgraphs that are run, rather than the entire graph.
getPlacePrunedGraph() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
Only place the subgraphs that are run, rather than the entire graph.
getPlatformInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Additional platform information.
getPlatformInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Additional platform information.
getPlatformInfo() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Additional platform information.
getPlatformInfoBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Additional platform information.
getPlatformInfoOrBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Additional platform information.
getPlatformInfoOrBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Additional platform information.
getPlatformInfoOrBuilder() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Additional platform information.
getPluginData() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Data that associates a summary with a certain plugin.
getPluginData() - Method in class org.tensorflow.framework.SummaryMetadata
Data that associates a summary with a certain plugin.
getPluginData() - Method in interface org.tensorflow.framework.SummaryMetadataOrBuilder
Data that associates a summary with a certain plugin.
getPluginDataBuilder() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Data that associates a summary with a certain plugin.
getPluginDataOrBuilder() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Data that associates a summary with a certain plugin.
getPluginDataOrBuilder() - Method in class org.tensorflow.framework.SummaryMetadata
Data that associates a summary with a certain plugin.
getPluginDataOrBuilder() - Method in interface org.tensorflow.framework.SummaryMetadataOrBuilder
Data that associates a summary with a certain plugin.
getPluginName() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
The name of the plugin this data pertains to.
getPluginName() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
The name of the plugin this data pertains to.
getPluginName() - Method in interface org.tensorflow.framework.SummaryMetadata.PluginDataOrBuilder
The name of the plugin this data pertains to.
getPluginNameBytes() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
The name of the plugin this data pertains to.
getPluginNameBytes() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
The name of the plugin this data pertains to.
getPluginNameBytes() - Method in interface org.tensorflow.framework.SummaryMetadata.PluginDataOrBuilder
The name of the plugin this data pertains to.
getPollingActiveDelayUsecs() - Method in class org.tensorflow.framework.GPUOptions.Builder
In the event polling loop sleep this many microseconds between PollEvents calls, when the queue is not empty.
getPollingActiveDelayUsecs() - Method in class org.tensorflow.framework.GPUOptions
In the event polling loop sleep this many microseconds between PollEvents calls, when the queue is not empty.
getPollingActiveDelayUsecs() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
In the event polling loop sleep this many microseconds between PollEvents calls, when the queue is not empty.
getPollingInactiveDelayMsecs() - Method in class org.tensorflow.framework.GPUOptions.Builder
This field is deprecated and ignored.
getPollingInactiveDelayMsecs() - Method in class org.tensorflow.framework.GPUOptions
This field is deprecated and ignored.
getPollingInactiveDelayMsecs() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
This field is deprecated and ignored.
getPrecedingNode() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
int32 preceding_node = 1;
getPrecedingNode() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
int32 preceding_node = 1;
getPrecedingNode() - Method in interface org.tensorflow.framework.CostGraphDef.Node.InputInfoOrBuilder
int32 preceding_node = 1;
getPrecedingPort() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
int32 preceding_port = 2;
getPrecedingPort() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
int32 preceding_port = 2;
getPrecedingPort() - Method in interface org.tensorflow.framework.CostGraphDef.Node.InputInfoOrBuilder
int32 preceding_port = 2;
getPredName() - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the pred tensor.
getPredName() - Method in class org.tensorflow.framework.CondContextDef
Name of the pred tensor.
getPredName() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Name of the pred tensor.
getPredNameBytes() - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the pred tensor.
getPredNameBytes() - Method in class org.tensorflow.framework.CondContextDef
Name of the pred tensor.
getPredNameBytes() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Name of the pred tensor.
getPriority() - Method in class org.tensorflow.framework.KernelDef.Builder
Prioritization of kernel amongst different devices.
getPriority() - Method in class org.tensorflow.framework.KernelDef
Prioritization of kernel amongst different devices.
getPriority() - Method in interface org.tensorflow.framework.KernelDefOrBuilder
Prioritization of kernel amongst different devices.
getProducer() - Method in class org.tensorflow.framework.VersionDef.Builder
The version of the code that produced this data.
getProducer() - Method in class org.tensorflow.framework.VersionDef
The version of the code that produced this data.
getProducer() - Method in interface org.tensorflow.framework.VersionDefOrBuilder
The version of the code that produced this data.
getProperties() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
.tensorflow.DeviceProperties properties = 2;
getProperties() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
.tensorflow.DeviceProperties properties = 2;
getProperties() - Method in interface tensorflow.DevicePropertiesProtos.NamedDeviceOrBuilder
.tensorflow.DeviceProperties properties = 2;
getPropertiesBuilder() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
.tensorflow.DeviceProperties properties = 2;
getPropertiesOrBuilder() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
.tensorflow.DeviceProperties properties = 2;
getPropertiesOrBuilder() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
.tensorflow.DeviceProperties properties = 2;
getPropertiesOrBuilder() - Method in interface tensorflow.DevicePropertiesProtos.NamedDeviceOrBuilder
.tensorflow.DeviceProperties properties = 2;
getProtocol() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The protocol to be used by this server.
getProtocol() - Method in class org.tensorflow.distruntime.ServerDef
The protocol to be used by this server.
getProtocol() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The protocol to be used by this server.
getProtocolBytes() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The protocol to be used by this server.
getProtocolBytes() - Method in class org.tensorflow.distruntime.ServerDef
The protocol to be used by this server.
getProtocolBytes() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The protocol to be used by this server.
getPtr() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Address of the allocation.
getPtr() - Method in class org.tensorflow.framework.AllocationDescription
Address of the allocation.
getPtr() - Method in interface org.tensorflow.framework.AllocationDescriptionOrBuilder
Address of the allocation.
getPtr() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Address of the allocation.
getPtr() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
Address of the allocation.
getPtr() - Method in interface org.tensorflow.framework.MemoryLogRawAllocationOrBuilder
Address of the allocation.
getQueueClosedExceptionTypes(int) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypes(int) - Method in class org.tensorflow.framework.QueueRunnerDef
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypes(int) - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesCount() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesCount() - Method in class org.tensorflow.framework.QueueRunnerDef
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesCount() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesList() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesList() - Method in class org.tensorflow.framework.QueueRunnerDef
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesList() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesValue(int) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesValue(int) - Method in class org.tensorflow.framework.QueueRunnerDef
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesValue(int) - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesValueList() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesValueList() - Method in class org.tensorflow.framework.QueueRunnerDef
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueClosedExceptionTypesValueList() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
getQueueName() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
Queue name.
getQueueName() - Method in class org.tensorflow.framework.QueueRunnerDef
Queue name.
getQueueName() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
Queue name.
getQueueNameBytes() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
Queue name.
getQueueNameBytes() - Method in class org.tensorflow.framework.QueueRunnerDef
Queue name.
getQueueNameBytes() - Method in interface org.tensorflow.framework.QueueRunnerDefOrBuilder
Queue name.
getRecvBufMaxChunk() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Guidance to formatting of large RecvBuf fields for transfer.
getRecvBufMaxChunk() - Method in class org.tensorflow.framework.ConfigProto.Experimental
Guidance to formatting of large RecvBuf fields for transfer.
getRecvBufMaxChunk() - Method in interface org.tensorflow.framework.ConfigProto.ExperimentalOrBuilder
Guidance to formatting of large RecvBuf fields for transfer.
getReferencedTensor(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensor(int) - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensor(int) - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorBuilderList() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorCount() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorCount() - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorCount() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorList() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorList() - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorList() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorOrBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorOrBuilder(int) - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorOrBuilder(int) - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorOrBuilderList() - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorOrBuilderList() - Method in class org.tensorflow.framework.NodeExecStats
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getReferencedTensorOrBuilderList() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
getRelease() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getRelease() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getRelease() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getReleaseBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getReleaseBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getReleaseBytes() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getRemapping() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Remapping (default is ON) Remap subgraphs onto more efficient implementations.
getRemapping() - Method in class org.tensorflow.framework.RewriterConfig
Remapping (default is ON) Remap subgraphs onto more efficient implementations.
getRemapping() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Remapping (default is ON) Remap subgraphs onto more efficient implementations.
getRemappingValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Remapping (default is ON) Remap subgraphs onto more efficient implementations.
getRemappingValue() - Method in class org.tensorflow.framework.RewriterConfig
Remapping (default is ON) Remap subgraphs onto more efficient implementations.
getRemappingValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Remapping (default is ON) Remap subgraphs onto more efficient implementations.
getRemoteGraph() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Definition of remote graph
getRemoteGraph() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Definition of remote graph
getRemoteGraph() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Definition of remote graph
getRemoteGraphBuilder() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Definition of remote graph
getRemoteGraphOrBuilder() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Definition of remote graph
getRemoteGraphOrBuilder() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Definition of remote graph
getRemoteGraphOrBuilder() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Definition of remote graph
getRenameTo() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
Change the name used to access this arg in the API from what is used in the GraphDef.
getRenameTo() - Method in class org.tensorflow.framework.ApiDef.Arg
Change the name used to access this arg in the API from what is used in the GraphDef.
getRenameTo() - Method in interface org.tensorflow.framework.ApiDef.ArgOrBuilder
Change the name used to access this arg in the API from what is used in the GraphDef.
getRenameTo() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Change the name used to access this attr in the API from what is used in the GraphDef.
getRenameTo() - Method in class org.tensorflow.framework.ApiDef.Attr
Change the name used to access this attr in the API from what is used in the GraphDef.
getRenameTo() - Method in interface org.tensorflow.framework.ApiDef.AttrOrBuilder
Change the name used to access this attr in the API from what is used in the GraphDef.
getRenameToBytes() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
Change the name used to access this arg in the API from what is used in the GraphDef.
getRenameToBytes() - Method in class org.tensorflow.framework.ApiDef.Arg
Change the name used to access this arg in the API from what is used in the GraphDef.
getRenameToBytes() - Method in interface org.tensorflow.framework.ApiDef.ArgOrBuilder
Change the name used to access this arg in the API from what is used in the GraphDef.
getRenameToBytes() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Change the name used to access this attr in the API from what is used in the GraphDef.
getRenameToBytes() - Method in class org.tensorflow.framework.ApiDef.Attr
Change the name used to access this attr in the API from what is used in the GraphDef.
getRenameToBytes() - Method in interface org.tensorflow.framework.ApiDef.AttrOrBuilder
Change the name used to access this attr in the API from what is used in the GraphDef.
getReportTensorAllocationsUponOom() - Method in class org.tensorflow.framework.RunOptions.Builder
When enabled, causes tensor allocation information to be included in the error message when the Run() call fails because the allocator ran out of memory (OOM).
getReportTensorAllocationsUponOom() - Method in class org.tensorflow.framework.RunOptions
When enabled, causes tensor allocation information to be included in the error message when the Run() call fails because the allocator ran out of memory (OOM).
getReportTensorAllocationsUponOom() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
When enabled, causes tensor allocation information to be included in the error message when the Run() call fails because the allocator ran out of memory (OOM).
getRequestedBytes() - Method in class org.tensorflow.framework.AllocationDescription.Builder
Total number of bytes requested
getRequestedBytes() - Method in class org.tensorflow.framework.AllocationDescription
Total number of bytes requested
getRequestedBytes() - Method in interface org.tensorflow.framework.AllocationDescriptionOrBuilder
Total number of bytes requested
getResetDiskByteUsage() - Method in class org.tensorflow.framework.DebugOptions.Builder
Whether the total disk usage of tfdbg is to be reset to zero in this Session.run call.
getResetDiskByteUsage() - Method in class org.tensorflow.framework.DebugOptions
Whether the total disk usage of tfdbg is to be reset to zero in this Session.run call.
getResetDiskByteUsage() - Method in interface org.tensorflow.framework.DebugOptionsOrBuilder
Whether the total disk usage of tfdbg is to be reset to zero in this Session.run call.
getResourceHandleVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
getResourceHandleVal(int) - Method in class org.tensorflow.framework.TensorProto
DT_RESOURCE
getResourceHandleVal(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_RESOURCE
getResourceHandleValBuilder(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
getResourceHandleValBuilderList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
getResourceHandleValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
getResourceHandleValCount() - Method in class org.tensorflow.framework.TensorProto
DT_RESOURCE
getResourceHandleValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_RESOURCE
getResourceHandleValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
getResourceHandleValList() - Method in class org.tensorflow.framework.TensorProto
DT_RESOURCE
getResourceHandleValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_RESOURCE
getResourceHandleValOrBuilder(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
getResourceHandleValOrBuilder(int) - Method in class org.tensorflow.framework.TensorProto
DT_RESOURCE
getResourceHandleValOrBuilder(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_RESOURCE
getResourceHandleValOrBuilderList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
getResourceHandleValOrBuilderList() - Method in class org.tensorflow.framework.TensorProto
DT_RESOURCE
getResourceHandleValOrBuilderList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_RESOURCE
getRestoreOpName() - Method in class org.tensorflow.util.SaverDef.Builder
The operation to run when restoring a model checkpoint.
getRestoreOpName() - Method in class org.tensorflow.util.SaverDef
The operation to run when restoring a model checkpoint.
getRestoreOpName() - Method in interface org.tensorflow.util.SaverDefOrBuilder
The operation to run when restoring a model checkpoint.
getRestoreOpNameBytes() - Method in class org.tensorflow.util.SaverDef.Builder
The operation to run when restoring a model checkpoint.
getRestoreOpNameBytes() - Method in class org.tensorflow.util.SaverDef
The operation to run when restoring a model checkpoint.
getRestoreOpNameBytes() - Method in interface org.tensorflow.util.SaverDefOrBuilder
The operation to run when restoring a model checkpoint.
getRet() - Method in class org.tensorflow.framework.FunctionDef.Builder
Deprecated.
getRet() - Method in class org.tensorflow.framework.FunctionDef
Deprecated.
getRet() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
Deprecated.
getRetCount() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
getRetCount() - Method in class org.tensorflow.framework.FunctionDef
 
getRetCount() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
getRetMap() - Method in class org.tensorflow.framework.FunctionDef.Builder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
getRetMap() - Method in class org.tensorflow.framework.FunctionDef
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
getRetMap() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
getRetOrDefault(String, String) - Method in class org.tensorflow.framework.FunctionDef.Builder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
getRetOrDefault(String, String) - Method in class org.tensorflow.framework.FunctionDef
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
getRetOrDefault(String, String) - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
getRetOrThrow(String) - Method in class org.tensorflow.framework.FunctionDef.Builder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
getRetOrThrow(String) - Method in class org.tensorflow.framework.FunctionDef
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
getRetOrThrow(String) - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
getRewriteOptions() - Method in class org.tensorflow.framework.GraphOptions.Builder
Options that control the type and amount of graph rewriting.
getRewriteOptions() - Method in class org.tensorflow.framework.GraphOptions
Options that control the type and amount of graph rewriting.
getRewriteOptions() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
Options that control the type and amount of graph rewriting.
getRewriteOptionsBuilder() - Method in class org.tensorflow.framework.GraphOptions.Builder
Options that control the type and amount of graph rewriting.
getRewriteOptionsOrBuilder() - Method in class org.tensorflow.framework.GraphOptions.Builder
Options that control the type and amount of graph rewriting.
getRewriteOptionsOrBuilder() - Method in class org.tensorflow.framework.GraphOptions
Options that control the type and amount of graph rewriting.
getRewriteOptionsOrBuilder() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
Options that control the type and amount of graph rewriting.
getRpcOptions() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply when this session uses the distributed runtime.
getRpcOptions() - Method in class org.tensorflow.framework.ConfigProto
Options that apply when this session uses the distributed runtime.
getRpcOptions() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Options that apply when this session uses the distributed runtime.
getRpcOptionsBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply when this session uses the distributed runtime.
getRpcOptionsOrBuilder() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply when this session uses the distributed runtime.
getRpcOptionsOrBuilder() - Method in class org.tensorflow.framework.ConfigProto
Options that apply when this session uses the distributed runtime.
getRpcOptionsOrBuilder() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Options that apply when this session uses the distributed runtime.
getRunConfiguration() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Run-specific parameters (arguments, etc)
getRunConfiguration() - Method in class org.tensorflow.util.testlog.TestResults
Run-specific parameters (arguments, etc)
getRunConfiguration() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
Run-specific parameters (arguments, etc)
getRunConfigurationBuilder() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Run-specific parameters (arguments, etc)
getRunConfigurationOrBuilder() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Run-specific parameters (arguments, etc)
getRunConfigurationOrBuilder() - Method in class org.tensorflow.util.testlog.TestResults
Run-specific parameters (arguments, etc)
getRunConfigurationOrBuilder() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
Run-specific parameters (arguments, etc)
getRunMetadata() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
Byte-encoded version of the `RunMetadata` proto in order to allow lazy deserialization.
getRunMetadata() - Method in class org.tensorflow.util.TaggedRunMetadata
Byte-encoded version of the `RunMetadata` proto in order to allow lazy deserialization.
getRunMetadata() - Method in interface org.tensorflow.util.TaggedRunMetadataOrBuilder
Byte-encoded version of the `RunMetadata` proto in order to allow lazy deserialization.
getRunMode() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Used for differentiating between continuous and debug builds.
getRunMode() - Method in class org.tensorflow.util.testlog.TestResults
Used for differentiating between continuous and debug builds.
getRunMode() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
Used for differentiating between continuous and debug builds.
getRunModeBytes() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Used for differentiating between continuous and debug builds.
getRunModeBytes() - Method in class org.tensorflow.util.testlog.TestResults
Used for differentiating between continuous and debug builds.
getRunModeBytes() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
Used for differentiating between continuous and debug builds.
getRunOptions() - Method in class org.tensorflow.framework.CallableOptions.Builder
Options that will be applied to each run.
getRunOptions() - Method in class org.tensorflow.framework.CallableOptions
Options that will be applied to each run.
getRunOptions() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Options that will be applied to each run.
getRunOptionsBuilder() - Method in class org.tensorflow.framework.CallableOptions.Builder
Options that will be applied to each run.
getRunOptionsOrBuilder() - Method in class org.tensorflow.framework.CallableOptions.Builder
Options that will be applied to each run.
getRunOptionsOrBuilder() - Method in class org.tensorflow.framework.CallableOptions
Options that will be applied to each run.
getRunOptionsOrBuilder() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Options that will be applied to each run.
getRunTime() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The amount of time the total run took (wall time in seconds)
getRunTime() - Method in class org.tensorflow.util.testlog.TestResults
The amount of time the total run took (wall time in seconds)
getRunTime() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The amount of time the total run took (wall time in seconds)
getS() - Method in class org.tensorflow.framework.AttrValue.Builder
"string"
getS() - Method in class org.tensorflow.framework.AttrValue
"string"
getS(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(string)"
getS(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(string)"
getS(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(string)"
getS() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"string"
getSampleRate() - Method in class org.tensorflow.framework.Summary.Audio.Builder
Sample rate of the audio in Hz.
getSampleRate() - Method in class org.tensorflow.framework.Summary.Audio
Sample rate of the audio in Hz.
getSampleRate() - Method in interface org.tensorflow.framework.Summary.AudioOrBuilder
Sample rate of the audio in Hz.
getSavedModelSchemaVersion() - Method in class org.tensorflow.framework.SavedModel.Builder
The schema version of the SavedModel instance.
getSavedModelSchemaVersion() - Method in class org.tensorflow.framework.SavedModel
The schema version of the SavedModel instance.
getSavedModelSchemaVersion() - Method in interface org.tensorflow.framework.SavedModelOrBuilder
The schema version of the SavedModel instance.
getSaverDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
SaverDef.
getSaverDef() - Method in class org.tensorflow.framework.MetaGraphDef
SaverDef.
getSaverDef() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
SaverDef.
getSaverDefBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
SaverDef.
getSaverDefOrBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
SaverDef.
getSaverDefOrBuilder() - Method in class org.tensorflow.framework.MetaGraphDef
SaverDef.
getSaverDefOrBuilder() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
SaverDef.
getSaveSliceInfoDef() - Method in class org.tensorflow.framework.VariableDef.Builder
Support for saving variables as slices of a larger variable.
getSaveSliceInfoDef() - Method in class org.tensorflow.framework.VariableDef
Support for saving variables as slices of a larger variable.
getSaveSliceInfoDef() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Support for saving variables as slices of a larger variable.
getSaveSliceInfoDefBuilder() - Method in class org.tensorflow.framework.VariableDef.Builder
Support for saving variables as slices of a larger variable.
getSaveSliceInfoDefOrBuilder() - Method in class org.tensorflow.framework.VariableDef.Builder
Support for saving variables as slices of a larger variable.
getSaveSliceInfoDefOrBuilder() - Method in class org.tensorflow.framework.VariableDef
Support for saving variables as slices of a larger variable.
getSaveSliceInfoDefOrBuilder() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Support for saving variables as slices of a larger variable.
getSaveTensorName() - Method in class org.tensorflow.util.SaverDef.Builder
The operation to run when saving a model checkpoint.
getSaveTensorName() - Method in class org.tensorflow.util.SaverDef
The operation to run when saving a model checkpoint.
getSaveTensorName() - Method in interface org.tensorflow.util.SaverDefOrBuilder
The operation to run when saving a model checkpoint.
getSaveTensorNameBytes() - Method in class org.tensorflow.util.SaverDef.Builder
The operation to run when saving a model checkpoint.
getSaveTensorNameBytes() - Method in class org.tensorflow.util.SaverDef
The operation to run when saving a model checkpoint.
getSaveTensorNameBytes() - Method in interface org.tensorflow.util.SaverDefOrBuilder
The operation to run when saving a model checkpoint.
getScheduledMicros() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 scheduled_micros = 9;
getScheduledMicros() - Method in class org.tensorflow.framework.NodeExecStats
int64 scheduled_micros = 9;
getScheduledMicros() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
int64 scheduled_micros = 9;
getScheduledNanos() - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 scheduled_nanos = 17;
getScheduledNanos() - Method in class org.tensorflow.framework.NodeExecStats
int64 scheduled_nanos = 17;
getScheduledNanos() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
int64 scheduled_nanos = 17;
getScomplexVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX64.
getScomplexVal(int) - Method in class org.tensorflow.framework.TensorProto
DT_COMPLEX64.
getScomplexVal(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_COMPLEX64.
getScomplexValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX64.
getScomplexValCount() - Method in class org.tensorflow.framework.TensorProto
DT_COMPLEX64.
getScomplexValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_COMPLEX64.
getScomplexValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX64.
getScomplexValList() - Method in class org.tensorflow.framework.TensorProto
DT_COMPLEX64.
getScomplexValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_COMPLEX64.
getScopedAllocatorOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Try to allocate some independent Op outputs contiguously in order to merge or eliminate downstream Ops (off by default).
getScopedAllocatorOptimization() - Method in class org.tensorflow.framework.RewriterConfig
Try to allocate some independent Op outputs contiguously in order to merge or eliminate downstream Ops (off by default).
getScopedAllocatorOptimization() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Try to allocate some independent Op outputs contiguously in order to merge or eliminate downstream Ops (off by default).
getScopedAllocatorOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Try to allocate some independent Op outputs contiguously in order to merge or eliminate downstream Ops (off by default).
getScopedAllocatorOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig
Try to allocate some independent Op outputs contiguously in order to merge or eliminate downstream Ops (off by default).
getScopedAllocatorOptimizationValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Try to allocate some independent Op outputs contiguously in order to merge or eliminate downstream Ops (off by default).
getScopedAllocatorOpts() - Method in class org.tensorflow.framework.RewriterConfig.Builder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
getScopedAllocatorOpts() - Method in class org.tensorflow.framework.RewriterConfig
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
getScopedAllocatorOpts() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
getScopedAllocatorOptsBuilder() - Method in class org.tensorflow.framework.RewriterConfig.Builder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
getScopedAllocatorOptsOrBuilder() - Method in class org.tensorflow.framework.RewriterConfig.Builder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
getScopedAllocatorOptsOrBuilder() - Method in class org.tensorflow.framework.RewriterConfig
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
getScopedAllocatorOptsOrBuilder() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
getSCount() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(string)"
getSCount() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(string)"
getSCount() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(string)"
getSerialIdentifier() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Unique serial number of the machine.
getSerialIdentifier() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Unique serial number of the machine.
getSerialIdentifier() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Unique serial number of the machine.
getSerialIdentifierBytes() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Unique serial number of the machine.
getSerialIdentifierBytes() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Unique serial number of the machine.
getSerialIdentifierBytes() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Unique serial number of the machine.
getSerializedExecutorParameters() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Parameters given to the executor
getSerializedExecutorParameters() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Optional: Parameters given to the executor
getSerializedExecutorParameters() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Optional: Parameters given to the executor
getSerializedSize() - Method in class org.tensorflow.distruntime.ClusterDef
 
getSerializedSize() - Method in class org.tensorflow.distruntime.JobDef
 
getSerializedSize() - Method in class org.tensorflow.distruntime.ServerDef
 
getSerializedSize() - Method in class org.tensorflow.example.BytesList
 
getSerializedSize() - Method in class org.tensorflow.example.Example
 
getSerializedSize() - Method in class org.tensorflow.example.ExampleParserConfiguration
 
getSerializedSize() - Method in class org.tensorflow.example.Feature
 
getSerializedSize() - Method in class org.tensorflow.example.FeatureConfiguration
 
getSerializedSize() - Method in class org.tensorflow.example.FeatureList
 
getSerializedSize() - Method in class org.tensorflow.example.FeatureLists
 
getSerializedSize() - Method in class org.tensorflow.example.Features
 
getSerializedSize() - Method in class org.tensorflow.example.FixedLenFeatureProto
 
getSerializedSize() - Method in class org.tensorflow.example.FloatList
 
getSerializedSize() - Method in class org.tensorflow.example.Int64List
 
getSerializedSize() - Method in class org.tensorflow.example.SequenceExample
 
getSerializedSize() - Method in class org.tensorflow.example.VarLenFeatureProto
 
getSerializedSize() - Method in class org.tensorflow.framework.AllocationDescription
 
getSerializedSize() - Method in class org.tensorflow.framework.AllocationRecord
 
getSerializedSize() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
getSerializedSize() - Method in class org.tensorflow.framework.ApiDef.Arg
 
getSerializedSize() - Method in class org.tensorflow.framework.ApiDef.Attr
 
getSerializedSize() - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
getSerializedSize() - Method in class org.tensorflow.framework.ApiDef
 
getSerializedSize() - Method in class org.tensorflow.framework.ApiDefs
 
getSerializedSize() - Method in class org.tensorflow.framework.AssetFileDef
 
getSerializedSize() - Method in class org.tensorflow.framework.AttrValue
 
getSerializedSize() - Method in class org.tensorflow.framework.AttrValue.ListValue
 
getSerializedSize() - Method in class org.tensorflow.framework.AutoParallelOptions
 
getSerializedSize() - Method in class org.tensorflow.framework.CallableOptions
 
getSerializedSize() - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
getSerializedSize() - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
getSerializedSize() - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
getSerializedSize() - Method in class org.tensorflow.framework.CollectionDef
 
getSerializedSize() - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
getSerializedSize() - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
getSerializedSize() - Method in class org.tensorflow.framework.CondContextDef
 
getSerializedSize() - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
getSerializedSize() - Method in class org.tensorflow.framework.ConfigProto
 
getSerializedSize() - Method in class org.tensorflow.framework.ControlFlowContextDef
 
getSerializedSize() - Method in class org.tensorflow.framework.CostGraphDef
 
getSerializedSize() - Method in class org.tensorflow.framework.CostGraphDef.Node
 
getSerializedSize() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.DebuggedSourceFile
 
getSerializedSize() - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
getSerializedSize() - Method in class org.tensorflow.framework.DebugOptions
 
getSerializedSize() - Method in class org.tensorflow.framework.DebugTensorWatch
 
getSerializedSize() - Method in class org.tensorflow.framework.DeviceAttributes
 
getSerializedSize() - Method in class org.tensorflow.framework.DeviceLocality
 
getSerializedSize() - Method in class org.tensorflow.framework.DeviceStepStats
 
getSerializedSize() - Method in class org.tensorflow.framework.FunctionDef
 
getSerializedSize() - Method in class org.tensorflow.framework.FunctionDefLibrary
 
getSerializedSize() - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
getSerializedSize() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
getSerializedSize() - Method in class org.tensorflow.framework.GPUOptions
 
getSerializedSize() - Method in class org.tensorflow.framework.GradientDef
 
getSerializedSize() - Method in class org.tensorflow.framework.GraphDef
 
getSerializedSize() - Method in class org.tensorflow.framework.GraphOptions
 
getSerializedSize() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.GraphTransferInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
getSerializedSize() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.HistogramProto
 
getSerializedSize() - Method in class org.tensorflow.framework.InterconnectLink
 
getSerializedSize() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
getSerializedSize() - Method in class org.tensorflow.framework.KernelDef
 
getSerializedSize() - Method in class org.tensorflow.framework.KernelList
 
getSerializedSize() - Method in class org.tensorflow.framework.LocalLinks
 
getSerializedSize() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
getSerializedSize() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
getSerializedSize() - Method in class org.tensorflow.framework.MemoryLogStep
 
getSerializedSize() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
getSerializedSize() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
getSerializedSize() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
getSerializedSize() - Method in class org.tensorflow.framework.MemoryStats
 
getSerializedSize() - Method in class org.tensorflow.framework.MetaGraphDef
 
getSerializedSize() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
getSerializedSize() - Method in class org.tensorflow.framework.NameAttrList
 
getSerializedSize() - Method in class org.tensorflow.framework.NamedTensorProto
 
getSerializedSize() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.NodeDef
 
getSerializedSize() - Method in class org.tensorflow.framework.NodeExecStats
 
getSerializedSize() - Method in class org.tensorflow.framework.NodeOutput
 
getSerializedSize() - Method in class org.tensorflow.framework.OpDef.ArgDef
 
getSerializedSize() - Method in class org.tensorflow.framework.OpDef.AttrDef
 
getSerializedSize() - Method in class org.tensorflow.framework.OpDef
 
getSerializedSize() - Method in class org.tensorflow.framework.OpDeprecation
 
getSerializedSize() - Method in class org.tensorflow.framework.OpList
 
getSerializedSize() - Method in class org.tensorflow.framework.OptimizerOptions
 
getSerializedSize() - Method in class org.tensorflow.framework.QueueRunnerDef
 
getSerializedSize() - Method in class org.tensorflow.framework.ReaderBaseState
 
getSerializedSize() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
getSerializedSize() - Method in class org.tensorflow.framework.ResourceHandleProto
 
getSerializedSize() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
getSerializedSize() - Method in class org.tensorflow.framework.RewriterConfig
 
getSerializedSize() - Method in class org.tensorflow.framework.RPCOptions
 
getSerializedSize() - Method in class org.tensorflow.framework.RunMetadata
 
getSerializedSize() - Method in class org.tensorflow.framework.RunOptions.Experimental
 
getSerializedSize() - Method in class org.tensorflow.framework.RunOptions
 
getSerializedSize() - Method in class org.tensorflow.framework.SavedModel
 
getSerializedSize() - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
getSerializedSize() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
getSerializedSize() - Method in class org.tensorflow.framework.SignatureDef
 
getSerializedSize() - Method in class org.tensorflow.framework.StepStats
 
getSerializedSize() - Method in class org.tensorflow.framework.Summary.Audio
 
getSerializedSize() - Method in class org.tensorflow.framework.Summary
 
getSerializedSize() - Method in class org.tensorflow.framework.Summary.Image
 
getSerializedSize() - Method in class org.tensorflow.framework.Summary.Value
 
getSerializedSize() - Method in class org.tensorflow.framework.SummaryDescription
 
getSerializedSize() - Method in class org.tensorflow.framework.SummaryMetadata
 
getSerializedSize() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
getSerializedSize() - Method in class org.tensorflow.framework.TensorConnection
 
getSerializedSize() - Method in class org.tensorflow.framework.TensorDescription
 
getSerializedSize() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
getSerializedSize() - Method in class org.tensorflow.framework.TensorInfo
 
getSerializedSize() - Method in class org.tensorflow.framework.TensorProto
 
getSerializedSize() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
getSerializedSize() - Method in class org.tensorflow.framework.TensorShapeProto
 
getSerializedSize() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
getSerializedSize() - Method in class org.tensorflow.framework.TensorSliceProto
 
getSerializedSize() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
getSerializedSize() - Method in class org.tensorflow.framework.ValuesDef
 
getSerializedSize() - Method in class org.tensorflow.framework.VariableDef
 
getSerializedSize() - Method in class org.tensorflow.framework.VariantTensorDataProto
 
getSerializedSize() - Method in class org.tensorflow.framework.VersionDef
 
getSerializedSize() - Method in class org.tensorflow.framework.WhileContextDef
 
getSerializedSize() - Method in class org.tensorflow.util.BundleEntryProto
 
getSerializedSize() - Method in class org.tensorflow.util.BundleHeaderProto
 
getSerializedSize() - Method in class org.tensorflow.util.Event
 
getSerializedSize() - Method in class org.tensorflow.util.IteratorStateMetadata
 
getSerializedSize() - Method in class org.tensorflow.util.LogMessage
 
getSerializedSize() - Method in class org.tensorflow.util.SavedSlice
 
getSerializedSize() - Method in class org.tensorflow.util.SavedSliceMeta
 
getSerializedSize() - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
getSerializedSize() - Method in class org.tensorflow.util.SavedTensorSlices
 
getSerializedSize() - Method in class org.tensorflow.util.SaverDef
 
getSerializedSize() - Method in class org.tensorflow.util.SessionLog
 
getSerializedSize() - Method in class org.tensorflow.util.TaggedRunMetadata
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.CommitId
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.CPUInfo
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.EntryValue
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.GPUInfo
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.MemoryInfo
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.PlatformInfo
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.RunConfiguration
 
getSerializedSize() - Method in class org.tensorflow.util.testlog.TestResults
 
getSerializedSize() - Method in class org.tensorflow.util.WatchdogConfig
 
getSerializedSize() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
getSerializedSize() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
getSerializedSize() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
getSerializedSize() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
getSerializedSize() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
getSerializedSize() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
getSerializedSize() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
getSerializedSize() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
getSerializedSize() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
getSerializedSize() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
getSerializedSize() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
getSerializedSize() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
getSessionInterOpThreadPool(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPool(int) - Method in class org.tensorflow.framework.ConfigProto
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPool(int) - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolBuilder(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolBuilderList() - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolCount() - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolCount() - Method in class org.tensorflow.framework.ConfigProto
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolCount() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolList() - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolList() - Method in class org.tensorflow.framework.ConfigProto
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolList() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolOrBuilder(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolOrBuilder(int) - Method in class org.tensorflow.framework.ConfigProto
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolOrBuilder(int) - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolOrBuilderList() - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolOrBuilderList() - Method in class org.tensorflow.framework.ConfigProto
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionInterOpThreadPoolOrBuilderList() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
This option is experimental - it may be replaced with a different mechanism in the future.
getSessionLog() - Method in class org.tensorflow.util.Event.Builder
The state of the session which can be used for restarting after crashes.
getSessionLog() - Method in class org.tensorflow.util.Event
The state of the session which can be used for restarting after crashes.
getSessionLog() - Method in interface org.tensorflow.util.EventOrBuilder
The state of the session which can be used for restarting after crashes.
getSessionLogBuilder() - Method in class org.tensorflow.util.Event.Builder
The state of the session which can be used for restarting after crashes.
getSessionLogOrBuilder() - Method in class org.tensorflow.util.Event.Builder
The state of the session which can be used for restarting after crashes.
getSessionLogOrBuilder() - Method in class org.tensorflow.util.Event
The state of the session which can be used for restarting after crashes.
getSessionLogOrBuilder() - Method in interface org.tensorflow.util.EventOrBuilder
The state of the session which can be used for restarting after crashes.
getShape() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorShapeProto shape = 2;
getShape() - Method in class org.tensorflow.example.FixedLenFeatureProto
.tensorflow.TensorShapeProto shape = 2;
getShape() - Method in interface org.tensorflow.example.FixedLenFeatureProtoOrBuilder
.tensorflow.TensorShapeProto shape = 2;
getShape() - Method in class org.tensorflow.framework.AttrValue.Builder
"shape"
getShape() - Method in class org.tensorflow.framework.AttrValue
"shape"
getShape(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
getShape(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(shape)"
getShape(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(shape)"
getShape() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"shape"
getShape() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.TensorShapeProto shape = 3;
getShape() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
.tensorflow.TensorShapeProto shape = 3;
getShape() - Method in interface org.tensorflow.framework.CostGraphDef.Node.OutputInfoOrBuilder
.tensorflow.TensorShapeProto shape = 3;
getShape(int) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
repeated int64 shape = 3;
getShape(int) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
repeated int64 shape = 3;
getShape(int) - Method in interface org.tensorflow.framework.GraphTransferConstNodeInfoOrBuilder
repeated int64 shape = 3;
getShape(int) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
repeated int64 shape = 2;
getShape(int) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
repeated int64 shape = 2;
getShape(int) - Method in interface org.tensorflow.framework.GraphTransferGraphInputNodeInfoOrBuilder
repeated int64 shape = 2;
getShape(int) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
repeated int64 shape = 2;
getShape(int) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
repeated int64 shape = 2;
getShape(int) - Method in interface org.tensorflow.framework.GraphTransferGraphOutputNodeInfoOrBuilder
repeated int64 shape = 2;
getShape() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.TensorShapeProto shape = 2;
getShape() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
.tensorflow.TensorShapeProto shape = 2;
getShape() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProtoOrBuilder
.tensorflow.TensorShapeProto shape = 2;
getShape() - Method in class org.tensorflow.framework.TensorDescription.Builder
Shape of the tensor.
getShape() - Method in class org.tensorflow.framework.TensorDescription
Shape of the tensor.
getShape() - Method in interface org.tensorflow.framework.TensorDescriptionOrBuilder
Shape of the tensor.
getShape() - Method in class org.tensorflow.util.BundleEntryProto.Builder
.tensorflow.TensorShapeProto shape = 2;
getShape() - Method in class org.tensorflow.util.BundleEntryProto
.tensorflow.TensorShapeProto shape = 2;
getShape() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
.tensorflow.TensorShapeProto shape = 2;
getShape() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Shape of the tensor
getShape() - Method in class org.tensorflow.util.SavedSliceMeta
Shape of the tensor
getShape() - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Shape of the tensor
getShapeBuilder() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorShapeProto shape = 2;
getShapeBuilder() - Method in class org.tensorflow.framework.AttrValue.Builder
"shape"
getShapeBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
getShapeBuilder() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.TensorShapeProto shape = 3;
getShapeBuilder() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.TensorShapeProto shape = 2;
getShapeBuilder() - Method in class org.tensorflow.framework.TensorDescription.Builder
Shape of the tensor.
getShapeBuilder() - Method in class org.tensorflow.util.BundleEntryProto.Builder
.tensorflow.TensorShapeProto shape = 2;
getShapeBuilder() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Shape of the tensor
getShapeBuilderList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
getShapeCount() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
getShapeCount() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(shape)"
getShapeCount() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(shape)"
getShapeCount() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
repeated int64 shape = 3;
getShapeCount() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
repeated int64 shape = 3;
getShapeCount() - Method in interface org.tensorflow.framework.GraphTransferConstNodeInfoOrBuilder
repeated int64 shape = 3;
getShapeCount() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
repeated int64 shape = 2;
getShapeCount() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
repeated int64 shape = 2;
getShapeCount() - Method in interface org.tensorflow.framework.GraphTransferGraphInputNodeInfoOrBuilder
repeated int64 shape = 2;
getShapeCount() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
repeated int64 shape = 2;
getShapeCount() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
repeated int64 shape = 2;
getShapeCount() - Method in interface org.tensorflow.framework.GraphTransferGraphOutputNodeInfoOrBuilder
repeated int64 shape = 2;
getShapeList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
getShapeList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(shape)"
getShapeList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(shape)"
getShapeList() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
repeated int64 shape = 3;
getShapeList() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
repeated int64 shape = 3;
getShapeList() - Method in interface org.tensorflow.framework.GraphTransferConstNodeInfoOrBuilder
repeated int64 shape = 3;
getShapeList() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
repeated int64 shape = 2;
getShapeList() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
repeated int64 shape = 2;
getShapeList() - Method in interface org.tensorflow.framework.GraphTransferGraphInputNodeInfoOrBuilder
repeated int64 shape = 2;
getShapeList() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
repeated int64 shape = 2;
getShapeList() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
repeated int64 shape = 2;
getShapeList() - Method in interface org.tensorflow.framework.GraphTransferGraphOutputNodeInfoOrBuilder
repeated int64 shape = 2;
getShapeOptimization() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Shape optimizations (default is ON) Simplify computations made on shapes.
getShapeOptimization() - Method in class org.tensorflow.framework.RewriterConfig
Shape optimizations (default is ON) Simplify computations made on shapes.
getShapeOptimization() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Shape optimizations (default is ON) Simplify computations made on shapes.
getShapeOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Shape optimizations (default is ON) Simplify computations made on shapes.
getShapeOptimizationValue() - Method in class org.tensorflow.framework.RewriterConfig
Shape optimizations (default is ON) Simplify computations made on shapes.
getShapeOptimizationValue() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Shape optimizations (default is ON) Simplify computations made on shapes.
getShapeOrBuilder() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorShapeProto shape = 2;
getShapeOrBuilder() - Method in class org.tensorflow.example.FixedLenFeatureProto
.tensorflow.TensorShapeProto shape = 2;
getShapeOrBuilder() - Method in interface org.tensorflow.example.FixedLenFeatureProtoOrBuilder
.tensorflow.TensorShapeProto shape = 2;
getShapeOrBuilder() - Method in class org.tensorflow.framework.AttrValue.Builder
"shape"
getShapeOrBuilder() - Method in class org.tensorflow.framework.AttrValue
"shape"
getShapeOrBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
getShapeOrBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(shape)"
getShapeOrBuilder(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(shape)"
getShapeOrBuilder() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"shape"
getShapeOrBuilder() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.TensorShapeProto shape = 3;
getShapeOrBuilder() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
.tensorflow.TensorShapeProto shape = 3;
getShapeOrBuilder() - Method in interface org.tensorflow.framework.CostGraphDef.Node.OutputInfoOrBuilder
.tensorflow.TensorShapeProto shape = 3;
getShapeOrBuilder() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.TensorShapeProto shape = 2;
getShapeOrBuilder() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
.tensorflow.TensorShapeProto shape = 2;
getShapeOrBuilder() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProtoOrBuilder
.tensorflow.TensorShapeProto shape = 2;
getShapeOrBuilder() - Method in class org.tensorflow.framework.TensorDescription.Builder
Shape of the tensor.
getShapeOrBuilder() - Method in class org.tensorflow.framework.TensorDescription
Shape of the tensor.
getShapeOrBuilder() - Method in interface org.tensorflow.framework.TensorDescriptionOrBuilder
Shape of the tensor.
getShapeOrBuilder() - Method in class org.tensorflow.util.BundleEntryProto.Builder
.tensorflow.TensorShapeProto shape = 2;
getShapeOrBuilder() - Method in class org.tensorflow.util.BundleEntryProto
.tensorflow.TensorShapeProto shape = 2;
getShapeOrBuilder() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
.tensorflow.TensorShapeProto shape = 2;
getShapeOrBuilder() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Shape of the tensor
getShapeOrBuilder() - Method in class org.tensorflow.util.SavedSliceMeta
Shape of the tensor
getShapeOrBuilder() - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Shape of the tensor
getShapeOrBuilderList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
getShapeOrBuilderList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(shape)"
getShapeOrBuilderList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(shape)"
getShapesOutputTensorName() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string shapes_output_tensor_name = 4;
getShapesOutputTensorName() - Method in class org.tensorflow.example.VarLenFeatureProto
string shapes_output_tensor_name = 4;
getShapesOutputTensorName() - Method in interface org.tensorflow.example.VarLenFeatureProtoOrBuilder
string shapes_output_tensor_name = 4;
getShapesOutputTensorNameBytes() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string shapes_output_tensor_name = 4;
getShapesOutputTensorNameBytes() - Method in class org.tensorflow.example.VarLenFeatureProto
string shapes_output_tensor_name = 4;
getShapesOutputTensorNameBytes() - Method in interface org.tensorflow.example.VarLenFeatureProtoOrBuilder
string shapes_output_tensor_name = 4;
getSharded() - Method in class org.tensorflow.util.SaverDef.Builder
Shard the save files, one per device that has Variable nodes.
getSharded() - Method in class org.tensorflow.util.SaverDef
Shard the save files, one per device that has Variable nodes.
getSharded() - Method in interface org.tensorflow.util.SaverDefOrBuilder
Shard the save files, one per device that has Variable nodes.
getShardId() - Method in class org.tensorflow.util.BundleEntryProto.Builder
The binary content of the tensor lies in: File "shard_id": bytes [offset, offset + size).
getShardId() - Method in class org.tensorflow.util.BundleEntryProto
The binary content of the tensor lies in: File "shard_id": bytes [offset, offset + size).
getShardId() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
The binary content of the tensor lies in: File "shard_id": bytes [offset, offset + size).
getSharedMemorySizePerMultiprocessor() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Shared memory size per multiprocessor in bytes.
getSharedMemorySizePerMultiprocessor() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Shared memory size per multiprocessor in bytes.
getSharedMemorySizePerMultiprocessor() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Shared memory size per multiprocessor in bytes.
getShutdownMode() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WorkerShutdownMode shutdown_mode = 1;
getShutdownMode() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
.tensorflow.WorkerShutdownMode shutdown_mode = 1;
getShutdownMode() - Method in interface org.tensorflow.util.WorkerHeartbeatRequestOrBuilder
.tensorflow.WorkerShutdownMode shutdown_mode = 1;
getShutdownModeValue() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WorkerShutdownMode shutdown_mode = 1;
getShutdownModeValue() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
.tensorflow.WorkerShutdownMode shutdown_mode = 1;
getShutdownModeValue() - Method in interface org.tensorflow.util.WorkerHeartbeatRequestOrBuilder
.tensorflow.WorkerShutdownMode shutdown_mode = 1;
getSignature() - Method in class org.tensorflow.framework.FunctionDef.Builder
The definition of the function's name, arguments, return values, attrs etc.
getSignature() - Method in class org.tensorflow.framework.FunctionDef
The definition of the function's name, arguments, return values, attrs etc.
getSignature() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
The definition of the function's name, arguments, return values, attrs etc.
getSignatureBuilder() - Method in class org.tensorflow.framework.FunctionDef.Builder
The definition of the function's name, arguments, return values, attrs etc.
getSignatureDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Deprecated.
getSignatureDef() - Method in class org.tensorflow.framework.MetaGraphDef
Deprecated.
getSignatureDef() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
Deprecated.
getSignatureDefCount() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
getSignatureDefCount() - Method in class org.tensorflow.framework.MetaGraphDef
 
getSignatureDefCount() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
getSignatureDefMap() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
getSignatureDefMap() - Method in class org.tensorflow.framework.MetaGraphDef
signature_def: Map from user supplied key for a signature to a single SignatureDef.
getSignatureDefMap() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
getSignatureDefOrDefault(String, SignatureDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
getSignatureDefOrDefault(String, SignatureDef) - Method in class org.tensorflow.framework.MetaGraphDef
signature_def: Map from user supplied key for a signature to a single SignatureDef.
getSignatureDefOrDefault(String, SignatureDef) - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
getSignatureDefOrThrow(String) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
getSignatureDefOrThrow(String) - Method in class org.tensorflow.framework.MetaGraphDef
signature_def: Map from user supplied key for a signature to a single SignatureDef.
getSignatureDefOrThrow(String) - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
getSignatureOrBuilder() - Method in class org.tensorflow.framework.FunctionDef.Builder
The definition of the function's name, arguments, return values, attrs etc.
getSignatureOrBuilder() - Method in class org.tensorflow.framework.FunctionDef
The definition of the function's name, arguments, return values, attrs etc.
getSignatureOrBuilder() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
The definition of the function's name, arguments, return values, attrs etc.
getSimpleValue() - Method in class org.tensorflow.framework.Summary.Value.Builder
float simple_value = 2;
getSimpleValue() - Method in class org.tensorflow.framework.Summary.Value
float simple_value = 2;
getSimpleValue() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
float simple_value = 2;
getSize() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
int64 size = 1;
getSize() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
int64 size = 1;
getSize() - Method in interface org.tensorflow.framework.CostGraphDef.Node.OutputInfoOrBuilder
int64 size = 1;
getSize() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
Size of the tensor in that dimension.
getSize() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
Size of the tensor in that dimension.
getSize() - Method in interface org.tensorflow.framework.TensorShapeProto.DimOrBuilder
Size of the tensor in that dimension.
getSize() - Method in class org.tensorflow.util.BundleEntryProto.Builder
int64 size = 5;
getSize() - Method in class org.tensorflow.util.BundleEntryProto
int64 size = 5;
getSize() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
int64 size = 5;
getSlice() - Method in class org.tensorflow.util.SavedSlice.Builder
Extent of the slice.
getSlice() - Method in class org.tensorflow.util.SavedSlice
Extent of the slice.
getSlice(int) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
getSlice(int) - Method in class org.tensorflow.util.SavedSliceMeta
Explicit list of slices saved in the checkpoint file.
getSlice(int) - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Explicit list of slices saved in the checkpoint file.
getSlice() - Method in interface org.tensorflow.util.SavedSliceOrBuilder
Extent of the slice.
getSliceBuilder() - Method in class org.tensorflow.util.SavedSlice.Builder
Extent of the slice.
getSliceBuilder(int) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
getSliceBuilderList() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
getSliceCount() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
getSliceCount() - Method in class org.tensorflow.util.SavedSliceMeta
Explicit list of slices saved in the checkpoint file.
getSliceCount() - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Explicit list of slices saved in the checkpoint file.
getSliceList() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
getSliceList() - Method in class org.tensorflow.util.SavedSliceMeta
Explicit list of slices saved in the checkpoint file.
getSliceList() - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Explicit list of slices saved in the checkpoint file.
getSliceOrBuilder() - Method in class org.tensorflow.util.SavedSlice.Builder
Extent of the slice.
getSliceOrBuilder() - Method in class org.tensorflow.util.SavedSlice
Extent of the slice.
getSliceOrBuilder(int) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
getSliceOrBuilder(int) - Method in class org.tensorflow.util.SavedSliceMeta
Explicit list of slices saved in the checkpoint file.
getSliceOrBuilder(int) - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Explicit list of slices saved in the checkpoint file.
getSliceOrBuilder() - Method in interface org.tensorflow.util.SavedSliceOrBuilder
Extent of the slice.
getSliceOrBuilderList() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
getSliceOrBuilderList() - Method in class org.tensorflow.util.SavedSliceMeta
Explicit list of slices saved in the checkpoint file.
getSliceOrBuilderList() - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Explicit list of slices saved in the checkpoint file.
getSlices(int) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
getSlices(int) - Method in class org.tensorflow.util.BundleEntryProto
Iff present, this entry represents a partitioned tensor.
getSlices(int) - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
Iff present, this entry represents a partitioned tensor.
getSlicesBuilder(int) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
getSlicesBuilderList() - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
getSlicesCount() - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
getSlicesCount() - Method in class org.tensorflow.util.BundleEntryProto
Iff present, this entry represents a partitioned tensor.
getSlicesCount() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
Iff present, this entry represents a partitioned tensor.
getSlicesList() - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
getSlicesList() - Method in class org.tensorflow.util.BundleEntryProto
Iff present, this entry represents a partitioned tensor.
getSlicesList() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
Iff present, this entry represents a partitioned tensor.
getSlicesOrBuilder(int) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
getSlicesOrBuilder(int) - Method in class org.tensorflow.util.BundleEntryProto
Iff present, this entry represents a partitioned tensor.
getSlicesOrBuilder(int) - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
Iff present, this entry represents a partitioned tensor.
getSlicesOrBuilderList() - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
getSlicesOrBuilderList() - Method in class org.tensorflow.util.BundleEntryProto
Iff present, this entry represents a partitioned tensor.
getSlicesOrBuilderList() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
Iff present, this entry represents a partitioned tensor.
getSList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(string)"
getSList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(string)"
getSList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(string)"
getSlot() - Method in class org.tensorflow.framework.NodeOutput.Builder
int32 slot = 1;
getSlot() - Method in class org.tensorflow.framework.NodeOutput
int32 slot = 1;
getSlot() - Method in interface org.tensorflow.framework.NodeOutputOrBuilder
int32 slot = 1;
getSlotName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
The name of the slot (e.g.
getSlotName() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
The name of the slot (e.g.
getSlotName() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReferenceOrBuilder
The name of the slot (e.g.
getSlotNameBytes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
The name of the slot (e.g.
getSlotNameBytes() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
The name of the slot (e.g.
getSlotNameBytes() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReferenceOrBuilder
The name of the slot (e.g.
getSlotVariableNodeId() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
An index into `CheckpointableObjectGraph.nodes`, indicating the `Object` with the value of the slot variable.
getSlotVariableNodeId() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
An index into `CheckpointableObjectGraph.nodes`, indicating the `Object` with the value of the slot variable.
getSlotVariableNodeId() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReferenceOrBuilder
An index into `CheckpointableObjectGraph.nodes`, indicating the `Object` with the value of the slot variable.
getSlotVariables(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
getSlotVariables(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Slot variables owned by this object.
getSlotVariables(int) - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Slot variables owned by this object.
getSlotVariablesBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
getSlotVariablesBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
getSlotVariablesCount() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
getSlotVariablesCount() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Slot variables owned by this object.
getSlotVariablesCount() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Slot variables owned by this object.
getSlotVariablesList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
getSlotVariablesList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Slot variables owned by this object.
getSlotVariablesList() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Slot variables owned by this object.
getSlotVariablesOrBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
getSlotVariablesOrBuilder(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Slot variables owned by this object.
getSlotVariablesOrBuilder(int) - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Slot variables owned by this object.
getSlotVariablesOrBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
getSlotVariablesOrBuilderList() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
Slot variables owned by this object.
getSlotVariablesOrBuilderList() - Method in interface tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObjectOrBuilder
Slot variables owned by this object.
getSnapshot() - Method in class org.tensorflow.util.testlog.CommitId.Builder
Hash of intermediate change between hash/changelist and what was tested.
getSnapshot() - Method in class org.tensorflow.util.testlog.CommitId
Hash of intermediate change between hash/changelist and what was tested.
getSnapshot() - Method in interface org.tensorflow.util.testlog.CommitIdOrBuilder
Hash of intermediate change between hash/changelist and what was tested.
getSnapshotBytes() - Method in class org.tensorflow.util.testlog.CommitId.Builder
Hash of intermediate change between hash/changelist and what was tested.
getSnapshotBytes() - Method in class org.tensorflow.util.testlog.CommitId
Hash of intermediate change between hash/changelist and what was tested.
getSnapshotBytes() - Method in interface org.tensorflow.util.testlog.CommitIdOrBuilder
Hash of intermediate change between hash/changelist and what was tested.
getSnapshotName() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the snapshot tensor.
getSnapshotName() - Method in class org.tensorflow.framework.VariableDef
Name of the snapshot tensor.
getSnapshotName() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Name of the snapshot tensor.
getSnapshotNameBytes() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the snapshot tensor.
getSnapshotNameBytes() - Method in class org.tensorflow.framework.VariableDef
Name of the snapshot tensor.
getSnapshotNameBytes() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Name of the snapshot tensor.
getSocOpId() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 soc_op_id = 4;
getSocOpId() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
int32 soc_op_id = 4;
getSocOpId() - Method in interface org.tensorflow.framework.GraphTransferNodeInfoOrBuilder
int32 soc_op_id = 4;
getSourceFiles(int) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
getSourceFiles(int) - Method in class org.tensorflow.framework.DebuggedSourceFiles
A collection of source code files.
getSourceFiles(int) - Method in interface org.tensorflow.framework.DebuggedSourceFilesOrBuilder
A collection of source code files.
getSourceFilesBuilder(int) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
getSourceFilesBuilderList() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
getSourceFilesCount() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
getSourceFilesCount() - Method in class org.tensorflow.framework.DebuggedSourceFiles
A collection of source code files.
getSourceFilesCount() - Method in interface org.tensorflow.framework.DebuggedSourceFilesOrBuilder
A collection of source code files.
getSourceFilesList() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
getSourceFilesList() - Method in class org.tensorflow.framework.DebuggedSourceFiles
A collection of source code files.
getSourceFilesList() - Method in interface org.tensorflow.framework.DebuggedSourceFilesOrBuilder
A collection of source code files.
getSourceFilesOrBuilder(int) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
getSourceFilesOrBuilder(int) - Method in class org.tensorflow.framework.DebuggedSourceFiles
A collection of source code files.
getSourceFilesOrBuilder(int) - Method in interface org.tensorflow.framework.DebuggedSourceFilesOrBuilder
A collection of source code files.
getSourceFilesOrBuilderList() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
getSourceFilesOrBuilderList() - Method in class org.tensorflow.framework.DebuggedSourceFiles
A collection of source code files.
getSourceFilesOrBuilderList() - Method in interface org.tensorflow.framework.DebuggedSourceFilesOrBuilder
A collection of source code files.
getStart() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
Start index of the slice, starting at 0.
getStart() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
Start index of the slice, starting at 0.
getStart() - Method in interface org.tensorflow.framework.TensorSliceProto.ExtentOrBuilder
Start index of the slice, starting at 0.
getStartTime() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The time the run started (in seconds of UTC time since Unix epoch)
getStartTime() - Method in class org.tensorflow.util.testlog.TestResults
The time the run started (in seconds of UTC time since Unix epoch)
getStartTime() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The time the run started (in seconds of UTC time since Unix epoch)
getStatus() - Method in class org.tensorflow.util.SessionLog.Builder
.tensorflow.SessionLog.SessionStatus status = 1;
getStatus() - Method in class org.tensorflow.util.SessionLog
.tensorflow.SessionLog.SessionStatus status = 1;
getStatus() - Method in interface org.tensorflow.util.SessionLogOrBuilder
.tensorflow.SessionLog.SessionStatus status = 1;
getStatusValue() - Method in class org.tensorflow.util.SessionLog.Builder
.tensorflow.SessionLog.SessionStatus status = 1;
getStatusValue() - Method in class org.tensorflow.util.SessionLog
.tensorflow.SessionLog.SessionStatus status = 1;
getStatusValue() - Method in interface org.tensorflow.util.SessionLogOrBuilder
.tensorflow.SessionLog.SessionStatus status = 1;
getStep() - Method in class org.tensorflow.util.Event.Builder
Global step of the event.
getStep() - Method in class org.tensorflow.util.Event
Global step of the event.
getStep() - Method in interface org.tensorflow.util.EventOrBuilder
Global step of the event.
getStepId() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Process-unique step id.
getStepId() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
Process-unique step id.
getStepId() - Method in interface org.tensorflow.framework.MemoryLogRawAllocationOrBuilder
Process-unique step id.
getStepId() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Process-unique step id.
getStepId() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
Process-unique step id.
getStepId() - Method in interface org.tensorflow.framework.MemoryLogRawDeallocationOrBuilder
Process-unique step id.
getStepId() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
Process-unique step id.
getStepId() - Method in class org.tensorflow.framework.MemoryLogStep
Process-unique step id.
getStepId() - Method in interface org.tensorflow.framework.MemoryLogStepOrBuilder
Process-unique step id.
getStepId() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Process-unique step id.
getStepId() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
Process-unique step id.
getStepId() - Method in interface org.tensorflow.framework.MemoryLogTensorAllocationOrBuilder
Process-unique step id.
getStepId() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Process-unique step id.
getStepId() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
Process-unique step id.
getStepId() - Method in interface org.tensorflow.framework.MemoryLogTensorOutputOrBuilder
Process-unique step id.
getStepStats() - Method in class org.tensorflow.framework.RunMetadata.Builder
Statistics traced for this step.
getStepStats() - Method in class org.tensorflow.framework.RunMetadata
Statistics traced for this step.
getStepStats() - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
Statistics traced for this step.
getStepStatsBuilder() - Method in class org.tensorflow.framework.RunMetadata.Builder
Statistics traced for this step.
getStepStatsOrBuilder() - Method in class org.tensorflow.framework.RunMetadata.Builder
Statistics traced for this step.
getStepStatsOrBuilder() - Method in class org.tensorflow.framework.RunMetadata
Statistics traced for this step.
getStepStatsOrBuilder() - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
Statistics traced for this step.
getStrength() - Method in class org.tensorflow.framework.InterconnectLink.Builder
int32 strength = 3;
getStrength() - Method in class org.tensorflow.framework.InterconnectLink
int32 strength = 3;
getStrength() - Method in interface org.tensorflow.framework.InterconnectLinkOrBuilder
int32 strength = 3;
getStringVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_STRING
getStringVal(int) - Method in class org.tensorflow.framework.TensorProto
DT_STRING
getStringVal(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_STRING
getStringValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_STRING
getStringValCount() - Method in class org.tensorflow.framework.TensorProto
DT_STRING
getStringValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_STRING
getStringValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_STRING
getStringValList() - Method in class org.tensorflow.framework.TensorProto
DT_STRING
getStringValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_STRING
getStringValue() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
string string_value = 2;
getStringValue() - Method in class org.tensorflow.util.testlog.EntryValue
string string_value = 2;
getStringValue() - Method in interface org.tensorflow.util.testlog.EntryValueOrBuilder
string string_value = 2;
getStringValueBytes() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
string string_value = 2;
getStringValueBytes() - Method in class org.tensorflow.util.testlog.EntryValue
string string_value = 2;
getStringValueBytes() - Method in interface org.tensorflow.util.testlog.EntryValueOrBuilder
string string_value = 2;
getStrippedDefaultAttrs() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A flag to denote whether default-valued attrs have been stripped from the nodes in this graph_def.
getStrippedDefaultAttrs() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
A flag to denote whether default-valued attrs have been stripped from the nodes in this graph_def.
getStrippedDefaultAttrs() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
A flag to denote whether default-valued attrs have been stripped from the nodes in this graph_def.
getStrippedOpList() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A copy of the OpDefs used by the producer of this graph_def.
getStrippedOpList() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
A copy of the OpDefs used by the producer of this graph_def.
getStrippedOpList() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
A copy of the OpDefs used by the producer of this graph_def.
getStrippedOpListBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A copy of the OpDefs used by the producer of this graph_def.
getStrippedOpListOrBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A copy of the OpDefs used by the producer of this graph_def.
getStrippedOpListOrBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
A copy of the OpDefs used by the producer of this graph_def.
getStrippedOpListOrBuilder() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
A copy of the OpDefs used by the producer of this graph_def.
getSum() - Method in class org.tensorflow.framework.HistogramProto.Builder
double sum = 4;
getSum() - Method in class org.tensorflow.framework.HistogramProto
double sum = 4;
getSum() - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
double sum = 4;
getSummary() - Method in class org.tensorflow.framework.ApiDef.Builder
One-line human-readable description of what the Op does.
getSummary() - Method in class org.tensorflow.framework.ApiDef
One-line human-readable description of what the Op does.
getSummary() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
One-line human-readable description of what the Op does.
getSummary() - Method in class org.tensorflow.framework.OpDef.Builder
One-line human-readable description of what the Op does.
getSummary() - Method in class org.tensorflow.framework.OpDef
One-line human-readable description of what the Op does.
getSummary() - Method in interface org.tensorflow.framework.OpDefOrBuilder
One-line human-readable description of what the Op does.
getSummary() - Method in class org.tensorflow.util.Event.Builder
A summary was generated.
getSummary() - Method in class org.tensorflow.util.Event
A summary was generated.
getSummary() - Method in interface org.tensorflow.util.EventOrBuilder
A summary was generated.
getSummaryBuilder() - Method in class org.tensorflow.util.Event.Builder
A summary was generated.
getSummaryBytes() - Method in class org.tensorflow.framework.ApiDef.Builder
One-line human-readable description of what the Op does.
getSummaryBytes() - Method in class org.tensorflow.framework.ApiDef
One-line human-readable description of what the Op does.
getSummaryBytes() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
One-line human-readable description of what the Op does.
getSummaryBytes() - Method in class org.tensorflow.framework.OpDef.Builder
One-line human-readable description of what the Op does.
getSummaryBytes() - Method in class org.tensorflow.framework.OpDef
One-line human-readable description of what the Op does.
getSummaryBytes() - Method in interface org.tensorflow.framework.OpDefOrBuilder
One-line human-readable description of what the Op does.
getSummaryDescription() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Longform readable description of the summary sequence.
getSummaryDescription() - Method in class org.tensorflow.framework.SummaryMetadata
Longform readable description of the summary sequence.
getSummaryDescription() - Method in interface org.tensorflow.framework.SummaryMetadataOrBuilder
Longform readable description of the summary sequence.
getSummaryDescriptionBytes() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Longform readable description of the summary sequence.
getSummaryDescriptionBytes() - Method in class org.tensorflow.framework.SummaryMetadata
Longform readable description of the summary sequence.
getSummaryDescriptionBytes() - Method in interface org.tensorflow.framework.SummaryMetadataOrBuilder
Longform readable description of the summary sequence.
getSummaryOrBuilder() - Method in class org.tensorflow.util.Event.Builder
A summary was generated.
getSummaryOrBuilder() - Method in class org.tensorflow.util.Event
A summary was generated.
getSummaryOrBuilder() - Method in interface org.tensorflow.util.EventOrBuilder
A summary was generated.
getSumSquares() - Method in class org.tensorflow.framework.HistogramProto.Builder
double sum_squares = 5;
getSumSquares() - Method in class org.tensorflow.framework.HistogramProto
double sum_squares = 5;
getSumSquares() - Method in interface org.tensorflow.framework.HistogramProtoOrBuilder
double sum_squares = 5;
getSwapMemory() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Whether GPU-CPU memory swap is enabled for this loop.
getSwapMemory() - Method in class org.tensorflow.framework.WhileContextDef
Whether GPU-CPU memory swap is enabled for this loop.
getSwapMemory() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Whether GPU-CPU memory swap is enabled for this loop.
getSystem() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getSystem() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getSystem() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getSystemBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getSystemBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getSystemBytes() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getTag() - Method in class org.tensorflow.framework.Summary.Value.Builder
Tag name for the data.
getTag() - Method in class org.tensorflow.framework.Summary.Value
Tag name for the data.
getTag() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
Tag name for the data.
getTag() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
Tag name associated with this metadata.
getTag() - Method in class org.tensorflow.util.TaggedRunMetadata
Tag name associated with this metadata.
getTag() - Method in interface org.tensorflow.util.TaggedRunMetadataOrBuilder
Tag name associated with this metadata.
getTagBytes() - Method in class org.tensorflow.framework.Summary.Value.Builder
Tag name for the data.
getTagBytes() - Method in class org.tensorflow.framework.Summary.Value
Tag name for the data.
getTagBytes() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
Tag name for the data.
getTagBytes() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
Tag name associated with this metadata.
getTagBytes() - Method in class org.tensorflow.util.TaggedRunMetadata
Tag name associated with this metadata.
getTagBytes() - Method in interface org.tensorflow.util.TaggedRunMetadataOrBuilder
Tag name associated with this metadata.
getTaggedRunMetadata() - Method in class org.tensorflow.util.Event.Builder
The metadata returned by running a session.run() call.
getTaggedRunMetadata() - Method in class org.tensorflow.util.Event
The metadata returned by running a session.run() call.
getTaggedRunMetadata() - Method in interface org.tensorflow.util.EventOrBuilder
The metadata returned by running a session.run() call.
getTaggedRunMetadataBuilder() - Method in class org.tensorflow.util.Event.Builder
The metadata returned by running a session.run() call.
getTaggedRunMetadataOrBuilder() - Method in class org.tensorflow.util.Event.Builder
The metadata returned by running a session.run() call.
getTaggedRunMetadataOrBuilder() - Method in class org.tensorflow.util.Event
The metadata returned by running a session.run() call.
getTaggedRunMetadataOrBuilder() - Method in interface org.tensorflow.util.EventOrBuilder
The metadata returned by running a session.run() call.
getTags(int) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User supplied tag(s) on the meta_graph and included graph_def.
getTags(int) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
User supplied tag(s) on the meta_graph and included graph_def.
getTags(int) - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
User supplied tag(s) on the meta_graph and included graph_def.
getTagsBytes(int) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User supplied tag(s) on the meta_graph and included graph_def.
getTagsBytes(int) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
User supplied tag(s) on the meta_graph and included graph_def.
getTagsBytes(int) - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
User supplied tag(s) on the meta_graph and included graph_def.
getTagsCount() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User supplied tag(s) on the meta_graph and included graph_def.
getTagsCount() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
User supplied tag(s) on the meta_graph and included graph_def.
getTagsCount() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
User supplied tag(s) on the meta_graph and included graph_def.
getTagsList() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User supplied tag(s) on the meta_graph and included graph_def.
getTagsList() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
User supplied tag(s) on the meta_graph and included graph_def.
getTagsList() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
User supplied tag(s) on the meta_graph and included graph_def.
getTarget(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Target Nodes.
getTarget(int) - Method in class org.tensorflow.framework.CallableOptions
Target Nodes.
getTarget(int) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Target Nodes.
getTarget() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The target of the run, e.g.: //tensorflow/core:kernels_adjust_contrast_op_benchmark_test
getTarget() - Method in class org.tensorflow.util.testlog.TestResults
The target of the run, e.g.: //tensorflow/core:kernels_adjust_contrast_op_benchmark_test
getTarget() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The target of the run, e.g.: //tensorflow/core:kernels_adjust_contrast_op_benchmark_test
getTargetBytes(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Target Nodes.
getTargetBytes(int) - Method in class org.tensorflow.framework.CallableOptions
Target Nodes.
getTargetBytes(int) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Target Nodes.
getTargetBytes() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The target of the run, e.g.: //tensorflow/core:kernels_adjust_contrast_op_benchmark_test
getTargetBytes() - Method in class org.tensorflow.util.testlog.TestResults
The target of the run, e.g.: //tensorflow/core:kernels_adjust_contrast_op_benchmark_test
getTargetBytes() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The target of the run, e.g.: //tensorflow/core:kernels_adjust_contrast_op_benchmark_test
getTargetCount() - Method in class org.tensorflow.framework.CallableOptions.Builder
Target Nodes.
getTargetCount() - Method in class org.tensorflow.framework.CallableOptions
Target Nodes.
getTargetCount() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Target Nodes.
getTargetList() - Method in class org.tensorflow.framework.CallableOptions.Builder
Target Nodes.
getTargetList() - Method in class org.tensorflow.framework.CallableOptions
Target Nodes.
getTargetList() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Target Nodes.
getTaskIndex() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The task index of this server in its job.
getTaskIndex() - Method in class org.tensorflow.distruntime.ServerDef
The task index of this server in its job.
getTaskIndex() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The task index of this server in its job.
getTasks() - Method in class org.tensorflow.distruntime.JobDef.Builder
Deprecated.
getTasks() - Method in class org.tensorflow.distruntime.JobDef
Deprecated.
getTasks() - Method in interface org.tensorflow.distruntime.JobDefOrBuilder
Deprecated.
getTasksCount() - Method in class org.tensorflow.distruntime.JobDef.Builder
 
getTasksCount() - Method in class org.tensorflow.distruntime.JobDef
 
getTasksCount() - Method in interface org.tensorflow.distruntime.JobDefOrBuilder
Mapping from task ID to "hostname:port" string.
getTasksMap() - Method in class org.tensorflow.distruntime.JobDef.Builder
Mapping from task ID to "hostname:port" string.
getTasksMap() - Method in class org.tensorflow.distruntime.JobDef
Mapping from task ID to "hostname:port" string.
getTasksMap() - Method in interface org.tensorflow.distruntime.JobDefOrBuilder
Mapping from task ID to "hostname:port" string.
getTasksOrDefault(int, String) - Method in class org.tensorflow.distruntime.JobDef.Builder
Mapping from task ID to "hostname:port" string.
getTasksOrDefault(int, String) - Method in class org.tensorflow.distruntime.JobDef
Mapping from task ID to "hostname:port" string.
getTasksOrDefault(int, String) - Method in interface org.tensorflow.distruntime.JobDefOrBuilder
Mapping from task ID to "hostname:port" string.
getTasksOrThrow(int) - Method in class org.tensorflow.distruntime.JobDef.Builder
Mapping from task ID to "hostname:port" string.
getTasksOrThrow(int) - Method in class org.tensorflow.distruntime.JobDef
Mapping from task ID to "hostname:port" string.
getTasksOrThrow(int) - Method in interface org.tensorflow.distruntime.JobDefOrBuilder
Mapping from task ID to "hostname:port" string.
getTempMemorySize() - Method in class org.tensorflow.framework.MemoryStats.Builder
int64 temp_memory_size = 1;
getTempMemorySize() - Method in class org.tensorflow.framework.MemoryStats
int64 temp_memory_size = 1;
getTempMemorySize() - Method in interface org.tensorflow.framework.MemoryStatsOrBuilder
int64 temp_memory_size = 1;
getTemporaryMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Temporary memory used by this node.
getTemporaryMemorySize() - Method in class org.tensorflow.framework.CostGraphDef.Node
Temporary memory used by this node.
getTemporaryMemorySize() - Method in interface org.tensorflow.framework.CostGraphDef.NodeOrBuilder
Temporary memory used by this node.
getTensor() - Method in class org.tensorflow.framework.AttrValue.Builder
"tensor"
getTensor() - Method in class org.tensorflow.framework.AttrValue
"tensor"
getTensor(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
getTensor(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(tensor)"
getTensor(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(tensor)"
getTensor() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"tensor"
getTensor() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Allocated tensor details.
getTensor() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
Allocated tensor details.
getTensor() - Method in interface org.tensorflow.framework.MemoryLogTensorAllocationOrBuilder
Allocated tensor details.
getTensor() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Output tensor details.
getTensor() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
Output tensor details.
getTensor() - Method in interface org.tensorflow.framework.MemoryLogTensorOutputOrBuilder
Output tensor details.
getTensor() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
getTensor() - Method in class org.tensorflow.framework.NamedTensorProto
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
getTensor() - Method in interface org.tensorflow.framework.NamedTensorProtoOrBuilder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
getTensor() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.TensorProto tensor = 8;
getTensor() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.TensorProto tensor = 8;
getTensor() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.TensorProto tensor = 8;
getTensor(int) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
getTensor(int) - Method in class org.tensorflow.util.SavedTensorSliceMeta
Each SavedSliceMeta describes the slices for one tensor.
getTensor(int) - Method in interface org.tensorflow.util.SavedTensorSliceMetaOrBuilder
Each SavedSliceMeta describes the slices for one tensor.
getTensorBuilder() - Method in class org.tensorflow.framework.AttrValue.Builder
"tensor"
getTensorBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
getTensorBuilder() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Allocated tensor details.
getTensorBuilder() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Output tensor details.
getTensorBuilder() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
getTensorBuilder() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.TensorProto tensor = 8;
getTensorBuilder(int) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
getTensorBuilderList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
getTensorBuilderList() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
getTensorConnection(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
getTensorConnection(int) - Method in class org.tensorflow.framework.CallableOptions
Tensors to be connected in the callable.
getTensorConnection(int) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Tensors to be connected in the callable.
getTensorConnectionBuilder(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
getTensorConnectionBuilderList() - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
getTensorConnectionCount() - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
getTensorConnectionCount() - Method in class org.tensorflow.framework.CallableOptions
Tensors to be connected in the callable.
getTensorConnectionCount() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Tensors to be connected in the callable.
getTensorConnectionList() - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
getTensorConnectionList() - Method in class org.tensorflow.framework.CallableOptions
Tensors to be connected in the callable.
getTensorConnectionList() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Tensors to be connected in the callable.
getTensorConnectionOrBuilder(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
getTensorConnectionOrBuilder(int) - Method in class org.tensorflow.framework.CallableOptions
Tensors to be connected in the callable.
getTensorConnectionOrBuilder(int) - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Tensors to be connected in the callable.
getTensorConnectionOrBuilderList() - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
getTensorConnectionOrBuilderList() - Method in class org.tensorflow.framework.CallableOptions
Tensors to be connected in the callable.
getTensorConnectionOrBuilderList() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Tensors to be connected in the callable.
getTensorContent() - Method in class org.tensorflow.framework.TensorProto.Builder
Serialized raw tensor content from either Tensor::AsProtoTensorContent or memcpy in tensorflow::grpc::EncodeTensorToByteBuffer.
getTensorContent() - Method in class org.tensorflow.framework.TensorProto
Serialized raw tensor content from either Tensor::AsProtoTensorContent or memcpy in tensorflow::grpc::EncodeTensorToByteBuffer.
getTensorContent() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
Serialized raw tensor content from either Tensor::AsProtoTensorContent or memcpy in tensorflow::grpc::EncodeTensorToByteBuffer.
getTensorContent(int) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
repeated bytes tensor_content = 1;
getTensorContent(int) - Method in class tensorflow.TransportOptions.RecvBufRespExtra
repeated bytes tensor_content = 1;
getTensorContent(int) - Method in interface tensorflow.TransportOptions.RecvBufRespExtraOrBuilder
repeated bytes tensor_content = 1;
getTensorContentCount() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
repeated bytes tensor_content = 1;
getTensorContentCount() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
repeated bytes tensor_content = 1;
getTensorContentCount() - Method in interface tensorflow.TransportOptions.RecvBufRespExtraOrBuilder
repeated bytes tensor_content = 1;
getTensorContentList() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
repeated bytes tensor_content = 1;
getTensorContentList() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
repeated bytes tensor_content = 1;
getTensorContentList() - Method in interface tensorflow.TransportOptions.RecvBufRespExtraOrBuilder
repeated bytes tensor_content = 1;
getTensorCount() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
getTensorCount() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(tensor)"
getTensorCount() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(tensor)"
getTensorCount() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
getTensorCount() - Method in class org.tensorflow.util.SavedTensorSliceMeta
Each SavedSliceMeta describes the slices for one tensor.
getTensorCount() - Method in interface org.tensorflow.util.SavedTensorSliceMetaOrBuilder
Each SavedSliceMeta describes the slices for one tensor.
getTensorDescription() - Method in class org.tensorflow.framework.NodeOutput.Builder
.tensorflow.TensorDescription tensor_description = 3;
getTensorDescription() - Method in class org.tensorflow.framework.NodeOutput
.tensorflow.TensorDescription tensor_description = 3;
getTensorDescription() - Method in interface org.tensorflow.framework.NodeOutputOrBuilder
.tensorflow.TensorDescription tensor_description = 3;
getTensorDescriptionBuilder() - Method in class org.tensorflow.framework.NodeOutput.Builder
.tensorflow.TensorDescription tensor_description = 3;
getTensorDescriptionOrBuilder() - Method in class org.tensorflow.framework.NodeOutput.Builder
.tensorflow.TensorDescription tensor_description = 3;
getTensorDescriptionOrBuilder() - Method in class org.tensorflow.framework.NodeOutput
.tensorflow.TensorDescription tensor_description = 3;
getTensorDescriptionOrBuilder() - Method in interface org.tensorflow.framework.NodeOutputOrBuilder
.tensorflow.TensorDescription tensor_description = 3;
getTensorflowGitVersion() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
The __git_version__ string of the tensorflow build used to write this graph.
getTensorflowGitVersion() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
The __git_version__ string of the tensorflow build used to write this graph.
getTensorflowGitVersion() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
The __git_version__ string of the tensorflow build used to write this graph.
getTensorflowGitVersionBytes() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
The __git_version__ string of the tensorflow build used to write this graph.
getTensorflowGitVersionBytes() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
The __git_version__ string of the tensorflow build used to write this graph.
getTensorflowGitVersionBytes() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
The __git_version__ string of the tensorflow build used to write this graph.
getTensorflowVersion() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
The __version__ string of the tensorflow build used to write this graph.
getTensorflowVersion() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
The __version__ string of the tensorflow build used to write this graph.
getTensorflowVersion() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
The __version__ string of the tensorflow build used to write this graph.
getTensorflowVersionBytes() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
The __version__ string of the tensorflow build used to write this graph.
getTensorflowVersionBytes() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
The __version__ string of the tensorflow build used to write this graph.
getTensorflowVersionBytes() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
The __version__ string of the tensorflow build used to write this graph.
getTensorInfo() - Method in class org.tensorflow.framework.AssetFileDef.Builder
The tensor to bind the asset filename to.
getTensorInfo() - Method in class org.tensorflow.framework.AssetFileDef
The tensor to bind the asset filename to.
getTensorInfo() - Method in interface org.tensorflow.framework.AssetFileDefOrBuilder
The tensor to bind the asset filename to.
getTensorInfoBuilder() - Method in class org.tensorflow.framework.AssetFileDef.Builder
The tensor to bind the asset filename to.
getTensorInfoOrBuilder() - Method in class org.tensorflow.framework.AssetFileDef.Builder
The tensor to bind the asset filename to.
getTensorInfoOrBuilder() - Method in class org.tensorflow.framework.AssetFileDef
The tensor to bind the asset filename to.
getTensorInfoOrBuilder() - Method in interface org.tensorflow.framework.AssetFileDefOrBuilder
The tensor to bind the asset filename to.
getTensorList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
getTensorList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(tensor)"
getTensorList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(tensor)"
getTensorList() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
getTensorList() - Method in class org.tensorflow.util.SavedTensorSliceMeta
Each SavedSliceMeta describes the slices for one tensor.
getTensorList() - Method in interface org.tensorflow.util.SavedTensorSliceMetaOrBuilder
Each SavedSliceMeta describes the slices for one tensor.
getTensorOrBuilder() - Method in class org.tensorflow.framework.AttrValue.Builder
"tensor"
getTensorOrBuilder() - Method in class org.tensorflow.framework.AttrValue
"tensor"
getTensorOrBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
getTensorOrBuilder(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(tensor)"
getTensorOrBuilder(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(tensor)"
getTensorOrBuilder() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"tensor"
getTensorOrBuilder() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Allocated tensor details.
getTensorOrBuilder() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
Allocated tensor details.
getTensorOrBuilder() - Method in interface org.tensorflow.framework.MemoryLogTensorAllocationOrBuilder
Allocated tensor details.
getTensorOrBuilder() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Output tensor details.
getTensorOrBuilder() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
Output tensor details.
getTensorOrBuilder() - Method in interface org.tensorflow.framework.MemoryLogTensorOutputOrBuilder
Output tensor details.
getTensorOrBuilder() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
getTensorOrBuilder() - Method in class org.tensorflow.framework.NamedTensorProto
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
getTensorOrBuilder() - Method in interface org.tensorflow.framework.NamedTensorProtoOrBuilder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
getTensorOrBuilder() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.TensorProto tensor = 8;
getTensorOrBuilder() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.TensorProto tensor = 8;
getTensorOrBuilder() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.TensorProto tensor = 8;
getTensorOrBuilder(int) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
getTensorOrBuilder(int) - Method in class org.tensorflow.util.SavedTensorSliceMeta
Each SavedSliceMeta describes the slices for one tensor.
getTensorOrBuilder(int) - Method in interface org.tensorflow.util.SavedTensorSliceMetaOrBuilder
Each SavedSliceMeta describes the slices for one tensor.
getTensorOrBuilderList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
getTensorOrBuilderList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(tensor)"
getTensorOrBuilderList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(tensor)"
getTensorOrBuilderList() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
getTensorOrBuilderList() - Method in class org.tensorflow.util.SavedTensorSliceMeta
Each SavedSliceMeta describes the slices for one tensor.
getTensorOrBuilderList() - Method in interface org.tensorflow.util.SavedTensorSliceMetaOrBuilder
Each SavedSliceMeta describes the slices for one tensor.
getTensors(int) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
getTensors(int) - Method in class org.tensorflow.framework.VariantTensorDataProto
Tensors contained within objects being serialized.
getTensors(int) - Method in interface org.tensorflow.framework.VariantTensorDataProtoOrBuilder
Tensors contained within objects being serialized.
getTensorsBuilder(int) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
getTensorsBuilderList() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
getTensorsCount() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
getTensorsCount() - Method in class org.tensorflow.framework.VariantTensorDataProto
Tensors contained within objects being serialized.
getTensorsCount() - Method in interface org.tensorflow.framework.VariantTensorDataProtoOrBuilder
Tensors contained within objects being serialized.
getTensorShape() - Method in class org.tensorflow.framework.TensorInfo.Builder
The static shape should be recorded here, to the extent that it can be known in advance.
getTensorShape() - Method in class org.tensorflow.framework.TensorInfo
The static shape should be recorded here, to the extent that it can be known in advance.
getTensorShape() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
The static shape should be recorded here, to the extent that it can be known in advance.
getTensorShape() - Method in class org.tensorflow.framework.TensorProto.Builder
Shape of the tensor.
getTensorShape() - Method in class org.tensorflow.framework.TensorProto
Shape of the tensor.
getTensorShape() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
Shape of the tensor.
getTensorShapeBuilder() - Method in class org.tensorflow.framework.TensorInfo.Builder
The static shape should be recorded here, to the extent that it can be known in advance.
getTensorShapeBuilder() - Method in class org.tensorflow.framework.TensorProto.Builder
Shape of the tensor.
getTensorShapeOrBuilder() - Method in class org.tensorflow.framework.TensorInfo.Builder
The static shape should be recorded here, to the extent that it can be known in advance.
getTensorShapeOrBuilder() - Method in class org.tensorflow.framework.TensorInfo
The static shape should be recorded here, to the extent that it can be known in advance.
getTensorShapeOrBuilder() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
The static shape should be recorded here, to the extent that it can be known in advance.
getTensorShapeOrBuilder() - Method in class org.tensorflow.framework.TensorProto.Builder
Shape of the tensor.
getTensorShapeOrBuilder() - Method in class org.tensorflow.framework.TensorProto
Shape of the tensor.
getTensorShapeOrBuilder() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
Shape of the tensor.
getTensorsList() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
getTensorsList() - Method in class org.tensorflow.framework.VariantTensorDataProto
Tensors contained within objects being serialized.
getTensorsList() - Method in interface org.tensorflow.framework.VariantTensorDataProtoOrBuilder
Tensors contained within objects being serialized.
getTensorsOrBuilder(int) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
getTensorsOrBuilder(int) - Method in class org.tensorflow.framework.VariantTensorDataProto
Tensors contained within objects being serialized.
getTensorsOrBuilder(int) - Method in interface org.tensorflow.framework.VariantTensorDataProtoOrBuilder
Tensors contained within objects being serialized.
getTensorsOrBuilderList() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
getTensorsOrBuilderList() - Method in class org.tensorflow.framework.VariantTensorDataProto
Tensors contained within objects being serialized.
getTensorsOrBuilderList() - Method in interface org.tensorflow.framework.VariantTensorDataProtoOrBuilder
Tensors contained within objects being serialized.
getThreadId() - Method in class org.tensorflow.framework.NodeExecStats.Builder
uint32 thread_id = 10;
getThreadId() - Method in class org.tensorflow.framework.NodeExecStats
uint32 thread_id = 10;
getThreadId() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
uint32 thread_id = 10;
getThroughput() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Throughput (in MB/s)
getThroughput() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
Throughput (in MB/s)
getThroughput() - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
Throughput (in MB/s)
getTimelineLabel() - Method in class org.tensorflow.framework.NodeExecStats.Builder
string timeline_label = 8;
getTimelineLabel() - Method in class org.tensorflow.framework.NodeExecStats
string timeline_label = 8;
getTimelineLabel() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
string timeline_label = 8;
getTimelineLabelBytes() - Method in class org.tensorflow.framework.NodeExecStats.Builder
string timeline_label = 8;
getTimelineLabelBytes() - Method in class org.tensorflow.framework.NodeExecStats
string timeline_label = 8;
getTimelineLabelBytes() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
string timeline_label = 8;
getTimelineStep() - Method in class org.tensorflow.framework.GraphOptions.Builder
If > 0, record a timeline every this many steps.
getTimelineStep() - Method in class org.tensorflow.framework.GraphOptions
If > 0, record a timeline every this many steps.
getTimelineStep() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
If > 0, record a timeline every this many steps.
getTimeoutInMs() - Method in class org.tensorflow.framework.RunOptions.Builder
Time to wait for operation to complete in milliseconds.
getTimeoutInMs() - Method in class org.tensorflow.framework.RunOptions
Time to wait for operation to complete in milliseconds.
getTimeoutInMs() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
Time to wait for operation to complete in milliseconds.
getTimeoutMs() - Method in class org.tensorflow.util.WatchdogConfig.Builder
int64 timeout_ms = 1;
getTimeoutMs() - Method in class org.tensorflow.util.WatchdogConfig
int64 timeout_ms = 1;
getTimeoutMs() - Method in interface org.tensorflow.util.WatchdogConfigOrBuilder
int64 timeout_ms = 1;
getTolerateDebugOpCreationFailures() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Do not error out if debug op creation fails (e.g., due to dtype incompatibility).
getTolerateDebugOpCreationFailures() - Method in class org.tensorflow.framework.DebugTensorWatch
Do not error out if debug op creation fails (e.g., due to dtype incompatibility).
getTolerateDebugOpCreationFailures() - Method in interface org.tensorflow.framework.DebugTensorWatchOrBuilder
Do not error out if debug op creation fails (e.g., due to dtype incompatibility).
getTotal() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
Total virtual memory in bytes
getTotal() - Method in class org.tensorflow.util.testlog.MemoryInfo
Total virtual memory in bytes
getTotal() - Method in interface org.tensorflow.util.testlog.MemoryInfoOrBuilder
Total virtual memory in bytes
getTotalBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
These are per-node allocator memory stats.
getTotalBytes() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
These are per-node allocator memory stats.
getTotalBytes() - Method in interface org.tensorflow.framework.AllocatorMemoryUsedOrBuilder
These are per-node allocator memory stats.
getToTensor() - Method in class org.tensorflow.framework.TensorConnection.Builder
A tensor name.
getToTensor() - Method in class org.tensorflow.framework.TensorConnection
A tensor name.
getToTensor() - Method in interface org.tensorflow.framework.TensorConnectionOrBuilder
A tensor name.
getToTensorBytes() - Method in class org.tensorflow.framework.TensorConnection.Builder
A tensor name.
getToTensorBytes() - Method in class org.tensorflow.framework.TensorConnection
A tensor name.
getToTensorBytes() - Method in interface org.tensorflow.framework.TensorConnectionOrBuilder
A tensor name.
getTraceLevel() - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.TraceLevel trace_level = 1;
getTraceLevel() - Method in class org.tensorflow.framework.RunOptions
.tensorflow.RunOptions.TraceLevel trace_level = 1;
getTraceLevel() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
.tensorflow.RunOptions.TraceLevel trace_level = 1;
getTraceLevelValue() - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.TraceLevel trace_level = 1;
getTraceLevelValue() - Method in class org.tensorflow.framework.RunOptions
.tensorflow.RunOptions.TraceLevel trace_level = 1;
getTraceLevelValue() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
.tensorflow.RunOptions.TraceLevel trace_level = 1;
getTrainable() - Method in class org.tensorflow.framework.VariableDef.Builder
Whether this variable should be trained.
getTrainable() - Method in class org.tensorflow.framework.VariableDef
Whether this variable should be trained.
getTrainable() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Whether this variable should be trained.
getType() - Method in class org.tensorflow.framework.AttrValue.Builder
"type"
getType() - Method in class org.tensorflow.framework.AttrValue
"type"
getType(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
getType(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(type)"
getType(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(type)"
getType() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"type"
getType() - Method in class org.tensorflow.framework.InterconnectLink.Builder
string type = 2;
getType() - Method in class org.tensorflow.framework.InterconnectLink
string type = 2;
getType() - Method in interface org.tensorflow.framework.InterconnectLinkOrBuilder
string type = 2;
getType() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Describes the type of one or more tensors that are accepted/produced by this input/output arg.
getType() - Method in class org.tensorflow.framework.OpDef.ArgDef
Describes the type of one or more tensors that are accepted/produced by this input/output arg.
getType() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
Describes the type of one or more tensors that are accepted/produced by this input/output arg.
getType() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
One of the type names from attr_value.proto ("string", "list(string)", "int", etc.).
getType() - Method in class org.tensorflow.framework.OpDef.AttrDef
One of the type names from attr_value.proto ("string", "list(string)", "int", etc.).
getType() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
One of the type names from attr_value.proto ("string", "list(string)", "int", etc.).
getType() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Type of the tensor
getType() - Method in class org.tensorflow.util.SavedSliceMeta
Type of the tensor
getType() - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Type of the tensor
getType() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Device type, e.g.
getType() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
Device type, e.g.
getType() - Method in interface org.tensorflow.util.testlog.AvailableDeviceInfoOrBuilder
Device type, e.g.
getType() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Device type (CPU, GPU, ...)
getType() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Device type (CPU, GPU, ...)
getType() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Device type (CPU, GPU, ...)
getTypeAttr() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
if specified, attr must have type "type"
getTypeAttr() - Method in class org.tensorflow.framework.OpDef.ArgDef
if specified, attr must have type "type"
getTypeAttr() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
if specified, attr must have type "type"
getTypeAttrBytes() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
if specified, attr must have type "type"
getTypeAttrBytes() - Method in class org.tensorflow.framework.OpDef.ArgDef
if specified, attr must have type "type"
getTypeAttrBytes() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
if specified, attr must have type "type"
getTypeBytes() - Method in class org.tensorflow.framework.InterconnectLink.Builder
string type = 2;
getTypeBytes() - Method in class org.tensorflow.framework.InterconnectLink
string type = 2;
getTypeBytes() - Method in interface org.tensorflow.framework.InterconnectLinkOrBuilder
string type = 2;
getTypeBytes() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
One of the type names from attr_value.proto ("string", "list(string)", "int", etc.).
getTypeBytes() - Method in class org.tensorflow.framework.OpDef.AttrDef
One of the type names from attr_value.proto ("string", "list(string)", "int", etc.).
getTypeBytes() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
One of the type names from attr_value.proto ("string", "list(string)", "int", etc.).
getTypeBytes() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Device type, e.g.
getTypeBytes() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
Device type, e.g.
getTypeBytes() - Method in interface org.tensorflow.util.testlog.AvailableDeviceInfoOrBuilder
Device type, e.g.
getTypeBytes() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Device type (CPU, GPU, ...)
getTypeBytes() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Device type (CPU, GPU, ...)
getTypeBytes() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Device type (CPU, GPU, ...)
getTypeCount() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
getTypeCount() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(type)"
getTypeCount() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(type)"
getTypeHint() - Method in class org.tensorflow.framework.SummaryDescription.Builder
Hint on how plugins should process the data in this series.
getTypeHint() - Method in class org.tensorflow.framework.SummaryDescription
Hint on how plugins should process the data in this series.
getTypeHint() - Method in interface org.tensorflow.framework.SummaryDescriptionOrBuilder
Hint on how plugins should process the data in this series.
getTypeHintBytes() - Method in class org.tensorflow.framework.SummaryDescription.Builder
Hint on how plugins should process the data in this series.
getTypeHintBytes() - Method in class org.tensorflow.framework.SummaryDescription
Hint on how plugins should process the data in this series.
getTypeHintBytes() - Method in interface org.tensorflow.framework.SummaryDescriptionOrBuilder
Hint on how plugins should process the data in this series.
getTypeList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
getTypeList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(type)"
getTypeList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(type)"
getTypeListAttr() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
If specified, attr must have type "list(type)", and none of type, type_attr, and number_attr may be specified.
getTypeListAttr() - Method in class org.tensorflow.framework.OpDef.ArgDef
If specified, attr must have type "list(type)", and none of type, type_attr, and number_attr may be specified.
getTypeListAttr() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
If specified, attr must have type "list(type)", and none of type, type_attr, and number_attr may be specified.
getTypeListAttrBytes() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
If specified, attr must have type "list(type)", and none of type, type_attr, and number_attr may be specified.
getTypeListAttrBytes() - Method in class org.tensorflow.framework.OpDef.ArgDef
If specified, attr must have type "list(type)", and none of type, type_attr, and number_attr may be specified.
getTypeListAttrBytes() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
If specified, attr must have type "list(type)", and none of type, type_attr, and number_attr may be specified.
getTypeName() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
string type_name = 3;
getTypeName() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
string type_name = 3;
getTypeName() - Method in interface org.tensorflow.framework.GraphTransferNodeInfoOrBuilder
string type_name = 3;
getTypeName() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Name of the type of objects being serialized.
getTypeName() - Method in class org.tensorflow.framework.VariantTensorDataProto
Name of the type of objects being serialized.
getTypeName() - Method in interface org.tensorflow.framework.VariantTensorDataProtoOrBuilder
Name of the type of objects being serialized.
getTypeNameBytes() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
string type_name = 3;
getTypeNameBytes() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
string type_name = 3;
getTypeNameBytes() - Method in interface org.tensorflow.framework.GraphTransferNodeInfoOrBuilder
string type_name = 3;
getTypeNameBytes() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Name of the type of objects being serialized.
getTypeNameBytes() - Method in class org.tensorflow.framework.VariantTensorDataProto
Name of the type of objects being serialized.
getTypeNameBytes() - Method in interface org.tensorflow.framework.VariantTensorDataProtoOrBuilder
Name of the type of objects being serialized.
getTypeValue() - Method in class org.tensorflow.framework.AttrValue.Builder
"type"
getTypeValue() - Method in class org.tensorflow.framework.AttrValue
"type"
getTypeValue(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
getTypeValue(int) - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(type)"
getTypeValue(int) - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(type)"
getTypeValue() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"type"
getTypeValue() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Describes the type of one or more tensors that are accepted/produced by this input/output arg.
getTypeValue() - Method in class org.tensorflow.framework.OpDef.ArgDef
Describes the type of one or more tensors that are accepted/produced by this input/output arg.
getTypeValue() - Method in interface org.tensorflow.framework.OpDef.ArgDefOrBuilder
Describes the type of one or more tensors that are accepted/produced by this input/output arg.
getTypeValue() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Type of the tensor
getTypeValue() - Method in class org.tensorflow.util.SavedSliceMeta
Type of the tensor
getTypeValue() - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Type of the tensor
getTypeValueList() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
getTypeValueList() - Method in class org.tensorflow.framework.AttrValue.ListValue
"list(type)"
getTypeValueList() - Method in interface org.tensorflow.framework.AttrValue.ListValueOrBuilder
"list(type)"
getUint32Val(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT32
getUint32Val(int) - Method in class org.tensorflow.framework.TensorProto
DT_UINT32
getUint32Val(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_UINT32
getUint32ValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT32
getUint32ValCount() - Method in class org.tensorflow.framework.TensorProto
DT_UINT32
getUint32ValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_UINT32
getUint32ValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT32
getUint32ValList() - Method in class org.tensorflow.framework.TensorProto
DT_UINT32
getUint32ValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_UINT32
getUint64Val(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT64
getUint64Val(int) - Method in class org.tensorflow.framework.TensorProto
DT_UINT64
getUint64Val(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_UINT64
getUint64ValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT64
getUint64ValCount() - Method in class org.tensorflow.framework.TensorProto
DT_UINT64
getUint64ValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_UINT64
getUint64ValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT64
getUint64ValList() - Method in class org.tensorflow.framework.TensorProto
DT_UINT64
getUint64ValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_UINT64
getUnknownFields() - Method in class org.tensorflow.distruntime.ClusterDef
 
getUnknownFields() - Method in class org.tensorflow.distruntime.JobDef
 
getUnknownFields() - Method in class org.tensorflow.distruntime.ServerDef
 
getUnknownFields() - Method in class org.tensorflow.example.BytesList
 
getUnknownFields() - Method in class org.tensorflow.example.Example
 
getUnknownFields() - Method in class org.tensorflow.example.ExampleParserConfiguration
 
getUnknownFields() - Method in class org.tensorflow.example.Feature
 
getUnknownFields() - Method in class org.tensorflow.example.FeatureConfiguration
 
getUnknownFields() - Method in class org.tensorflow.example.FeatureList
 
getUnknownFields() - Method in class org.tensorflow.example.FeatureLists
 
getUnknownFields() - Method in class org.tensorflow.example.Features
 
getUnknownFields() - Method in class org.tensorflow.example.FixedLenFeatureProto
 
getUnknownFields() - Method in class org.tensorflow.example.FloatList
 
getUnknownFields() - Method in class org.tensorflow.example.Int64List
 
getUnknownFields() - Method in class org.tensorflow.example.SequenceExample
 
getUnknownFields() - Method in class org.tensorflow.example.VarLenFeatureProto
 
getUnknownFields() - Method in class org.tensorflow.framework.AllocationDescription
 
getUnknownFields() - Method in class org.tensorflow.framework.AllocationRecord
 
getUnknownFields() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
getUnknownFields() - Method in class org.tensorflow.framework.ApiDef.Arg
 
getUnknownFields() - Method in class org.tensorflow.framework.ApiDef.Attr
 
getUnknownFields() - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
getUnknownFields() - Method in class org.tensorflow.framework.ApiDef
 
getUnknownFields() - Method in class org.tensorflow.framework.ApiDefs
 
getUnknownFields() - Method in class org.tensorflow.framework.AssetFileDef
 
getUnknownFields() - Method in class org.tensorflow.framework.AttrValue
 
getUnknownFields() - Method in class org.tensorflow.framework.AttrValue.ListValue
 
getUnknownFields() - Method in class org.tensorflow.framework.AutoParallelOptions
 
getUnknownFields() - Method in class org.tensorflow.framework.CallableOptions
 
getUnknownFields() - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
getUnknownFields() - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
getUnknownFields() - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
getUnknownFields() - Method in class org.tensorflow.framework.CollectionDef
 
getUnknownFields() - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
getUnknownFields() - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
getUnknownFields() - Method in class org.tensorflow.framework.CondContextDef
 
getUnknownFields() - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
getUnknownFields() - Method in class org.tensorflow.framework.ConfigProto
 
getUnknownFields() - Method in class org.tensorflow.framework.ControlFlowContextDef
 
getUnknownFields() - Method in class org.tensorflow.framework.CostGraphDef
 
getUnknownFields() - Method in class org.tensorflow.framework.CostGraphDef.Node
 
getUnknownFields() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.DebuggedSourceFile
 
getUnknownFields() - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
getUnknownFields() - Method in class org.tensorflow.framework.DebugOptions
 
getUnknownFields() - Method in class org.tensorflow.framework.DebugTensorWatch
 
getUnknownFields() - Method in class org.tensorflow.framework.DeviceAttributes
 
getUnknownFields() - Method in class org.tensorflow.framework.DeviceLocality
 
getUnknownFields() - Method in class org.tensorflow.framework.DeviceStepStats
 
getUnknownFields() - Method in class org.tensorflow.framework.FunctionDef
 
getUnknownFields() - Method in class org.tensorflow.framework.FunctionDefLibrary
 
getUnknownFields() - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
getUnknownFields() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
getUnknownFields() - Method in class org.tensorflow.framework.GPUOptions
 
getUnknownFields() - Method in class org.tensorflow.framework.GradientDef
 
getUnknownFields() - Method in class org.tensorflow.framework.GraphDef
 
getUnknownFields() - Method in class org.tensorflow.framework.GraphOptions
 
getUnknownFields() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.GraphTransferInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
getUnknownFields() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.HistogramProto
 
getUnknownFields() - Method in class org.tensorflow.framework.InterconnectLink
 
getUnknownFields() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
getUnknownFields() - Method in class org.tensorflow.framework.KernelDef
 
getUnknownFields() - Method in class org.tensorflow.framework.KernelList
 
getUnknownFields() - Method in class org.tensorflow.framework.LocalLinks
 
getUnknownFields() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
getUnknownFields() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
getUnknownFields() - Method in class org.tensorflow.framework.MemoryLogStep
 
getUnknownFields() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
getUnknownFields() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
getUnknownFields() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
getUnknownFields() - Method in class org.tensorflow.framework.MemoryStats
 
getUnknownFields() - Method in class org.tensorflow.framework.MetaGraphDef
 
getUnknownFields() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
getUnknownFields() - Method in class org.tensorflow.framework.NameAttrList
 
getUnknownFields() - Method in class org.tensorflow.framework.NamedTensorProto
 
getUnknownFields() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.NodeDef
 
getUnknownFields() - Method in class org.tensorflow.framework.NodeExecStats
 
getUnknownFields() - Method in class org.tensorflow.framework.NodeOutput
 
getUnknownFields() - Method in class org.tensorflow.framework.OpDef.ArgDef
 
getUnknownFields() - Method in class org.tensorflow.framework.OpDef.AttrDef
 
getUnknownFields() - Method in class org.tensorflow.framework.OpDef
 
getUnknownFields() - Method in class org.tensorflow.framework.OpDeprecation
 
getUnknownFields() - Method in class org.tensorflow.framework.OpList
 
getUnknownFields() - Method in class org.tensorflow.framework.OptimizerOptions
 
getUnknownFields() - Method in class org.tensorflow.framework.QueueRunnerDef
 
getUnknownFields() - Method in class org.tensorflow.framework.ReaderBaseState
 
getUnknownFields() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
getUnknownFields() - Method in class org.tensorflow.framework.ResourceHandleProto
 
getUnknownFields() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
getUnknownFields() - Method in class org.tensorflow.framework.RewriterConfig
 
getUnknownFields() - Method in class org.tensorflow.framework.RPCOptions
 
getUnknownFields() - Method in class org.tensorflow.framework.RunMetadata
 
getUnknownFields() - Method in class org.tensorflow.framework.RunOptions.Experimental
 
getUnknownFields() - Method in class org.tensorflow.framework.RunOptions
 
getUnknownFields() - Method in class org.tensorflow.framework.SavedModel
 
getUnknownFields() - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
getUnknownFields() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
getUnknownFields() - Method in class org.tensorflow.framework.SignatureDef
 
getUnknownFields() - Method in class org.tensorflow.framework.StepStats
 
getUnknownFields() - Method in class org.tensorflow.framework.Summary.Audio
 
getUnknownFields() - Method in class org.tensorflow.framework.Summary
 
getUnknownFields() - Method in class org.tensorflow.framework.Summary.Image
 
getUnknownFields() - Method in class org.tensorflow.framework.Summary.Value
 
getUnknownFields() - Method in class org.tensorflow.framework.SummaryDescription
 
getUnknownFields() - Method in class org.tensorflow.framework.SummaryMetadata
 
getUnknownFields() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
getUnknownFields() - Method in class org.tensorflow.framework.TensorConnection
 
getUnknownFields() - Method in class org.tensorflow.framework.TensorDescription
 
getUnknownFields() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
getUnknownFields() - Method in class org.tensorflow.framework.TensorInfo
 
getUnknownFields() - Method in class org.tensorflow.framework.TensorProto
 
getUnknownFields() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
getUnknownFields() - Method in class org.tensorflow.framework.TensorShapeProto
 
getUnknownFields() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
getUnknownFields() - Method in class org.tensorflow.framework.TensorSliceProto
 
getUnknownFields() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
getUnknownFields() - Method in class org.tensorflow.framework.ValuesDef
 
getUnknownFields() - Method in class org.tensorflow.framework.VariableDef
 
getUnknownFields() - Method in class org.tensorflow.framework.VariantTensorDataProto
 
getUnknownFields() - Method in class org.tensorflow.framework.VersionDef
 
getUnknownFields() - Method in class org.tensorflow.framework.WhileContextDef
 
getUnknownFields() - Method in class org.tensorflow.util.BundleEntryProto
 
getUnknownFields() - Method in class org.tensorflow.util.BundleHeaderProto
 
getUnknownFields() - Method in class org.tensorflow.util.Event
 
getUnknownFields() - Method in class org.tensorflow.util.IteratorStateMetadata
 
getUnknownFields() - Method in class org.tensorflow.util.LogMessage
 
getUnknownFields() - Method in class org.tensorflow.util.SavedSlice
 
getUnknownFields() - Method in class org.tensorflow.util.SavedSliceMeta
 
getUnknownFields() - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
getUnknownFields() - Method in class org.tensorflow.util.SavedTensorSlices
 
getUnknownFields() - Method in class org.tensorflow.util.SaverDef
 
getUnknownFields() - Method in class org.tensorflow.util.SessionLog
 
getUnknownFields() - Method in class org.tensorflow.util.TaggedRunMetadata
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.CommitId
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.CPUInfo
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.EntryValue
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.GPUInfo
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.MemoryInfo
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.PlatformInfo
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.RunConfiguration
 
getUnknownFields() - Method in class org.tensorflow.util.testlog.TestResults
 
getUnknownFields() - Method in class org.tensorflow.util.WatchdogConfig
 
getUnknownFields() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
getUnknownFields() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
getUnknownFields() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
getUnknownFields() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
getUnknownFields() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
getUnknownFields() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
getUnknownFields() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
getUnknownFields() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
getUnknownFields() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
getUnknownFields() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
getUnknownFields() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
getUnknownFields() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
getUnknownRank() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
If true, the number of dimensions in the shape is unknown.
getUnknownRank() - Method in class org.tensorflow.framework.TensorShapeProto
If true, the number of dimensions in the shape is unknown.
getUnknownRank() - Method in interface org.tensorflow.framework.TensorShapeProtoOrBuilder
If true, the number of dimensions in the shape is unknown.
getUseNumaAffinity() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
If true, and supported by the platform, the runtime will attempt to use NUMA affinity where applicable.
getUseNumaAffinity() - Method in class org.tensorflow.framework.ConfigProto.Experimental
If true, and supported by the platform, the runtime will attempt to use NUMA affinity where applicable.
getUseNumaAffinity() - Method in interface org.tensorflow.framework.ConfigProto.ExperimentalOrBuilder
If true, and supported by the platform, the runtime will attempt to use NUMA affinity where applicable.
getUsePerSessionThreads() - Method in class org.tensorflow.framework.ConfigProto.Builder
If true, use a new set of threads for this session rather than the global pool of threads.
getUsePerSessionThreads() - Method in class org.tensorflow.framework.ConfigProto
If true, use a new set of threads for this session rather than the global pool of threads.
getUsePerSessionThreads() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
If true, use a new set of threads for this session rather than the global pool of threads.
getUseRpcForInprocessMaster() - Method in class org.tensorflow.framework.RPCOptions.Builder
If true, always use RPC to contact the session target.
getUseRpcForInprocessMaster() - Method in class org.tensorflow.framework.RPCOptions
If true, always use RPC to contact the session target.
getUseRpcForInprocessMaster() - Method in interface org.tensorflow.framework.RPCOptionsOrBuilder
If true, always use RPC to contact the session target.
getUseRunHandlerPool() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
If true, then operations (using the inter-op pool) across all session::run() calls will be centrally scheduled, optimizing for (median and tail) latency.
getUseRunHandlerPool() - Method in class org.tensorflow.framework.RunOptions.Experimental
If true, then operations (using the inter-op pool) across all session::run() calls will be centrally scheduled, optimizing for (median and tail) latency.
getUseRunHandlerPool() - Method in interface org.tensorflow.framework.RunOptions.ExperimentalOrBuilder
If true, then operations (using the inter-op pool) across all session::run() calls will be centrally scheduled, optimizing for (median and tail) latency.
getUseUnifiedMemory() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If true, uses CUDA unified memory for memory allocations.
getUseUnifiedMemory() - Method in class org.tensorflow.framework.GPUOptions.Experimental
If true, uses CUDA unified memory for memory allocations.
getUseUnifiedMemory() - Method in interface org.tensorflow.framework.GPUOptions.ExperimentalOrBuilder
If true, uses CUDA unified memory for memory allocations.
getUuid() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
Final entry in output of "nvidia-smi -L"
getUuid() - Method in class org.tensorflow.util.testlog.GPUInfo
Final entry in output of "nvidia-smi -L"
getUuid() - Method in interface org.tensorflow.util.testlog.GPUInfoOrBuilder
Final entry in output of "nvidia-smi -L"
getUuidBytes() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
Final entry in output of "nvidia-smi -L"
getUuidBytes() - Method in class org.tensorflow.util.testlog.GPUInfo
Final entry in output of "nvidia-smi -L"
getUuidBytes() - Method in interface org.tensorflow.util.testlog.GPUInfoOrBuilder
Final entry in output of "nvidia-smi -L"
getValue(int) - Method in class org.tensorflow.example.BytesList.Builder
repeated bytes value = 1;
getValue(int) - Method in class org.tensorflow.example.BytesList
repeated bytes value = 1;
getValue(int) - Method in interface org.tensorflow.example.BytesListOrBuilder
repeated bytes value = 1;
getValue(int) - Method in class org.tensorflow.example.FloatList.Builder
repeated float value = 1 [packed = true];
getValue(int) - Method in class org.tensorflow.example.FloatList
repeated float value = 1 [packed = true];
getValue(int) - Method in interface org.tensorflow.example.FloatListOrBuilder
repeated float value = 1 [packed = true];
getValue(int) - Method in class org.tensorflow.example.Int64List.Builder
repeated int64 value = 1 [packed = true];
getValue(int) - Method in class org.tensorflow.example.Int64List
repeated int64 value = 1 [packed = true];
getValue(int) - Method in interface org.tensorflow.example.Int64ListOrBuilder
repeated int64 value = 1 [packed = true];
getValue(int) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
getValue(int) - Method in class org.tensorflow.framework.CollectionDef.AnyList
repeated .google.protobuf.Any value = 1;
getValue(int) - Method in interface org.tensorflow.framework.CollectionDef.AnyListOrBuilder
repeated .google.protobuf.Any value = 1;
getValue(int) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
repeated bytes value = 1;
getValue(int) - Method in class org.tensorflow.framework.CollectionDef.BytesList
repeated bytes value = 1;
getValue(int) - Method in interface org.tensorflow.framework.CollectionDef.BytesListOrBuilder
repeated bytes value = 1;
getValue(int) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
repeated float value = 1 [packed = true];
getValue(int) - Method in class org.tensorflow.framework.CollectionDef.FloatList
repeated float value = 1 [packed = true];
getValue(int) - Method in interface org.tensorflow.framework.CollectionDef.FloatListOrBuilder
repeated float value = 1 [packed = true];
getValue(int) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
repeated int64 value = 1 [packed = true];
getValue(int) - Method in class org.tensorflow.framework.CollectionDef.Int64List
repeated int64 value = 1 [packed = true];
getValue(int) - Method in interface org.tensorflow.framework.CollectionDef.Int64ListOrBuilder
repeated int64 value = 1 [packed = true];
getValue(int) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
repeated string value = 1;
getValue(int) - Method in class org.tensorflow.framework.CollectionDef.NodeList
repeated string value = 1;
getValue(int) - Method in interface org.tensorflow.framework.CollectionDef.NodeListOrBuilder
repeated string value = 1;
getValue(int) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
getValue(int) - Method in class org.tensorflow.framework.Summary
Set of values for the summary.
getValue(int) - Method in interface org.tensorflow.framework.SummaryOrBuilder
Set of values for the summary.
getValueBuilder(int) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
getValueBuilder(int) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
getValueBuilderList() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
getValueBuilderList() - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
getValueBytes(int) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
repeated string value = 1;
getValueBytes(int) - Method in class org.tensorflow.framework.CollectionDef.NodeList
repeated string value = 1;
getValueBytes(int) - Method in interface org.tensorflow.framework.CollectionDef.NodeListOrBuilder
repeated string value = 1;
getValueCase() - Method in class org.tensorflow.framework.AttrValue.Builder
 
getValueCase() - Method in class org.tensorflow.framework.AttrValue
 
getValueCase() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
 
getValueCase() - Method in class org.tensorflow.framework.Summary.Value.Builder
 
getValueCase() - Method in class org.tensorflow.framework.Summary.Value
 
getValueCase() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
 
getValueCount() - Method in class org.tensorflow.example.BytesList.Builder
repeated bytes value = 1;
getValueCount() - Method in class org.tensorflow.example.BytesList
repeated bytes value = 1;
getValueCount() - Method in interface org.tensorflow.example.BytesListOrBuilder
repeated bytes value = 1;
getValueCount() - Method in class org.tensorflow.example.FloatList.Builder
repeated float value = 1 [packed = true];
getValueCount() - Method in class org.tensorflow.example.FloatList
repeated float value = 1 [packed = true];
getValueCount() - Method in interface org.tensorflow.example.FloatListOrBuilder
repeated float value = 1 [packed = true];
getValueCount() - Method in class org.tensorflow.example.Int64List.Builder
repeated int64 value = 1 [packed = true];
getValueCount() - Method in class org.tensorflow.example.Int64List
repeated int64 value = 1 [packed = true];
getValueCount() - Method in interface org.tensorflow.example.Int64ListOrBuilder
repeated int64 value = 1 [packed = true];
getValueCount() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
getValueCount() - Method in class org.tensorflow.framework.CollectionDef.AnyList
repeated .google.protobuf.Any value = 1;
getValueCount() - Method in interface org.tensorflow.framework.CollectionDef.AnyListOrBuilder
repeated .google.protobuf.Any value = 1;
getValueCount() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
repeated bytes value = 1;
getValueCount() - Method in class org.tensorflow.framework.CollectionDef.BytesList
repeated bytes value = 1;
getValueCount() - Method in interface org.tensorflow.framework.CollectionDef.BytesListOrBuilder
repeated bytes value = 1;
getValueCount() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
repeated float value = 1 [packed = true];
getValueCount() - Method in class org.tensorflow.framework.CollectionDef.FloatList
repeated float value = 1 [packed = true];
getValueCount() - Method in interface org.tensorflow.framework.CollectionDef.FloatListOrBuilder
repeated float value = 1 [packed = true];
getValueCount() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
repeated int64 value = 1 [packed = true];
getValueCount() - Method in class org.tensorflow.framework.CollectionDef.Int64List
repeated int64 value = 1 [packed = true];
getValueCount() - Method in interface org.tensorflow.framework.CollectionDef.Int64ListOrBuilder
repeated int64 value = 1 [packed = true];
getValueCount() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
repeated string value = 1;
getValueCount() - Method in class org.tensorflow.framework.CollectionDef.NodeList
repeated string value = 1;
getValueCount() - Method in interface org.tensorflow.framework.CollectionDef.NodeListOrBuilder
repeated string value = 1;
getValueCount() - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
getValueCount() - Method in class org.tensorflow.framework.Summary
Set of values for the summary.
getValueCount() - Method in interface org.tensorflow.framework.SummaryOrBuilder
Set of values for the summary.
getValueDescriptor() - Method in enum org.tensorflow.framework.ApiDef.Visibility
 
getValueDescriptor() - Method in enum org.tensorflow.framework.Code
 
getValueDescriptor() - Method in enum org.tensorflow.framework.DataType
 
getValueDescriptor() - Method in enum org.tensorflow.framework.GraphTransferInfo.Destination
 
getValueDescriptor() - Method in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
 
getValueDescriptor() - Method in enum org.tensorflow.framework.OptimizerOptions.Level
 
getValueDescriptor() - Method in enum org.tensorflow.framework.RewriterConfig.MemOptType
 
getValueDescriptor() - Method in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
 
getValueDescriptor() - Method in enum org.tensorflow.framework.RewriterConfig.Toggle
 
getValueDescriptor() - Method in enum org.tensorflow.framework.RunOptions.TraceLevel
 
getValueDescriptor() - Method in enum org.tensorflow.util.BundleHeaderProto.Endianness
 
getValueDescriptor() - Method in enum org.tensorflow.util.LogMessage.Level
 
getValueDescriptor() - Method in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
 
getValueDescriptor() - Method in enum org.tensorflow.util.SessionLog.SessionStatus
 
getValueDescriptor() - Method in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
 
getValueDescriptor() - Method in enum org.tensorflow.util.WorkerHealth
 
getValueDescriptor() - Method in enum org.tensorflow.util.WorkerShutdownMode
 
getValueList() - Method in class org.tensorflow.example.BytesList.Builder
repeated bytes value = 1;
getValueList() - Method in class org.tensorflow.example.BytesList
repeated bytes value = 1;
getValueList() - Method in interface org.tensorflow.example.BytesListOrBuilder
repeated bytes value = 1;
getValueList() - Method in class org.tensorflow.example.FloatList.Builder
repeated float value = 1 [packed = true];
getValueList() - Method in class org.tensorflow.example.FloatList
repeated float value = 1 [packed = true];
getValueList() - Method in interface org.tensorflow.example.FloatListOrBuilder
repeated float value = 1 [packed = true];
getValueList() - Method in class org.tensorflow.example.Int64List.Builder
repeated int64 value = 1 [packed = true];
getValueList() - Method in class org.tensorflow.example.Int64List
repeated int64 value = 1 [packed = true];
getValueList() - Method in interface org.tensorflow.example.Int64ListOrBuilder
repeated int64 value = 1 [packed = true];
getValueList() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
getValueList() - Method in class org.tensorflow.framework.CollectionDef.AnyList
repeated .google.protobuf.Any value = 1;
getValueList() - Method in interface org.tensorflow.framework.CollectionDef.AnyListOrBuilder
repeated .google.protobuf.Any value = 1;
getValueList() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
repeated bytes value = 1;
getValueList() - Method in class org.tensorflow.framework.CollectionDef.BytesList
repeated bytes value = 1;
getValueList() - Method in interface org.tensorflow.framework.CollectionDef.BytesListOrBuilder
repeated bytes value = 1;
getValueList() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
repeated float value = 1 [packed = true];
getValueList() - Method in class org.tensorflow.framework.CollectionDef.FloatList
repeated float value = 1 [packed = true];
getValueList() - Method in interface org.tensorflow.framework.CollectionDef.FloatListOrBuilder
repeated float value = 1 [packed = true];
getValueList() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
repeated int64 value = 1 [packed = true];
getValueList() - Method in class org.tensorflow.framework.CollectionDef.Int64List
repeated int64 value = 1 [packed = true];
getValueList() - Method in interface org.tensorflow.framework.CollectionDef.Int64ListOrBuilder
repeated int64 value = 1 [packed = true];
getValueList() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
repeated string value = 1;
getValueList() - Method in class org.tensorflow.framework.CollectionDef.NodeList
repeated string value = 1;
getValueList() - Method in interface org.tensorflow.framework.CollectionDef.NodeListOrBuilder
repeated string value = 1;
getValueList() - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
getValueList() - Method in class org.tensorflow.framework.Summary
Set of values for the summary.
getValueList() - Method in interface org.tensorflow.framework.SummaryOrBuilder
Set of values for the summary.
getValueOrBuilder(int) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
getValueOrBuilder(int) - Method in class org.tensorflow.framework.CollectionDef.AnyList
repeated .google.protobuf.Any value = 1;
getValueOrBuilder(int) - Method in interface org.tensorflow.framework.CollectionDef.AnyListOrBuilder
repeated .google.protobuf.Any value = 1;
getValueOrBuilder(int) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
getValueOrBuilder(int) - Method in class org.tensorflow.framework.Summary
Set of values for the summary.
getValueOrBuilder(int) - Method in interface org.tensorflow.framework.SummaryOrBuilder
Set of values for the summary.
getValueOrBuilderList() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
getValueOrBuilderList() - Method in class org.tensorflow.framework.CollectionDef.AnyList
repeated .google.protobuf.Any value = 1;
getValueOrBuilderList() - Method in interface org.tensorflow.framework.CollectionDef.AnyListOrBuilder
repeated .google.protobuf.Any value = 1;
getValueOrBuilderList() - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
getValueOrBuilderList() - Method in class org.tensorflow.framework.Summary
Set of values for the summary.
getValueOrBuilderList() - Method in interface org.tensorflow.framework.SummaryOrBuilder
Set of values for the summary.
getValues(int) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names that have been seen in this context.
getValues(int) - Method in class org.tensorflow.framework.ValuesDef
Value names that have been seen in this context.
getValues(int) - Method in interface org.tensorflow.framework.ValuesDefOrBuilder
Value names that have been seen in this context.
getValuesBytes(int) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names that have been seen in this context.
getValuesBytes(int) - Method in class org.tensorflow.framework.ValuesDef
Value names that have been seen in this context.
getValuesBytes(int) - Method in interface org.tensorflow.framework.ValuesDefOrBuilder
Value names that have been seen in this context.
getValuesCount() - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names that have been seen in this context.
getValuesCount() - Method in class org.tensorflow.framework.ValuesDef
Value names that have been seen in this context.
getValuesCount() - Method in interface org.tensorflow.framework.ValuesDefOrBuilder
Value names that have been seen in this context.
getValuesDef() - Method in class org.tensorflow.framework.CondContextDef.Builder
Values and external values in control flow context.
getValuesDef() - Method in class org.tensorflow.framework.CondContextDef
Values and external values in control flow context.
getValuesDef() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Values and external values in control flow context.
getValuesDef() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Values and external values in control flow context.
getValuesDef() - Method in class org.tensorflow.framework.WhileContextDef
Values and external values in control flow context.
getValuesDef() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Values and external values in control flow context.
getValuesDefBuilder() - Method in class org.tensorflow.framework.CondContextDef.Builder
Values and external values in control flow context.
getValuesDefBuilder() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Values and external values in control flow context.
getValuesDefOrBuilder() - Method in class org.tensorflow.framework.CondContextDef.Builder
Values and external values in control flow context.
getValuesDefOrBuilder() - Method in class org.tensorflow.framework.CondContextDef
Values and external values in control flow context.
getValuesDefOrBuilder() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Values and external values in control flow context.
getValuesDefOrBuilder() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Values and external values in control flow context.
getValuesDefOrBuilder() - Method in class org.tensorflow.framework.WhileContextDef
Values and external values in control flow context.
getValuesDefOrBuilder() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Values and external values in control flow context.
getValuesList() - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names that have been seen in this context.
getValuesList() - Method in class org.tensorflow.framework.ValuesDef
Value names that have been seen in this context.
getValuesList() - Method in interface org.tensorflow.framework.ValuesDefOrBuilder
Value names that have been seen in this context.
getValuesOutputTensorName() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
string values_output_tensor_name = 4;
getValuesOutputTensorName() - Method in class org.tensorflow.example.FixedLenFeatureProto
string values_output_tensor_name = 4;
getValuesOutputTensorName() - Method in interface org.tensorflow.example.FixedLenFeatureProtoOrBuilder
string values_output_tensor_name = 4;
getValuesOutputTensorName() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string values_output_tensor_name = 2;
getValuesOutputTensorName() - Method in class org.tensorflow.example.VarLenFeatureProto
string values_output_tensor_name = 2;
getValuesOutputTensorName() - Method in interface org.tensorflow.example.VarLenFeatureProtoOrBuilder
string values_output_tensor_name = 2;
getValuesOutputTensorNameBytes() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
string values_output_tensor_name = 4;
getValuesOutputTensorNameBytes() - Method in class org.tensorflow.example.FixedLenFeatureProto
string values_output_tensor_name = 4;
getValuesOutputTensorNameBytes() - Method in interface org.tensorflow.example.FixedLenFeatureProtoOrBuilder
string values_output_tensor_name = 4;
getValuesOutputTensorNameBytes() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string values_output_tensor_name = 2;
getValuesOutputTensorNameBytes() - Method in class org.tensorflow.example.VarLenFeatureProto
string values_output_tensor_name = 2;
getValuesOutputTensorNameBytes() - Method in interface org.tensorflow.example.VarLenFeatureProtoOrBuilder
string values_output_tensor_name = 2;
getValuesTensorName() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The shape of the values Tensor is [?].
getValuesTensorName() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
The shape of the values Tensor is [?].
getValuesTensorName() - Method in interface org.tensorflow.framework.TensorInfo.CooSparseOrBuilder
The shape of the values Tensor is [?].
getValuesTensorNameBytes() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The shape of the values Tensor is [?].
getValuesTensorNameBytes() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
The shape of the values Tensor is [?].
getValuesTensorNameBytes() - Method in interface org.tensorflow.framework.TensorInfo.CooSparseOrBuilder
The shape of the values Tensor is [?].
getVariableName() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the variable tensor.
getVariableName() - Method in class org.tensorflow.framework.VariableDef
Name of the variable tensor.
getVariableName() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Name of the variable tensor.
getVariableNameBytes() - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the variable tensor.
getVariableNameBytes() - Method in class org.tensorflow.framework.VariableDef
Name of the variable tensor.
getVariableNameBytes() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Name of the variable tensor.
getVariantVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
getVariantVal(int) - Method in class org.tensorflow.framework.TensorProto
DT_VARIANT
getVariantVal(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_VARIANT
getVariantValBuilder(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
getVariantValBuilderList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
getVariantValCount() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
getVariantValCount() - Method in class org.tensorflow.framework.TensorProto
DT_VARIANT
getVariantValCount() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_VARIANT
getVariantValList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
getVariantValList() - Method in class org.tensorflow.framework.TensorProto
DT_VARIANT
getVariantValList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_VARIANT
getVariantValOrBuilder(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
getVariantValOrBuilder(int) - Method in class org.tensorflow.framework.TensorProto
DT_VARIANT
getVariantValOrBuilder(int) - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_VARIANT
getVariantValOrBuilderList() - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
getVariantValOrBuilderList() - Method in class org.tensorflow.framework.TensorProto
DT_VARIANT
getVariantValOrBuilderList() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
DT_VARIANT
getVarLenFeature() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
getVarLenFeature() - Method in class org.tensorflow.example.FeatureConfiguration
.tensorflow.VarLenFeatureProto var_len_feature = 2;
getVarLenFeature() - Method in interface org.tensorflow.example.FeatureConfigurationOrBuilder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
getVarLenFeatureBuilder() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
getVarLenFeatureOrBuilder() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
getVarLenFeatureOrBuilder() - Method in class org.tensorflow.example.FeatureConfiguration
.tensorflow.VarLenFeatureProto var_len_feature = 2;
getVarLenFeatureOrBuilder() - Method in interface org.tensorflow.example.FeatureConfigurationOrBuilder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
getVarOffset(int) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Offset of this variable into the full variable.
getVarOffset(int) - Method in class org.tensorflow.framework.SaveSliceInfoDef
Offset of this variable into the full variable.
getVarOffset(int) - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Offset of this variable into the full variable.
getVarOffsetCount() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Offset of this variable into the full variable.
getVarOffsetCount() - Method in class org.tensorflow.framework.SaveSliceInfoDef
Offset of this variable into the full variable.
getVarOffsetCount() - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Offset of this variable into the full variable.
getVarOffsetList() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Offset of this variable into the full variable.
getVarOffsetList() - Method in class org.tensorflow.framework.SaveSliceInfoDef
Offset of this variable into the full variable.
getVarOffsetList() - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Offset of this variable into the full variable.
getVarShape(int) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of this variable.
getVarShape(int) - Method in class org.tensorflow.framework.SaveSliceInfoDef
Shape of this variable.
getVarShape(int) - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Shape of this variable.
getVarShapeCount() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of this variable.
getVarShapeCount() - Method in class org.tensorflow.framework.SaveSliceInfoDef
Shape of this variable.
getVarShapeCount() - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Shape of this variable.
getVarShapeList() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of this variable.
getVarShapeList() - Method in class org.tensorflow.framework.SaveSliceInfoDef
Shape of this variable.
getVarShapeList() - Method in interface org.tensorflow.framework.SaveSliceInfoDefOrBuilder
Shape of this variable.
getVendor() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Vendor (Intel, nvidia, ...)
getVendor() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Vendor (Intel, nvidia, ...)
getVendor() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Vendor (Intel, nvidia, ...)
getVendorBytes() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Vendor (Intel, nvidia, ...)
getVendorBytes() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
Vendor (Intel, nvidia, ...)
getVendorBytes() - Method in interface tensorflow.DevicePropertiesProtos.DevicePropertiesOrBuilder
Vendor (Intel, nvidia, ...)
getVersion() - Method in class org.tensorflow.framework.GraphDef.Builder
Deprecated.
getVersion() - Method in class org.tensorflow.framework.GraphDef
Deprecated.
getVersion() - Method in interface org.tensorflow.framework.GraphDefOrBuilder
Deprecated.
getVersion() - Method in class org.tensorflow.framework.OpDeprecation.Builder
First GraphDef version at which the op is disallowed.
getVersion() - Method in class org.tensorflow.framework.OpDeprecation
First GraphDef version at which the op is disallowed.
getVersion() - Method in interface org.tensorflow.framework.OpDeprecationOrBuilder
First GraphDef version at which the op is disallowed.
getVersion() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Versioning of the tensor bundle format.
getVersion() - Method in class org.tensorflow.util.BundleHeaderProto
Versioning of the tensor bundle format.
getVersion() - Method in interface org.tensorflow.util.BundleHeaderProtoOrBuilder
Versioning of the tensor bundle format.
getVersion() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
A user-specified version string.
getVersion() - Method in class org.tensorflow.util.IteratorStateMetadata
A user-specified version string.
getVersion() - Method in interface org.tensorflow.util.IteratorStateMetadataOrBuilder
A user-specified version string.
getVersion() - Method in class org.tensorflow.util.SaverDef.Builder
.tensorflow.SaverDef.CheckpointFormatVersion version = 7;
getVersion() - Method in class org.tensorflow.util.SaverDef
.tensorflow.SaverDef.CheckpointFormatVersion version = 7;
getVersion() - Method in interface org.tensorflow.util.SaverDefOrBuilder
.tensorflow.SaverDef.CheckpointFormatVersion version = 7;
getVersion() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getVersion() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getVersion() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getVersionBuilder() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Versioning of the tensor bundle format.
getVersionBytes() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
A user-specified version string.
getVersionBytes() - Method in class org.tensorflow.util.IteratorStateMetadata
A user-specified version string.
getVersionBytes() - Method in interface org.tensorflow.util.IteratorStateMetadataOrBuilder
A user-specified version string.
getVersionBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
getVersionBytes() - Method in class org.tensorflow.util.testlog.PlatformInfo
e.g.
getVersionBytes() - Method in interface org.tensorflow.util.testlog.PlatformInfoOrBuilder
e.g.
getVersionNumber() - Method in class org.tensorflow.framework.TensorProto.Builder
Version number.
getVersionNumber() - Method in class org.tensorflow.framework.TensorProto
Version number.
getVersionNumber() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
Version number.
getVersionOrBuilder() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Versioning of the tensor bundle format.
getVersionOrBuilder() - Method in class org.tensorflow.util.BundleHeaderProto
Versioning of the tensor bundle format.
getVersionOrBuilder() - Method in interface org.tensorflow.util.BundleHeaderProtoOrBuilder
Versioning of the tensor bundle format.
getVersions() - Method in class org.tensorflow.framework.GraphDef.Builder
Compatibility versions of the graph.
getVersions() - Method in class org.tensorflow.framework.GraphDef
Compatibility versions of the graph.
getVersions() - Method in interface org.tensorflow.framework.GraphDefOrBuilder
Compatibility versions of the graph.
getVersions() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Compatibility version of this checkpoint.
getVersions() - Method in class org.tensorflow.util.SavedTensorSliceMeta
Compatibility version of this checkpoint.
getVersions() - Method in interface org.tensorflow.util.SavedTensorSliceMetaOrBuilder
Compatibility version of this checkpoint.
getVersionsBuilder() - Method in class org.tensorflow.framework.GraphDef.Builder
Compatibility versions of the graph.
getVersionsBuilder() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Compatibility version of this checkpoint.
getVersionsOrBuilder() - Method in class org.tensorflow.framework.GraphDef.Builder
Compatibility versions of the graph.
getVersionsOrBuilder() - Method in class org.tensorflow.framework.GraphDef
Compatibility versions of the graph.
getVersionsOrBuilder() - Method in interface org.tensorflow.framework.GraphDefOrBuilder
Compatibility versions of the graph.
getVersionsOrBuilder() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Compatibility version of this checkpoint.
getVersionsOrBuilder() - Method in class org.tensorflow.util.SavedTensorSliceMeta
Compatibility version of this checkpoint.
getVersionsOrBuilder() - Method in interface org.tensorflow.util.SavedTensorSliceMetaOrBuilder
Compatibility version of this checkpoint.
getVersionValue() - Method in class org.tensorflow.util.SaverDef.Builder
.tensorflow.SaverDef.CheckpointFormatVersion version = 7;
getVersionValue() - Method in class org.tensorflow.util.SaverDef
.tensorflow.SaverDef.CheckpointFormatVersion version = 7;
getVersionValue() - Method in interface org.tensorflow.util.SaverDefOrBuilder
.tensorflow.SaverDef.CheckpointFormatVersion version = 7;
getVirtualDevices(int) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
getVirtualDevices(int) - Method in class org.tensorflow.framework.GPUOptions.Experimental
The multi virtual device settings.
getVirtualDevices(int) - Method in interface org.tensorflow.framework.GPUOptions.ExperimentalOrBuilder
The multi virtual device settings.
getVirtualDevicesBuilder(int) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
getVirtualDevicesBuilderList() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
getVirtualDevicesCount() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
getVirtualDevicesCount() - Method in class org.tensorflow.framework.GPUOptions.Experimental
The multi virtual device settings.
getVirtualDevicesCount() - Method in interface org.tensorflow.framework.GPUOptions.ExperimentalOrBuilder
The multi virtual device settings.
getVirtualDevicesList() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
getVirtualDevicesList() - Method in class org.tensorflow.framework.GPUOptions.Experimental
The multi virtual device settings.
getVirtualDevicesList() - Method in interface org.tensorflow.framework.GPUOptions.ExperimentalOrBuilder
The multi virtual device settings.
getVirtualDevicesOrBuilder(int) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
getVirtualDevicesOrBuilder(int) - Method in class org.tensorflow.framework.GPUOptions.Experimental
The multi virtual device settings.
getVirtualDevicesOrBuilder(int) - Method in interface org.tensorflow.framework.GPUOptions.ExperimentalOrBuilder
The multi virtual device settings.
getVirtualDevicesOrBuilderList() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
getVirtualDevicesOrBuilderList() - Method in class org.tensorflow.framework.GPUOptions.Experimental
The multi virtual device settings.
getVirtualDevicesOrBuilderList() - Method in interface org.tensorflow.framework.GPUOptions.ExperimentalOrBuilder
The multi virtual device settings.
getVisibility() - Method in class org.tensorflow.framework.ApiDef.Builder
.tensorflow.ApiDef.Visibility visibility = 2;
getVisibility() - Method in class org.tensorflow.framework.ApiDef
.tensorflow.ApiDef.Visibility visibility = 2;
getVisibility() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
.tensorflow.ApiDef.Visibility visibility = 2;
getVisibilityValue() - Method in class org.tensorflow.framework.ApiDef.Builder
.tensorflow.ApiDef.Visibility visibility = 2;
getVisibilityValue() - Method in class org.tensorflow.framework.ApiDef
.tensorflow.ApiDef.Visibility visibility = 2;
getVisibilityValue() - Method in interface org.tensorflow.framework.ApiDefOrBuilder
.tensorflow.ApiDef.Visibility visibility = 2;
getVisibleDeviceList() - Method in class org.tensorflow.framework.GPUOptions.Builder
A comma-separated list of GPU ids that determines the 'visible' to 'virtual' mapping of GPU devices.
getVisibleDeviceList() - Method in class org.tensorflow.framework.GPUOptions
A comma-separated list of GPU ids that determines the 'visible' to 'virtual' mapping of GPU devices.
getVisibleDeviceList() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
A comma-separated list of GPU ids that determines the 'visible' to 'virtual' mapping of GPU devices.
getVisibleDeviceListBytes() - Method in class org.tensorflow.framework.GPUOptions.Builder
A comma-separated list of GPU ids that determines the 'visible' to 'virtual' mapping of GPU devices.
getVisibleDeviceListBytes() - Method in class org.tensorflow.framework.GPUOptions
A comma-separated list of GPU ids that determines the 'visible' to 'virtual' mapping of GPU devices.
getVisibleDeviceListBytes() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
A comma-separated list of GPU ids that determines the 'visible' to 'virtual' mapping of GPU devices.
getWallTime() - Method in class org.tensorflow.util.Event.Builder
Timestamp of the event.
getWallTime() - Method in class org.tensorflow.util.Event
Timestamp of the event.
getWallTime() - Method in interface org.tensorflow.util.EventOrBuilder
Timestamp of the event.
getWallTime() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Total wall time used for all iterations (in seconds)
getWallTime() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
Total wall time used for all iterations (in seconds)
getWallTime() - Method in interface org.tensorflow.util.testlog.BenchmarkEntryOrBuilder
Total wall time used for all iterations (in seconds)
getWatchdogConfig() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WatchdogConfig watchdog_config = 2;
getWatchdogConfig() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
.tensorflow.WatchdogConfig watchdog_config = 2;
getWatchdogConfig() - Method in interface org.tensorflow.util.WorkerHeartbeatRequestOrBuilder
.tensorflow.WatchdogConfig watchdog_config = 2;
getWatchdogConfigBuilder() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WatchdogConfig watchdog_config = 2;
getWatchdogConfigOrBuilder() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WatchdogConfig watchdog_config = 2;
getWatchdogConfigOrBuilder() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
.tensorflow.WatchdogConfig watchdog_config = 2;
getWatchdogConfigOrBuilder() - Method in interface org.tensorflow.util.WorkerHeartbeatRequestOrBuilder
.tensorflow.WatchdogConfig watchdog_config = 2;
getWhatCase() - Method in class org.tensorflow.util.Event.Builder
 
getWhatCase() - Method in class org.tensorflow.util.Event
 
getWhatCase() - Method in interface org.tensorflow.util.EventOrBuilder
 
getWhileCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.WhileContextDef while_ctxt = 2;
getWhileCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef
.tensorflow.WhileContextDef while_ctxt = 2;
getWhileCtxt() - Method in interface org.tensorflow.framework.ControlFlowContextDefOrBuilder
.tensorflow.WhileContextDef while_ctxt = 2;
getWhileCtxtBuilder() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.WhileContextDef while_ctxt = 2;
getWhileCtxtOrBuilder() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.WhileContextDef while_ctxt = 2;
getWhileCtxtOrBuilder() - Method in class org.tensorflow.framework.ControlFlowContextDef
.tensorflow.WhileContextDef while_ctxt = 2;
getWhileCtxtOrBuilder() - Method in interface org.tensorflow.framework.ControlFlowContextDefOrBuilder
.tensorflow.WhileContextDef while_ctxt = 2;
getWidth() - Method in class org.tensorflow.framework.Summary.Image.Builder
int32 width = 2;
getWidth() - Method in class org.tensorflow.framework.Summary.Image
int32 width = 2;
getWidth() - Method in interface org.tensorflow.framework.Summary.ImageOrBuilder
int32 width = 2;
getWorkerLog(int) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
getWorkerLog(int) - Method in class org.tensorflow.util.WorkerHeartbeatResponse
repeated .tensorflow.Event worker_log = 2;
getWorkerLog(int) - Method in interface org.tensorflow.util.WorkerHeartbeatResponseOrBuilder
repeated .tensorflow.Event worker_log = 2;
getWorkerLogBuilder(int) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
getWorkerLogBuilderList() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
getWorkerLogCount() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
getWorkerLogCount() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
repeated .tensorflow.Event worker_log = 2;
getWorkerLogCount() - Method in interface org.tensorflow.util.WorkerHeartbeatResponseOrBuilder
repeated .tensorflow.Event worker_log = 2;
getWorkerLogList() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
getWorkerLogList() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
repeated .tensorflow.Event worker_log = 2;
getWorkerLogList() - Method in interface org.tensorflow.util.WorkerHeartbeatResponseOrBuilder
repeated .tensorflow.Event worker_log = 2;
getWorkerLogOrBuilder(int) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
getWorkerLogOrBuilder(int) - Method in class org.tensorflow.util.WorkerHeartbeatResponse
repeated .tensorflow.Event worker_log = 2;
getWorkerLogOrBuilder(int) - Method in interface org.tensorflow.util.WorkerHeartbeatResponseOrBuilder
repeated .tensorflow.Event worker_log = 2;
getWorkerLogOrBuilderList() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
getWorkerLogOrBuilderList() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
repeated .tensorflow.Event worker_log = 2;
getWorkerLogOrBuilderList() - Method in interface org.tensorflow.util.WorkerHeartbeatResponseOrBuilder
repeated .tensorflow.Event worker_log = 2;
getWorkFinished() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
int64 work_finished = 2;
getWorkFinished() - Method in class org.tensorflow.framework.ReaderBaseState
int64 work_finished = 2;
getWorkFinished() - Method in interface org.tensorflow.framework.ReaderBaseStateOrBuilder
int64 work_finished = 2;
getWorkStarted() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
int64 work_started = 1;
getWorkStarted() - Method in class org.tensorflow.framework.ReaderBaseState
int64 work_started = 1;
getWorkStarted() - Method in interface org.tensorflow.framework.ReaderBaseStateOrBuilder
int64 work_started = 1;
GLOBAL_JIT_LEVEL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OptimizerOptions
 
GLOBAL_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ThreadPoolOptionProto
 
GLOBAL_STEP_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebugOptions
 
GPU_OPTIONS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
GPUInfo - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.GPUInfo
GPUInfo.Builder - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.GPUInfo
GPUInfoOrBuilder - Interface in org.tensorflow.util.testlog
 
GPUOptions - Class in org.tensorflow.framework
Protobuf type tensorflow.GPUOptions
GPUOptions.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.GPUOptions
GPUOptions.Experimental - Class in org.tensorflow.framework
Protobuf type tensorflow.GPUOptions.Experimental
GPUOptions.Experimental.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.GPUOptions.Experimental
GPUOptions.Experimental.VirtualDevices - Class in org.tensorflow.framework
Configuration for breaking down a visible GPU into multiple "virtual" devices.
GPUOptions.Experimental.VirtualDevices.Builder - Class in org.tensorflow.framework
Configuration for breaking down a visible GPU into multiple "virtual" devices.
GPUOptions.Experimental.VirtualDevicesOrBuilder - Interface in org.tensorflow.framework
 
GPUOptions.ExperimentalOrBuilder - Interface in org.tensorflow.framework
 
GPUOptionsOrBuilder - Interface in org.tensorflow.framework
 
GRADIENT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.FunctionDefLibrary
 
GRADIENT_FUNC_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GradientDef
 
GradientDef - Class in org.tensorflow.framework
GradientDef defines the gradient function of a function defined in a function library.
GradientDef.Builder - Class in org.tensorflow.framework
GradientDef defines the gradient function of a function defined in a function library.
GradientDefOrBuilder - Interface in org.tensorflow.framework
 
GRAPH_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef
 
GRAPH_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.util.Event
 
GRAPH_INPUT_NODE_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferInfo
 
GRAPH_INPUT_NODE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
GRAPH_OP_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
GRAPH_OPTIONS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
GRAPH_OUTPUT_NODE_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferInfo
 
GRAPH_OUTPUT_NODE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
GraphDef - Class in org.tensorflow.framework
Represents the graph of operations
GraphDef.Builder - Class in org.tensorflow.framework
Represents the graph of operations
GraphDefOrBuilder - Interface in org.tensorflow.framework
 
GraphOptions - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphOptions
GraphOptions.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphOptions
GraphOptionsOrBuilder - Interface in org.tensorflow.framework
 
GraphProtos - Class in org.tensorflow.framework
 
GraphTransferConstNodeInfo - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferConstNodeInfo
GraphTransferConstNodeInfo.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferConstNodeInfo
GraphTransferConstNodeInfoOrBuilder - Interface in org.tensorflow.framework
 
GraphTransferGraphInputNodeInfo - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferGraphInputNodeInfo
GraphTransferGraphInputNodeInfo.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferGraphInputNodeInfo
GraphTransferGraphInputNodeInfoOrBuilder - Interface in org.tensorflow.framework
 
GraphTransferGraphOutputNodeInfo - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferGraphOutputNodeInfo
GraphTransferGraphOutputNodeInfo.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferGraphOutputNodeInfo
GraphTransferGraphOutputNodeInfoOrBuilder - Interface in org.tensorflow.framework
 
GraphTransferInfo - Class in org.tensorflow.framework
Protocol buffer representing a handle to a tensorflow resource.
GraphTransferInfo.Builder - Class in org.tensorflow.framework
Protocol buffer representing a handle to a tensorflow resource.
GraphTransferInfo.Destination - Enum in org.tensorflow.framework
Protobuf enum tensorflow.GraphTransferInfo.Destination
GraphTransferInfoOrBuilder - Interface in org.tensorflow.framework
 
GraphTransferInfoProto - Class in org.tensorflow.framework
 
GraphTransferNodeInfo - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferNodeInfo
GraphTransferNodeInfo.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferNodeInfo
GraphTransferNodeInfoOrBuilder - Interface in org.tensorflow.framework
 
GraphTransferNodeInput - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferNodeInput
GraphTransferNodeInput.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferNodeInput
GraphTransferNodeInputInfo - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferNodeInputInfo
GraphTransferNodeInputInfo.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferNodeInputInfo
GraphTransferNodeInputInfoOrBuilder - Interface in org.tensorflow.framework
 
GraphTransferNodeInputOrBuilder - Interface in org.tensorflow.framework
 
GraphTransferNodeOutputInfo - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferNodeOutputInfo
GraphTransferNodeOutputInfo.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.GraphTransferNodeOutputInfo
GraphTransferNodeOutputInfoOrBuilder - Interface in org.tensorflow.framework
 

H

HALF_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
HANDLE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogStep
 
HARDWARE_TRACE_VALUE - Static variable in enum org.tensorflow.framework.RunOptions.TraceLevel
HARDWARE_TRACE = 2;
HAS_MINIMUM_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.AttrDef
 
HAS_SINGLE_REFERENCE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocationDescription
 
hasAllocationDescription() - Method in class org.tensorflow.framework.TensorDescription.Builder
Information about the size and allocator used for the data
hasAllocationDescription() - Method in class org.tensorflow.framework.TensorDescription
Information about the size and allocator used for the data
hasAllocationDescription() - Method in interface org.tensorflow.framework.TensorDescriptionOrBuilder
Information about the size and allocator used for the data
hasAllowedValues() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
A list of values that this kernel supports for this attr.
hasAllowedValues() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
A list of values that this kernel supports for this attr.
hasAllowedValues() - Method in interface org.tensorflow.framework.KernelDef.AttrConstraintOrBuilder
A list of values that this kernel supports for this attr.
hasAllowedValues() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
The set of allowed values.
hasAllowedValues() - Method in class org.tensorflow.framework.OpDef.AttrDef
The set of allowed values.
hasAllowedValues() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
The set of allowed values.
hasAnyInfo() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A serialized protobuf.
hasAnyInfo() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
A serialized protobuf.
hasAnyInfo() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
A serialized protobuf.
hasAnyList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.AnyList any_list = 5;
hasAnyList() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.AnyList any_list = 5;
hasAnyList() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.AnyList any_list = 5;
hasAudio() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Audio audio = 6;
hasAudio() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.Summary.Audio audio = 6;
hasAudio() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.Summary.Audio audio = 6;
hasAutoParallel() - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
hasAutoParallel() - Method in class org.tensorflow.framework.RewriterConfig
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
hasAutoParallel() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
hasBuildConfiguration() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The configuration of the build (compiled opt? with cuda? any copts?)
hasBuildConfiguration() - Method in class org.tensorflow.util.testlog.TestResults
The configuration of the build (compiled opt? with cuda? any copts?)
hasBuildConfiguration() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The configuration of the build (compiled opt? with cuda? any copts?)
hasBytesList() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.BytesList bytes_list = 1;
hasBytesList() - Method in class org.tensorflow.example.Feature
.tensorflow.BytesList bytes_list = 1;
hasBytesList() - Method in interface org.tensorflow.example.FeatureOrBuilder
.tensorflow.BytesList bytes_list = 1;
hasBytesList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
hasBytesList() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.BytesList bytes_list = 2;
hasBytesList() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
hasCluster() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The cluster of which this server is a member.
hasCluster() - Method in class org.tensorflow.distruntime.ServerDef
The cluster of which this server is a member.
hasCluster() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The cluster of which this server is a member.
hasClusterDef() - Method in class org.tensorflow.framework.ConfigProto.Builder
Optional list of all workers to use in this session.
hasClusterDef() - Method in class org.tensorflow.framework.ConfigProto
Optional list of all workers to use in this session.
hasClusterDef() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Optional list of all workers to use in this session.
hasCommitId() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The commit id (git hash or changelist)
hasCommitId() - Method in class org.tensorflow.util.testlog.TestResults
The commit id (git hash or changelist)
hasCommitId() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The commit id (git hash or changelist)
hasCondCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.CondContextDef cond_ctxt = 1;
hasCondCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef
.tensorflow.CondContextDef cond_ctxt = 1;
hasCondCtxt() - Method in interface org.tensorflow.framework.ControlFlowContextDefOrBuilder
.tensorflow.CondContextDef cond_ctxt = 1;
hasContext() - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.Features context = 1;
hasContext() - Method in class org.tensorflow.example.SequenceExample
.tensorflow.Features context = 1;
hasContext() - Method in interface org.tensorflow.example.SequenceExampleOrBuilder
.tensorflow.Features context = 1;
hasCooSparse() - Method in class org.tensorflow.framework.TensorInfo.Builder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
hasCooSparse() - Method in class org.tensorflow.framework.TensorInfo
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
hasCooSparse() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
hasCostGraph() - Method in class org.tensorflow.framework.RunMetadata.Builder
The cost graph for the computation defined by the run call.
hasCostGraph() - Method in class org.tensorflow.framework.RunMetadata
The cost graph for the computation defined by the run call.
hasCostGraph() - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
The cost graph for the computation defined by the run call.
hasCpuInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
CPU Information.
hasCpuInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration
CPU Information.
hasCpuInfo() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
CPU Information.
hasData() - Method in class org.tensorflow.util.SavedSlice.Builder
The raw data of the slice is stored as a TensorProto.
hasData() - Method in class org.tensorflow.util.SavedSlice
The raw data of the slice is stored as a TensorProto.
hasData() - Method in interface org.tensorflow.util.SavedSliceOrBuilder
The raw data of the slice is stored as a TensorProto.
hasData() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This exists in all but the first item of each checkpoint file.
hasData() - Method in class org.tensorflow.util.SavedTensorSlices
This exists in all but the first item of each checkpoint file.
hasData() - Method in interface org.tensorflow.util.SavedTensorSlicesOrBuilder
This exists in all but the first item of each checkpoint file.
hasDebugOptions() - Method in class org.tensorflow.framework.RunOptions.Builder
EXPERIMENTAL.
hasDebugOptions() - Method in class org.tensorflow.framework.RunOptions
EXPERIMENTAL.
hasDebugOptions() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
EXPERIMENTAL.
hasDefaultSessionConfig() - Method in class org.tensorflow.distruntime.ServerDef.Builder
The default configuration for sessions that run on this server.
hasDefaultSessionConfig() - Method in class org.tensorflow.distruntime.ServerDef
The default configuration for sessions that run on this server.
hasDefaultSessionConfig() - Method in interface org.tensorflow.distruntime.ServerDefOrBuilder
The default configuration for sessions that run on this server.
hasDefaultValue() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorProto default_value = 3;
hasDefaultValue() - Method in class org.tensorflow.example.FixedLenFeatureProto
.tensorflow.TensorProto default_value = 3;
hasDefaultValue() - Method in interface org.tensorflow.example.FixedLenFeatureProtoOrBuilder
.tensorflow.TensorProto default_value = 3;
hasDefaultValue() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Specify a new default value to use for this attr.
hasDefaultValue() - Method in class org.tensorflow.framework.ApiDef.Attr
Specify a new default value to use for this attr.
hasDefaultValue() - Method in interface org.tensorflow.framework.ApiDef.AttrOrBuilder
Specify a new default value to use for this attr.
hasDefaultValue() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A reasonable default for this attribute if the user does not supply a value.
hasDefaultValue() - Method in class org.tensorflow.framework.OpDef.AttrDef
A reasonable default for this attribute if the user does not supply a value.
hasDefaultValue() - Method in interface org.tensorflow.framework.OpDef.AttrDefOrBuilder
A reasonable default for this attribute if the user does not supply a value.
hasDeprecation() - Method in class org.tensorflow.framework.OpDef.Builder
Optional deprecation based on GraphDef versions.
hasDeprecation() - Method in class org.tensorflow.framework.OpDef
Optional deprecation based on GraphDef versions.
hasDeprecation() - Method in interface org.tensorflow.framework.OpDefOrBuilder
Optional deprecation based on GraphDef versions.
hasEntries() - Method in class org.tensorflow.util.testlog.TestResults.Builder
The list of tests or benchmarks in this run.
hasEntries() - Method in class org.tensorflow.util.testlog.TestResults
The list of tests or benchmarks in this run.
hasEntries() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
The list of tests or benchmarks in this run.
hasExperimental() - Method in class org.tensorflow.framework.ConfigProto.Builder
.tensorflow.ConfigProto.Experimental experimental = 16;
hasExperimental() - Method in class org.tensorflow.framework.ConfigProto
.tensorflow.ConfigProto.Experimental experimental = 16;
hasExperimental() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
.tensorflow.ConfigProto.Experimental experimental = 16;
hasExperimental() - Method in class org.tensorflow.framework.GPUOptions.Builder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
hasExperimental() - Method in class org.tensorflow.framework.GPUOptions
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
hasExperimental() - Method in interface org.tensorflow.framework.GPUOptionsOrBuilder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
hasExperimental() - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.Experimental experimental = 8;
hasExperimental() - Method in class org.tensorflow.framework.RunOptions
.tensorflow.RunOptions.Experimental experimental = 8;
hasExperimental() - Method in interface org.tensorflow.framework.RunOptionsOrBuilder
.tensorflow.RunOptions.Experimental experimental = 8;
hasExperimentalDebugInfo() - Method in class org.tensorflow.framework.NodeDef.Builder
This stores debug information associated with the node.
hasExperimentalDebugInfo() - Method in class org.tensorflow.framework.NodeDef
This stores debug information associated with the node.
hasExperimentalDebugInfo() - Method in interface org.tensorflow.framework.NodeDefOrBuilder
This stores debug information associated with the node.
hasFeatureLists() - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.FeatureLists feature_lists = 2;
hasFeatureLists() - Method in class org.tensorflow.example.SequenceExample
.tensorflow.FeatureLists feature_lists = 2;
hasFeatureLists() - Method in interface org.tensorflow.example.SequenceExampleOrBuilder
.tensorflow.FeatureLists feature_lists = 2;
hasFeatures() - Method in class org.tensorflow.example.Example.Builder
.tensorflow.Features features = 1;
hasFeatures() - Method in class org.tensorflow.example.Example
.tensorflow.Features features = 1;
hasFeatures() - Method in interface org.tensorflow.example.ExampleOrBuilder
.tensorflow.Features features = 1;
hasFixedLenFeature() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
hasFixedLenFeature() - Method in class org.tensorflow.example.FeatureConfiguration
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
hasFixedLenFeature() - Method in interface org.tensorflow.example.FeatureConfigurationOrBuilder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
hasFloatList() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.FloatList float_list = 2;
hasFloatList() - Method in class org.tensorflow.example.Feature
.tensorflow.FloatList float_list = 2;
hasFloatList() - Method in interface org.tensorflow.example.FeatureOrBuilder
.tensorflow.FloatList float_list = 2;
hasFloatList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.FloatList float_list = 4;
hasFloatList() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.FloatList float_list = 4;
hasFloatList() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.FloatList float_list = 4;
hasFunc() - Method in class org.tensorflow.framework.AttrValue.Builder
"func" represents a function.
hasFunc() - Method in class org.tensorflow.framework.AttrValue
"func" represents a function.
hasFunc() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"func" represents a function.
hasGpuOptions() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all GPUs.
hasGpuOptions() - Method in class org.tensorflow.framework.ConfigProto
Options that apply to all GPUs.
hasGpuOptions() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Options that apply to all GPUs.
hasGraphDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
GraphDef.
hasGraphDef() - Method in class org.tensorflow.framework.MetaGraphDef
GraphDef.
hasGraphDef() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
GraphDef.
hasGraphOptions() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all graphs.
hasGraphOptions() - Method in class org.tensorflow.framework.ConfigProto
Options that apply to all graphs.
hasGraphOptions() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Options that apply to all graphs.
HASH_CODE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ResourceHandleProto
 
HASH_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.CommitId
 
hashCode() - Method in class org.tensorflow.distruntime.ClusterDef
 
hashCode() - Method in class org.tensorflow.distruntime.JobDef
 
hashCode() - Method in class org.tensorflow.distruntime.ServerDef
 
hashCode() - Method in class org.tensorflow.example.BytesList
 
hashCode() - Method in class org.tensorflow.example.Example
 
hashCode() - Method in class org.tensorflow.example.ExampleParserConfiguration
 
hashCode() - Method in class org.tensorflow.example.Feature
 
hashCode() - Method in class org.tensorflow.example.FeatureConfiguration
 
hashCode() - Method in class org.tensorflow.example.FeatureList
 
hashCode() - Method in class org.tensorflow.example.FeatureLists
 
hashCode() - Method in class org.tensorflow.example.Features
 
hashCode() - Method in class org.tensorflow.example.FixedLenFeatureProto
 
hashCode() - Method in class org.tensorflow.example.FloatList
 
hashCode() - Method in class org.tensorflow.example.Int64List
 
hashCode() - Method in class org.tensorflow.example.SequenceExample
 
hashCode() - Method in class org.tensorflow.example.VarLenFeatureProto
 
hashCode() - Method in class org.tensorflow.framework.AllocationDescription
 
hashCode() - Method in class org.tensorflow.framework.AllocationRecord
 
hashCode() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
hashCode() - Method in class org.tensorflow.framework.ApiDef.Arg
 
hashCode() - Method in class org.tensorflow.framework.ApiDef.Attr
 
hashCode() - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
hashCode() - Method in class org.tensorflow.framework.ApiDef
 
hashCode() - Method in class org.tensorflow.framework.ApiDefs
 
hashCode() - Method in class org.tensorflow.framework.AssetFileDef
 
hashCode() - Method in class org.tensorflow.framework.AttrValue
 
hashCode() - Method in class org.tensorflow.framework.AttrValue.ListValue
 
hashCode() - Method in class org.tensorflow.framework.AutoParallelOptions
 
hashCode() - Method in class org.tensorflow.framework.CallableOptions
 
hashCode() - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
hashCode() - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
hashCode() - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
hashCode() - Method in class org.tensorflow.framework.CollectionDef
 
hashCode() - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
hashCode() - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
hashCode() - Method in class org.tensorflow.framework.CondContextDef
 
hashCode() - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
hashCode() - Method in class org.tensorflow.framework.ConfigProto
 
hashCode() - Method in class org.tensorflow.framework.ControlFlowContextDef
 
hashCode() - Method in class org.tensorflow.framework.CostGraphDef
 
hashCode() - Method in class org.tensorflow.framework.CostGraphDef.Node
 
hashCode() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
hashCode() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
hashCode() - Method in class org.tensorflow.framework.DebuggedSourceFile
 
hashCode() - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
hashCode() - Method in class org.tensorflow.framework.DebugOptions
 
hashCode() - Method in class org.tensorflow.framework.DebugTensorWatch
 
hashCode() - Method in class org.tensorflow.framework.DeviceAttributes
 
hashCode() - Method in class org.tensorflow.framework.DeviceLocality
 
hashCode() - Method in class org.tensorflow.framework.DeviceStepStats
 
hashCode() - Method in class org.tensorflow.framework.FunctionDef
 
hashCode() - Method in class org.tensorflow.framework.FunctionDefLibrary
 
hashCode() - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
hashCode() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
hashCode() - Method in class org.tensorflow.framework.GPUOptions
 
hashCode() - Method in class org.tensorflow.framework.GradientDef
 
hashCode() - Method in class org.tensorflow.framework.GraphDef
 
hashCode() - Method in class org.tensorflow.framework.GraphOptions
 
hashCode() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
hashCode() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
hashCode() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
hashCode() - Method in class org.tensorflow.framework.GraphTransferInfo
 
hashCode() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
hashCode() - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
hashCode() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
hashCode() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
hashCode() - Method in class org.tensorflow.framework.HistogramProto
 
hashCode() - Method in class org.tensorflow.framework.InterconnectLink
 
hashCode() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
hashCode() - Method in class org.tensorflow.framework.KernelDef
 
hashCode() - Method in class org.tensorflow.framework.KernelList
 
hashCode() - Method in class org.tensorflow.framework.LocalLinks
 
hashCode() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
hashCode() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
hashCode() - Method in class org.tensorflow.framework.MemoryLogStep
 
hashCode() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
hashCode() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
hashCode() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
hashCode() - Method in class org.tensorflow.framework.MemoryStats
 
hashCode() - Method in class org.tensorflow.framework.MetaGraphDef
 
hashCode() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
hashCode() - Method in class org.tensorflow.framework.NameAttrList
 
hashCode() - Method in class org.tensorflow.framework.NamedTensorProto
 
hashCode() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
hashCode() - Method in class org.tensorflow.framework.NodeDef
 
hashCode() - Method in class org.tensorflow.framework.NodeExecStats
 
hashCode() - Method in class org.tensorflow.framework.NodeOutput
 
hashCode() - Method in class org.tensorflow.framework.OpDef.ArgDef
 
hashCode() - Method in class org.tensorflow.framework.OpDef.AttrDef
 
hashCode() - Method in class org.tensorflow.framework.OpDef
 
hashCode() - Method in class org.tensorflow.framework.OpDeprecation
 
hashCode() - Method in class org.tensorflow.framework.OpList
 
hashCode() - Method in class org.tensorflow.framework.OptimizerOptions
 
hashCode() - Method in class org.tensorflow.framework.QueueRunnerDef
 
hashCode() - Method in class org.tensorflow.framework.ReaderBaseState
 
hashCode() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
hashCode() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
hashCode() - Method in class org.tensorflow.framework.ResourceHandleProto
 
hashCode() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
hashCode() - Method in class org.tensorflow.framework.RewriterConfig
 
hashCode() - Method in class org.tensorflow.framework.RPCOptions
 
hashCode() - Method in class org.tensorflow.framework.RunMetadata
 
hashCode() - Method in class org.tensorflow.framework.RunOptions.Experimental
 
hashCode() - Method in class org.tensorflow.framework.RunOptions
 
hashCode() - Method in class org.tensorflow.framework.SavedModel
 
hashCode() - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
hashCode() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
hashCode() - Method in class org.tensorflow.framework.SignatureDef
 
hashCode() - Method in class org.tensorflow.framework.StepStats
 
hashCode() - Method in class org.tensorflow.framework.Summary.Audio
 
hashCode() - Method in class org.tensorflow.framework.Summary
 
hashCode() - Method in class org.tensorflow.framework.Summary.Image
 
hashCode() - Method in class org.tensorflow.framework.Summary.Value
 
hashCode() - Method in class org.tensorflow.framework.SummaryDescription
 
hashCode() - Method in class org.tensorflow.framework.SummaryMetadata
 
hashCode() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
hashCode() - Method in class org.tensorflow.framework.TensorConnection
 
hashCode() - Method in class org.tensorflow.framework.TensorDescription
 
hashCode() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
hashCode() - Method in class org.tensorflow.framework.TensorInfo
 
hashCode() - Method in class org.tensorflow.framework.TensorProto
 
hashCode() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
hashCode() - Method in class org.tensorflow.framework.TensorShapeProto
 
hashCode() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
hashCode() - Method in class org.tensorflow.framework.TensorSliceProto
 
hashCode() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
hashCode() - Method in class org.tensorflow.framework.ValuesDef
 
hashCode() - Method in class org.tensorflow.framework.VariableDef
 
hashCode() - Method in class org.tensorflow.framework.VariantTensorDataProto
 
hashCode() - Method in class org.tensorflow.framework.VersionDef
 
hashCode() - Method in class org.tensorflow.framework.WhileContextDef
 
hashCode() - Method in class org.tensorflow.util.BundleEntryProto
 
hashCode() - Method in class org.tensorflow.util.BundleHeaderProto
 
hashCode() - Method in class org.tensorflow.util.Event
 
hashCode() - Method in class org.tensorflow.util.IteratorStateMetadata
 
hashCode() - Method in class org.tensorflow.util.LogMessage
 
hashCode() - Method in class org.tensorflow.util.SavedSlice
 
hashCode() - Method in class org.tensorflow.util.SavedSliceMeta
 
hashCode() - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
hashCode() - Method in class org.tensorflow.util.SavedTensorSlices
 
hashCode() - Method in class org.tensorflow.util.SaverDef
 
hashCode() - Method in class org.tensorflow.util.SessionLog
 
hashCode() - Method in class org.tensorflow.util.TaggedRunMetadata
 
hashCode() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
hashCode() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
hashCode() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
hashCode() - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
hashCode() - Method in class org.tensorflow.util.testlog.CommitId
 
hashCode() - Method in class org.tensorflow.util.testlog.CPUInfo
 
hashCode() - Method in class org.tensorflow.util.testlog.EntryValue
 
hashCode() - Method in class org.tensorflow.util.testlog.GPUInfo
 
hashCode() - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
hashCode() - Method in class org.tensorflow.util.testlog.MemoryInfo
 
hashCode() - Method in class org.tensorflow.util.testlog.PlatformInfo
 
hashCode() - Method in class org.tensorflow.util.testlog.RunConfiguration
 
hashCode() - Method in class org.tensorflow.util.testlog.TestResults
 
hashCode() - Method in class org.tensorflow.util.WatchdogConfig
 
hashCode() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
hashCode() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
hashCode() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
hashCode() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
hashCode() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
hashCode() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
hashCode() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
hashCode() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
hashCode() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
hashCode() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
hashCode() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
hashCode() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
hasHisto() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.HistogramProto histo = 5;
hasHisto() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.HistogramProto histo = 5;
hasHisto() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.HistogramProto histo = 5;
hasImage() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Image image = 4;
hasImage() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.Summary.Image image = 4;
hasImage() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.Summary.Image image = 4;
hasInt64List() - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.Int64List int64_list = 3;
hasInt64List() - Method in class org.tensorflow.example.Feature
.tensorflow.Int64List int64_list = 3;
hasInt64List() - Method in interface org.tensorflow.example.FeatureOrBuilder
.tensorflow.Int64List int64_list = 3;
hasInt64List() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.Int64List int64_list = 3;
hasInt64List() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.Int64List int64_list = 3;
hasInt64List() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.Int64List int64_list = 3;
hasLibrary() - Method in class org.tensorflow.framework.GraphDef.Builder
EXPERIMENTAL.
hasLibrary() - Method in class org.tensorflow.framework.GraphDef
EXPERIMENTAL.
hasLibrary() - Method in interface org.tensorflow.framework.GraphDefOrBuilder
EXPERIMENTAL.
hasLinks() - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional local interconnect links to other devices.
hasLinks() - Method in class org.tensorflow.framework.DeviceLocality
Optional local interconnect links to other devices.
hasLinks() - Method in interface org.tensorflow.framework.DeviceLocalityOrBuilder
Optional local interconnect links to other devices.
hasList() - Method in class org.tensorflow.framework.AttrValue.Builder
any "list(...)"
hasList() - Method in class org.tensorflow.framework.AttrValue
any "list(...)"
hasList() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
any "list(...)"
hasLocality() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Platform-specific data about device that may be useful for supporting efficient data transfers.
hasLocality() - Method in class org.tensorflow.framework.DeviceAttributes
Platform-specific data about device that may be useful for supporting efficient data transfers.
hasLocality() - Method in interface org.tensorflow.framework.DeviceAttributesOrBuilder
Platform-specific data about device that may be useful for supporting efficient data transfers.
hasLogMessage() - Method in class org.tensorflow.util.Event.Builder
The user output a log message.
hasLogMessage() - Method in class org.tensorflow.util.Event
The user output a log message.
hasLogMessage() - Method in interface org.tensorflow.util.EventOrBuilder
The user output a log message.
hasMachineConfiguration() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Machine-specific parameters (Platform and CPU info)
hasMachineConfiguration() - Method in class org.tensorflow.util.testlog.TestResults
Machine-specific parameters (Platform and CPU info)
hasMachineConfiguration() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
Machine-specific parameters (Platform and CPU info)
hasMemoryInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
.tensorflow.MemoryInfo memory_info = 6;
hasMemoryInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration
.tensorflow.MemoryInfo memory_info = 6;
hasMemoryInfo() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
.tensorflow.MemoryInfo memory_info = 6;
hasMemoryStats() - Method in class org.tensorflow.framework.NodeExecStats.Builder
.tensorflow.MemoryStats memory_stats = 12;
hasMemoryStats() - Method in class org.tensorflow.framework.NodeExecStats
.tensorflow.MemoryStats memory_stats = 12;
hasMemoryStats() - Method in interface org.tensorflow.framework.NodeExecStatsOrBuilder
.tensorflow.MemoryStats memory_stats = 12;
hasMeta() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
hasMeta() - Method in class org.tensorflow.util.SavedTensorSlices
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
hasMeta() - Method in interface org.tensorflow.util.SavedTensorSlicesOrBuilder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
hasMetadata() - Method in class org.tensorflow.framework.Summary.Value.Builder
Contains metadata on the summary value such as which plugins may use it.
hasMetadata() - Method in class org.tensorflow.framework.Summary.Value
Contains metadata on the summary value such as which plugins may use it.
hasMetadata() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
Contains metadata on the summary value such as which plugins may use it.
hasMetaInfoDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
hasMetaInfoDef() - Method in class org.tensorflow.framework.MetaGraphDef
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
hasMetaInfoDef() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
hasNodeList() - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.NodeList node_list = 1;
hasNodeList() - Method in class org.tensorflow.framework.CollectionDef
.tensorflow.CollectionDef.NodeList node_list = 1;
hasNodeList() - Method in interface org.tensorflow.framework.CollectionDefOrBuilder
.tensorflow.CollectionDef.NodeList node_list = 1;
hasOptimizerOptions() - Method in class org.tensorflow.framework.GraphOptions.Builder
Options controlling how graph is optimized.
hasOptimizerOptions() - Method in class org.tensorflow.framework.GraphOptions
Options controlling how graph is optimized.
hasOptimizerOptions() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
Options controlling how graph is optimized.
hasPlatformInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Additional platform information.
hasPlatformInfo() - Method in class org.tensorflow.util.testlog.MachineConfiguration
Additional platform information.
hasPlatformInfo() - Method in interface org.tensorflow.util.testlog.MachineConfigurationOrBuilder
Additional platform information.
hasPluginData() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Data that associates a summary with a certain plugin.
hasPluginData() - Method in class org.tensorflow.framework.SummaryMetadata
Data that associates a summary with a certain plugin.
hasPluginData() - Method in interface org.tensorflow.framework.SummaryMetadataOrBuilder
Data that associates a summary with a certain plugin.
hasProperties() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
.tensorflow.DeviceProperties properties = 2;
hasProperties() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
.tensorflow.DeviceProperties properties = 2;
hasProperties() - Method in interface tensorflow.DevicePropertiesProtos.NamedDeviceOrBuilder
.tensorflow.DeviceProperties properties = 2;
hasRemoteGraph() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Definition of remote graph
hasRemoteGraph() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
Definition of remote graph
hasRemoteGraph() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfoOrBuilder
Definition of remote graph
hasRewriteOptions() - Method in class org.tensorflow.framework.GraphOptions.Builder
Options that control the type and amount of graph rewriting.
hasRewriteOptions() - Method in class org.tensorflow.framework.GraphOptions
Options that control the type and amount of graph rewriting.
hasRewriteOptions() - Method in interface org.tensorflow.framework.GraphOptionsOrBuilder
Options that control the type and amount of graph rewriting.
hasRpcOptions() - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply when this session uses the distributed runtime.
hasRpcOptions() - Method in class org.tensorflow.framework.ConfigProto
Options that apply when this session uses the distributed runtime.
hasRpcOptions() - Method in interface org.tensorflow.framework.ConfigProtoOrBuilder
Options that apply when this session uses the distributed runtime.
hasRunConfiguration() - Method in class org.tensorflow.util.testlog.TestResults.Builder
Run-specific parameters (arguments, etc)
hasRunConfiguration() - Method in class org.tensorflow.util.testlog.TestResults
Run-specific parameters (arguments, etc)
hasRunConfiguration() - Method in interface org.tensorflow.util.testlog.TestResultsOrBuilder
Run-specific parameters (arguments, etc)
hasRunOptions() - Method in class org.tensorflow.framework.CallableOptions.Builder
Options that will be applied to each run.
hasRunOptions() - Method in class org.tensorflow.framework.CallableOptions
Options that will be applied to each run.
hasRunOptions() - Method in interface org.tensorflow.framework.CallableOptionsOrBuilder
Options that will be applied to each run.
hasSaverDef() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
SaverDef.
hasSaverDef() - Method in class org.tensorflow.framework.MetaGraphDef
SaverDef.
hasSaverDef() - Method in interface org.tensorflow.framework.MetaGraphDefOrBuilder
SaverDef.
hasSaveSliceInfoDef() - Method in class org.tensorflow.framework.VariableDef.Builder
Support for saving variables as slices of a larger variable.
hasSaveSliceInfoDef() - Method in class org.tensorflow.framework.VariableDef
Support for saving variables as slices of a larger variable.
hasSaveSliceInfoDef() - Method in interface org.tensorflow.framework.VariableDefOrBuilder
Support for saving variables as slices of a larger variable.
hasScopedAllocatorOpts() - Method in class org.tensorflow.framework.RewriterConfig.Builder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
hasScopedAllocatorOpts() - Method in class org.tensorflow.framework.RewriterConfig
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
hasScopedAllocatorOpts() - Method in interface org.tensorflow.framework.RewriterConfigOrBuilder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
hasSessionLog() - Method in class org.tensorflow.util.Event.Builder
The state of the session which can be used for restarting after crashes.
hasSessionLog() - Method in class org.tensorflow.util.Event
The state of the session which can be used for restarting after crashes.
hasSessionLog() - Method in interface org.tensorflow.util.EventOrBuilder
The state of the session which can be used for restarting after crashes.
hasShape() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorShapeProto shape = 2;
hasShape() - Method in class org.tensorflow.example.FixedLenFeatureProto
.tensorflow.TensorShapeProto shape = 2;
hasShape() - Method in interface org.tensorflow.example.FixedLenFeatureProtoOrBuilder
.tensorflow.TensorShapeProto shape = 2;
hasShape() - Method in class org.tensorflow.framework.AttrValue.Builder
"shape"
hasShape() - Method in class org.tensorflow.framework.AttrValue
"shape"
hasShape() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"shape"
hasShape() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.TensorShapeProto shape = 3;
hasShape() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
.tensorflow.TensorShapeProto shape = 3;
hasShape() - Method in interface org.tensorflow.framework.CostGraphDef.Node.OutputInfoOrBuilder
.tensorflow.TensorShapeProto shape = 3;
hasShape() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.TensorShapeProto shape = 2;
hasShape() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
.tensorflow.TensorShapeProto shape = 2;
hasShape() - Method in interface org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProtoOrBuilder
.tensorflow.TensorShapeProto shape = 2;
hasShape() - Method in class org.tensorflow.framework.TensorDescription.Builder
Shape of the tensor.
hasShape() - Method in class org.tensorflow.framework.TensorDescription
Shape of the tensor.
hasShape() - Method in interface org.tensorflow.framework.TensorDescriptionOrBuilder
Shape of the tensor.
hasShape() - Method in class org.tensorflow.util.BundleEntryProto.Builder
.tensorflow.TensorShapeProto shape = 2;
hasShape() - Method in class org.tensorflow.util.BundleEntryProto
.tensorflow.TensorShapeProto shape = 2;
hasShape() - Method in interface org.tensorflow.util.BundleEntryProtoOrBuilder
.tensorflow.TensorShapeProto shape = 2;
hasShape() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Shape of the tensor
hasShape() - Method in class org.tensorflow.util.SavedSliceMeta
Shape of the tensor
hasShape() - Method in interface org.tensorflow.util.SavedSliceMetaOrBuilder
Shape of the tensor
hasSignature() - Method in class org.tensorflow.framework.FunctionDef.Builder
The definition of the function's name, arguments, return values, attrs etc.
hasSignature() - Method in class org.tensorflow.framework.FunctionDef
The definition of the function's name, arguments, return values, attrs etc.
hasSignature() - Method in interface org.tensorflow.framework.FunctionDefOrBuilder
The definition of the function's name, arguments, return values, attrs etc.
hasSlice() - Method in class org.tensorflow.util.SavedSlice.Builder
Extent of the slice.
hasSlice() - Method in class org.tensorflow.util.SavedSlice
Extent of the slice.
hasSlice() - Method in interface org.tensorflow.util.SavedSliceOrBuilder
Extent of the slice.
hasStepStats() - Method in class org.tensorflow.framework.RunMetadata.Builder
Statistics traced for this step.
hasStepStats() - Method in class org.tensorflow.framework.RunMetadata
Statistics traced for this step.
hasStepStats() - Method in interface org.tensorflow.framework.RunMetadataOrBuilder
Statistics traced for this step.
hasStrippedOpList() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A copy of the OpDefs used by the producer of this graph_def.
hasStrippedOpList() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
A copy of the OpDefs used by the producer of this graph_def.
hasStrippedOpList() - Method in interface org.tensorflow.framework.MetaGraphDef.MetaInfoDefOrBuilder
A copy of the OpDefs used by the producer of this graph_def.
hasSummary() - Method in class org.tensorflow.util.Event.Builder
A summary was generated.
hasSummary() - Method in class org.tensorflow.util.Event
A summary was generated.
hasSummary() - Method in interface org.tensorflow.util.EventOrBuilder
A summary was generated.
hasTaggedRunMetadata() - Method in class org.tensorflow.util.Event.Builder
The metadata returned by running a session.run() call.
hasTaggedRunMetadata() - Method in class org.tensorflow.util.Event
The metadata returned by running a session.run() call.
hasTaggedRunMetadata() - Method in interface org.tensorflow.util.EventOrBuilder
The metadata returned by running a session.run() call.
hasTensor() - Method in class org.tensorflow.framework.AttrValue.Builder
"tensor"
hasTensor() - Method in class org.tensorflow.framework.AttrValue
"tensor"
hasTensor() - Method in interface org.tensorflow.framework.AttrValueOrBuilder
"tensor"
hasTensor() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Allocated tensor details.
hasTensor() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
Allocated tensor details.
hasTensor() - Method in interface org.tensorflow.framework.MemoryLogTensorAllocationOrBuilder
Allocated tensor details.
hasTensor() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Output tensor details.
hasTensor() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
Output tensor details.
hasTensor() - Method in interface org.tensorflow.framework.MemoryLogTensorOutputOrBuilder
Output tensor details.
hasTensor() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
hasTensor() - Method in class org.tensorflow.framework.NamedTensorProto
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
hasTensor() - Method in interface org.tensorflow.framework.NamedTensorProtoOrBuilder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
hasTensor() - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.TensorProto tensor = 8;
hasTensor() - Method in class org.tensorflow.framework.Summary.Value
.tensorflow.TensorProto tensor = 8;
hasTensor() - Method in interface org.tensorflow.framework.Summary.ValueOrBuilder
.tensorflow.TensorProto tensor = 8;
hasTensorDescription() - Method in class org.tensorflow.framework.NodeOutput.Builder
.tensorflow.TensorDescription tensor_description = 3;
hasTensorDescription() - Method in class org.tensorflow.framework.NodeOutput
.tensorflow.TensorDescription tensor_description = 3;
hasTensorDescription() - Method in interface org.tensorflow.framework.NodeOutputOrBuilder
.tensorflow.TensorDescription tensor_description = 3;
hasTensorInfo() - Method in class org.tensorflow.framework.AssetFileDef.Builder
The tensor to bind the asset filename to.
hasTensorInfo() - Method in class org.tensorflow.framework.AssetFileDef
The tensor to bind the asset filename to.
hasTensorInfo() - Method in interface org.tensorflow.framework.AssetFileDefOrBuilder
The tensor to bind the asset filename to.
hasTensorShape() - Method in class org.tensorflow.framework.TensorInfo.Builder
The static shape should be recorded here, to the extent that it can be known in advance.
hasTensorShape() - Method in class org.tensorflow.framework.TensorInfo
The static shape should be recorded here, to the extent that it can be known in advance.
hasTensorShape() - Method in interface org.tensorflow.framework.TensorInfoOrBuilder
The static shape should be recorded here, to the extent that it can be known in advance.
hasTensorShape() - Method in class org.tensorflow.framework.TensorProto.Builder
Shape of the tensor.
hasTensorShape() - Method in class org.tensorflow.framework.TensorProto
Shape of the tensor.
hasTensorShape() - Method in interface org.tensorflow.framework.TensorProtoOrBuilder
Shape of the tensor.
hasValuesDef() - Method in class org.tensorflow.framework.CondContextDef.Builder
Values and external values in control flow context.
hasValuesDef() - Method in class org.tensorflow.framework.CondContextDef
Values and external values in control flow context.
hasValuesDef() - Method in interface org.tensorflow.framework.CondContextDefOrBuilder
Values and external values in control flow context.
hasValuesDef() - Method in class org.tensorflow.framework.WhileContextDef.Builder
Values and external values in control flow context.
hasValuesDef() - Method in class org.tensorflow.framework.WhileContextDef
Values and external values in control flow context.
hasValuesDef() - Method in interface org.tensorflow.framework.WhileContextDefOrBuilder
Values and external values in control flow context.
hasVarLenFeature() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
hasVarLenFeature() - Method in class org.tensorflow.example.FeatureConfiguration
.tensorflow.VarLenFeatureProto var_len_feature = 2;
hasVarLenFeature() - Method in interface org.tensorflow.example.FeatureConfigurationOrBuilder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
hasVersion() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Versioning of the tensor bundle format.
hasVersion() - Method in class org.tensorflow.util.BundleHeaderProto
Versioning of the tensor bundle format.
hasVersion() - Method in interface org.tensorflow.util.BundleHeaderProtoOrBuilder
Versioning of the tensor bundle format.
hasVersions() - Method in class org.tensorflow.framework.GraphDef.Builder
Compatibility versions of the graph.
hasVersions() - Method in class org.tensorflow.framework.GraphDef
Compatibility versions of the graph.
hasVersions() - Method in interface org.tensorflow.framework.GraphDefOrBuilder
Compatibility versions of the graph.
hasVersions() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Compatibility version of this checkpoint.
hasVersions() - Method in class org.tensorflow.util.SavedTensorSliceMeta
Compatibility version of this checkpoint.
hasVersions() - Method in interface org.tensorflow.util.SavedTensorSliceMetaOrBuilder
Compatibility version of this checkpoint.
hasWatchdogConfig() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WatchdogConfig watchdog_config = 2;
hasWatchdogConfig() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
.tensorflow.WatchdogConfig watchdog_config = 2;
hasWatchdogConfig() - Method in interface org.tensorflow.util.WorkerHeartbeatRequestOrBuilder
.tensorflow.WatchdogConfig watchdog_config = 2;
hasWhileCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.WhileContextDef while_ctxt = 2;
hasWhileCtxt() - Method in class org.tensorflow.framework.ControlFlowContextDef
.tensorflow.WhileContextDef while_ctxt = 2;
hasWhileCtxt() - Method in interface org.tensorflow.framework.ControlFlowContextDefOrBuilder
.tensorflow.WhileContextDef while_ctxt = 2;
HEALTH_STATUS_FIELD_NUMBER - Static variable in class org.tensorflow.util.WorkerHeartbeatResponse
 
HEIGHT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Image
 
HEURISTICS_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.MemOptType
Use any combination of swapping and recomputation heuristics.
HEXAGON_VALUE - Static variable in enum org.tensorflow.framework.GraphTransferInfo.Destination
HEXAGON = 1;
HIDDEN_VALUE - Static variable in enum org.tensorflow.framework.ApiDef.Visibility
Hide this op by putting it into an internal namespace (or whatever is appropriate in the target language).
HISTO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Value
 
HistogramProto - Class in org.tensorflow.framework
Serialization format for histogram module in core/lib/histogram/histogram.h
HistogramProto.Builder - Class in org.tensorflow.framework
Serialization format for histogram module in core/lib/histogram/histogram.h
HistogramProtoOrBuilder - Interface in org.tensorflow.framework
 
HOST_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebuggedSourceFile
 
HOST_MEMORY_ARG_FIELD_NUMBER - Static variable in class org.tensorflow.framework.KernelDef
 
HOST_TEMP_MEMORY_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
HOSTNAME_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.MachineConfiguration
 
HOSTNAME_FIELD_NUMBER - Static variable in class org.tensorflow.util.WorkerHeartbeatResponse
 

I

I_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue
 
I_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue.ListValue
 
ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
IMAGE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Value
 
IN_ARG_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
INACCURATE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
INCARNATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceAttributes
 
INDEX_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogTensorOutput
 
INDICES_OUTPUT_TENSOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.example.VarLenFeatureProto
 
INDICES_TENSOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorInfo.CooSparse
 
INFER_SHAPES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphOptions
 
INFO_VALUE - Static variable in enum org.tensorflow.util.LogMessage.Level
INFO = 20;
INITIAL_VALUE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VariableDef
 
INITIALIZER_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VariableDef
 
INPUT_ARG_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
INPUT_COUNT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInfo
 
INPUT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeDef
 
INPUT_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
INPUTS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SignatureDef
 
INT64_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.example.Feature
 
INT64_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CollectionDef
 
INT64_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
Int64List - Class in org.tensorflow.example
Protobuf type tensorflow.Int64List
Int64List.Builder - Class in org.tensorflow.example
Protobuf type tensorflow.Int64List
Int64ListOrBuilder - Interface in org.tensorflow.example
 
INT_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
INTER_OP_PARALLELISM_THREADS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
INTER_OP_THREAD_POOL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunOptions
 
InterconnectLink - Class in org.tensorflow.framework
Protobuf type tensorflow.InterconnectLink
InterconnectLink.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.InterconnectLink
InterconnectLinkOrBuilder - Interface in org.tensorflow.framework
 
INTERNAL_ERROR_VALUE - Static variable in enum org.tensorflow.util.WorkerHealth
INTERNAL_ERROR = 2;
INTERNAL_VALUE - Static variable in enum org.tensorflow.framework.Code
Internal errors.
internalGetFieldAccessorTable() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.distruntime.ClusterDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.distruntime.JobDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.distruntime.JobDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.distruntime.ServerDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.BytesList.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.BytesList
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.Example.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.Example
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.ExampleParserConfiguration
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.Feature.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.Feature
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.FeatureConfiguration
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.FeatureList.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.FeatureList
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.FeatureLists.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.FeatureLists
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.Features.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.Features
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.FixedLenFeatureProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.FloatList.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.FloatList
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.Int64List.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.Int64List
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.SequenceExample.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.SequenceExample
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.example.VarLenFeatureProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AllocationDescription
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AllocationRecord
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ApiDef.Arg
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ApiDef.Attr
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ApiDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ApiDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ApiDefs.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ApiDefs
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AssetFileDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AttrValue.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AttrValue
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AttrValue.ListValue
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.AutoParallelOptions
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CallableOptions
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CondContextDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CondContextDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ConfigProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ConfigProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ControlFlowContextDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CostGraphDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CostGraphDef.Node
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DebuggedSourceFile
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DebugOptions.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DebugOptions
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DebugTensorWatch
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DeviceAttributes
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DeviceLocality
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.DeviceStepStats
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.FunctionDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.FunctionDefLibrary
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GPUOptions.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GPUOptions
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GradientDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GradientDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphOptions.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphOptions
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.HistogramProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.HistogramProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.InterconnectLink
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.KernelDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.KernelDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.KernelList.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.KernelList
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.LocalLinks.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.LocalLinks
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogStep
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryStats.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MemoryStats
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MetaGraphDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NameAttrList.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NameAttrList
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NamedTensorProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NodeDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NodeDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NodeExecStats
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NodeOutput.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.NodeOutput
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OpDef.ArgDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OpDef.AttrDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OpDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OpDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OpDeprecation
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OpList.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OpList
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.OptimizerOptions
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.QueueRunnerDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ReaderBaseState
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ResourceHandleProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RewriterConfig
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RPCOptions.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RPCOptions
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RunMetadata.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RunMetadata
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RunOptions.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RunOptions.Experimental
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.RunOptions
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SavedModel.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SavedModel
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SignatureDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.StepStats.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.StepStats
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.Summary.Audio
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.Summary.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.Summary.Image.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.Summary.Image
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.Summary
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.Summary.Value.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.Summary.Value
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SummaryDescription
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SummaryMetadata
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorConnection.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorConnection
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorDescription.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorDescription
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorShapeProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.TensorSliceProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ValuesDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.ValuesDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.VariableDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.VariableDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.VariantTensorDataProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.VersionDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.VersionDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.framework.WhileContextDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.BundleEntryProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.BundleHeaderProto
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.Event.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.Event
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.IteratorStateMetadata
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.LogMessage.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.LogMessage
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SavedSlice.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SavedSlice
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SavedSliceMeta
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SavedTensorSlices
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SaverDef.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SaverDef
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SessionLog.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.SessionLog
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.TaggedRunMetadata
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.CommitId
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.CPUInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.EntryValue
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.GPUInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.MemoryInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.PlatformInfo
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.RunConfiguration
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.testlog.TestResults
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.WatchdogConfig
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
internalGetFieldAccessorTable() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
internalGetFieldAccessorTable() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
internalGetFieldAccessorTable() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
internalGetFieldAccessorTable() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
internalGetFieldAccessorTable() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
internalGetFieldAccessorTable() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
internalGetFieldAccessorTable() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
internalGetFieldAccessorTable() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
internalGetFieldAccessorTable() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
internalGetFieldAccessorTable() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
internalGetFieldAccessorTable() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
internalGetFieldAccessorTable() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
internalGetFieldAccessorTable() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
internalGetFieldAccessorTable() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
internalGetFieldAccessorTable() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
internalGetFieldAccessorTable() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
internalGetFieldAccessorTable() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
internalGetFieldAccessorTable() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
internalGetFieldAccessorTable() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
internalGetFieldAccessorTable() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
internalGetFieldAccessorTable() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
internalGetMapField(int) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.distruntime.JobDef
 
internalGetMapField(int) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.example.ExampleParserConfiguration
 
internalGetMapField(int) - Method in class org.tensorflow.example.FeatureLists.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.example.FeatureLists
 
internalGetMapField(int) - Method in class org.tensorflow.example.Features.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.example.Features
 
internalGetMapField(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.framework.CallableOptions
 
internalGetMapField(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.framework.ConfigProto
 
internalGetMapField(int) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.framework.FunctionDef
 
internalGetMapField(int) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.framework.MetaGraphDef
 
internalGetMapField(int) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.framework.NameAttrList
 
internalGetMapField(int) - Method in class org.tensorflow.framework.NodeDef.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.framework.NodeDef
 
internalGetMapField(int) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
internalGetMapField(int) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.framework.SignatureDef
 
internalGetMapField(int) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.framework.ValuesDef
 
internalGetMapField(int) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
internalGetMapField(int) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
internalGetMapField(int) - Method in class org.tensorflow.util.testlog.CPUInfo
 
internalGetMapField(int) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
internalGetMapField(int) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
internalGetMutableMapField(int) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.example.FeatureLists.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.example.Features.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.framework.NodeDef.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
internalGetMutableMapField(int) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
internalGetMutableMapField(int) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
internalGetValueMap() - Static method in enum org.tensorflow.framework.ApiDef.Visibility
 
internalGetValueMap() - Static method in enum org.tensorflow.framework.Code
 
internalGetValueMap() - Static method in enum org.tensorflow.framework.DataType
 
internalGetValueMap() - Static method in enum org.tensorflow.framework.GraphTransferInfo.Destination
 
internalGetValueMap() - Static method in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
 
internalGetValueMap() - Static method in enum org.tensorflow.framework.OptimizerOptions.Level
 
internalGetValueMap() - Static method in enum org.tensorflow.framework.RewriterConfig.MemOptType
 
internalGetValueMap() - Static method in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
 
internalGetValueMap() - Static method in enum org.tensorflow.framework.RewriterConfig.Toggle
 
internalGetValueMap() - Static method in enum org.tensorflow.framework.RunOptions.TraceLevel
 
internalGetValueMap() - Static method in enum org.tensorflow.util.BundleHeaderProto.Endianness
 
internalGetValueMap() - Static method in enum org.tensorflow.util.LogMessage.Level
 
internalGetValueMap() - Static method in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
 
internalGetValueMap() - Static method in enum org.tensorflow.util.SessionLog.SessionStatus
 
internalGetValueMap() - Static method in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
 
internalGetValueMap() - Static method in enum org.tensorflow.util.WorkerHealth
 
internalGetValueMap() - Static method in enum org.tensorflow.util.WorkerShutdownMode
 
INTRA_OP_PARALLELISM_THREADS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
INVALID_ARGUMENT_VALUE - Static variable in enum org.tensorflow.framework.Code
Client specified an invalid argument.
IS_AGGREGATE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
IS_COMMUTATIVE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
IS_FINAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
IS_REF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.ArgDef
 
IS_RESOURCE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VariableDef
 
IS_STATEFUL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
isInitialized() - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
isInitialized() - Method in class org.tensorflow.distruntime.ClusterDef
 
isInitialized() - Method in class org.tensorflow.distruntime.JobDef.Builder
 
isInitialized() - Method in class org.tensorflow.distruntime.JobDef
 
isInitialized() - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
isInitialized() - Method in class org.tensorflow.distruntime.ServerDef
 
isInitialized() - Method in class org.tensorflow.example.BytesList.Builder
 
isInitialized() - Method in class org.tensorflow.example.BytesList
 
isInitialized() - Method in class org.tensorflow.example.Example.Builder
 
isInitialized() - Method in class org.tensorflow.example.Example
 
isInitialized() - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
isInitialized() - Method in class org.tensorflow.example.ExampleParserConfiguration
 
isInitialized() - Method in class org.tensorflow.example.Feature.Builder
 
isInitialized() - Method in class org.tensorflow.example.Feature
 
isInitialized() - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
isInitialized() - Method in class org.tensorflow.example.FeatureConfiguration
 
isInitialized() - Method in class org.tensorflow.example.FeatureList.Builder
 
isInitialized() - Method in class org.tensorflow.example.FeatureList
 
isInitialized() - Method in class org.tensorflow.example.FeatureLists.Builder
 
isInitialized() - Method in class org.tensorflow.example.FeatureLists
 
isInitialized() - Method in class org.tensorflow.example.Features.Builder
 
isInitialized() - Method in class org.tensorflow.example.Features
 
isInitialized() - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
isInitialized() - Method in class org.tensorflow.example.FixedLenFeatureProto
 
isInitialized() - Method in class org.tensorflow.example.FloatList.Builder
 
isInitialized() - Method in class org.tensorflow.example.FloatList
 
isInitialized() - Method in class org.tensorflow.example.Int64List.Builder
 
isInitialized() - Method in class org.tensorflow.example.Int64List
 
isInitialized() - Method in class org.tensorflow.example.SequenceExample.Builder
 
isInitialized() - Method in class org.tensorflow.example.SequenceExample
 
isInitialized() - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
isInitialized() - Method in class org.tensorflow.example.VarLenFeatureProto
 
isInitialized() - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
isInitialized() - Method in class org.tensorflow.framework.AllocationDescription
 
isInitialized() - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
isInitialized() - Method in class org.tensorflow.framework.AllocationRecord
 
isInitialized() - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
isInitialized() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
isInitialized() - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ApiDef.Arg
 
isInitialized() - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ApiDef.Attr
 
isInitialized() - Method in class org.tensorflow.framework.ApiDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
isInitialized() - Method in class org.tensorflow.framework.ApiDef
 
isInitialized() - Method in class org.tensorflow.framework.ApiDefs.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ApiDefs
 
isInitialized() - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.AssetFileDef
 
isInitialized() - Method in class org.tensorflow.framework.AttrValue.Builder
 
isInitialized() - Method in class org.tensorflow.framework.AttrValue
 
isInitialized() - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
isInitialized() - Method in class org.tensorflow.framework.AttrValue.ListValue
 
isInitialized() - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
isInitialized() - Method in class org.tensorflow.framework.AutoParallelOptions
 
isInitialized() - Method in class org.tensorflow.framework.CallableOptions.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CallableOptions
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
isInitialized() - Method in class org.tensorflow.framework.CondContextDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CondContextDef
 
isInitialized() - Method in class org.tensorflow.framework.ConfigProto.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
isInitialized() - Method in class org.tensorflow.framework.ConfigProto
 
isInitialized() - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ControlFlowContextDef
 
isInitialized() - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CostGraphDef
 
isInitialized() - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
isInitialized() - Method in class org.tensorflow.framework.CostGraphDef.Node
 
isInitialized() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
isInitialized() - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
isInitialized() - Method in class org.tensorflow.framework.DebuggedSourceFile
 
isInitialized() - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
isInitialized() - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
isInitialized() - Method in class org.tensorflow.framework.DebugOptions.Builder
 
isInitialized() - Method in class org.tensorflow.framework.DebugOptions
 
isInitialized() - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
isInitialized() - Method in class org.tensorflow.framework.DebugTensorWatch
 
isInitialized() - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
isInitialized() - Method in class org.tensorflow.framework.DeviceAttributes
 
isInitialized() - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
isInitialized() - Method in class org.tensorflow.framework.DeviceLocality
 
isInitialized() - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
isInitialized() - Method in class org.tensorflow.framework.DeviceStepStats
 
isInitialized() - Method in class org.tensorflow.framework.FunctionDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.FunctionDef
 
isInitialized() - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
isInitialized() - Method in class org.tensorflow.framework.FunctionDefLibrary
 
isInitialized() - Method in class org.tensorflow.framework.GPUOptions.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
isInitialized() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
isInitialized() - Method in class org.tensorflow.framework.GPUOptions
 
isInitialized() - Method in class org.tensorflow.framework.GradientDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GradientDef
 
isInitialized() - Method in class org.tensorflow.framework.GraphDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GraphDef
 
isInitialized() - Method in class org.tensorflow.framework.GraphOptions.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GraphOptions
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferInfo
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
isInitialized() - Method in class org.tensorflow.framework.HistogramProto.Builder
 
isInitialized() - Method in class org.tensorflow.framework.HistogramProto
 
isInitialized() - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
isInitialized() - Method in class org.tensorflow.framework.InterconnectLink
 
isInitialized() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
isInitialized() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
isInitialized() - Method in class org.tensorflow.framework.KernelDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.KernelDef
 
isInitialized() - Method in class org.tensorflow.framework.KernelList.Builder
 
isInitialized() - Method in class org.tensorflow.framework.KernelList
 
isInitialized() - Method in class org.tensorflow.framework.LocalLinks.Builder
 
isInitialized() - Method in class org.tensorflow.framework.LocalLinks
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogStep
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
isInitialized() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
isInitialized() - Method in class org.tensorflow.framework.MemoryStats.Builder
 
isInitialized() - Method in class org.tensorflow.framework.MemoryStats
 
isInitialized() - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.MetaGraphDef
 
isInitialized() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
isInitialized() - Method in class org.tensorflow.framework.NameAttrList.Builder
 
isInitialized() - Method in class org.tensorflow.framework.NameAttrList
 
isInitialized() - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
isInitialized() - Method in class org.tensorflow.framework.NamedTensorProto
 
isInitialized() - Method in class org.tensorflow.framework.NodeDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
isInitialized() - Method in class org.tensorflow.framework.NodeDef
 
isInitialized() - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
isInitialized() - Method in class org.tensorflow.framework.NodeExecStats
 
isInitialized() - Method in class org.tensorflow.framework.NodeOutput.Builder
 
isInitialized() - Method in class org.tensorflow.framework.NodeOutput
 
isInitialized() - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.OpDef.ArgDef
 
isInitialized() - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.OpDef.AttrDef
 
isInitialized() - Method in class org.tensorflow.framework.OpDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.OpDef
 
isInitialized() - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
isInitialized() - Method in class org.tensorflow.framework.OpDeprecation
 
isInitialized() - Method in class org.tensorflow.framework.OpList.Builder
 
isInitialized() - Method in class org.tensorflow.framework.OpList
 
isInitialized() - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
isInitialized() - Method in class org.tensorflow.framework.OptimizerOptions
 
isInitialized() - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.QueueRunnerDef
 
isInitialized() - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ReaderBaseState
 
isInitialized() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
isInitialized() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
isInitialized() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
isInitialized() - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ResourceHandleProto
 
isInitialized() - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
isInitialized() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
isInitialized() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
isInitialized() - Method in class org.tensorflow.framework.RewriterConfig
 
isInitialized() - Method in class org.tensorflow.framework.RPCOptions.Builder
 
isInitialized() - Method in class org.tensorflow.framework.RPCOptions
 
isInitialized() - Method in class org.tensorflow.framework.RunMetadata.Builder
 
isInitialized() - Method in class org.tensorflow.framework.RunMetadata
 
isInitialized() - Method in class org.tensorflow.framework.RunOptions.Builder
 
isInitialized() - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
isInitialized() - Method in class org.tensorflow.framework.RunOptions.Experimental
 
isInitialized() - Method in class org.tensorflow.framework.RunOptions
 
isInitialized() - Method in class org.tensorflow.framework.SavedModel.Builder
 
isInitialized() - Method in class org.tensorflow.framework.SavedModel
 
isInitialized() - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
isInitialized() - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
isInitialized() - Method in class org.tensorflow.framework.SignatureDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.SignatureDef
 
isInitialized() - Method in class org.tensorflow.framework.StepStats.Builder
 
isInitialized() - Method in class org.tensorflow.framework.StepStats
 
isInitialized() - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
isInitialized() - Method in class org.tensorflow.framework.Summary.Audio
 
isInitialized() - Method in class org.tensorflow.framework.Summary.Builder
 
isInitialized() - Method in class org.tensorflow.framework.Summary.Image.Builder
 
isInitialized() - Method in class org.tensorflow.framework.Summary.Image
 
isInitialized() - Method in class org.tensorflow.framework.Summary
 
isInitialized() - Method in class org.tensorflow.framework.Summary.Value.Builder
 
isInitialized() - Method in class org.tensorflow.framework.Summary.Value
 
isInitialized() - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
isInitialized() - Method in class org.tensorflow.framework.SummaryDescription
 
isInitialized() - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
isInitialized() - Method in class org.tensorflow.framework.SummaryMetadata
 
isInitialized() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
isInitialized() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
isInitialized() - Method in class org.tensorflow.framework.TensorConnection.Builder
 
isInitialized() - Method in class org.tensorflow.framework.TensorConnection
 
isInitialized() - Method in class org.tensorflow.framework.TensorDescription.Builder
 
isInitialized() - Method in class org.tensorflow.framework.TensorDescription
 
isInitialized() - Method in class org.tensorflow.framework.TensorInfo.Builder
 
isInitialized() - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
isInitialized() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
isInitialized() - Method in class org.tensorflow.framework.TensorInfo
 
isInitialized() - Method in class org.tensorflow.framework.TensorProto.Builder
 
isInitialized() - Method in class org.tensorflow.framework.TensorProto
 
isInitialized() - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
isInitialized() - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
isInitialized() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
isInitialized() - Method in class org.tensorflow.framework.TensorShapeProto
 
isInitialized() - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
isInitialized() - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
isInitialized() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
isInitialized() - Method in class org.tensorflow.framework.TensorSliceProto
 
isInitialized() - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
isInitialized() - Method in class org.tensorflow.framework.ValuesDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.ValuesDef
 
isInitialized() - Method in class org.tensorflow.framework.VariableDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.VariableDef
 
isInitialized() - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
isInitialized() - Method in class org.tensorflow.framework.VariantTensorDataProto
 
isInitialized() - Method in class org.tensorflow.framework.VersionDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.VersionDef
 
isInitialized() - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
isInitialized() - Method in class org.tensorflow.framework.WhileContextDef
 
isInitialized() - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
isInitialized() - Method in class org.tensorflow.util.BundleEntryProto
 
isInitialized() - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
isInitialized() - Method in class org.tensorflow.util.BundleHeaderProto
 
isInitialized() - Method in class org.tensorflow.util.Event.Builder
 
isInitialized() - Method in class org.tensorflow.util.Event
 
isInitialized() - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
isInitialized() - Method in class org.tensorflow.util.IteratorStateMetadata
 
isInitialized() - Method in class org.tensorflow.util.LogMessage.Builder
 
isInitialized() - Method in class org.tensorflow.util.LogMessage
 
isInitialized() - Method in class org.tensorflow.util.SavedSlice.Builder
 
isInitialized() - Method in class org.tensorflow.util.SavedSlice
 
isInitialized() - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
isInitialized() - Method in class org.tensorflow.util.SavedSliceMeta
 
isInitialized() - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
isInitialized() - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
isInitialized() - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
isInitialized() - Method in class org.tensorflow.util.SavedTensorSlices
 
isInitialized() - Method in class org.tensorflow.util.SaverDef.Builder
 
isInitialized() - Method in class org.tensorflow.util.SaverDef
 
isInitialized() - Method in class org.tensorflow.util.SessionLog.Builder
 
isInitialized() - Method in class org.tensorflow.util.SessionLog
 
isInitialized() - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
isInitialized() - Method in class org.tensorflow.util.TaggedRunMetadata
 
isInitialized() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
isInitialized() - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
isInitialized() - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
isInitialized() - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
isInitialized() - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.CommitId
 
isInitialized() - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.CPUInfo
 
isInitialized() - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.EntryValue
 
isInitialized() - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.GPUInfo
 
isInitialized() - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
isInitialized() - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.MemoryInfo
 
isInitialized() - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.PlatformInfo
 
isInitialized() - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.RunConfiguration
 
isInitialized() - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
isInitialized() - Method in class org.tensorflow.util.testlog.TestResults
 
isInitialized() - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
isInitialized() - Method in class org.tensorflow.util.WatchdogConfig
 
isInitialized() - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
isInitialized() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
isInitialized() - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
isInitialized() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
isInitialized() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
isInitialized() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
isInitialized() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
isInitialized() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
isInitialized() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
isInitialized() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
isInitialized() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
isInitialized() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
isInitialized() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
isInitialized() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
isInitialized() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
isInitialized() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
isInitialized() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
isInitialized() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
isInitialized() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
isInitialized() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
isInitialized() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
isInitialized() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
isInitialized() - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
isInitialized() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
ISOLATE_SESSION_STATE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
IteratorProtos - Class in org.tensorflow.util
 
IteratorStateMetadata - Class in org.tensorflow.util
Protocol buffer representing the metadata for an iterator's state stored as a Variant tensor.
IteratorStateMetadata.Builder - Class in org.tensorflow.util
Protocol buffer representing the metadata for an iterator's state stored as a Variant tensor.
IteratorStateMetadataOrBuilder - Interface in org.tensorflow.util
 
ITERS_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.BenchmarkEntry
 

J

JOB_FIELD_NUMBER - Static variable in class org.tensorflow.distruntime.ClusterDef
 
JOB_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.distruntime.ServerDef
 
JobDef - Class in org.tensorflow.distruntime
Defines a single job in a TensorFlow cluster.
JobDef.Builder - Class in org.tensorflow.distruntime
Defines a single job in a TensorFlow cluster.
JobDefOrBuilder - Interface in org.tensorflow.distruntime
 

K

KEEP_CHECKPOINT_EVERY_N_HOURS_FIELD_NUMBER - Static variable in class org.tensorflow.util.SaverDef
 
KERNEL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.KernelList
 
KERNEL_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogTensorAllocation
 
KERNEL_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogTensorOutput
 
KernelDef - Class in org.tensorflow.framework
Protobuf type tensorflow.KernelDef
KernelDef.AttrConstraint - Class in org.tensorflow.framework
Protobuf type tensorflow.KernelDef.AttrConstraint
KernelDef.AttrConstraint.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.KernelDef.AttrConstraint
KernelDef.AttrConstraintOrBuilder - Interface in org.tensorflow.framework
 
KernelDef.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.KernelDef
KernelDefOrBuilder - Interface in org.tensorflow.framework
 
KernelDefProtos - Class in org.tensorflow.framework
 
KernelList - Class in org.tensorflow.framework
A collection of KernelDefs
KernelList.Builder - Class in org.tensorflow.framework
A collection of KernelDefs
KernelListOrBuilder - Interface in org.tensorflow.framework
 
KEYS_FIELD_NUMBER - Static variable in class org.tensorflow.util.IteratorStateMetadata
 

L

L0_VALUE - Static variable in enum org.tensorflow.framework.OptimizerOptions.Level
No optimizations
L1_CACHE_SIZE_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
L1_VALUE - Static variable in enum org.tensorflow.framework.OptimizerOptions.Level
L1 is the default level.
L2_CACHE_SIZE_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
L3_CACHE_SIZE_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
LABEL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.KernelDef
 
LAST_MODIFIED_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebuggedSourceFile
 
LAYOUT_OPTIMIZER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
LEGACY_VALUE - Static variable in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
Internal legacy format.
LENGTH_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorSliceProto.Extent
 
LENGTH_FRAMES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Audio
 
LEVEL_FIELD_NUMBER - Static variable in class org.tensorflow.util.LogMessage
 
LIBRARY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphDef
 
LINES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebuggedSourceFile
 
LINK_FIELD_NUMBER - Static variable in class org.tensorflow.framework.LocalLinks
 
LINKAGE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.PlatformInfo
 
LINKS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceLocality
 
LIST_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue
 
LITTLE_VALUE - Static variable in enum org.tensorflow.util.BundleHeaderProto.Endianness
LITTLE = 0;
LIVE_BYTES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocatorMemoryUsed
 
LOCAL_NAME_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
LOCALITY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceAttributes
 
LocalLinks - Class in org.tensorflow.framework
Protobuf type tensorflow.LocalLinks
LocalLinks.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.LocalLinks
LocalLinksOrBuilder - Interface in org.tensorflow.framework
 
LOG_DEVICE_PLACEMENT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
LOG_MESSAGE_FIELD_NUMBER - Static variable in class org.tensorflow.util.Event
 
LogMemoryProtos - Class in org.tensorflow.framework
 
LogMessage - Class in org.tensorflow.util
Protocol buffer used for logging messages to the events file.
LogMessage.Builder - Class in org.tensorflow.util
Protocol buffer used for logging messages to the events file.
LogMessage.Level - Enum in org.tensorflow.util
Protobuf enum tensorflow.LogMessage.Level
LogMessageOrBuilder - Interface in org.tensorflow.util
 
LOOP_ENTER_NAMES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
LOOP_EXIT_NAMES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
LOOP_OPTIMIZATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 

M

MACHINE_CONFIGURATION_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
MACHINE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.PlatformInfo
 
MachineConfiguration - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.MachineConfiguration
MachineConfiguration.Builder - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.MachineConfiguration
MachineConfigurationOrBuilder - Interface in org.tensorflow.util.testlog
 
MANUAL_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.MemOptType
Driven by manual op-level annotations.
MAX_BYTE_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
MAX_FIELD_NUMBER - Static variable in class org.tensorflow.framework.HistogramProto
 
MAX_FOLDED_CONSTANT_IN_BYTES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OptimizerOptions
 
MAX_TO_KEEP_FIELD_NUMBER - Static variable in class org.tensorflow.util.SaverDef
 
MAXIMUM_ITERATIONS_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
MAYBE_TYPE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ResourceHandleProto
 
MemmappedFileSystem - Class in tensorflow
 
MemmappedFileSystem.MemmappedFileSystemDirectory - Class in tensorflow
A directory of regions in a memmapped file.
MemmappedFileSystem.MemmappedFileSystemDirectory.Builder - Class in tensorflow
A directory of regions in a memmapped file.
MemmappedFileSystem.MemmappedFileSystemDirectoryElement - Class in tensorflow
A message that describes one region of memmapped file.
MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder - Class in tensorflow
A message that describes one region of memmapped file.
MemmappedFileSystem.MemmappedFileSystemDirectoryElementOrBuilder - Interface in tensorflow
 
MemmappedFileSystem.MemmappedFileSystemDirectoryOrBuilder - Interface in tensorflow
 
MEMORY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
MEMORY_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.MachineConfiguration
 
MEMORY_LIMIT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceAttributes
 
MEMORY_LIMIT_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
MEMORY_LIMIT_MB_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
MEMORY_OPTIMIZATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
MEMORY_OPTIMIZER_TARGET_NODE_NAME_SCOPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
MEMORY_SIZE_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
MEMORY_STATS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
MEMORY_TIME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
MemoryInfo - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.MemoryInfo
MemoryInfo.Builder - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.MemoryInfo
MemoryInfoOrBuilder - Interface in org.tensorflow.util.testlog
 
MemoryLogRawAllocation - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogRawAllocation
MemoryLogRawAllocation.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogRawAllocation
MemoryLogRawAllocationOrBuilder - Interface in org.tensorflow.framework
 
MemoryLogRawDeallocation - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogRawDeallocation
MemoryLogRawDeallocation.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogRawDeallocation
MemoryLogRawDeallocationOrBuilder - Interface in org.tensorflow.framework
 
MemoryLogStep - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogStep
MemoryLogStep.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogStep
MemoryLogStepOrBuilder - Interface in org.tensorflow.framework
 
MemoryLogTensorAllocation - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogTensorAllocation
MemoryLogTensorAllocation.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogTensorAllocation
MemoryLogTensorAllocationOrBuilder - Interface in org.tensorflow.framework
 
MemoryLogTensorDeallocation - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogTensorDeallocation
MemoryLogTensorDeallocation.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogTensorDeallocation
MemoryLogTensorDeallocationOrBuilder - Interface in org.tensorflow.framework
 
MemoryLogTensorOutput - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogTensorOutput
MemoryLogTensorOutput.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.MemoryLogTensorOutput
MemoryLogTensorOutputOrBuilder - Interface in org.tensorflow.framework
 
MemoryStats - Class in org.tensorflow.framework
For memory tracking.
MemoryStats.Builder - Class in org.tensorflow.framework
For memory tracking.
MemoryStatsOrBuilder - Interface in org.tensorflow.framework
 
mergeAllocationDescription(AllocationDescription) - Method in class org.tensorflow.framework.TensorDescription.Builder
Information about the size and allocator used for the data
mergeAllowedValues(AttrValue) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
A list of values that this kernel supports for this attr.
mergeAllowedValues(AttrValue) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
The set of allowed values.
mergeAnyInfo(Any) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A serialized protobuf.
mergeAnyList(CollectionDef.AnyList) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.AnyList any_list = 5;
mergeAudio(Summary.Audio) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Audio audio = 6;
mergeAutoParallel(AutoParallelOptions) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
mergeBuildConfiguration(BuildConfiguration) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The configuration of the build (compiled opt? with cuda? any copts?)
mergeBytesList(BytesList) - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.BytesList bytes_list = 1;
mergeBytesList(CollectionDef.BytesList) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
mergeCluster(ClusterDef) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The cluster of which this server is a member.
mergeClusterDef(ClusterDef) - Method in class org.tensorflow.framework.ConfigProto.Builder
Optional list of all workers to use in this session.
mergeCommitId(CommitId) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The commit id (git hash or changelist)
mergeCondCtxt(CondContextDef) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.CondContextDef cond_ctxt = 1;
mergeContext(Features) - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.Features context = 1;
mergeCooSparse(TensorInfo.CooSparse) - Method in class org.tensorflow.framework.TensorInfo.Builder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
mergeCostGraph(CostGraphDef) - Method in class org.tensorflow.framework.RunMetadata.Builder
The cost graph for the computation defined by the run call.
mergeCpuInfo(CPUInfo) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
CPU Information.
mergeData(TensorProto) - Method in class org.tensorflow.util.SavedSlice.Builder
The raw data of the slice is stored as a TensorProto.
mergeData(SavedSlice) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This exists in all but the first item of each checkpoint file.
mergeDebugOptions(DebugOptions) - Method in class org.tensorflow.framework.RunOptions.Builder
EXPERIMENTAL.
mergeDefaultSessionConfig(ConfigProto) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The default configuration for sessions that run on this server.
mergeDefaultValue(TensorProto) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorProto default_value = 3;
mergeDefaultValue(AttrValue) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Specify a new default value to use for this attr.
mergeDefaultValue(AttrValue) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A reasonable default for this attribute if the user does not supply a value.
mergeDeprecation(OpDeprecation) - Method in class org.tensorflow.framework.OpDef.Builder
Optional deprecation based on GraphDef versions.
mergeEntries(BenchmarkEntries) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The list of tests or benchmarks in this run.
mergeExperimental(ConfigProto.Experimental) - Method in class org.tensorflow.framework.ConfigProto.Builder
.tensorflow.ConfigProto.Experimental experimental = 16;
mergeExperimental(GPUOptions.Experimental) - Method in class org.tensorflow.framework.GPUOptions.Builder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
mergeExperimental(RunOptions.Experimental) - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.Experimental experimental = 8;
mergeExperimentalDebugInfo(NodeDef.ExperimentalDebugInfo) - Method in class org.tensorflow.framework.NodeDef.Builder
This stores debug information associated with the node.
mergeFeatureLists(FeatureLists) - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.FeatureLists feature_lists = 2;
mergeFeatures(Features) - Method in class org.tensorflow.example.Example.Builder
.tensorflow.Features features = 1;
mergeFixedLenFeature(FixedLenFeatureProto) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
mergeFloatList(FloatList) - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.FloatList float_list = 2;
mergeFloatList(CollectionDef.FloatList) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.FloatList float_list = 4;
mergeFrom(Message) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
mergeFrom(ClusterDef) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
mergeFrom(JobDef) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
mergeFrom(ServerDef) - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.BytesList.Builder
 
mergeFrom(BytesList) - Method in class org.tensorflow.example.BytesList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.BytesList.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.Example.Builder
 
mergeFrom(Example) - Method in class org.tensorflow.example.Example.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.Example.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
mergeFrom(ExampleParserConfiguration) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.Feature.Builder
 
mergeFrom(Feature) - Method in class org.tensorflow.example.Feature.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.Feature.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
mergeFrom(FeatureConfiguration) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.FeatureList.Builder
 
mergeFrom(FeatureList) - Method in class org.tensorflow.example.FeatureList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.FeatureList.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.FeatureLists.Builder
 
mergeFrom(FeatureLists) - Method in class org.tensorflow.example.FeatureLists.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.FeatureLists.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.Features.Builder
 
mergeFrom(Features) - Method in class org.tensorflow.example.Features.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.Features.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
mergeFrom(FixedLenFeatureProto) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.FloatList.Builder
 
mergeFrom(FloatList) - Method in class org.tensorflow.example.FloatList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.FloatList.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.Int64List.Builder
 
mergeFrom(Int64List) - Method in class org.tensorflow.example.Int64List.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.Int64List.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.SequenceExample.Builder
 
mergeFrom(SequenceExample) - Method in class org.tensorflow.example.SequenceExample.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.SequenceExample.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
mergeFrom(VarLenFeatureProto) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
mergeFrom(AllocationDescription) - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
mergeFrom(AllocationRecord) - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
mergeFrom(AllocatorMemoryUsed) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
mergeFrom(ApiDef.Arg) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
mergeFrom(ApiDef.Attr) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ApiDef.Builder
 
mergeFrom(ApiDef) - Method in class org.tensorflow.framework.ApiDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ApiDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
mergeFrom(ApiDef.Endpoint) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ApiDefs.Builder
 
mergeFrom(ApiDefs) - Method in class org.tensorflow.framework.ApiDefs.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ApiDefs.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
mergeFrom(AssetFileDef) - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.AttrValue.Builder
 
mergeFrom(AttrValue) - Method in class org.tensorflow.framework.AttrValue.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.AttrValue.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
mergeFrom(AttrValue.ListValue) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
mergeFrom(AutoParallelOptions) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
mergeFrom(CallableOptions) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
mergeFrom(CollectionDef.AnyList) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CollectionDef.Builder
 
mergeFrom(CollectionDef) - Method in class org.tensorflow.framework.CollectionDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CollectionDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
mergeFrom(CollectionDef.BytesList) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
mergeFrom(CollectionDef.FloatList) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
mergeFrom(CollectionDef.Int64List) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
mergeFrom(CollectionDef.NodeList) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CondContextDef.Builder
 
mergeFrom(CondContextDef) - Method in class org.tensorflow.framework.CondContextDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CondContextDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
mergeFrom(ConfigProto) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
mergeFrom(ConfigProto.Experimental) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
mergeFrom(ControlFlowContextDef) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
mergeFrom(CostGraphDef) - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
mergeFrom(CostGraphDef.Node) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
mergeFrom(CostGraphDef.Node.InputInfo) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
mergeFrom(CostGraphDef.Node.OutputInfo) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
mergeFrom(DebuggedSourceFile) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
mergeFrom(DebuggedSourceFiles) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.DebugOptions.Builder
 
mergeFrom(DebugOptions) - Method in class org.tensorflow.framework.DebugOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.DebugOptions.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
mergeFrom(DebugTensorWatch) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
mergeFrom(DeviceAttributes) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
mergeFrom(DeviceLocality) - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
mergeFrom(DeviceStepStats) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
mergeFrom(FunctionDef) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
mergeFrom(FunctionDefLibrary) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GPUOptions.Builder
 
mergeFrom(GPUOptions) - Method in class org.tensorflow.framework.GPUOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GPUOptions.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
mergeFrom(GPUOptions.Experimental) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
mergeFrom(GPUOptions.Experimental.VirtualDevices) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GradientDef.Builder
 
mergeFrom(GradientDef) - Method in class org.tensorflow.framework.GradientDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GradientDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GraphDef.Builder
 
mergeFrom(GraphDef) - Method in class org.tensorflow.framework.GraphDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GraphDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GraphOptions.Builder
 
mergeFrom(GraphOptions) - Method in class org.tensorflow.framework.GraphOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GraphOptions.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
mergeFrom(GraphTransferConstNodeInfo) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
mergeFrom(GraphTransferGraphInputNodeInfo) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
mergeFrom(GraphTransferGraphOutputNodeInfo) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
mergeFrom(GraphTransferInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
mergeFrom(GraphTransferNodeInfo) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
mergeFrom(GraphTransferNodeInput) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
mergeFrom(GraphTransferNodeInputInfo) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
mergeFrom(GraphTransferNodeOutputInfo) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.HistogramProto.Builder
 
mergeFrom(HistogramProto) - Method in class org.tensorflow.framework.HistogramProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.HistogramProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
mergeFrom(InterconnectLink) - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
mergeFrom(KernelDef.AttrConstraint) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.KernelDef.Builder
 
mergeFrom(KernelDef) - Method in class org.tensorflow.framework.KernelDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.KernelDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.KernelList.Builder
 
mergeFrom(KernelList) - Method in class org.tensorflow.framework.KernelList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.KernelList.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.LocalLinks.Builder
 
mergeFrom(LocalLinks) - Method in class org.tensorflow.framework.LocalLinks.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.LocalLinks.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
mergeFrom(MemoryLogRawAllocation) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
mergeFrom(MemoryLogRawDeallocation) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
mergeFrom(MemoryLogStep) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
mergeFrom(MemoryLogTensorAllocation) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
mergeFrom(MemoryLogTensorDeallocation) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
mergeFrom(MemoryLogTensorOutput) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.MemoryStats.Builder
 
mergeFrom(MemoryStats) - Method in class org.tensorflow.framework.MemoryStats.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.MemoryStats.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
mergeFrom(MetaGraphDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
mergeFrom(MetaGraphDef.MetaInfoDef) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
mergeFrom(NameAttrList) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
mergeFrom(NamedTensorProto) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.NodeDef.Builder
 
mergeFrom(NodeDef) - Method in class org.tensorflow.framework.NodeDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.NodeDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
mergeFrom(NodeDef.ExperimentalDebugInfo) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
mergeFrom(NodeExecStats) - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.NodeOutput.Builder
 
mergeFrom(NodeOutput) - Method in class org.tensorflow.framework.NodeOutput.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.NodeOutput.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
mergeFrom(OpDef.ArgDef) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
mergeFrom(OpDef.AttrDef) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.OpDef.Builder
 
mergeFrom(OpDef) - Method in class org.tensorflow.framework.OpDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.OpDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
mergeFrom(OpDeprecation) - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.OpList.Builder
 
mergeFrom(OpList) - Method in class org.tensorflow.framework.OpList.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.OpList.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
mergeFrom(OptimizerOptions) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
mergeFrom(QueueRunnerDef) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
mergeFrom(ReaderBaseState) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
mergeFrom(RemoteFusedGraphExecuteInfo) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
mergeFrom(RemoteFusedGraphExecuteInfo.TensorShapeTypeProto) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
mergeFrom(ResourceHandleProto) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
mergeFrom(RewriterConfig) - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
mergeFrom(RewriterConfig.CustomGraphOptimizer) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.RPCOptions.Builder
 
mergeFrom(RPCOptions) - Method in class org.tensorflow.framework.RPCOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.RPCOptions.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.RunMetadata.Builder
 
mergeFrom(RunMetadata) - Method in class org.tensorflow.framework.RunMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.RunMetadata.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.RunOptions.Builder
 
mergeFrom(RunOptions) - Method in class org.tensorflow.framework.RunOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.RunOptions.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
mergeFrom(RunOptions.Experimental) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.SavedModel.Builder
 
mergeFrom(SavedModel) - Method in class org.tensorflow.framework.SavedModel.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.SavedModel.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
mergeFrom(SaveSliceInfoDef) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
mergeFrom(ScopedAllocatorOptions) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
mergeFrom(SignatureDef) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.StepStats.Builder
 
mergeFrom(StepStats) - Method in class org.tensorflow.framework.StepStats.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.StepStats.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
mergeFrom(Summary.Audio) - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.Summary.Builder
 
mergeFrom(Summary) - Method in class org.tensorflow.framework.Summary.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.Summary.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.Summary.Image.Builder
 
mergeFrom(Summary.Image) - Method in class org.tensorflow.framework.Summary.Image.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.Summary.Image.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.Summary.Value.Builder
 
mergeFrom(Summary.Value) - Method in class org.tensorflow.framework.Summary.Value.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.Summary.Value.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
mergeFrom(SummaryDescription) - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
mergeFrom(SummaryMetadata) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
mergeFrom(SummaryMetadata.PluginData) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.TensorConnection.Builder
 
mergeFrom(TensorConnection) - Method in class org.tensorflow.framework.TensorConnection.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.TensorConnection.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.TensorDescription.Builder
 
mergeFrom(TensorDescription) - Method in class org.tensorflow.framework.TensorDescription.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.TensorDescription.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.TensorInfo.Builder
 
mergeFrom(TensorInfo) - Method in class org.tensorflow.framework.TensorInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.TensorInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
mergeFrom(TensorInfo.CooSparse) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.TensorProto.Builder
 
mergeFrom(TensorProto) - Method in class org.tensorflow.framework.TensorProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.TensorProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
mergeFrom(TensorShapeProto) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
mergeFrom(TensorShapeProto.Dim) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
mergeFrom(TensorSliceProto) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
mergeFrom(TensorSliceProto.Extent) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
mergeFrom(ThreadPoolOptionProto) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
mergeFrom(ValuesDef) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.VariableDef.Builder
 
mergeFrom(VariableDef) - Method in class org.tensorflow.framework.VariableDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.VariableDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
mergeFrom(VariantTensorDataProto) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.VersionDef.Builder
 
mergeFrom(VersionDef) - Method in class org.tensorflow.framework.VersionDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.VersionDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
mergeFrom(WhileContextDef) - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
mergeFrom(BundleEntryProto) - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
mergeFrom(BundleHeaderProto) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.Event.Builder
 
mergeFrom(Event) - Method in class org.tensorflow.util.Event.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.Event.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
mergeFrom(IteratorStateMetadata) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.LogMessage.Builder
 
mergeFrom(LogMessage) - Method in class org.tensorflow.util.LogMessage.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.LogMessage.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.SavedSlice.Builder
 
mergeFrom(SavedSlice) - Method in class org.tensorflow.util.SavedSlice.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.SavedSlice.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
mergeFrom(SavedSliceMeta) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
mergeFrom(SavedTensorSliceMeta) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
mergeFrom(SavedTensorSlices) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.SaverDef.Builder
 
mergeFrom(SaverDef) - Method in class org.tensorflow.util.SaverDef.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.SaverDef.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.SessionLog.Builder
 
mergeFrom(SessionLog) - Method in class org.tensorflow.util.SessionLog.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.SessionLog.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
mergeFrom(TaggedRunMetadata) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
mergeFrom(AvailableDeviceInfo) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
mergeFrom(BenchmarkEntries) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
mergeFrom(BenchmarkEntry) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
mergeFrom(BuildConfiguration) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
mergeFrom(CommitId) - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
mergeFrom(CPUInfo) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
mergeFrom(EntryValue) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
mergeFrom(GPUInfo) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
mergeFrom(MachineConfiguration) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
mergeFrom(MemoryInfo) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
mergeFrom(PlatformInfo) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
mergeFrom(RunConfiguration) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
mergeFrom(TestResults) - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
mergeFrom(WatchdogConfig) - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
mergeFrom(WorkerHeartbeatRequest) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
mergeFrom(Message) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
mergeFrom(WorkerHeartbeatResponse) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
mergeFrom(Message) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
mergeFrom(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
mergeFrom(Message) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
mergeFrom(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
mergeFrom(Message) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
mergeFrom(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
mergeFrom(Message) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
mergeFrom(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
mergeFrom(Message) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
mergeFrom(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
mergeFrom(Message) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
mergeFrom(DevicePropertiesProtos.DeviceProperties) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
mergeFrom(Message) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
mergeFrom(DevicePropertiesProtos.NamedDevice) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
mergeFrom(Message) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
mergeFrom(MemmappedFileSystem.MemmappedFileSystemDirectory) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
mergeFrom(Message) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
mergeFrom(MemmappedFileSystem.MemmappedFileSystemDirectoryElement) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
mergeFrom(Message) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
mergeFrom(TransportOptions.RecvBufRespExtra) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
mergeFunc(NameAttrList) - Method in class org.tensorflow.framework.AttrValue.Builder
"func" represents a function.
mergeGpuOptions(GPUOptions) - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all GPUs.
mergeGraphDef(GraphDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
GraphDef.
mergeGraphOptions(GraphOptions) - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all graphs.
mergeHisto(HistogramProto) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.HistogramProto histo = 5;
mergeImage(Summary.Image) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Image image = 4;
mergeInt64List(Int64List) - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.Int64List int64_list = 3;
mergeInt64List(CollectionDef.Int64List) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.Int64List int64_list = 3;
mergeLibrary(FunctionDefLibrary) - Method in class org.tensorflow.framework.GraphDef.Builder
EXPERIMENTAL.
mergeLinks(LocalLinks) - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional local interconnect links to other devices.
mergeList(AttrValue.ListValue) - Method in class org.tensorflow.framework.AttrValue.Builder
any "list(...)"
mergeLocality(DeviceLocality) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Platform-specific data about device that may be useful for supporting efficient data transfers.
mergeLogMessage(LogMessage) - Method in class org.tensorflow.util.Event.Builder
The user output a log message.
mergeMachineConfiguration(MachineConfiguration) - Method in class org.tensorflow.util.testlog.TestResults.Builder
Machine-specific parameters (Platform and CPU info)
mergeMemoryInfo(MemoryInfo) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
.tensorflow.MemoryInfo memory_info = 6;
mergeMemoryStats(MemoryStats) - Method in class org.tensorflow.framework.NodeExecStats.Builder
.tensorflow.MemoryStats memory_stats = 12;
mergeMeta(SavedTensorSliceMeta) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
mergeMetadata(SummaryMetadata) - Method in class org.tensorflow.framework.Summary.Value.Builder
Contains metadata on the summary value such as which plugins may use it.
mergeMetaInfoDef(MetaGraphDef.MetaInfoDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
mergeNodeList(CollectionDef.NodeList) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.NodeList node_list = 1;
mergeOptimizerOptions(OptimizerOptions) - Method in class org.tensorflow.framework.GraphOptions.Builder
Options controlling how graph is optimized.
mergePlatformInfo(PlatformInfo) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Additional platform information.
mergePluginData(SummaryMetadata.PluginData) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Data that associates a summary with a certain plugin.
mergeProperties(DevicePropertiesProtos.DeviceProperties) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
.tensorflow.DeviceProperties properties = 2;
mergeRemoteGraph(GraphDef) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Definition of remote graph
mergeRewriteOptions(RewriterConfig) - Method in class org.tensorflow.framework.GraphOptions.Builder
Options that control the type and amount of graph rewriting.
mergeRpcOptions(RPCOptions) - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply when this session uses the distributed runtime.
mergeRunConfiguration(RunConfiguration) - Method in class org.tensorflow.util.testlog.TestResults.Builder
Run-specific parameters (arguments, etc)
mergeRunOptions(RunOptions) - Method in class org.tensorflow.framework.CallableOptions.Builder
Options that will be applied to each run.
mergeSaverDef(SaverDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
SaverDef.
mergeSaveSliceInfoDef(SaveSliceInfoDef) - Method in class org.tensorflow.framework.VariableDef.Builder
Support for saving variables as slices of a larger variable.
mergeScopedAllocatorOpts(ScopedAllocatorOptions) - Method in class org.tensorflow.framework.RewriterConfig.Builder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
mergeSessionLog(SessionLog) - Method in class org.tensorflow.util.Event.Builder
The state of the session which can be used for restarting after crashes.
mergeShape(TensorShapeProto) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorShapeProto shape = 2;
mergeShape(TensorShapeProto) - Method in class org.tensorflow.framework.AttrValue.Builder
"shape"
mergeShape(TensorShapeProto) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.TensorShapeProto shape = 3;
mergeShape(TensorShapeProto) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.TensorShapeProto shape = 2;
mergeShape(TensorShapeProto) - Method in class org.tensorflow.framework.TensorDescription.Builder
Shape of the tensor.
mergeShape(TensorShapeProto) - Method in class org.tensorflow.util.BundleEntryProto.Builder
.tensorflow.TensorShapeProto shape = 2;
mergeShape(TensorShapeProto) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Shape of the tensor
mergeSignature(OpDef) - Method in class org.tensorflow.framework.FunctionDef.Builder
The definition of the function's name, arguments, return values, attrs etc.
mergeSlice(TensorSliceProto) - Method in class org.tensorflow.util.SavedSlice.Builder
Extent of the slice.
mergeStepStats(StepStats) - Method in class org.tensorflow.framework.RunMetadata.Builder
Statistics traced for this step.
mergeStrippedOpList(OpList) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A copy of the OpDefs used by the producer of this graph_def.
mergeSummary(Summary) - Method in class org.tensorflow.util.Event.Builder
A summary was generated.
mergeTaggedRunMetadata(TaggedRunMetadata) - Method in class org.tensorflow.util.Event.Builder
The metadata returned by running a session.run() call.
mergeTensor(TensorProto) - Method in class org.tensorflow.framework.AttrValue.Builder
"tensor"
mergeTensor(TensorDescription) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Allocated tensor details.
mergeTensor(TensorDescription) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Output tensor details.
mergeTensor(TensorProto) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
mergeTensor(TensorProto) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.TensorProto tensor = 8;
mergeTensorDescription(TensorDescription) - Method in class org.tensorflow.framework.NodeOutput.Builder
.tensorflow.TensorDescription tensor_description = 3;
mergeTensorInfo(TensorInfo) - Method in class org.tensorflow.framework.AssetFileDef.Builder
The tensor to bind the asset filename to.
mergeTensorShape(TensorShapeProto) - Method in class org.tensorflow.framework.TensorInfo.Builder
The static shape should be recorded here, to the extent that it can be known in advance.
mergeTensorShape(TensorShapeProto) - Method in class org.tensorflow.framework.TensorProto.Builder
Shape of the tensor.
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.BytesList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.Example.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.Feature.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.FeatureList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.FeatureLists.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.Features.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.FloatList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.Int64List.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.SequenceExample.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ApiDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ApiDefs.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AttrValue.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CondContextDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DebugOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GPUOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GradientDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.HistogramProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.KernelDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.KernelList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.LocalLinks.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryStats.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NodeDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NodeOutput.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OpDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OpList.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RPCOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RunMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RunOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SavedModel.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.StepStats.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.Summary.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.Summary.Image.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.Summary.Value.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorConnection.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorDescription.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.VariableDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.VersionDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.Event.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.LogMessage.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SavedSlice.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SaverDef.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SessionLog.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
mergeValuesDef(ValuesDef) - Method in class org.tensorflow.framework.CondContextDef.Builder
Values and external values in control flow context.
mergeValuesDef(ValuesDef) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Values and external values in control flow context.
mergeVarLenFeature(VarLenFeatureProto) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
mergeVersion(VersionDef) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Versioning of the tensor bundle format.
mergeVersions(VersionDef) - Method in class org.tensorflow.framework.GraphDef.Builder
Compatibility versions of the graph.
mergeVersions(VersionDef) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Compatibility version of this checkpoint.
mergeWatchdogConfig(WatchdogConfig) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WatchdogConfig watchdog_config = 2;
mergeWhileCtxt(WhileContextDef) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.WhileContextDef while_ctxt = 2;
MESSAGE_FIELD_NUMBER - Static variable in class org.tensorflow.util.LogMessage
 
META_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedTensorSlices
 
META_GRAPH_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.util.Event
 
META_GRAPH_VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
META_GRAPHS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SavedModel
 
META_INFO_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef
 
META_OPTIMIZER_ITERATIONS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
META_OPTIMIZER_TIMEOUT_MS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
METADATA_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Value
 
METADATA_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VariantTensorDataProto
 
MetaGraphDef - Class in org.tensorflow.framework
NOTE: This protocol buffer is evolving, and will go through revisions in the coming months.
MetaGraphDef.Builder - Class in org.tensorflow.framework
NOTE: This protocol buffer is evolving, and will go through revisions in the coming months.
MetaGraphDef.MetaInfoDef - Class in org.tensorflow.framework
Meta information regarding the graph to be exported.
MetaGraphDef.MetaInfoDef.Builder - Class in org.tensorflow.framework
Meta information regarding the graph to be exported.
MetaGraphDef.MetaInfoDefOrBuilder - Interface in org.tensorflow.framework
 
MetaGraphDefOrBuilder - Interface in org.tensorflow.framework
 
MetaGraphProtos - Class in org.tensorflow.framework
 
METHOD_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SignatureDef
 
MHZ_PER_CPU_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.CPUInfo
 
MIN_CONSUMER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VersionDef
 
MIN_FIELD_NUMBER - Static variable in class org.tensorflow.framework.HistogramProto
 
MIN_GRAPH_NODES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
MINIMUM_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.AttrDef
 
MODE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.BuildConfiguration
 
MODEL_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.GPUInfo
 
MODEL_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
MSG_FIELD_NUMBER - Static variable in class org.tensorflow.util.SessionLog
 

N

NAME_FIELD_NUMBER - Static variable in class org.tensorflow.distruntime.JobDef
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef.Arg
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef.Attr
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef.Endpoint
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceAttributes
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInfo
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.KernelDef.AttrConstraint
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NameAttrList
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NamedTensorProto
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeDef
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.ArgDef
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.AttrDef
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ResourceHandleProto
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorInfo
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorShapeProto.Dim
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedSlice
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedSliceMeta
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.BenchmarkEntry
 
NAME_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
NAME_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
NAME_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.NamedDevice
 
NAME_FIELD_NUMBER - Static variable in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
NameAttrList - Class in org.tensorflow.framework
A list of attr names and their values.
NameAttrList.Builder - Class in org.tensorflow.framework
A list of attr names and their values.
NameAttrListOrBuilder - Interface in org.tensorflow.framework
 
NamedTensorProto - Class in org.tensorflow.framework
A pair of tensor name and tensor values.
NamedTensorProto.Builder - Class in org.tensorflow.framework
A pair of tensor name and tensor values.
NamedTensorProtoOrBuilder - Interface in org.tensorflow.framework
 
NamedTensorProtos - Class in org.tensorflow.framework
 
NESTED_CONTEXTS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CondContextDef
 
NESTED_CONTEXTS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
newBuilder() - Static method in class org.tensorflow.distruntime.ClusterDef
 
newBuilder(ClusterDef) - Static method in class org.tensorflow.distruntime.ClusterDef
 
newBuilder() - Static method in class org.tensorflow.distruntime.JobDef
 
newBuilder(JobDef) - Static method in class org.tensorflow.distruntime.JobDef
 
newBuilder() - Static method in class org.tensorflow.distruntime.ServerDef
 
newBuilder(ServerDef) - Static method in class org.tensorflow.distruntime.ServerDef
 
newBuilder() - Static method in class org.tensorflow.example.BytesList
 
newBuilder(BytesList) - Static method in class org.tensorflow.example.BytesList
 
newBuilder() - Static method in class org.tensorflow.example.Example
 
newBuilder(Example) - Static method in class org.tensorflow.example.Example
 
newBuilder() - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
newBuilder(ExampleParserConfiguration) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
newBuilder() - Static method in class org.tensorflow.example.Feature
 
newBuilder(Feature) - Static method in class org.tensorflow.example.Feature
 
newBuilder() - Static method in class org.tensorflow.example.FeatureConfiguration
 
newBuilder(FeatureConfiguration) - Static method in class org.tensorflow.example.FeatureConfiguration
 
newBuilder() - Static method in class org.tensorflow.example.FeatureList
 
newBuilder(FeatureList) - Static method in class org.tensorflow.example.FeatureList
 
newBuilder() - Static method in class org.tensorflow.example.FeatureLists
 
newBuilder(FeatureLists) - Static method in class org.tensorflow.example.FeatureLists
 
newBuilder() - Static method in class org.tensorflow.example.Features
 
newBuilder(Features) - Static method in class org.tensorflow.example.Features
 
newBuilder() - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
newBuilder(FixedLenFeatureProto) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
newBuilder() - Static method in class org.tensorflow.example.FloatList
 
newBuilder(FloatList) - Static method in class org.tensorflow.example.FloatList
 
newBuilder() - Static method in class org.tensorflow.example.Int64List
 
newBuilder(Int64List) - Static method in class org.tensorflow.example.Int64List
 
newBuilder() - Static method in class org.tensorflow.example.SequenceExample
 
newBuilder(SequenceExample) - Static method in class org.tensorflow.example.SequenceExample
 
newBuilder() - Static method in class org.tensorflow.example.VarLenFeatureProto
 
newBuilder(VarLenFeatureProto) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
newBuilder() - Static method in class org.tensorflow.framework.AllocationDescription
 
newBuilder(AllocationDescription) - Static method in class org.tensorflow.framework.AllocationDescription
 
newBuilder() - Static method in class org.tensorflow.framework.AllocationRecord
 
newBuilder(AllocationRecord) - Static method in class org.tensorflow.framework.AllocationRecord
 
newBuilder() - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
newBuilder(AllocatorMemoryUsed) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
newBuilder() - Static method in class org.tensorflow.framework.ApiDef.Arg
 
newBuilder(ApiDef.Arg) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
newBuilder() - Static method in class org.tensorflow.framework.ApiDef.Attr
 
newBuilder(ApiDef.Attr) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
newBuilder() - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
newBuilder(ApiDef.Endpoint) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
newBuilder() - Static method in class org.tensorflow.framework.ApiDef
 
newBuilder(ApiDef) - Static method in class org.tensorflow.framework.ApiDef
 
newBuilder() - Static method in class org.tensorflow.framework.ApiDefs
 
newBuilder(ApiDefs) - Static method in class org.tensorflow.framework.ApiDefs
 
newBuilder() - Static method in class org.tensorflow.framework.AssetFileDef
 
newBuilder(AssetFileDef) - Static method in class org.tensorflow.framework.AssetFileDef
 
newBuilder() - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
newBuilder(AttrValue.ListValue) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
newBuilder() - Static method in class org.tensorflow.framework.AttrValue
 
newBuilder(AttrValue) - Static method in class org.tensorflow.framework.AttrValue
 
newBuilder() - Static method in class org.tensorflow.framework.AutoParallelOptions
 
newBuilder(AutoParallelOptions) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
newBuilder() - Static method in class org.tensorflow.framework.CallableOptions
 
newBuilder(CallableOptions) - Static method in class org.tensorflow.framework.CallableOptions
 
newBuilder() - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
newBuilder(CollectionDef.AnyList) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
newBuilder() - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
newBuilder(CollectionDef.BytesList) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
newBuilder() - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
newBuilder(CollectionDef.FloatList) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
newBuilder() - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
newBuilder(CollectionDef.Int64List) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
newBuilder() - Static method in class org.tensorflow.framework.CollectionDef
 
newBuilder(CollectionDef) - Static method in class org.tensorflow.framework.CollectionDef
 
newBuilder() - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
newBuilder(CollectionDef.NodeList) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
newBuilder() - Static method in class org.tensorflow.framework.CondContextDef
 
newBuilder(CondContextDef) - Static method in class org.tensorflow.framework.CondContextDef
 
newBuilder() - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
newBuilder(ConfigProto.Experimental) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
newBuilder() - Static method in class org.tensorflow.framework.ConfigProto
 
newBuilder(ConfigProto) - Static method in class org.tensorflow.framework.ConfigProto
 
newBuilder() - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
newBuilder(ControlFlowContextDef) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
newBuilder() - Static method in class org.tensorflow.framework.CostGraphDef
 
newBuilder(CostGraphDef) - Static method in class org.tensorflow.framework.CostGraphDef
 
newBuilder() - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
newBuilder(CostGraphDef.Node.InputInfo) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
newBuilder() - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
newBuilder(CostGraphDef.Node) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
newBuilder() - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
newBuilder(CostGraphDef.Node.OutputInfo) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
newBuilder() - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
newBuilder(DebuggedSourceFile) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
newBuilder() - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
newBuilder(DebuggedSourceFiles) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
newBuilder() - Static method in class org.tensorflow.framework.DebugOptions
 
newBuilder(DebugOptions) - Static method in class org.tensorflow.framework.DebugOptions
 
newBuilder() - Static method in class org.tensorflow.framework.DebugTensorWatch
 
newBuilder(DebugTensorWatch) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
newBuilder() - Static method in class org.tensorflow.framework.DeviceAttributes
 
newBuilder(DeviceAttributes) - Static method in class org.tensorflow.framework.DeviceAttributes
 
newBuilder() - Static method in class org.tensorflow.framework.DeviceLocality
 
newBuilder(DeviceLocality) - Static method in class org.tensorflow.framework.DeviceLocality
 
newBuilder() - Static method in class org.tensorflow.framework.DeviceStepStats
 
newBuilder(DeviceStepStats) - Static method in class org.tensorflow.framework.DeviceStepStats
 
newBuilder() - Static method in class org.tensorflow.framework.FunctionDef
 
newBuilder(FunctionDef) - Static method in class org.tensorflow.framework.FunctionDef
 
newBuilder() - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
newBuilder(FunctionDefLibrary) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
newBuilder() - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
newBuilder(GPUOptions.Experimental) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
newBuilder() - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
newBuilder(GPUOptions.Experimental.VirtualDevices) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
newBuilder() - Static method in class org.tensorflow.framework.GPUOptions
 
newBuilder(GPUOptions) - Static method in class org.tensorflow.framework.GPUOptions
 
newBuilder() - Static method in class org.tensorflow.framework.GradientDef
 
newBuilder(GradientDef) - Static method in class org.tensorflow.framework.GradientDef
 
newBuilder() - Static method in class org.tensorflow.framework.GraphDef
 
newBuilder(GraphDef) - Static method in class org.tensorflow.framework.GraphDef
 
newBuilder() - Static method in class org.tensorflow.framework.GraphOptions
 
newBuilder(GraphOptions) - Static method in class org.tensorflow.framework.GraphOptions
 
newBuilder() - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
newBuilder(GraphTransferConstNodeInfo) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
newBuilder() - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
newBuilder(GraphTransferGraphInputNodeInfo) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
newBuilder() - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
newBuilder(GraphTransferGraphOutputNodeInfo) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
newBuilder() - Static method in class org.tensorflow.framework.GraphTransferInfo
 
newBuilder(GraphTransferInfo) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
newBuilder() - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
newBuilder(GraphTransferNodeInfo) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
newBuilder() - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
newBuilder(GraphTransferNodeInput) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
newBuilder() - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
newBuilder(GraphTransferNodeInputInfo) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
newBuilder() - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
newBuilder(GraphTransferNodeOutputInfo) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
newBuilder() - Static method in class org.tensorflow.framework.HistogramProto
 
newBuilder(HistogramProto) - Static method in class org.tensorflow.framework.HistogramProto
 
newBuilder() - Static method in class org.tensorflow.framework.InterconnectLink
 
newBuilder(InterconnectLink) - Static method in class org.tensorflow.framework.InterconnectLink
 
newBuilder() - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
newBuilder(KernelDef.AttrConstraint) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
newBuilder() - Static method in class org.tensorflow.framework.KernelDef
 
newBuilder(KernelDef) - Static method in class org.tensorflow.framework.KernelDef
 
newBuilder() - Static method in class org.tensorflow.framework.KernelList
 
newBuilder(KernelList) - Static method in class org.tensorflow.framework.KernelList
 
newBuilder() - Static method in class org.tensorflow.framework.LocalLinks
 
newBuilder(LocalLinks) - Static method in class org.tensorflow.framework.LocalLinks
 
newBuilder() - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
newBuilder(MemoryLogRawAllocation) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
newBuilder() - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
newBuilder(MemoryLogRawDeallocation) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
newBuilder() - Static method in class org.tensorflow.framework.MemoryLogStep
 
newBuilder(MemoryLogStep) - Static method in class org.tensorflow.framework.MemoryLogStep
 
newBuilder() - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
newBuilder(MemoryLogTensorAllocation) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
newBuilder() - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
newBuilder(MemoryLogTensorDeallocation) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
newBuilder() - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
newBuilder(MemoryLogTensorOutput) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
newBuilder() - Static method in class org.tensorflow.framework.MemoryStats
 
newBuilder(MemoryStats) - Static method in class org.tensorflow.framework.MemoryStats
 
newBuilder() - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
newBuilder(MetaGraphDef.MetaInfoDef) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
newBuilder() - Static method in class org.tensorflow.framework.MetaGraphDef
 
newBuilder(MetaGraphDef) - Static method in class org.tensorflow.framework.MetaGraphDef
 
newBuilder() - Static method in class org.tensorflow.framework.NameAttrList
 
newBuilder(NameAttrList) - Static method in class org.tensorflow.framework.NameAttrList
 
newBuilder() - Static method in class org.tensorflow.framework.NamedTensorProto
 
newBuilder(NamedTensorProto) - Static method in class org.tensorflow.framework.NamedTensorProto
 
newBuilder() - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
newBuilder(NodeDef.ExperimentalDebugInfo) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
newBuilder() - Static method in class org.tensorflow.framework.NodeDef
 
newBuilder(NodeDef) - Static method in class org.tensorflow.framework.NodeDef
 
newBuilder() - Static method in class org.tensorflow.framework.NodeExecStats
 
newBuilder(NodeExecStats) - Static method in class org.tensorflow.framework.NodeExecStats
 
newBuilder() - Static method in class org.tensorflow.framework.NodeOutput
 
newBuilder(NodeOutput) - Static method in class org.tensorflow.framework.NodeOutput
 
newBuilder() - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
newBuilder(OpDef.ArgDef) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
newBuilder() - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
newBuilder(OpDef.AttrDef) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
newBuilder() - Static method in class org.tensorflow.framework.OpDef
 
newBuilder(OpDef) - Static method in class org.tensorflow.framework.OpDef
 
newBuilder() - Static method in class org.tensorflow.framework.OpDeprecation
 
newBuilder(OpDeprecation) - Static method in class org.tensorflow.framework.OpDeprecation
 
newBuilder() - Static method in class org.tensorflow.framework.OpList
 
newBuilder(OpList) - Static method in class org.tensorflow.framework.OpList
 
newBuilder() - Static method in class org.tensorflow.framework.OptimizerOptions
 
newBuilder(OptimizerOptions) - Static method in class org.tensorflow.framework.OptimizerOptions
 
newBuilder() - Static method in class org.tensorflow.framework.QueueRunnerDef
 
newBuilder(QueueRunnerDef) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
newBuilder() - Static method in class org.tensorflow.framework.ReaderBaseState
 
newBuilder(ReaderBaseState) - Static method in class org.tensorflow.framework.ReaderBaseState
 
newBuilder() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
newBuilder(RemoteFusedGraphExecuteInfo) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
newBuilder() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
newBuilder(RemoteFusedGraphExecuteInfo.TensorShapeTypeProto) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
newBuilder() - Static method in class org.tensorflow.framework.ResourceHandleProto
 
newBuilder(ResourceHandleProto) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
newBuilder() - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
newBuilder(RewriterConfig.CustomGraphOptimizer) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
newBuilder() - Static method in class org.tensorflow.framework.RewriterConfig
 
newBuilder(RewriterConfig) - Static method in class org.tensorflow.framework.RewriterConfig
 
newBuilder() - Static method in class org.tensorflow.framework.RPCOptions
 
newBuilder(RPCOptions) - Static method in class org.tensorflow.framework.RPCOptions
 
newBuilder() - Static method in class org.tensorflow.framework.RunMetadata
 
newBuilder(RunMetadata) - Static method in class org.tensorflow.framework.RunMetadata
 
newBuilder() - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
newBuilder(RunOptions.Experimental) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
newBuilder() - Static method in class org.tensorflow.framework.RunOptions
 
newBuilder(RunOptions) - Static method in class org.tensorflow.framework.RunOptions
 
newBuilder() - Static method in class org.tensorflow.framework.SavedModel
 
newBuilder(SavedModel) - Static method in class org.tensorflow.framework.SavedModel
 
newBuilder() - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
newBuilder(SaveSliceInfoDef) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
newBuilder() - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
newBuilder(ScopedAllocatorOptions) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
newBuilder() - Static method in class org.tensorflow.framework.SignatureDef
 
newBuilder(SignatureDef) - Static method in class org.tensorflow.framework.SignatureDef
 
newBuilder() - Static method in class org.tensorflow.framework.StepStats
 
newBuilder(StepStats) - Static method in class org.tensorflow.framework.StepStats
 
newBuilder() - Static method in class org.tensorflow.framework.Summary.Audio
 
newBuilder(Summary.Audio) - Static method in class org.tensorflow.framework.Summary.Audio
 
newBuilder() - Static method in class org.tensorflow.framework.Summary.Image
 
newBuilder(Summary.Image) - Static method in class org.tensorflow.framework.Summary.Image
 
newBuilder() - Static method in class org.tensorflow.framework.Summary
 
newBuilder(Summary) - Static method in class org.tensorflow.framework.Summary
 
newBuilder() - Static method in class org.tensorflow.framework.Summary.Value
 
newBuilder(Summary.Value) - Static method in class org.tensorflow.framework.Summary.Value
 
newBuilder() - Static method in class org.tensorflow.framework.SummaryDescription
 
newBuilder(SummaryDescription) - Static method in class org.tensorflow.framework.SummaryDescription
 
newBuilder() - Static method in class org.tensorflow.framework.SummaryMetadata
 
newBuilder(SummaryMetadata) - Static method in class org.tensorflow.framework.SummaryMetadata
 
newBuilder() - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
newBuilder(SummaryMetadata.PluginData) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
newBuilder() - Static method in class org.tensorflow.framework.TensorConnection
 
newBuilder(TensorConnection) - Static method in class org.tensorflow.framework.TensorConnection
 
newBuilder() - Static method in class org.tensorflow.framework.TensorDescription
 
newBuilder(TensorDescription) - Static method in class org.tensorflow.framework.TensorDescription
 
newBuilder() - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
newBuilder(TensorInfo.CooSparse) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
newBuilder() - Static method in class org.tensorflow.framework.TensorInfo
 
newBuilder(TensorInfo) - Static method in class org.tensorflow.framework.TensorInfo
 
newBuilder() - Static method in class org.tensorflow.framework.TensorProto
 
newBuilder(TensorProto) - Static method in class org.tensorflow.framework.TensorProto
 
newBuilder() - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
newBuilder(TensorShapeProto.Dim) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
newBuilder() - Static method in class org.tensorflow.framework.TensorShapeProto
 
newBuilder(TensorShapeProto) - Static method in class org.tensorflow.framework.TensorShapeProto
 
newBuilder() - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
newBuilder(TensorSliceProto.Extent) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
newBuilder() - Static method in class org.tensorflow.framework.TensorSliceProto
 
newBuilder(TensorSliceProto) - Static method in class org.tensorflow.framework.TensorSliceProto
 
newBuilder() - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
newBuilder(ThreadPoolOptionProto) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
newBuilder() - Static method in class org.tensorflow.framework.ValuesDef
 
newBuilder(ValuesDef) - Static method in class org.tensorflow.framework.ValuesDef
 
newBuilder() - Static method in class org.tensorflow.framework.VariableDef
 
newBuilder(VariableDef) - Static method in class org.tensorflow.framework.VariableDef
 
newBuilder() - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
newBuilder(VariantTensorDataProto) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
newBuilder() - Static method in class org.tensorflow.framework.VersionDef
 
newBuilder(VersionDef) - Static method in class org.tensorflow.framework.VersionDef
 
newBuilder() - Static method in class org.tensorflow.framework.WhileContextDef
 
newBuilder(WhileContextDef) - Static method in class org.tensorflow.framework.WhileContextDef
 
newBuilder() - Static method in class org.tensorflow.util.BundleEntryProto
 
newBuilder(BundleEntryProto) - Static method in class org.tensorflow.util.BundleEntryProto
 
newBuilder() - Static method in class org.tensorflow.util.BundleHeaderProto
 
newBuilder(BundleHeaderProto) - Static method in class org.tensorflow.util.BundleHeaderProto
 
newBuilder() - Static method in class org.tensorflow.util.Event
 
newBuilder(Event) - Static method in class org.tensorflow.util.Event
 
newBuilder() - Static method in class org.tensorflow.util.IteratorStateMetadata
 
newBuilder(IteratorStateMetadata) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
newBuilder() - Static method in class org.tensorflow.util.LogMessage
 
newBuilder(LogMessage) - Static method in class org.tensorflow.util.LogMessage
 
newBuilder() - Static method in class org.tensorflow.util.SavedSlice
 
newBuilder(SavedSlice) - Static method in class org.tensorflow.util.SavedSlice
 
newBuilder() - Static method in class org.tensorflow.util.SavedSliceMeta
 
newBuilder(SavedSliceMeta) - Static method in class org.tensorflow.util.SavedSliceMeta
 
newBuilder() - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
newBuilder(SavedTensorSliceMeta) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
newBuilder() - Static method in class org.tensorflow.util.SavedTensorSlices
 
newBuilder(SavedTensorSlices) - Static method in class org.tensorflow.util.SavedTensorSlices
 
newBuilder() - Static method in class org.tensorflow.util.SaverDef
 
newBuilder(SaverDef) - Static method in class org.tensorflow.util.SaverDef
 
newBuilder() - Static method in class org.tensorflow.util.SessionLog
 
newBuilder(SessionLog) - Static method in class org.tensorflow.util.SessionLog
 
newBuilder() - Static method in class org.tensorflow.util.TaggedRunMetadata
 
newBuilder(TaggedRunMetadata) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
newBuilder() - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
newBuilder(AvailableDeviceInfo) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
newBuilder() - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
newBuilder(BenchmarkEntries) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
newBuilder() - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
newBuilder(BenchmarkEntry) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
newBuilder() - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
newBuilder(BuildConfiguration) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
newBuilder() - Static method in class org.tensorflow.util.testlog.CommitId
 
newBuilder(CommitId) - Static method in class org.tensorflow.util.testlog.CommitId
 
newBuilder() - Static method in class org.tensorflow.util.testlog.CPUInfo
 
newBuilder(CPUInfo) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
newBuilder() - Static method in class org.tensorflow.util.testlog.EntryValue
 
newBuilder(EntryValue) - Static method in class org.tensorflow.util.testlog.EntryValue
 
newBuilder() - Static method in class org.tensorflow.util.testlog.GPUInfo
 
newBuilder(GPUInfo) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
newBuilder() - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
newBuilder(MachineConfiguration) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
newBuilder() - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
newBuilder(MemoryInfo) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
newBuilder() - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
newBuilder(PlatformInfo) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
newBuilder() - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
newBuilder(RunConfiguration) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
newBuilder() - Static method in class org.tensorflow.util.testlog.TestResults
 
newBuilder(TestResults) - Static method in class org.tensorflow.util.testlog.TestResults
 
newBuilder() - Static method in class org.tensorflow.util.WatchdogConfig
 
newBuilder(WatchdogConfig) - Static method in class org.tensorflow.util.WatchdogConfig
 
newBuilder() - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
newBuilder(WorkerHeartbeatRequest) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
newBuilder() - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
newBuilder(WorkerHeartbeatResponse) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
newBuilder() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
newBuilder(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
newBuilder() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
newBuilder(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
newBuilder() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
newBuilder(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
newBuilder() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
newBuilder(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
newBuilder() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
newBuilder(CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
newBuilder() - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
newBuilder(DevicePropertiesProtos.DeviceProperties) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
newBuilder() - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
newBuilder(DevicePropertiesProtos.NamedDevice) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
newBuilder() - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
newBuilder(MemmappedFileSystem.MemmappedFileSystemDirectory) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
newBuilder() - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
newBuilder(MemmappedFileSystem.MemmappedFileSystemDirectoryElement) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
newBuilder() - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
newBuilder(TransportOptions.RecvBufRespExtra) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
newBuilderForType() - Method in class org.tensorflow.distruntime.ClusterDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.distruntime.ClusterDef
 
newBuilderForType() - Method in class org.tensorflow.distruntime.JobDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.distruntime.JobDef
 
newBuilderForType() - Method in class org.tensorflow.distruntime.ServerDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.distruntime.ServerDef
 
newBuilderForType() - Method in class org.tensorflow.example.BytesList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.BytesList
 
newBuilderForType() - Method in class org.tensorflow.example.Example
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.Example
 
newBuilderForType() - Method in class org.tensorflow.example.ExampleParserConfiguration
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.ExampleParserConfiguration
 
newBuilderForType() - Method in class org.tensorflow.example.Feature
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.Feature
 
newBuilderForType() - Method in class org.tensorflow.example.FeatureConfiguration
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.FeatureConfiguration
 
newBuilderForType() - Method in class org.tensorflow.example.FeatureList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.FeatureList
 
newBuilderForType() - Method in class org.tensorflow.example.FeatureLists
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.FeatureLists
 
newBuilderForType() - Method in class org.tensorflow.example.Features
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.Features
 
newBuilderForType() - Method in class org.tensorflow.example.FixedLenFeatureProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.FixedLenFeatureProto
 
newBuilderForType() - Method in class org.tensorflow.example.FloatList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.FloatList
 
newBuilderForType() - Method in class org.tensorflow.example.Int64List
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.Int64List
 
newBuilderForType() - Method in class org.tensorflow.example.SequenceExample
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.SequenceExample
 
newBuilderForType() - Method in class org.tensorflow.example.VarLenFeatureProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.example.VarLenFeatureProto
 
newBuilderForType() - Method in class org.tensorflow.framework.AllocationDescription
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.AllocationDescription
 
newBuilderForType() - Method in class org.tensorflow.framework.AllocationRecord
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.AllocationRecord
 
newBuilderForType() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
newBuilderForType() - Method in class org.tensorflow.framework.ApiDef.Arg
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ApiDef.Arg
 
newBuilderForType() - Method in class org.tensorflow.framework.ApiDef.Attr
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ApiDef.Attr
 
newBuilderForType() - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
newBuilderForType() - Method in class org.tensorflow.framework.ApiDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ApiDef
 
newBuilderForType() - Method in class org.tensorflow.framework.ApiDefs
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ApiDefs
 
newBuilderForType() - Method in class org.tensorflow.framework.AssetFileDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.AssetFileDef
 
newBuilderForType() - Method in class org.tensorflow.framework.AttrValue.ListValue
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.AttrValue.ListValue
 
newBuilderForType() - Method in class org.tensorflow.framework.AttrValue
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.AttrValue
 
newBuilderForType() - Method in class org.tensorflow.framework.AutoParallelOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.AutoParallelOptions
 
newBuilderForType() - Method in class org.tensorflow.framework.CallableOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CallableOptions
 
newBuilderForType() - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
newBuilderForType() - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
newBuilderForType() - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
newBuilderForType() - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
newBuilderForType() - Method in class org.tensorflow.framework.CollectionDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CollectionDef
 
newBuilderForType() - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
newBuilderForType() - Method in class org.tensorflow.framework.CondContextDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CondContextDef
 
newBuilderForType() - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
newBuilderForType() - Method in class org.tensorflow.framework.ConfigProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ConfigProto
 
newBuilderForType() - Method in class org.tensorflow.framework.ControlFlowContextDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ControlFlowContextDef
 
newBuilderForType() - Method in class org.tensorflow.framework.CostGraphDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CostGraphDef
 
newBuilderForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.CostGraphDef.Node
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CostGraphDef.Node
 
newBuilderForType() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.DebuggedSourceFile
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.DebuggedSourceFile
 
newBuilderForType() - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
newBuilderForType() - Method in class org.tensorflow.framework.DebugOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.DebugOptions
 
newBuilderForType() - Method in class org.tensorflow.framework.DebugTensorWatch
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.DebugTensorWatch
 
newBuilderForType() - Method in class org.tensorflow.framework.DeviceAttributes
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.DeviceAttributes
 
newBuilderForType() - Method in class org.tensorflow.framework.DeviceLocality
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.DeviceLocality
 
newBuilderForType() - Method in class org.tensorflow.framework.DeviceStepStats
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.DeviceStepStats
 
newBuilderForType() - Method in class org.tensorflow.framework.FunctionDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.FunctionDef
 
newBuilderForType() - Method in class org.tensorflow.framework.FunctionDefLibrary
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.FunctionDefLibrary
 
newBuilderForType() - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
newBuilderForType() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
newBuilderForType() - Method in class org.tensorflow.framework.GPUOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GPUOptions
 
newBuilderForType() - Method in class org.tensorflow.framework.GradientDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GradientDef
 
newBuilderForType() - Method in class org.tensorflow.framework.GraphDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GraphDef
 
newBuilderForType() - Method in class org.tensorflow.framework.GraphOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GraphOptions
 
newBuilderForType() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.GraphTransferInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GraphTransferInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
newBuilderForType() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.HistogramProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.HistogramProto
 
newBuilderForType() - Method in class org.tensorflow.framework.InterconnectLink
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.InterconnectLink
 
newBuilderForType() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
newBuilderForType() - Method in class org.tensorflow.framework.KernelDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.KernelDef
 
newBuilderForType() - Method in class org.tensorflow.framework.KernelList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.KernelList
 
newBuilderForType() - Method in class org.tensorflow.framework.LocalLinks
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.LocalLinks
 
newBuilderForType() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
newBuilderForType() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
newBuilderForType() - Method in class org.tensorflow.framework.MemoryLogStep
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.MemoryLogStep
 
newBuilderForType() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
newBuilderForType() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
newBuilderForType() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
newBuilderForType() - Method in class org.tensorflow.framework.MemoryStats
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.MemoryStats
 
newBuilderForType() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
newBuilderForType() - Method in class org.tensorflow.framework.MetaGraphDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.MetaGraphDef
 
newBuilderForType() - Method in class org.tensorflow.framework.NameAttrList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.NameAttrList
 
newBuilderForType() - Method in class org.tensorflow.framework.NamedTensorProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.NamedTensorProto
 
newBuilderForType() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.NodeDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.NodeDef
 
newBuilderForType() - Method in class org.tensorflow.framework.NodeExecStats
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.NodeExecStats
 
newBuilderForType() - Method in class org.tensorflow.framework.NodeOutput
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.NodeOutput
 
newBuilderForType() - Method in class org.tensorflow.framework.OpDef.ArgDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.OpDef.ArgDef
 
newBuilderForType() - Method in class org.tensorflow.framework.OpDef.AttrDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.OpDef.AttrDef
 
newBuilderForType() - Method in class org.tensorflow.framework.OpDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.OpDef
 
newBuilderForType() - Method in class org.tensorflow.framework.OpDeprecation
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.OpDeprecation
 
newBuilderForType() - Method in class org.tensorflow.framework.OpList
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.OpList
 
newBuilderForType() - Method in class org.tensorflow.framework.OptimizerOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.OptimizerOptions
 
newBuilderForType() - Method in class org.tensorflow.framework.QueueRunnerDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.QueueRunnerDef
 
newBuilderForType() - Method in class org.tensorflow.framework.ReaderBaseState
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ReaderBaseState
 
newBuilderForType() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
newBuilderForType() - Method in class org.tensorflow.framework.ResourceHandleProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ResourceHandleProto
 
newBuilderForType() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
newBuilderForType() - Method in class org.tensorflow.framework.RewriterConfig
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.RewriterConfig
 
newBuilderForType() - Method in class org.tensorflow.framework.RPCOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.RPCOptions
 
newBuilderForType() - Method in class org.tensorflow.framework.RunMetadata
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.RunMetadata
 
newBuilderForType() - Method in class org.tensorflow.framework.RunOptions.Experimental
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.RunOptions.Experimental
 
newBuilderForType() - Method in class org.tensorflow.framework.RunOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.RunOptions
 
newBuilderForType() - Method in class org.tensorflow.framework.SavedModel
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.SavedModel
 
newBuilderForType() - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
newBuilderForType() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
newBuilderForType() - Method in class org.tensorflow.framework.SignatureDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.SignatureDef
 
newBuilderForType() - Method in class org.tensorflow.framework.StepStats
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.StepStats
 
newBuilderForType() - Method in class org.tensorflow.framework.Summary.Audio
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.Summary.Audio
 
newBuilderForType() - Method in class org.tensorflow.framework.Summary.Image
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.Summary.Image
 
newBuilderForType() - Method in class org.tensorflow.framework.Summary
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.Summary
 
newBuilderForType() - Method in class org.tensorflow.framework.Summary.Value
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.Summary.Value
 
newBuilderForType() - Method in class org.tensorflow.framework.SummaryDescription
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.SummaryDescription
 
newBuilderForType() - Method in class org.tensorflow.framework.SummaryMetadata
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.SummaryMetadata
 
newBuilderForType() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
newBuilderForType() - Method in class org.tensorflow.framework.TensorConnection
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.TensorConnection
 
newBuilderForType() - Method in class org.tensorflow.framework.TensorDescription
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.TensorDescription
 
newBuilderForType() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
newBuilderForType() - Method in class org.tensorflow.framework.TensorInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.TensorInfo
 
newBuilderForType() - Method in class org.tensorflow.framework.TensorProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.TensorProto
 
newBuilderForType() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
newBuilderForType() - Method in class org.tensorflow.framework.TensorShapeProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.TensorShapeProto
 
newBuilderForType() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
newBuilderForType() - Method in class org.tensorflow.framework.TensorSliceProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.TensorSliceProto
 
newBuilderForType() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
newBuilderForType() - Method in class org.tensorflow.framework.ValuesDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.ValuesDef
 
newBuilderForType() - Method in class org.tensorflow.framework.VariableDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.VariableDef
 
newBuilderForType() - Method in class org.tensorflow.framework.VariantTensorDataProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.VariantTensorDataProto
 
newBuilderForType() - Method in class org.tensorflow.framework.VersionDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.VersionDef
 
newBuilderForType() - Method in class org.tensorflow.framework.WhileContextDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.framework.WhileContextDef
 
newBuilderForType() - Method in class org.tensorflow.util.BundleEntryProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.BundleEntryProto
 
newBuilderForType() - Method in class org.tensorflow.util.BundleHeaderProto
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.BundleHeaderProto
 
newBuilderForType() - Method in class org.tensorflow.util.Event
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.Event
 
newBuilderForType() - Method in class org.tensorflow.util.IteratorStateMetadata
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.IteratorStateMetadata
 
newBuilderForType() - Method in class org.tensorflow.util.LogMessage
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.LogMessage
 
newBuilderForType() - Method in class org.tensorflow.util.SavedSlice
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.SavedSlice
 
newBuilderForType() - Method in class org.tensorflow.util.SavedSliceMeta
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.SavedSliceMeta
 
newBuilderForType() - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
newBuilderForType() - Method in class org.tensorflow.util.SavedTensorSlices
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.SavedTensorSlices
 
newBuilderForType() - Method in class org.tensorflow.util.SaverDef
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.SaverDef
 
newBuilderForType() - Method in class org.tensorflow.util.SessionLog
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.SessionLog
 
newBuilderForType() - Method in class org.tensorflow.util.TaggedRunMetadata
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.TaggedRunMetadata
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.CommitId
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.CommitId
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.CPUInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.CPUInfo
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.EntryValue
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.EntryValue
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.GPUInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.GPUInfo
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.MemoryInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.MemoryInfo
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.PlatformInfo
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.PlatformInfo
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.RunConfiguration
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.RunConfiguration
 
newBuilderForType() - Method in class org.tensorflow.util.testlog.TestResults
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.testlog.TestResults
 
newBuilderForType() - Method in class org.tensorflow.util.WatchdogConfig
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.WatchdogConfig
 
newBuilderForType() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
newBuilderForType() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
newBuilderForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
newBuilderForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
newBuilderForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
newBuilderForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
newBuilderForType() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
newBuilderForType() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
newBuilderForType() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
newBuilderForType() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
newBuilderForType() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
newBuilderForType() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
NO_MEM_OPT_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.MemOptType
Disabled in the meta-optimizer.
NO_TRACE_VALUE - Static variable in enum org.tensorflow.framework.RunOptions.TraceLevel
NO_TRACE = 0;
NODE_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.FunctionDef
 
NODE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef
 
NODE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphDef
 
NODE_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
NODE_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInfo
 
NODE_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInput
 
NODE_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
NODE_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
NODE_ID_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
NODE_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferInfo
 
NODE_INPUT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
NODE_INPUT_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferInfo
 
NODE_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CollectionDef
 
NODE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebugTensorWatch
 
NODE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
NODE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Value
 
NODE_OUTPUT_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferInfo
 
NODE_STATS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceStepStats
 
NodeDef - Class in org.tensorflow.framework
Protobuf type tensorflow.NodeDef
NodeDef.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.NodeDef
NodeDef.ExperimentalDebugInfo - Class in org.tensorflow.framework
Protobuf type tensorflow.NodeDef.ExperimentalDebugInfo
NodeDef.ExperimentalDebugInfo.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.NodeDef.ExperimentalDebugInfo
NodeDef.ExperimentalDebugInfoOrBuilder - Interface in org.tensorflow.framework
 
NodeDefOrBuilder - Interface in org.tensorflow.framework
 
NodeExecStats - Class in org.tensorflow.framework
Time/size stats recorded for a single execution of a graph node.
NodeExecStats.Builder - Class in org.tensorflow.framework
Time/size stats recorded for a single execution of a graph node.
NodeExecStatsOrBuilder - Interface in org.tensorflow.framework
 
NodeOutput - Class in org.tensorflow.framework
Output sizes recorded for a single execution of a graph node.
NodeOutput.Builder - Class in org.tensorflow.framework
Output sizes recorded for a single execution of a graph node.
NodeOutputOrBuilder - Interface in org.tensorflow.framework
 
NodeProto - Class in org.tensorflow.framework
 
NODES_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
NOP_VALUE - Static variable in enum org.tensorflow.framework.GraphTransferInfo.Destination
NOP = 0;
NOT_FOUND_VALUE - Static variable in enum org.tensorflow.framework.Code
Some requested entity (e.g., file or directory) was not found.
NUM_BYTES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawAllocation
 
NUM_CHANNELS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Audio
 
NUM_CORES_ALLOWED_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.CPUInfo
 
NUM_CORES_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.CPUInfo
 
NUM_CORES_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
NUM_DEV_TO_DEV_COPY_STREAMS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions.Experimental
 
NUM_FIELD_NUMBER - Static variable in class org.tensorflow.framework.HistogramProto
 
NUM_RECORDS_PRODUCED_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ReaderBaseState
 
NUM_REGISTERS_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
NUM_REPLICAS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AutoParallelOptions
 
NUM_SHARDS_FIELD_NUMBER - Static variable in class org.tensorflow.util.BundleHeaderProto
 
NUM_THREADS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ThreadPoolOptionProto
 
NUMA_NODE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceLocality
 
NUMBER_ATTR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.ArgDef
 

O

OBSOLETE_OLD_STYLE_HISTOGRAM_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Value
 
OFF_VALUE - Static variable in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
OFF = -1;
OFF_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.Toggle
OFF = 2;
OFFSET_FIELD_NUMBER - Static variable in class org.tensorflow.util.BundleEntryProto
 
OFFSET_FIELD_NUMBER - Static variable in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
OK_VALUE - Static variable in enum org.tensorflow.framework.Code
Not an error; returned on success
OK_VALUE - Static variable in enum org.tensorflow.util.WorkerHealth
By default a worker is healthy.
ON_1_VALUE - Static variable in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
The following settings turn on compilation, with higher values being more aggressive.
ON_2_VALUE - Static variable in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
ON_2 = 2;
ON_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.Toggle
ON = 1;
ONE_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
ONE = 1;
OP_END_REL_MICROS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
OP_END_REL_NANOS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
OP_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDefs
 
OP_FIELD_NUMBER - Static variable in class org.tensorflow.framework.KernelDef
 
OP_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeDef
 
OP_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpList
 
OP_START_REL_MICROS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
OP_START_REL_NANOS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
OpDef - Class in org.tensorflow.framework
Defines an operation.
OpDef.ArgDef - Class in org.tensorflow.framework
For describing inputs and outputs.
OpDef.ArgDef.Builder - Class in org.tensorflow.framework
For describing inputs and outputs.
OpDef.ArgDefOrBuilder - Interface in org.tensorflow.framework
 
OpDef.AttrDef - Class in org.tensorflow.framework
Description of the graph-construction-time configuration of this Op.
OpDef.AttrDef.Builder - Class in org.tensorflow.framework
Description of the graph-construction-time configuration of this Op.
OpDef.AttrDefOrBuilder - Interface in org.tensorflow.framework
 
OpDef.Builder - Class in org.tensorflow.framework
Defines an operation.
OpDefOrBuilder - Interface in org.tensorflow.framework
 
OpDefProtos - Class in org.tensorflow.framework
 
OpDeprecation - Class in org.tensorflow.framework
Information about version-dependent deprecation of an op
OpDeprecation.Builder - Class in org.tensorflow.framework
Information about version-dependent deprecation of an op
OpDeprecationOrBuilder - Interface in org.tensorflow.framework
 
OPERATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawAllocation
 
OPERATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawDeallocation
 
OPERATION_TIMEOUT_IN_MS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
OpList - Class in org.tensorflow.framework
A collection of OpDefs
OpList.Builder - Class in org.tensorflow.framework
A collection of OpDefs
OpListOrBuilder - Interface in org.tensorflow.framework
 
OPT_LEVEL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OptimizerOptions
 
OPTIMIZER_OPTIONS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphOptions
 
OptimizerOptions - Class in org.tensorflow.framework
Options passed to the graph optimizer
OptimizerOptions.Builder - Class in org.tensorflow.framework
Options passed to the graph optimizer
OptimizerOptions.GlobalJitLevel - Enum in org.tensorflow.framework
Control the use of the compiler/jit.
OptimizerOptions.Level - Enum in org.tensorflow.framework
Optimization level
OptimizerOptionsOrBuilder - Interface in org.tensorflow.framework
 
OPTIMIZERS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
OPTS_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.BuildConfiguration
 
org.tensorflow.distruntime - package org.tensorflow.distruntime
 
org.tensorflow.example - package org.tensorflow.example
 
org.tensorflow.framework - package org.tensorflow.framework
 
org.tensorflow.util - package org.tensorflow.util
 
org.tensorflow.util.testlog - package org.tensorflow.util.testlog
 
ORIGINAL_NODE_NAMES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
ORIGINAL_VARIABLE_NODE_ID_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
OUT_ARG_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
OUT_OF_RANGE_VALUE - Static variable in enum org.tensorflow.framework.Code
Operation tried to iterate past the valid input range.
OUTPUT_ARG_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
OUTPUT_COUNT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInfo
 
OUTPUT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
OUTPUT_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
OUTPUT_PARTITION_GRAPHS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunOptions
 
OUTPUT_PORT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInput
 
OUTPUT_SLOT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebugTensorWatch
 
OUTPUTS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SignatureDef
 

P

PADDING_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInfo
 
PARALLEL_ITERATIONS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
PARAMETER_MAP_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.distruntime.JobDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.JobDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.BytesList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.BytesList
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.Example
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Example
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.Feature
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Feature
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.FeatureList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureList
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.FeatureLists
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureLists
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.Features
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Features
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.FloatList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FloatList
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.Int64List
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Int64List
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.SequenceExample
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.SequenceExample
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ApiDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ApiDefs
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDefs
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.AttrValue
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CallableOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CallableOptions
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CondContextDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CondContextDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ConfigProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.DebugOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugOptions
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.FunctionDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GPUOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GradientDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GradientDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GraphDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GraphOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphOptions
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.HistogramProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.HistogramProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.KernelDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.KernelList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelList
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.LocalLinks
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.LocalLinks
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryStats
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryStats
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.NameAttrList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NameAttrList
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.NodeDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.NodeOutput
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeOutput
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.OpDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.OpList
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpList
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.RPCOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RPCOptions
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.RunMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.RunOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.SavedModel
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SavedModel
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.SignatureDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SignatureDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.StepStats
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.StepStats
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.Summary.Image
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Image
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.Summary
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.Summary.Value
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Value
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.TensorConnection
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorConnection
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.TensorDescription
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorDescription
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.TensorInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.TensorProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.ValuesDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ValuesDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.VariableDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariableDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.VersionDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VersionDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.Event
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.Event
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.LogMessage
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.LogMessage
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.SavedSlice
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSlice
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.SaverDef
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SaverDef
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.SessionLog
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SessionLog
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseDelimitedFrom(InputStream) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseDelimitedFrom(InputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseDelimitedFrom(InputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseDelimitedFrom(InputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseDelimitedFrom(InputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseDelimitedFrom(InputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseDelimitedFrom(InputStream) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseDelimitedFrom(InputStream) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseDelimitedFrom(InputStream) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseDelimitedFrom(InputStream) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseDelimitedFrom(InputStream) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ClusterDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.distruntime.JobDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.JobDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.distruntime.JobDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.JobDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.distruntime.JobDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.JobDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.distruntime.JobDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.JobDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.distruntime.JobDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.JobDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ServerDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.BytesList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.BytesList
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.BytesList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.BytesList
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.BytesList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.BytesList
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.BytesList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.BytesList
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.BytesList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.BytesList
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.Example
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Example
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.Example
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Example
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.Example
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.Example
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.Example
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Example
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.Example
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Example
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.Feature
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Feature
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.Feature
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Feature
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.Feature
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.Feature
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.Feature
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Feature
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.Feature
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Feature
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureConfiguration
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.FeatureList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureList
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.FeatureList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureList
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.FeatureList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureList
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.FeatureList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureList
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.FeatureList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureList
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.FeatureLists
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureLists
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.FeatureLists
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureLists
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.FeatureLists
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureLists
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.FeatureLists
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureLists
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.FeatureLists
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureLists
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.Features
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Features
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.Features
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Features
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.Features
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.Features
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.Features
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Features
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.Features
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Features
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.FloatList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FloatList
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.FloatList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FloatList
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.FloatList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.FloatList
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.FloatList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FloatList
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.FloatList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.FloatList
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.Int64List
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Int64List
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.Int64List
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Int64List
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.Int64List
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.Int64List
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.Int64List
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Int64List
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.Int64List
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.Int64List
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.SequenceExample
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.SequenceExample
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.SequenceExample
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.SequenceExample
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.SequenceExample
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.SequenceExample
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.SequenceExample
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.SequenceExample
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.SequenceExample
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.SequenceExample
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationDescription
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationRecord
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ApiDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ApiDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ApiDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ApiDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ApiDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ApiDefs
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDefs
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ApiDefs
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDefs
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ApiDefs
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDefs
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ApiDefs
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDefs
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ApiDefs
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDefs
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AssetFileDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.AttrValue
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.AttrValue
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.AttrValue
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.AttrValue
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.AttrValue
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValue
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CallableOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CallableOptions
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CallableOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CallableOptions
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CallableOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CallableOptions
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CallableOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CallableOptions
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CallableOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CallableOptions
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CollectionDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CollectionDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CollectionDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CollectionDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CollectionDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CollectionDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CondContextDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CondContextDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CondContextDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CondContextDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CondContextDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CondContextDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CondContextDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CondContextDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CondContextDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CondContextDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ConfigProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ConfigProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ConfigProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ConfigProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ConfigProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.DebugOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugOptions
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.DebugOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugOptions
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.DebugOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugOptions
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.DebugOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugOptions
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.DebugOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugOptions
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceAttributes
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceLocality
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceStepStats
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.FunctionDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.FunctionDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.FunctionDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.FunctionDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.FunctionDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GPUOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GPUOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GPUOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GPUOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GPUOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GPUOptions
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GradientDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GradientDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GradientDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GradientDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GradientDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GradientDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GradientDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GradientDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GradientDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GradientDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GraphDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GraphDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GraphDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GraphDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GraphDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GraphOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphOptions
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GraphOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphOptions
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GraphOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphOptions
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GraphOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphOptions
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GraphOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphOptions
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.HistogramProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.HistogramProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.HistogramProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.HistogramProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.HistogramProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.HistogramProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.HistogramProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.HistogramProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.HistogramProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.HistogramProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.InterconnectLink
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.KernelDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.KernelDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.KernelDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.KernelDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.KernelDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.KernelList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelList
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.KernelList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelList
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.KernelList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelList
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.KernelList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelList
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.KernelList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelList
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.LocalLinks
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.LocalLinks
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.LocalLinks
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.LocalLinks
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.LocalLinks
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.LocalLinks
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.LocalLinks
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.LocalLinks
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.LocalLinks
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.LocalLinks
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogStep
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.MemoryStats
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryStats
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.MemoryStats
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryStats
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.MemoryStats
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryStats
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.MemoryStats
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryStats
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.MemoryStats
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MemoryStats
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.NameAttrList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NameAttrList
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.NameAttrList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NameAttrList
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.NameAttrList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NameAttrList
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.NameAttrList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NameAttrList
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.NameAttrList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NameAttrList
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NamedTensorProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.NodeDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.NodeDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.NodeDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.NodeDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.NodeDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeExecStats
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.NodeOutput
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeOutput
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.NodeOutput
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeOutput
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.NodeOutput
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeOutput
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.NodeOutput
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeOutput
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.NodeOutput
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeOutput
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.OpDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.OpDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.OpDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.OpDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.OpDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDeprecation
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.OpList
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpList
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.OpList
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpList
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.OpList
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpList
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.OpList
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpList
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.OpList
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpList
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OptimizerOptions
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ReaderBaseState
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfig
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.RPCOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RPCOptions
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.RPCOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RPCOptions
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.RPCOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RPCOptions
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.RPCOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RPCOptions
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.RPCOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RPCOptions
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.RunMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunMetadata
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.RunMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunMetadata
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.RunMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunMetadata
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.RunMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunMetadata
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.RunMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunMetadata
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.RunOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.RunOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.RunOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.RunOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.RunOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RunOptions
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.SavedModel
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SavedModel
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.SavedModel
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SavedModel
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.SavedModel
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SavedModel
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.SavedModel
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SavedModel
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.SavedModel
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SavedModel
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.SignatureDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SignatureDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.SignatureDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SignatureDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.SignatureDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SignatureDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.SignatureDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SignatureDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.SignatureDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SignatureDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.StepStats
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.StepStats
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.StepStats
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.StepStats
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.StepStats
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.StepStats
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.StepStats
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.StepStats
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.StepStats
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.StepStats
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Audio
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.Summary.Image
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Image
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.Summary.Image
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Image
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.Summary.Image
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Image
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.Summary.Image
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Image
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.Summary.Image
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Image
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.Summary
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.Summary
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.Summary
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.Summary
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.Summary
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.Summary.Value
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Value
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.Summary.Value
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Value
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.Summary.Value
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Value
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.Summary.Value
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Value
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.Summary.Value
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.Summary.Value
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryDescription
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.TensorConnection
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorConnection
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.TensorConnection
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorConnection
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.TensorConnection
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorConnection
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.TensorConnection
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorConnection
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.TensorConnection
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorConnection
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.TensorDescription
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorDescription
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.TensorDescription
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorDescription
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.TensorDescription
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorDescription
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.TensorDescription
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorDescription
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.TensorDescription
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorDescription
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.TensorInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.TensorInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.TensorInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.TensorInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.TensorInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.TensorProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.TensorProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.TensorProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.TensorProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.TensorProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.ValuesDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ValuesDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.ValuesDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ValuesDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.ValuesDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ValuesDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.ValuesDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ValuesDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.ValuesDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ValuesDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.VariableDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariableDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.VariableDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariableDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.VariableDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariableDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.VariableDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariableDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.VariableDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariableDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.VersionDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VersionDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.VersionDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VersionDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.VersionDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VersionDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.VersionDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VersionDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.VersionDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VersionDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.framework.WhileContextDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleEntryProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.BundleHeaderProto
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.Event
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.Event
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.Event
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.Event
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.Event
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.Event
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.Event
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.Event
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.Event
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.Event
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.LogMessage
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.LogMessage
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.LogMessage
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.LogMessage
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.LogMessage
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.LogMessage
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.LogMessage
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.LogMessage
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.LogMessage
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.LogMessage
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.SavedSlice
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSlice
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.SavedSlice
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSlice
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.SavedSlice
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSlice
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.SavedSlice
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSlice
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.SavedSlice
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSlice
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedSliceMeta
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSlices
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.SaverDef
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SaverDef
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.SaverDef
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SaverDef
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.SaverDef
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.SaverDef
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.SaverDef
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SaverDef
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.SaverDef
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SaverDef
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.SessionLog
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SessionLog
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.SessionLog
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SessionLog
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.SessionLog
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.SessionLog
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.SessionLog
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SessionLog
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.SessionLog
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.SessionLog
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CommitId
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.EntryValue
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.TestResults
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WatchdogConfig
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parseFrom(ByteBuffer) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseFrom(ByteString) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseFrom(byte[]) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseFrom(InputStream) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseFrom(CodedInputStream) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parseFrom(ByteBuffer) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseFrom(ByteString) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseFrom(byte[]) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseFrom(InputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseFrom(CodedInputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parseFrom(ByteBuffer) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseFrom(ByteString) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseFrom(byte[]) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseFrom(InputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseFrom(CodedInputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parseFrom(ByteBuffer) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseFrom(ByteString) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseFrom(byte[]) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseFrom(InputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseFrom(CodedInputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parseFrom(ByteBuffer) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseFrom(ByteString) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseFrom(byte[]) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseFrom(InputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseFrom(CodedInputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parseFrom(ByteBuffer) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseFrom(ByteString) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseFrom(byte[]) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseFrom(InputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseFrom(CodedInputStream) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parseFrom(ByteBuffer) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseFrom(ByteString) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseFrom(byte[]) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseFrom(InputStream) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseFrom(CodedInputStream) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parseFrom(ByteBuffer) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseFrom(ByteString) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseFrom(byte[]) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseFrom(InputStream) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseFrom(CodedInputStream) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parseFrom(ByteBuffer) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseFrom(ByteString) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseFrom(byte[]) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseFrom(InputStream) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseFrom(CodedInputStream) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parseFrom(ByteBuffer) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseFrom(ByteString) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseFrom(byte[]) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseFrom(InputStream) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseFrom(CodedInputStream) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parseFrom(ByteBuffer) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseFrom(ByteString) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseFrom(byte[]) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseFrom(InputStream) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseFrom(CodedInputStream) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
parser() - Static method in class org.tensorflow.distruntime.ClusterDef
 
parser() - Static method in class org.tensorflow.distruntime.JobDef
 
parser() - Static method in class org.tensorflow.distruntime.ServerDef
 
parser() - Static method in class org.tensorflow.example.BytesList
 
parser() - Static method in class org.tensorflow.example.Example
 
parser() - Static method in class org.tensorflow.example.ExampleParserConfiguration
 
parser() - Static method in class org.tensorflow.example.Feature
 
parser() - Static method in class org.tensorflow.example.FeatureConfiguration
 
parser() - Static method in class org.tensorflow.example.FeatureList
 
parser() - Static method in class org.tensorflow.example.FeatureLists
 
parser() - Static method in class org.tensorflow.example.Features
 
parser() - Static method in class org.tensorflow.example.FixedLenFeatureProto
 
parser() - Static method in class org.tensorflow.example.FloatList
 
parser() - Static method in class org.tensorflow.example.Int64List
 
parser() - Static method in class org.tensorflow.example.SequenceExample
 
parser() - Static method in class org.tensorflow.example.VarLenFeatureProto
 
parser() - Static method in class org.tensorflow.framework.AllocationDescription
 
parser() - Static method in class org.tensorflow.framework.AllocationRecord
 
parser() - Static method in class org.tensorflow.framework.AllocatorMemoryUsed
 
parser() - Static method in class org.tensorflow.framework.ApiDef.Arg
 
parser() - Static method in class org.tensorflow.framework.ApiDef.Attr
 
parser() - Static method in class org.tensorflow.framework.ApiDef.Endpoint
 
parser() - Static method in class org.tensorflow.framework.ApiDef
 
parser() - Static method in class org.tensorflow.framework.ApiDefs
 
parser() - Static method in class org.tensorflow.framework.AssetFileDef
 
parser() - Static method in class org.tensorflow.framework.AttrValue.ListValue
 
parser() - Static method in class org.tensorflow.framework.AttrValue
 
parser() - Static method in class org.tensorflow.framework.AutoParallelOptions
 
parser() - Static method in class org.tensorflow.framework.CallableOptions
 
parser() - Static method in class org.tensorflow.framework.CollectionDef.AnyList
 
parser() - Static method in class org.tensorflow.framework.CollectionDef.BytesList
 
parser() - Static method in class org.tensorflow.framework.CollectionDef.FloatList
 
parser() - Static method in class org.tensorflow.framework.CollectionDef.Int64List
 
parser() - Static method in class org.tensorflow.framework.CollectionDef.NodeList
 
parser() - Static method in class org.tensorflow.framework.CollectionDef
 
parser() - Static method in class org.tensorflow.framework.CondContextDef
 
parser() - Static method in class org.tensorflow.framework.ConfigProto.Experimental
 
parser() - Static method in class org.tensorflow.framework.ConfigProto
 
parser() - Static method in class org.tensorflow.framework.ControlFlowContextDef
 
parser() - Static method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
parser() - Static method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
parser() - Static method in class org.tensorflow.framework.CostGraphDef.Node
 
parser() - Static method in class org.tensorflow.framework.CostGraphDef
 
parser() - Static method in class org.tensorflow.framework.DebuggedSourceFile
 
parser() - Static method in class org.tensorflow.framework.DebuggedSourceFiles
 
parser() - Static method in class org.tensorflow.framework.DebugOptions
 
parser() - Static method in class org.tensorflow.framework.DebugTensorWatch
 
parser() - Static method in class org.tensorflow.framework.DeviceAttributes
 
parser() - Static method in class org.tensorflow.framework.DeviceLocality
 
parser() - Static method in class org.tensorflow.framework.DeviceStepStats
 
parser() - Static method in class org.tensorflow.framework.FunctionDef
 
parser() - Static method in class org.tensorflow.framework.FunctionDefLibrary
 
parser() - Static method in class org.tensorflow.framework.GPUOptions.Experimental
 
parser() - Static method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
parser() - Static method in class org.tensorflow.framework.GPUOptions
 
parser() - Static method in class org.tensorflow.framework.GradientDef
 
parser() - Static method in class org.tensorflow.framework.GraphDef
 
parser() - Static method in class org.tensorflow.framework.GraphOptions
 
parser() - Static method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
parser() - Static method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
parser() - Static method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
parser() - Static method in class org.tensorflow.framework.GraphTransferInfo
 
parser() - Static method in class org.tensorflow.framework.GraphTransferNodeInfo
 
parser() - Static method in class org.tensorflow.framework.GraphTransferNodeInput
 
parser() - Static method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
parser() - Static method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
parser() - Static method in class org.tensorflow.framework.HistogramProto
 
parser() - Static method in class org.tensorflow.framework.InterconnectLink
 
parser() - Static method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
parser() - Static method in class org.tensorflow.framework.KernelDef
 
parser() - Static method in class org.tensorflow.framework.KernelList
 
parser() - Static method in class org.tensorflow.framework.LocalLinks
 
parser() - Static method in class org.tensorflow.framework.MemoryLogRawAllocation
 
parser() - Static method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
parser() - Static method in class org.tensorflow.framework.MemoryLogStep
 
parser() - Static method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
parser() - Static method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
parser() - Static method in class org.tensorflow.framework.MemoryLogTensorOutput
 
parser() - Static method in class org.tensorflow.framework.MemoryStats
 
parser() - Static method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
parser() - Static method in class org.tensorflow.framework.MetaGraphDef
 
parser() - Static method in class org.tensorflow.framework.NameAttrList
 
parser() - Static method in class org.tensorflow.framework.NamedTensorProto
 
parser() - Static method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
parser() - Static method in class org.tensorflow.framework.NodeDef
 
parser() - Static method in class org.tensorflow.framework.NodeExecStats
 
parser() - Static method in class org.tensorflow.framework.NodeOutput
 
parser() - Static method in class org.tensorflow.framework.OpDef.ArgDef
 
parser() - Static method in class org.tensorflow.framework.OpDef.AttrDef
 
parser() - Static method in class org.tensorflow.framework.OpDef
 
parser() - Static method in class org.tensorflow.framework.OpDeprecation
 
parser() - Static method in class org.tensorflow.framework.OpList
 
parser() - Static method in class org.tensorflow.framework.OptimizerOptions
 
parser() - Static method in class org.tensorflow.framework.QueueRunnerDef
 
parser() - Static method in class org.tensorflow.framework.ReaderBaseState
 
parser() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
parser() - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
parser() - Static method in class org.tensorflow.framework.ResourceHandleProto
 
parser() - Static method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
parser() - Static method in class org.tensorflow.framework.RewriterConfig
 
parser() - Static method in class org.tensorflow.framework.RPCOptions
 
parser() - Static method in class org.tensorflow.framework.RunMetadata
 
parser() - Static method in class org.tensorflow.framework.RunOptions.Experimental
 
parser() - Static method in class org.tensorflow.framework.RunOptions
 
parser() - Static method in class org.tensorflow.framework.SavedModel
 
parser() - Static method in class org.tensorflow.framework.SaveSliceInfoDef
 
parser() - Static method in class org.tensorflow.framework.ScopedAllocatorOptions
 
parser() - Static method in class org.tensorflow.framework.SignatureDef
 
parser() - Static method in class org.tensorflow.framework.StepStats
 
parser() - Static method in class org.tensorflow.framework.Summary.Audio
 
parser() - Static method in class org.tensorflow.framework.Summary.Image
 
parser() - Static method in class org.tensorflow.framework.Summary
 
parser() - Static method in class org.tensorflow.framework.Summary.Value
 
parser() - Static method in class org.tensorflow.framework.SummaryDescription
 
parser() - Static method in class org.tensorflow.framework.SummaryMetadata
 
parser() - Static method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
parser() - Static method in class org.tensorflow.framework.TensorConnection
 
parser() - Static method in class org.tensorflow.framework.TensorDescription
 
parser() - Static method in class org.tensorflow.framework.TensorInfo.CooSparse
 
parser() - Static method in class org.tensorflow.framework.TensorInfo
 
parser() - Static method in class org.tensorflow.framework.TensorProto
 
parser() - Static method in class org.tensorflow.framework.TensorShapeProto.Dim
 
parser() - Static method in class org.tensorflow.framework.TensorShapeProto
 
parser() - Static method in class org.tensorflow.framework.TensorSliceProto.Extent
 
parser() - Static method in class org.tensorflow.framework.TensorSliceProto
 
parser() - Static method in class org.tensorflow.framework.ThreadPoolOptionProto
 
parser() - Static method in class org.tensorflow.framework.ValuesDef
 
parser() - Static method in class org.tensorflow.framework.VariableDef
 
parser() - Static method in class org.tensorflow.framework.VariantTensorDataProto
 
parser() - Static method in class org.tensorflow.framework.VersionDef
 
parser() - Static method in class org.tensorflow.framework.WhileContextDef
 
parser() - Static method in class org.tensorflow.util.BundleEntryProto
 
parser() - Static method in class org.tensorflow.util.BundleHeaderProto
 
parser() - Static method in class org.tensorflow.util.Event
 
parser() - Static method in class org.tensorflow.util.IteratorStateMetadata
 
parser() - Static method in class org.tensorflow.util.LogMessage
 
parser() - Static method in class org.tensorflow.util.SavedSlice
 
parser() - Static method in class org.tensorflow.util.SavedSliceMeta
 
parser() - Static method in class org.tensorflow.util.SavedTensorSliceMeta
 
parser() - Static method in class org.tensorflow.util.SavedTensorSlices
 
parser() - Static method in class org.tensorflow.util.SaverDef
 
parser() - Static method in class org.tensorflow.util.SessionLog
 
parser() - Static method in class org.tensorflow.util.TaggedRunMetadata
 
parser() - Static method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
parser() - Static method in class org.tensorflow.util.testlog.BenchmarkEntries
 
parser() - Static method in class org.tensorflow.util.testlog.BenchmarkEntry
 
parser() - Static method in class org.tensorflow.util.testlog.BuildConfiguration
 
parser() - Static method in class org.tensorflow.util.testlog.CommitId
 
parser() - Static method in class org.tensorflow.util.testlog.CPUInfo
 
parser() - Static method in class org.tensorflow.util.testlog.EntryValue
 
parser() - Static method in class org.tensorflow.util.testlog.GPUInfo
 
parser() - Static method in class org.tensorflow.util.testlog.MachineConfiguration
 
parser() - Static method in class org.tensorflow.util.testlog.MemoryInfo
 
parser() - Static method in class org.tensorflow.util.testlog.PlatformInfo
 
parser() - Static method in class org.tensorflow.util.testlog.RunConfiguration
 
parser() - Static method in class org.tensorflow.util.testlog.TestResults
 
parser() - Static method in class org.tensorflow.util.WatchdogConfig
 
parser() - Static method in class org.tensorflow.util.WorkerHeartbeatRequest
 
parser() - Static method in class org.tensorflow.util.WorkerHeartbeatResponse
 
parser() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
parser() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
parser() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
parser() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
parser() - Static method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
parser() - Static method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
parser() - Static method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
parser() - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
parser() - Static method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
parser() - Static method in class tensorflow.TransportOptions.RecvBufRespExtra
 
PARTITION_GRAPHS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunMetadata
 
PEAK_BYTES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocatorMemoryUsed
 
PENDING_CHANGELIST_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.CommitId
 
PER_PROCESS_GPU_MEMORY_FRACTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions
 
PERMISSION_DENIED_VALUE - Static variable in enum org.tensorflow.framework.Code
The caller does not have permission to execute the specified operation.
PERSISTENT_MEMORY_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
PERSISTENT_MEMORY_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryStats
 
PERSISTENT_TENSOR_ALLOC_IDS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryStats
 
PHYSICAL_DESCRIPTION_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
PHYSICAL_DEVICE_DESC_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DeviceAttributes
 
PIN_TO_HOST_OPTIMIZATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
PIVOT_FOR_BODY_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
PIVOT_FOR_PRED_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
PIVOT_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CondContextDef
 
PIVOT_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
PLACE_PRUNED_GRAPH_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphOptions
 
PLACEHOLDER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue
 
PLACEMENT_PERIOD_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
PLATFORM_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.MachineConfiguration
 
PlatformInfo - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.PlatformInfo
PlatformInfo.Builder - Class in org.tensorflow.util.testlog
Protobuf type tensorflow.PlatformInfo
PlatformInfoOrBuilder - Interface in org.tensorflow.util.testlog
 
PLUGIN_DATA_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SummaryMetadata
 
PLUGIN_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SummaryMetadata.PluginData
 
POLLING_ACTIVE_DELAY_USECS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions
 
POLLING_INACTIVE_DELAY_MSECS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions
 
PRECEDING_NODE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
PRECEDING_PORT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
PRED_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CondContextDef
 
PRIORITY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.KernelDef
 
PRODUCER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VersionDef
 
PROPERTIES_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.NamedDevice
 
PROTOCOL_FIELD_NUMBER - Static variable in class org.tensorflow.distruntime.ServerDef
 
PTR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocationDescription
 
PTR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawAllocation
 
putAllAttr(Map<String, AttrValue>) - Method in class org.tensorflow.framework.FunctionDef.Builder
Attributes specific to this function definition.
putAllAttr(Map<String, AttrValue>) - Method in class org.tensorflow.framework.NameAttrList.Builder
map<string, .tensorflow.AttrValue> attr = 2;
putAllAttr(Map<String, AttrValue>) - Method in class org.tensorflow.framework.NodeDef.Builder
Operation-specific graph-construction-time configuration.
putAllCacheSize(Map<String, Long>) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Cache sizes (in bytes), e.g.
putAllCollectionDef(Map<String, CollectionDef>) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
collection_def: Map from collection name to collections.
putAllDeviceCount(Map<String, Integer>) - Method in class org.tensorflow.framework.ConfigProto.Builder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
putAllEnvironment(Map<String, String>) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Version of the tools and libraries used with this device (e.g.
putAllExternalValues(Map<String, String>) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names referenced by but external to this context.
putAllExtras(Map<String, EntryValue>) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Generic map from result key to value.
putAllFeature(Map<String, Feature>) - Method in class org.tensorflow.example.Features.Builder
Map from feature name to feature.
putAllFeatureList(Map<String, FeatureList>) - Method in class org.tensorflow.example.FeatureLists.Builder
Map from feature name to feature list.
putAllFeatureMap(Map<String, FeatureConfiguration>) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
putAllFeedDevices(Map<String, String>) - Method in class org.tensorflow.framework.CallableOptions.Builder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
putAllFetchDevices(Map<String, String>) - Method in class org.tensorflow.framework.CallableOptions.Builder
map<string, string> fetch_devices = 7;
putAllInputs(Map<String, TensorInfo>) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named input parameters.
putAllOutputs(Map<String, TensorInfo>) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named output parameters.
putAllParameterMap(Map<String, AttrValue>) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
map<string, .tensorflow.AttrValue> parameter_map = 2;
putAllRet(Map<String, String>) - Method in class org.tensorflow.framework.FunctionDef.Builder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
putAllSignatureDef(Map<String, SignatureDef>) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
putAllTasks(Map<Integer, String>) - Method in class org.tensorflow.distruntime.JobDef.Builder
Mapping from task ID to "hostname:port" string.
putAttr(String, AttrValue) - Method in class org.tensorflow.framework.FunctionDef.Builder
Attributes specific to this function definition.
putAttr(String, AttrValue) - Method in class org.tensorflow.framework.NameAttrList.Builder
map<string, .tensorflow.AttrValue> attr = 2;
putAttr(String, AttrValue) - Method in class org.tensorflow.framework.NodeDef.Builder
Operation-specific graph-construction-time configuration.
putCacheSize(String, long) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Cache sizes (in bytes), e.g.
putCollectionDef(String, CollectionDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
collection_def: Map from collection name to collections.
putDeviceCount(String, int) - Method in class org.tensorflow.framework.ConfigProto.Builder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
putEnvironment(String, String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Version of the tools and libraries used with this device (e.g.
putExternalValues(String, String) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names referenced by but external to this context.
putExtras(String, EntryValue) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Generic map from result key to value.
putFeature(String, Feature) - Method in class org.tensorflow.example.Features.Builder
Map from feature name to feature.
putFeatureList(String, FeatureList) - Method in class org.tensorflow.example.FeatureLists.Builder
Map from feature name to feature list.
putFeatureMap(String, FeatureConfiguration) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
putFeedDevices(String, String) - Method in class org.tensorflow.framework.CallableOptions.Builder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
putFetchDevices(String, String) - Method in class org.tensorflow.framework.CallableOptions.Builder
map<string, string> fetch_devices = 7;
putInputs(String, TensorInfo) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named input parameters.
putOutputs(String, TensorInfo) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named output parameters.
putParameterMap(String, AttrValue) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
map<string, .tensorflow.AttrValue> parameter_map = 2;
putRet(String, String) - Method in class org.tensorflow.framework.FunctionDef.Builder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
putSignatureDef(String, SignatureDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
putTasks(int, String) - Method in class org.tensorflow.distruntime.JobDef.Builder
Mapping from task ID to "hostname:port" string.
PYTHON_BENCHMARK_VALUE - Static variable in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
PYTHON_BENCHMARK = 2;

Q

QUEUE_CLOSED_EXCEPTION_TYPES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.QueueRunnerDef
 
QUEUE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.QueueRunnerDef
 
QueueRunnerDef - Class in org.tensorflow.framework
Protocol buffer representing a QueueRunner.
QueueRunnerDef.Builder - Class in org.tensorflow.framework
Protocol buffer representing a QueueRunner.
QueueRunnerDefOrBuilder - Interface in org.tensorflow.framework
 
QueueRunnerProtos - Class in org.tensorflow.framework
 

R

ReaderBaseProtos - Class in org.tensorflow.framework
 
ReaderBaseState - Class in org.tensorflow.framework
For serializing and restoring the state of ReaderBase, see reader_base.h for details.
ReaderBaseState.Builder - Class in org.tensorflow.framework
For serializing and restoring the state of ReaderBase, see reader_base.h for details.
ReaderBaseStateOrBuilder - Interface in org.tensorflow.framework
 
RECEIVED_SHUTDOWN_SIGNAL_VALUE - Static variable in enum org.tensorflow.util.WorkerHealth
RECEIVED_SHUTDOWN_SIGNAL = 1;
RECOMPUTATION_HEURISTICS_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.MemOptType
Recomputation heuristics will recompute ops (such as Relu activation) during backprop instead of storing them, reducing peak memory usage.
RECV_BUF_MAX_CHUNK_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto.Experimental
 
REFERENCED_TENSOR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ClusterProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.distruntime.ClusterProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.distruntime.ServerProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.distruntime.ServerProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.example.ExampleParserConfigurationProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.example.ExampleParserConfigurationProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.example.ExampleProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.example.ExampleProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.example.FeatureProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.example.FeatureProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AllocationDescriptionProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.AllocationDescriptionProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ApiDefProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.ApiDefProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.AttrValueProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.AttrValueProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ConfigProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.ConfigProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ControlFlowProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.ControlFlowProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.CostGraphProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.CostGraphProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DebugProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.DebugProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.DeviceAttributesProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.DeviceAttributesProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ErrorCodesProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.ErrorCodesProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.FunctionProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.FunctionProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.GraphProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.GraphTransferInfoProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.GraphTransferInfoProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.KernelDefProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.KernelDefProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.LogMemoryProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.LogMemoryProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.MetaGraphProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.MetaGraphProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NamedTensorProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.NamedTensorProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.NodeProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.NodeProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.OpDefProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.OpDefProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.QueueRunnerProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.QueueRunnerProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ReaderBaseProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.ReaderBaseProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfoProto
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfoProto
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.ResourceHandle
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.ResourceHandle
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.RewriterConfigProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.RewriterConfigProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SavedModelProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.SavedModelProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.StepStatsProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.StepStatsProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.SummaryProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.SummaryProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorDescriptionProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.TensorDescriptionProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.TensorProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorShapeProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.TensorShapeProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TensorSliceProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.TensorSliceProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.TypesProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.TypesProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VariableProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.VariableProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.framework.VersionsProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.framework.VersionsProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.util.EventProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.util.EventProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.util.IteratorProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.util.IteratorProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.util.SavedTensorSliceProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.util.SavedTensorSliceProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.util.SaverProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.util.SaverProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.util.TensorBundleProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.util.TensorBundleProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class org.tensorflow.util.testlog.TestLogProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class org.tensorflow.util.testlog.TestLogProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass
 
registerAllExtensions(ExtensionRegistry) - Static method in class tensorflow.CheckpointableObjectGraphOuterClass
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class tensorflow.DevicePropertiesProtos
 
registerAllExtensions(ExtensionRegistry) - Static method in class tensorflow.DevicePropertiesProtos
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class tensorflow.MemmappedFileSystem
 
registerAllExtensions(ExtensionRegistry) - Static method in class tensorflow.MemmappedFileSystem
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class tensorflow.TransportOptions
 
registerAllExtensions(ExtensionRegistry) - Static method in class tensorflow.TransportOptions
 
RELEASE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.PlatformInfo
 
REMAPPING_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
REMOTE_GRAPH_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
RemoteFusedGraphExecuteInfo - Class in org.tensorflow.framework
Protocol buffer representing a handle to a tensorflow resource.
RemoteFusedGraphExecuteInfo.Builder - Class in org.tensorflow.framework
Protocol buffer representing a handle to a tensorflow resource.
RemoteFusedGraphExecuteInfo.TensorShapeTypeProto - Class in org.tensorflow.framework
Protobuf type tensorflow.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
RemoteFusedGraphExecuteInfo.TensorShapeTypeProtoOrBuilder - Interface in org.tensorflow.framework
 
RemoteFusedGraphExecuteInfoOrBuilder - Interface in org.tensorflow.framework
 
RemoteFusedGraphExecuteInfoProto - Class in org.tensorflow.framework
 
removeAllocationRecords(int) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
removeAssetFileDef(int) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
removeAttr(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
removeAttr(String) - Method in class org.tensorflow.framework.FunctionDef.Builder
Attributes specific to this function definition.
removeAttr(String) - Method in class org.tensorflow.framework.NameAttrList.Builder
map<string, .tensorflow.AttrValue> attr = 2;
removeAttr(String) - Method in class org.tensorflow.framework.NodeDef.Builder
Operation-specific graph-construction-time configuration.
removeAttr(int) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
removeAttributes(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
removeAvailableDeviceInfo(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
removeCacheSize(String) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Cache sizes (in bytes), e.g.
removeChildren(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
removeCollectionDef(String) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
collection_def: Map from collection name to collections.
removeConstNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
removeConstraint(int) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
removeCustomOptimizers(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
removeDebugTensorWatchOpts(int) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
removeDefaultGraphInputTensorShape(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
removeDefaultGraphOutputTensorShape(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
removeDeviceCount(String) - Method in class org.tensorflow.framework.ConfigProto.Builder
Map from device type name (e.g., "CPU" or "GPU" ) to maximum number of devices of that type to use.
removeDeviceInfo(int) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
removeDevStats(int) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
removeDim(int) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
removeElement(int) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
removeEndpoint(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
removeEntry(int) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
removeEnvironment(String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Version of the tools and libraries used with this device (e.g.
removeExtent(int) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
removeExternalValues(String) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names referenced by but external to this context.
removeExtras(String) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Generic map from result key to value.
removeFeature(int) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
removeFeature(String) - Method in class org.tensorflow.example.Features.Builder
Map from feature name to feature.
removeFeatureList(String) - Method in class org.tensorflow.example.FeatureLists.Builder
Map from feature name to feature list.
removeFeatureMap(String) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
map<string, .tensorflow.FeatureConfiguration> feature_map = 1;
removeFeedDevices(String) - Method in class org.tensorflow.framework.CallableOptions.Builder
The Tensor objects fed in the callable and fetched from the callable are expected to be backed by host (CPU) memory by default.
removeFetchDevices(String) - Method in class org.tensorflow.framework.CallableOptions.Builder
map<string, string> fetch_devices = 7;
removeFunc(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
removeFunction(int) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
removeGradient(int) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
removeGraphInputNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
removeGraphOutputNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
removeInArg(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
removeInputArg(int) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
removeInputInfo(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
removeInputs(String) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named input parameters.
removeJob(int) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
removeKernel(int) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
removeLink(int) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
removeMemory(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
removeMetaGraphs(int) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
removeNestedContexts(int) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
removeNestedContexts(int) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
removeNode(int) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
removeNode(int) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
removeNodeDef(int) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
removeNodeInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
removeNodeInput(int) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
removeNodeInputInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
removeNodeOutputInfo(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
removeNodes(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
removeNodeStats(int) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
removeOp(int) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
removeOp(int) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
removeOutArg(int) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
removeOutput(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
removeOutputArg(int) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
removeOutputInfo(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
removeOutputs(String) - Method in class org.tensorflow.framework.SignatureDef.Builder
Named output parameters.
removeParameterMap(String) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
map<string, .tensorflow.AttrValue> parameter_map = 2;
removePartitionGraphs(int) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
removeReferencedTensor(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
removeResourceHandleVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
removeRet(String) - Method in class org.tensorflow.framework.FunctionDef.Builder
A mapping from the output arg names from `signature` to the outputs from `node_def` that should be returned by the function.
removeSessionInterOpThreadPool(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
removeShape(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
removeSignatureDef(String) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
signature_def: Map from user supplied key for a signature to a single SignatureDef.
removeSlice(int) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
removeSlices(int) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
removeSlotVariables(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
removeSourceFiles(int) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
removeTasks(int) - Method in class org.tensorflow.distruntime.JobDef.Builder
Mapping from task ID to "hostname:port" string.
removeTensor(int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
removeTensor(int) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
removeTensorConnection(int) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
removeTensors(int) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
removeValue(int) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
removeValue(int) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
removeVariantVal(int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
removeVirtualDevices(int) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
removeWorkerLog(int) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
RENAME_TO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef.Arg
 
RENAME_TO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef.Attr
 
REPORT_TENSOR_ALLOCATIONS_UPON_OOM_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunOptions
 
REQUESTED_BYTES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocationDescription
 
RESET_DISK_BYTE_USAGE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebugOptions
 
RESOURCE_EXHAUSTED_VALUE - Static variable in enum org.tensorflow.framework.Code
Some resource has been exhausted, perhaps a per-user quota, or perhaps the entire file system is out of space.
RESOURCE_HANDLE_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
ResourceHandle - Class in org.tensorflow.framework
 
ResourceHandleProto - Class in org.tensorflow.framework
Protocol buffer representing a handle to a tensorflow resource.
ResourceHandleProto.Builder - Class in org.tensorflow.framework
Protocol buffer representing a handle to a tensorflow resource.
ResourceHandleProtoOrBuilder - Interface in org.tensorflow.framework
 
RESTORE_OP_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.util.SaverDef
 
RET_FIELD_NUMBER - Static variable in class org.tensorflow.framework.FunctionDef
 
REWRITE_OPTIONS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphOptions
 
RewriterConfig - Class in org.tensorflow.framework
Graph rewriting is experimental and subject to change, not covered by any API stability guarantees.
RewriterConfig.Builder - Class in org.tensorflow.framework
Graph rewriting is experimental and subject to change, not covered by any API stability guarantees.
RewriterConfig.CustomGraphOptimizer - Class in org.tensorflow.framework
Message to describe custom graph optimizer and its parameters
RewriterConfig.CustomGraphOptimizer.Builder - Class in org.tensorflow.framework
Message to describe custom graph optimizer and its parameters
RewriterConfig.CustomGraphOptimizerOrBuilder - Interface in org.tensorflow.framework
 
RewriterConfig.MemOptType - Enum in org.tensorflow.framework
Protobuf enum tensorflow.RewriterConfig.MemOptType
RewriterConfig.NumIterationsType - Enum in org.tensorflow.framework
Enum controlling the number of times to run optimizers.
RewriterConfig.Toggle - Enum in org.tensorflow.framework
Protobuf enum tensorflow.RewriterConfig.Toggle
RewriterConfigOrBuilder - Interface in org.tensorflow.framework
 
RewriterConfigProtos - Class in org.tensorflow.framework
 
RPC_OPTIONS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
RPCOptions - Class in org.tensorflow.framework
Protobuf type tensorflow.RPCOptions
RPCOptions.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.RPCOptions
RPCOptionsOrBuilder - Interface in org.tensorflow.framework
 
RUN_CONFIGURATION_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
RUN_METADATA_FIELD_NUMBER - Static variable in class org.tensorflow.util.TaggedRunMetadata
 
RUN_MODE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
RUN_OPTIONS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CallableOptions
 
RUN_TIME_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
RunConfiguration - Class in org.tensorflow.util.testlog
Run-specific items such as arguments to the test / benchmark.
RunConfiguration.Builder - Class in org.tensorflow.util.testlog
Run-specific items such as arguments to the test / benchmark.
RunConfigurationOrBuilder - Interface in org.tensorflow.util.testlog
 
RunMetadata - Class in org.tensorflow.framework
Metadata output (i.e., non-Tensor) for a single Run() call.
RunMetadata.Builder - Class in org.tensorflow.framework
Metadata output (i.e., non-Tensor) for a single Run() call.
RunMetadataOrBuilder - Interface in org.tensorflow.framework
 
RunOptions - Class in org.tensorflow.framework
Options for a single Run() call.
RunOptions.Builder - Class in org.tensorflow.framework
Options for a single Run() call.
RunOptions.Experimental - Class in org.tensorflow.framework
Everything inside Experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
RunOptions.Experimental.Builder - Class in org.tensorflow.framework
Everything inside Experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
RunOptions.ExperimentalOrBuilder - Interface in org.tensorflow.framework
 
RunOptions.TraceLevel - Enum in org.tensorflow.framework
TODO(pbar) Turn this into a TraceOptions proto which allows tracing to be controlled in a more orthogonal manner?
RunOptionsOrBuilder - Interface in org.tensorflow.framework
 

S

S_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue.ListValue
 
S_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue
 
SAMPLE_RATE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Audio
 
SAVE_SLICE_INFO_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VariableDef
 
SAVE_TENSOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.util.SaverDef
 
SAVED_MODEL_SCHEMA_VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SavedModel
 
SavedModel - Class in org.tensorflow.framework
SavedModel is the high level serialization format for TensorFlow Models.
SavedModel.Builder - Class in org.tensorflow.framework
SavedModel is the high level serialization format for TensorFlow Models.
SavedModelOrBuilder - Interface in org.tensorflow.framework
 
SavedModelProtos - Class in org.tensorflow.framework
 
SavedSlice - Class in org.tensorflow.util
Saved tensor slice: it stores the name of the tensors, the slice, and the raw data.
SavedSlice.Builder - Class in org.tensorflow.util
Saved tensor slice: it stores the name of the tensors, the slice, and the raw data.
SavedSliceMeta - Class in org.tensorflow.util
Metadata describing the set of slices of the same tensor saved in a checkpoint file.
SavedSliceMeta.Builder - Class in org.tensorflow.util
Metadata describing the set of slices of the same tensor saved in a checkpoint file.
SavedSliceMetaOrBuilder - Interface in org.tensorflow.util
 
SavedSliceOrBuilder - Interface in org.tensorflow.util
 
SavedTensorSliceMeta - Class in org.tensorflow.util
Metadata describing the set of tensor slices saved in a checkpoint file.
SavedTensorSliceMeta.Builder - Class in org.tensorflow.util
Metadata describing the set of tensor slices saved in a checkpoint file.
SavedTensorSliceMetaOrBuilder - Interface in org.tensorflow.util
 
SavedTensorSliceProtos - Class in org.tensorflow.util
 
SavedTensorSlices - Class in org.tensorflow.util
Each record in a v3 checkpoint file is a serialized SavedTensorSlices message.
SavedTensorSlices.Builder - Class in org.tensorflow.util
Each record in a v3 checkpoint file is a serialized SavedTensorSlices message.
SavedTensorSlicesOrBuilder - Interface in org.tensorflow.util
 
SAVER_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef
 
SaverDef - Class in org.tensorflow.util
Protocol buffer representing the configuration of a Saver.
SaverDef.Builder - Class in org.tensorflow.util
Protocol buffer representing the configuration of a Saver.
SaverDef.CheckpointFormatVersion - Enum in org.tensorflow.util
A version number that identifies a different on-disk checkpoint format.
SaverDefOrBuilder - Interface in org.tensorflow.util
 
SaverProtos - Class in org.tensorflow.util
 
SaveSliceInfoDef - Class in org.tensorflow.framework
Protobuf type tensorflow.SaveSliceInfoDef
SaveSliceInfoDef.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.SaveSliceInfoDef
SaveSliceInfoDefOrBuilder - Interface in org.tensorflow.framework
 
SCHEDULED_MICROS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
SCHEDULED_NANOS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
SCHEDULING_HEURISTICS_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.MemOptType
Scheduling will split big ops such as AddN and try to enforce a schedule of the new computations that decreases peak memory usage.
SCOMPLEX_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
SCOPED_ALLOCATOR_OPTIMIZATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
SCOPED_ALLOCATOR_OPTS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
ScopedAllocatorOptions - Class in org.tensorflow.framework
Protobuf type tensorflow.ScopedAllocatorOptions
ScopedAllocatorOptions.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.ScopedAllocatorOptions
ScopedAllocatorOptionsOrBuilder - Interface in org.tensorflow.framework
 
SequenceExample - Class in org.tensorflow.example
Protobuf type tensorflow.SequenceExample
SequenceExample.Builder - Class in org.tensorflow.example
Protobuf type tensorflow.SequenceExample
SequenceExampleOrBuilder - Interface in org.tensorflow.example
 
SERIAL_IDENTIFIER_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.MachineConfiguration
 
SERIALIZED_EXECUTOR_PARAMETERS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
ServerDef - Class in org.tensorflow.distruntime
Defines the configuration of a single TensorFlow server.
ServerDef.Builder - Class in org.tensorflow.distruntime
Defines the configuration of a single TensorFlow server.
ServerDefOrBuilder - Interface in org.tensorflow.distruntime
 
ServerProtos - Class in org.tensorflow.distruntime
 
SESSION_INTER_OP_THREAD_POOL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
SESSION_LOG_FIELD_NUMBER - Static variable in class org.tensorflow.util.Event
 
SessionLog - Class in org.tensorflow.util
Protocol buffer used for logging session state.
SessionLog.Builder - Class in org.tensorflow.util
Protocol buffer used for logging session state.
SessionLog.SessionStatus - Enum in org.tensorflow.util
Protobuf enum tensorflow.SessionLog.SessionStatus
SessionLogOrBuilder - Interface in org.tensorflow.util
 
setAliasInputPort(long) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
If >= 0, the output is an alias of an input.
setAllEndRelMicros(long) - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_end_rel_micros = 5;
setAllEndRelNanos(long) - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_end_rel_nanos = 16;
setAllocatedBytes(long) - Method in class org.tensorflow.framework.AllocationDescription.Builder
Total number of bytes allocated if known
setAllocationDescription(AllocationDescription) - Method in class org.tensorflow.framework.TensorDescription.Builder
Information about the size and allocator used for the data
setAllocationDescription(AllocationDescription.Builder) - Method in class org.tensorflow.framework.TensorDescription.Builder
Information about the size and allocator used for the data
setAllocationId(long) - Method in class org.tensorflow.framework.AllocationDescription.Builder
Identifier of the allocated buffer if known
setAllocationId(long) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Id of the tensor buffer being allocated, used to match to a corresponding deallocation.
setAllocationId(long) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Id of the tensor buffer being deallocated, used to match to a corresponding allocation.
setAllocationId(long) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
Id of the tensor buffer being deallocated, used to match to a corresponding allocation.
setAllocationRecords(int, AllocationRecord) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
setAllocationRecords(int, AllocationRecord.Builder) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The allocation and deallocation timeline.
setAllocatorBytesInUse(long) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
These are snapshots of the overall allocator memory stats.
setAllocatorName(String) - Method in class org.tensorflow.framework.AllocationDescription.Builder
Name of the allocator used
setAllocatorName(String) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
string allocator_name = 1;
setAllocatorName(String) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Name of the allocator used.
setAllocatorName(String) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Name of the allocator used.
setAllocatorName(String) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
Name of the allocator used.
setAllocatorNameBytes(ByteString) - Method in class org.tensorflow.framework.AllocationDescription.Builder
Name of the allocator used
setAllocatorNameBytes(ByteString) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
string allocator_name = 1;
setAllocatorNameBytes(ByteString) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Name of the allocator used.
setAllocatorNameBytes(ByteString) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Name of the allocator used.
setAllocatorNameBytes(ByteString) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
Name of the allocator used.
setAllocatorType(String) - Method in class org.tensorflow.framework.GPUOptions.Builder
The type of GPU allocation strategy to use.
setAllocatorTypeBytes(ByteString) - Method in class org.tensorflow.framework.GPUOptions.Builder
The type of GPU allocation strategy to use.
setAllocBytes(long) - Method in class org.tensorflow.framework.AllocationRecord.Builder
Number of bytes allocated, or de-allocated if negative.
setAllocMicros(long) - Method in class org.tensorflow.framework.AllocationRecord.Builder
The timestamp of the operation.
setAllowedValues(AttrValue) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
A list of values that this kernel supports for this attr.
setAllowedValues(AttrValue.Builder) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
A list of values that this kernel supports for this attr.
setAllowedValues(AttrValue) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
The set of allowed values.
setAllowedValues(AttrValue.Builder) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
The set of allowed values.
setAllowGrowth(boolean) - Method in class org.tensorflow.framework.GPUOptions.Builder
If true, the allocator does not pre-allocate the entire specified GPU memory region, instead starting small and growing as needed.
setAllowSoftPlacement(boolean) - Method in class org.tensorflow.framework.ConfigProto.Builder
Whether soft placement is allowed.
setAllowsUninitializedInput(boolean) - Method in class org.tensorflow.framework.OpDef.Builder
By default, all inputs to an Op must be initialized Tensors.
setAllStartMicros(long) - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_start_micros = 2;
setAllStartNanos(long) - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 all_start_nanos = 13;
setAnyInfo(Any) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A serialized protobuf.
setAnyInfo(Any.Builder) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A serialized protobuf.
setAnyList(CollectionDef.AnyList) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.AnyList any_list = 5;
setAnyList(CollectionDef.AnyList.Builder) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.AnyList any_list = 5;
setArgOrder(int, String) - Method in class org.tensorflow.framework.ApiDef.Builder
List of original in_arg names to specify new argument order.
setArgument(int, String) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
repeated string argument = 1;
setArithmeticOptimization(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Arithmetic optimizations (default is ON) e.g.
setArithmeticOptimizationValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Arithmetic optimizations (default is ON) e.g.
setAssetFileDef(int, AssetFileDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
setAssetFileDef(int, AssetFileDef.Builder) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
Asset file def to be used with the defined graph.
setAttr(int, ApiDef.Attr) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
setAttr(int, ApiDef.Attr.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Attr attr = 6;
setAttr(int, OpDef.AttrDef) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
setAttr(int, OpDef.AttrDef.Builder) - Method in class org.tensorflow.framework.OpDef.Builder
repeated .tensorflow.OpDef.AttrDef attr = 4;
setAttributes(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
setAttributes(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Serialized data specific to this object.
setAudio(Summary.Audio) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Audio audio = 6;
setAudio(Summary.Audio.Builder) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Audio audio = 6;
setAutoParallel(AutoParallelOptions) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
setAutoParallel(AutoParallelOptions.Builder) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures AutoParallel optimization passes either through the meta-optimizer or when manually specified through the optimizers field.
setAvailable(long) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
Immediately available memory in bytes
setAvailableDeviceInfo(int, AvailableDeviceInfo) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
setAvailableDeviceInfo(int, AvailableDeviceInfo.Builder) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Devices accessible to the test (e.g.
setB(boolean) - Method in class org.tensorflow.framework.AttrValue.Builder
"bool"
setB(int, boolean) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(bool)"
setBackProp(boolean) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Whether backprop is enabled for this while loop.
setBadConsumers(int, int) - Method in class org.tensorflow.framework.VersionDef.Builder
Specific consumer versions which are disallowed (e.g.
setBandwidth(long) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Memory bandwidth in KB/s
setBenchmarkType(TestResults.BenchmarkType) - Method in class org.tensorflow.util.testlog.TestResults.Builder
.tensorflow.TestResults.BenchmarkType benchmark_type = 10;
setBenchmarkTypeValue(int) - Method in class org.tensorflow.util.testlog.TestResults.Builder
.tensorflow.TestResults.BenchmarkType benchmark_type = 10;
setBits(String) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setBitsBytes(ByteString) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setBoolVal(int, boolean) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_BOOL
setBranch(int) - Method in class org.tensorflow.framework.CondContextDef.Builder
Branch prediction.
setBucket(int, double) - Method in class org.tensorflow.framework.HistogramProto.Builder
repeated double bucket = 7 [packed = true];
setBucketLimit(int, double) - Method in class org.tensorflow.framework.HistogramProto.Builder
Parallel arrays encoding the bucket boundaries and the bucket values.
setBuildConfiguration(BuildConfiguration) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The configuration of the build (compiled opt? with cuda? any copts?)
setBuildConfiguration(BuildConfiguration.Builder) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The configuration of the build (compiled opt? with cuda? any copts?)
setBuildCostModel(long) - Method in class org.tensorflow.framework.GraphOptions.Builder
The number of steps to run before returning a cost model detailing the memory usage and performance of each node of the graph.
setBuildCostModelAfter(long) - Method in class org.tensorflow.framework.GraphOptions.Builder
The number of steps to skip before collecting statistics for the cost model.
setBusId(int) - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional bus locality of device.
setBusId(String) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
e.g.
setBusIdBytes(ByteString) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
e.g.
setBytes(long) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Byte size of the file.
setBytesList(BytesList) - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.BytesList bytes_list = 1;
setBytesList(BytesList.Builder) - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.BytesList bytes_list = 1;
setBytesList(CollectionDef.BytesList) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
setBytesList(CollectionDef.BytesList.Builder) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.BytesList bytes_list = 2;
setCancelOpName(String) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
The operation to run to cancel the queue.
setCancelOpNameBytes(ByteString) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
The operation to run to cancel the queue.
setCcFlags(int, String) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
CC compiler flags, if known
setChangelist(long) - Method in class org.tensorflow.util.testlog.CommitId.Builder
Submitted changelist.
setCheckpointKey(String) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
The generated name of the Tensor in the checkpoint.
setCheckpointKeyBytes(ByteString) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
The generated name of the Tensor in the checkpoint.
setCheckpointPath(String) - Method in class org.tensorflow.util.SessionLog.Builder
This checkpoint_path contains both the path and filename.
setCheckpointPathBytes(ByteString) - Method in class org.tensorflow.util.SessionLog.Builder
This checkpoint_path contains both the path and filename.
setChildren(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
setChildren(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Objects which this object depends on.
setCloseOpName(String) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
The operation to run to close the queue.
setCloseOpNameBytes(ByteString) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
The operation to run to close the queue.
setCluster(ClusterDef) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The cluster of which this server is a member.
setCluster(ClusterDef.Builder) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The cluster of which this server is a member.
setClusterDef(ClusterDef) - Method in class org.tensorflow.framework.ConfigProto.Builder
Optional list of all workers to use in this session.
setClusterDef(ClusterDef.Builder) - Method in class org.tensorflow.framework.ConfigProto.Builder
Optional list of all workers to use in this session.
setCollectiveGraphKey(long) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
If non-zero, declares that this graph is going to use collective ops and must synchronize step_ids with any other graph with this same group_key value (in a distributed computation where tasks run disjoint graphs).
setCollectiveGroupLeader(String) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Task name for group resolution.
setCollectiveGroupLeaderBytes(ByteString) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Task name for group resolution.
setCollectiveRingOrder(String) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If non-empty, defines a good GPU ring order on a single worker based on device interconnect.
setCollectiveRingOrderBytes(ByteString) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If non-empty, defines a good GPU ring order on a single worker based on device interconnect.
setColorspace(int) - Method in class org.tensorflow.framework.Summary.Image.Builder
Valid colorspace values are 1 - grayscale 2 - grayscale + alpha 3 - RGB 4 - RGBA 5 - DIGITAL_YUV 6 - BGRA
setCommitId(CommitId) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The commit id (git hash or changelist)
setCommitId(CommitId.Builder) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The commit id (git hash or changelist)
setCompressionAlgorithm(String) - Method in class org.tensorflow.framework.RPCOptions.Builder
The compression algorithm to be used.
setCompressionAlgorithmBytes(ByteString) - Method in class org.tensorflow.framework.RPCOptions.Builder
The compression algorithm to be used.
setCompressionLevel(int) - Method in class org.tensorflow.framework.RPCOptions.Builder
If compression_algorithm is set, the compression level to be used.
setComputeCost(long) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Estimate of the computational cost of this node, in microseconds.
setComputeTime(long) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Analytical estimate of the computational cost of this node, in microseconds.
setCondCtxt(CondContextDef) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.CondContextDef cond_ctxt = 1;
setCondCtxt(CondContextDef.Builder) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.CondContextDef cond_ctxt = 1;
setConstantFolding(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Fold constants (default is ON) Statically infer the value of tensors when possible, and materialize the result using constants.
setConstantFoldingValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Fold constants (default is ON) Statically infer the value of tensors when possible, and materialize the result using constants.
setConstNodeInfo(int, GraphTransferConstNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
setConstNodeInfo(int, GraphTransferConstNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferConstNodeInfo const_node_info = 2;
setConstraint(int, KernelDef.AttrConstraint) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
setConstraint(int, KernelDef.AttrConstraint.Builder) - Method in class org.tensorflow.framework.KernelDef.Builder
repeated .tensorflow.KernelDef.AttrConstraint constraint = 3;
setContainer(String) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Container in which this resource is placed.
setContainerBytes(ByteString) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Container in which this resource is placed.
setContent(ByteString) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
The content to store for the plugin.
setContentType(String) - Method in class org.tensorflow.framework.Summary.Audio.Builder
string content_type = 5;
setContentTypeBytes(ByteString) - Method in class org.tensorflow.framework.Summary.Audio.Builder
string content_type = 5;
setContext(Features) - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.Features context = 1;
setContext(Features.Builder) - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.Features context = 1;
setContextName(String) - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the context.
setContextName(String) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the context.
setContextNameBytes(ByteString) - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the context.
setContextNameBytes(ByteString) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the context.
setControlInput(int, int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Ids of the control inputs for this node.
setCooSparse(TensorInfo.CooSparse) - Method in class org.tensorflow.framework.TensorInfo.Builder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
setCooSparse(TensorInfo.CooSparse.Builder) - Method in class org.tensorflow.framework.TensorInfo.Builder
There are many possible encodings of sparse matrices (https://en.wikipedia.org/wiki/Sparse_matrix).
setCostGraph(CostGraphDef) - Method in class org.tensorflow.framework.RunMetadata.Builder
The cost graph for the computation defined by the run call.
setCostGraph(CostGraphDef.Builder) - Method in class org.tensorflow.framework.RunMetadata.Builder
The cost graph for the computation defined by the run call.
setCpuGovernor(String) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
What kind of cpu scaling is enabled on the host.
setCpuGovernorBytes(ByteString) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
What kind of cpu scaling is enabled on the host.
setCpuInfo(String) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Additional cpu information.
setCpuInfo(CPUInfo) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
CPU Information.
setCpuInfo(CPUInfo.Builder) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
CPU Information.
setCpuInfoBytes(ByteString) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
Additional cpu information.
setCpuTime(double) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Total cpu time used for all iterations (in seconds)
setCrc32C(int) - Method in class org.tensorflow.util.BundleEntryProto.Builder
The CRC32C checksum of the tensor bytes.
setCurrentWork(ByteString) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
bytes current_work = 4;
setCustomOptimizers(int, RewriterConfig.CustomGraphOptimizer) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
setCustomOptimizers(int, RewriterConfig.CustomGraphOptimizer.Builder) - Method in class org.tensorflow.framework.RewriterConfig.Builder
list of CustomGraphOptimizers to apply.
setData(ByteString) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
bytes data = 4;
setData(TensorProto) - Method in class org.tensorflow.util.SavedSlice.Builder
The raw data of the slice is stored as a TensorProto.
setData(TensorProto.Builder) - Method in class org.tensorflow.util.SavedSlice.Builder
The raw data of the slice is stored as a TensorProto.
setData(SavedSlice) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This exists in all but the first item of each checkpoint file.
setData(SavedSlice.Builder) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This exists in all but the first item of each checkpoint file.
setDcomplexVal(int, double) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX128.
setDebugOps(int, String) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name(s) of the debugging op(s).
setDebugOptions(DebugOptions) - Method in class org.tensorflow.framework.RunOptions.Builder
EXPERIMENTAL.
setDebugOptions(DebugOptions.Builder) - Method in class org.tensorflow.framework.RunOptions.Builder
EXPERIMENTAL.
setDebugStripper(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Strips debug-related nodes from the graph (off by default).
setDebugStripperValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Strips debug-related nodes from the graph (off by default).
setDebugTensorWatchOpts(int, DebugTensorWatch) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
setDebugTensorWatchOpts(int, DebugTensorWatch.Builder) - Method in class org.tensorflow.framework.DebugOptions.Builder
Debugging options
setDebugUrls(int, String) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
URL(s) for debug targets(s).
setDefaultGraphInputTensorShape(int, RemoteFusedGraphExecuteInfo.TensorShapeTypeProto) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
setDefaultGraphInputTensorShape(int, RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op
setDefaultGraphOutputTensorShape(int, RemoteFusedGraphExecuteInfo.TensorShapeTypeProto) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
setDefaultGraphOutputTensorShape(int, RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Default graph input tensor shape used to allocate memory before executing op TODO(satok): Remote output tensor shape once shape information is stored in NodeDef
setDefaultSessionConfig(ConfigProto) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The default configuration for sessions that run on this server.
setDefaultSessionConfig(ConfigProto.Builder) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The default configuration for sessions that run on this server.
setDefaultValue(TensorProto) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorProto default_value = 3;
setDefaultValue(TensorProto.Builder) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorProto default_value = 3;
setDefaultValue(AttrValue) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Specify a new default value to use for this attr.
setDefaultValue(AttrValue.Builder) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Specify a new default value to use for this attr.
setDefaultValue(AttrValue) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A reasonable default for this attribute if the user does not supply a value.
setDefaultValue(AttrValue.Builder) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A reasonable default for this attribute if the user does not supply a value.
setDeferred(boolean) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
True if the deallocation is queued and will be performed later, e.g.
setDeferredDeletionBytes(long) - Method in class org.tensorflow.framework.GPUOptions.Builder
Delay deletion of up to this many bytes to reduce the number of interactions with gpu driver code.
setDenseShapeTensorName(String) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The dynamic logical shape represented by the SparseTensor is recorded in the Tensor referenced here.
setDenseShapeTensorNameBytes(ByteString) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The dynamic logical shape represented by the SparseTensor is recorded in the Tensor referenced here.
setDependencyOptimization(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Control dependency optimizations (default is ON).
setDependencyOptimizationValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Control dependency optimizations (default is ON).
setDeprecated(boolean) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Set if this endpoint is deprecated.
setDeprecation(OpDeprecation) - Method in class org.tensorflow.framework.OpDef.Builder
Optional deprecation based on GraphDef versions.
setDeprecation(OpDeprecation.Builder) - Method in class org.tensorflow.framework.OpDef.Builder
Optional deprecation based on GraphDef versions.
setDeprecationMessage(String) - Method in class org.tensorflow.framework.ApiDef.Builder
If this op is deprecated, set deprecation message to the message that should be logged when this op is used.
setDeprecationMessageBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Builder
If this op is deprecated, set deprecation message to the message that should be logged when this op is used.
setDeprecationVersion(int) - Method in class org.tensorflow.framework.ApiDef.Builder
Major version when the op will be deleted.
setDeprecationVersion(int) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Major version when an endpoint will be deleted.
setDescription(String) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
Note: this will replace any inherited arg doc.
setDescription(String) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Note: this will replace any inherited attr doc, there is no current way of modifying attr descriptions as can be done with op descriptions.
setDescription(String) - Method in class org.tensorflow.framework.ApiDef.Builder
Additional, longer human-readable description of what the Op does.
setDescription(String) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Human readable description.
setDescription(String) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
Human-readable description.
setDescription(String) - Method in class org.tensorflow.framework.OpDef.Builder
Additional, longer human-readable description of what the Op does.
setDescriptionBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
Note: this will replace any inherited arg doc.
setDescriptionBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Note: this will replace any inherited attr doc, there is no current way of modifying attr descriptions as can be done with op descriptions.
setDescriptionBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Builder
Additional, longer human-readable description of what the Op does.
setDescriptionBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Human readable description.
setDescriptionBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
Human-readable description.
setDescriptionBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.Builder
Additional, longer human-readable description of what the Op does.
setDescriptionPrefix(String) - Method in class org.tensorflow.framework.ApiDef.Builder
Modify an existing/inherited description by adding text to the beginning or end.
setDescriptionPrefixBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Builder
Modify an existing/inherited description by adding text to the beginning or end.
setDescriptionSuffix(String) - Method in class org.tensorflow.framework.ApiDef.Builder
string description_suffix = 10;
setDescriptionSuffixBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Builder
string description_suffix = 10;
setDestination(GraphTransferInfo.Destination) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Destination of graph transfer
setDestinationValue(int) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Destination of graph transfer
setDevice(String) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The device of the node.
setDevice(String) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
string device = 1;
setDevice(String) - Method in class org.tensorflow.framework.NodeDef.Builder
A (possibly partial) specification for the device on which this node should be placed.
setDevice(String) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Unique name for the device containing the resource.
setDeviceBytes(ByteString) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The device of the node.
setDeviceBytes(ByteString) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
string device = 1;
setDeviceBytes(ByteString) - Method in class org.tensorflow.framework.NodeDef.Builder
A (possibly partial) specification for the device on which this node should be placed.
setDeviceBytes(ByteString) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Unique name for the device containing the resource.
setDeviceFilters(int, String) - Method in class org.tensorflow.framework.ConfigProto.Builder
When any filters are present sessions will ignore all devices which do not match the filters.
setDeviceId(int) - Method in class org.tensorflow.framework.InterconnectLink.Builder
int32 device_id = 1;
setDeviceInfo(int, Any) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
setDeviceInfo(int, Any.Builder) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Other devices that are attached and relevant (e.g.
setDevicePersistentMemorySize(long) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Deprecated.
setDevicePersistentMemorySize(long) - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
setDevicePersistentTensorAllocIds(int, long) - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
setDeviceTempMemorySize(long) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Deprecated.
setDeviceTempMemorySize(long) - Method in class org.tensorflow.framework.MemoryStats.Builder
Deprecated.
setDeviceType(String) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
String representation of device_type.
setDeviceType(String) - Method in class org.tensorflow.framework.KernelDef.Builder
Type of device this kernel runs on.
setDeviceTypeBytes(ByteString) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
String representation of device_type.
setDeviceTypeBytes(ByteString) - Method in class org.tensorflow.framework.KernelDef.Builder
Type of device this kernel runs on.
setDevStats(int, DeviceStepStats) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
setDevStats(int, DeviceStepStats.Builder) - Method in class org.tensorflow.framework.StepStats.Builder
repeated .tensorflow.DeviceStepStats dev_stats = 1;
setDim(int, TensorShapeProto.Dim) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
setDim(int, TensorShapeProto.Dim.Builder) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
Dimensions of the tensor, such as {"input", 30}, {"output", 40} for a 30 x 40 2D tensor.
setDisableMetaOptimizer(boolean) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Disable the entire meta optimizer (off by default).
setDisableModelPruning(boolean) - Method in class org.tensorflow.framework.RewriterConfig.Builder
If true, don't remove unnecessary ops from the graph
setDisplayName(String) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Display name for viewing in TensorBoard.
setDisplayNameBytes(ByteString) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Display name for viewing in TensorBoard.
setDoCommonSubexpressionElimination(boolean) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
If true, optimize the graph using common subexpression elimination.
setDoConstantFolding(boolean) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
If true, perform constant folding optimization on the graph.
setDoFunctionInlining(boolean) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
If true, perform function inlining on the graph.
setDoubleVal(int, double) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_DOUBLE.
setDoubleValue(double) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
double double_value = 1;
setDtype(DataType) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.DataType dtype = 1;
setDtype(DataType) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
.tensorflow.DataType dtype = 1;
setDtype(DataType) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.DataType dtype = 4;
setDtype(DataType) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
.tensorflow.DataType dtype = 5;
setDtype(DataType) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
.tensorflow.DataType dtype = 3;
setDtype(DataType) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
.tensorflow.DataType dtype = 3;
setDtype(DataType) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.DataType dtype = 1;
setDtype(DataType) - Method in class org.tensorflow.framework.TensorDescription.Builder
Data type of tensor elements
setDtype(DataType) - Method in class org.tensorflow.framework.TensorInfo.Builder
.tensorflow.DataType dtype = 2;
setDtype(DataType) - Method in class org.tensorflow.framework.TensorProto.Builder
.tensorflow.DataType dtype = 1;
setDtype(DataType) - Method in class org.tensorflow.util.BundleEntryProto.Builder
The tensor dtype and shape.
setDtypeValue(int) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.DataType dtype = 1;
setDtypeValue(int) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
.tensorflow.DataType dtype = 1;
setDtypeValue(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.DataType dtype = 4;
setDtypeValue(int) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
.tensorflow.DataType dtype = 5;
setDtypeValue(int) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
.tensorflow.DataType dtype = 3;
setDtypeValue(int) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
.tensorflow.DataType dtype = 3;
setDtypeValue(int) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.DataType dtype = 1;
setDtypeValue(int) - Method in class org.tensorflow.framework.TensorDescription.Builder
Data type of tensor elements
setDtypeValue(int) - Method in class org.tensorflow.framework.TensorInfo.Builder
.tensorflow.DataType dtype = 2;
setDtypeValue(int) - Method in class org.tensorflow.framework.TensorProto.Builder
.tensorflow.DataType dtype = 1;
setDtypeValue(int) - Method in class org.tensorflow.util.BundleEntryProto.Builder
The tensor dtype and shape.
setElement(int, MemmappedFileSystem.MemmappedFileSystemDirectoryElement) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
setElement(int, MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
repeated .tensorflow.MemmappedFileSystemDirectoryElement element = 1;
setEnable(boolean) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
bool enable = 1;
setEnableBfloat16Sendrecv(boolean) - Method in class org.tensorflow.framework.GraphOptions.Builder
If true, transfer float values between processes as bfloat16.
setEnableOp(int, String) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
If present, only perform optimization for these ops.
setEnableRecvScheduling(boolean) - Method in class org.tensorflow.framework.GraphOptions.Builder
If true, use control flow to schedule the activation of Recv nodes.
setEncodedAudioString(ByteString) - Method in class org.tensorflow.framework.Summary.Audio.Builder
Encoded audio data and its associated RFC 2045 content type (e.g.
setEncodedImageString(ByteString) - Method in class org.tensorflow.framework.Summary.Image.Builder
Image data in encoded format.
setEndianness(BundleHeaderProto.Endianness) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
.tensorflow.BundleHeaderProto.Endianness endianness = 2;
setEndiannessValue(int) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
.tensorflow.BundleHeaderProto.Endianness endianness = 2;
setEndpoint(int, ApiDef.Endpoint) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
setEndpoint(int, ApiDef.Endpoint.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Endpoint endpoint = 3;
setEnqueueOpName(int, String) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of enqueue operations.
setEntries(BenchmarkEntries) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The list of tests or benchmarks in this run.
setEntries(BenchmarkEntries.Builder) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The list of tests or benchmarks in this run.
setEntry(int, BenchmarkEntry) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
setEntry(int, BenchmarkEntry.Builder) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
repeated .tensorflow.BenchmarkEntry entry = 1;
setExecutorName(String) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Executor's name
setExecutorNameBytes(ByteString) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Executor's name
setExecutorType(String) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Which executor to use, the default executor will be used if it is an empty string or "DEFAULT"
setExecutorTypeBytes(ByteString) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Which executor to use, the default executor will be used if it is an empty string or "DEFAULT"
setExperimental(ConfigProto.Experimental) - Method in class org.tensorflow.framework.ConfigProto.Builder
.tensorflow.ConfigProto.Experimental experimental = 16;
setExperimental(ConfigProto.Experimental.Builder) - Method in class org.tensorflow.framework.ConfigProto.Builder
.tensorflow.ConfigProto.Experimental experimental = 16;
setExperimental(GPUOptions.Experimental) - Method in class org.tensorflow.framework.GPUOptions.Builder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
setExperimental(GPUOptions.Experimental.Builder) - Method in class org.tensorflow.framework.GPUOptions.Builder
Everything inside experimental is subject to change and is not subject to API stability guarantees in https://www.tensorflow.org/guide/version_compat.
setExperimental(RunOptions.Experimental) - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.Experimental experimental = 8;
setExperimental(RunOptions.Experimental.Builder) - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.Experimental experimental = 8;
setExperimentalDebugInfo(NodeDef.ExperimentalDebugInfo) - Method in class org.tensorflow.framework.NodeDef.Builder
This stores debug information associated with the node.
setExperimentalDebugInfo(NodeDef.ExperimentalDebugInfo.Builder) - Method in class org.tensorflow.framework.NodeDef.Builder
This stores debug information associated with the node.
setExplanation(String) - Method in class org.tensorflow.framework.OpDeprecation.Builder
Explanation of why it was deprecated and what to use instead.
setExplanationBytes(ByteString) - Method in class org.tensorflow.framework.OpDeprecation.Builder
Explanation of why it was deprecated and what to use instead.
setExtent(int, TensorSliceProto.Extent) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
setExtent(int, TensorSliceProto.Extent.Builder) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
Extent of the slice in all tensor dimensions.
setF(float) - Method in class org.tensorflow.framework.AttrValue.Builder
"float"
setF(int, float) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(float)"
setFailOnOptimizerErrors(boolean) - Method in class org.tensorflow.framework.RewriterConfig.Builder
If true, any optimization pass failing will cause the MetaOptimizer to stop with an error.
setFeature(int, Feature) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
setFeature(int, Feature.Builder) - Method in class org.tensorflow.example.FeatureList.Builder
repeated .tensorflow.Feature feature = 1;
setFeatureLists(FeatureLists) - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.FeatureLists feature_lists = 2;
setFeatureLists(FeatureLists.Builder) - Method in class org.tensorflow.example.SequenceExample.Builder
.tensorflow.FeatureLists feature_lists = 2;
setFeatures(Features) - Method in class org.tensorflow.example.Example.Builder
.tensorflow.Features features = 1;
setFeatures(Features.Builder) - Method in class org.tensorflow.example.Example.Builder
.tensorflow.Features features = 1;
setFeed(int, String) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be fed in the callable.
setFetch(int, String) - Method in class org.tensorflow.framework.CallableOptions.Builder
Fetches.
setFetchSkipSync(boolean) - Method in class org.tensorflow.framework.CallableOptions.Builder
By default, RunCallable() will synchronize the GPU stream before returning fetched tensors on a GPU device, to ensure that the values in those tensors have been produced.
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.BytesList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.Example.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.Feature.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.FeatureList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.FeatureLists.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.Features.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.FloatList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.Int64List.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.SequenceExample.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ApiDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ApiDefs.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AttrValue.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CondContextDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DebugOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GPUOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GradientDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.HistogramProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.KernelDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.KernelList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.LocalLinks.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MemoryStats.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NodeDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.NodeOutput.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OpDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OpList.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RPCOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RunMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RunOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SavedModel.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.StepStats.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.Summary.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.Summary.Image.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.Summary.Value.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorConnection.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorDescription.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.VariableDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.VersionDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.Event.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.LogMessage.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SavedSlice.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SaverDef.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.SessionLog.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
setFilename(String) - Method in class org.tensorflow.framework.AssetFileDef.Builder
The filename within an assets directory.
setFilenameBytes(ByteString) - Method in class org.tensorflow.framework.AssetFileDef.Builder
The filename within an assets directory.
setFilenameTensorName(String) - Method in class org.tensorflow.util.SaverDef.Builder
The name of the tensor in which to specify the filename when saving or restoring a model checkpoint.
setFilenameTensorNameBytes(ByteString) - Method in class org.tensorflow.util.SaverDef.Builder
The name of the tensor in which to specify the filename when saving or restoring a model checkpoint.
setFilePath(String) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Path to the source code file.
setFilePathBytes(ByteString) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Path to the source code file.
setFileVersion(String) - Method in class org.tensorflow.util.Event.Builder
An event file was started, with the specified version.
setFileVersionBytes(ByteString) - Method in class org.tensorflow.util.Event.Builder
An event file was started, with the specified version.
setFixedLenFeature(FixedLenFeatureProto) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
setFixedLenFeature(FixedLenFeatureProto.Builder) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.FixedLenFeatureProto fixed_len_feature = 1;
setFloatList(FloatList) - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.FloatList float_list = 2;
setFloatList(FloatList.Builder) - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.FloatList float_list = 2;
setFloatList(CollectionDef.FloatList) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.FloatList float_list = 4;
setFloatList(CollectionDef.FloatList.Builder) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.FloatList float_list = 4;
setFloatVal(int, float) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_FLOAT.
setForceGpuCompatible(boolean) - Method in class org.tensorflow.framework.GPUOptions.Builder
Force all tensors to be gpu_compatible.
setFrequency(long) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Core Frequency in Mhz
setFromTensor(String) - Method in class org.tensorflow.framework.TensorConnection.Builder
A tensor name.
setFromTensorBytes(ByteString) - Method in class org.tensorflow.framework.TensorConnection.Builder
A tensor name.
setFullName(String) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Name of the full variable of which this is a slice.
setFullName(String) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
The full name of the variable/tensor, if applicable.
setFullNameBytes(ByteString) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Name of the full variable of which this is a slice.
setFullNameBytes(ByteString) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
The full name of the variable/tensor, if applicable.
setFullShape(int, long) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of the full variable.
setFunc(NameAttrList) - Method in class org.tensorflow.framework.AttrValue.Builder
"func" represents a function.
setFunc(NameAttrList.Builder) - Method in class org.tensorflow.framework.AttrValue.Builder
"func" represents a function.
setFunc(int, NameAttrList) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
setFunc(int, NameAttrList.Builder) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(attr)"
setFunction(int, FunctionDef) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
setFunction(int, FunctionDef.Builder) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.FunctionDef function = 1;
setFunctionName(String) - Method in class org.tensorflow.framework.GradientDef.Builder
The function name.
setFunctionNameBytes(ByteString) - Method in class org.tensorflow.framework.GradientDef.Builder
The function name.
setFunctionOptimization(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Function optimizations (default is ON).
setFunctionOptimizationValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Function optimizations (default is ON).
setGlobalJitLevel(OptimizerOptions.GlobalJitLevel) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
.tensorflow.OptimizerOptions.GlobalJitLevel global_jit_level = 5;
setGlobalJitLevelValue(int) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
.tensorflow.OptimizerOptions.GlobalJitLevel global_jit_level = 5;
setGlobalName(String) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
The global name of the threadpool.
setGlobalNameBytes(ByteString) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
The global name of the threadpool.
setGlobalStep(long) - Method in class org.tensorflow.framework.DebugOptions.Builder
Caller-specified global step count.
setGpuOptions(GPUOptions) - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all GPUs.
setGpuOptions(GPUOptions.Builder) - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all GPUs.
setGradient(int, GradientDef) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
setGradient(int, GradientDef.Builder) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
repeated .tensorflow.GradientDef gradient = 2;
setGradientFunc(String) - Method in class org.tensorflow.framework.GradientDef.Builder
The gradient function's name.
setGradientFuncBytes(ByteString) - Method in class org.tensorflow.framework.GradientDef.Builder
The gradient function's name.
setGraphDef(GraphDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
GraphDef.
setGraphDef(GraphDef.Builder) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
GraphDef.
setGraphDef(ByteString) - Method in class org.tensorflow.util.Event.Builder
An encoded version of a GraphDef.
setGraphInputNodeInfo(int, GraphTransferGraphInputNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
setGraphInputNodeInfo(int, GraphTransferGraphInputNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
Input Node parameters of transferred graph
setGraphInputNodeName(int, String) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph input node name
setGraphOpName(String) - Method in class org.tensorflow.framework.ApiDef.Builder
Name of the op (in the OpDef) to specify the API for.
setGraphOpNameBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Builder
Name of the op (in the OpDef) to specify the API for.
setGraphOptions(GraphOptions) - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all graphs.
setGraphOptions(GraphOptions.Builder) - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply to all graphs.
setGraphOutputNodeInfo(int, GraphTransferGraphOutputNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
setGraphOutputNodeInfo(int, GraphTransferGraphOutputNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferGraphOutputNodeInfo graph_output_node_info = 6;
setGraphOutputNodeName(int, String) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Remote fused graph output node name
setHalfVal(int, int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_HALF, DT_BFLOAT16.
setHandle(String) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
Handle describing the feeds and fetches of the step.
setHandleBytes(ByteString) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
Handle describing the feeds and fetches of the step.
setHash(String) - Method in class org.tensorflow.util.testlog.CommitId.Builder
string hash = 2;
setHashBytes(ByteString) - Method in class org.tensorflow.util.testlog.CommitId.Builder
string hash = 2;
setHashCode(long) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Hash code for the type of the resource.
setHasMinimum(boolean) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
For type == "int", this is a minimum value.
setHasSingleReference(boolean) - Method in class org.tensorflow.framework.AllocationDescription.Builder
Set if this tensor only has one remaining reference
setHealthStatus(WorkerHealth) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
.tensorflow.WorkerHealth health_status = 1;
setHealthStatusValue(int) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
.tensorflow.WorkerHealth health_status = 1;
setHeight(int) - Method in class org.tensorflow.framework.Summary.Image.Builder
Dimensions of the image.
setHisto(HistogramProto) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.HistogramProto histo = 5;
setHisto(HistogramProto.Builder) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.HistogramProto histo = 5;
setHost(String) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
The host name on which a source code file is located.
setHostBytes(ByteString) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
The host name on which a source code file is located.
setHostMemoryArg(int, String) - Method in class org.tensorflow.framework.KernelDef.Builder
Names of the Op's input_/output_args that reside in host memory instead of device memory.
setHostname(String) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Host name of machine that ran the benchmark.
setHostname(String) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
string hostname = 3;
setHostnameBytes(ByteString) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Host name of machine that ran the benchmark.
setHostnameBytes(ByteString) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
string hostname = 3;
setHostTempMemorySize(long) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Deprecated.
setI(long) - Method in class org.tensorflow.framework.AttrValue.Builder
"int"
setI(int, long) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(int)"
setId(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The id of the node.
setImage(Summary.Image) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Image image = 4;
setImage(Summary.Image.Builder) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.Summary.Image image = 4;
setInaccurate(boolean) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Are the costs inaccurate?
setInArg(int, ApiDef.Arg) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
setInArg(int, ApiDef.Arg.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg in_arg = 4;
setIncarnation(long) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
A device is assigned a global unique number each time it is initialized.
setIndex(int) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Index of the output being set.
setIndicesOutputTensorName(String) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string indices_output_tensor_name = 3;
setIndicesOutputTensorNameBytes(ByteString) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string indices_output_tensor_name = 3;
setIndicesTensorName(String) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The indices Tensor must have dtype int64 and shape [?, ?].
setIndicesTensorNameBytes(ByteString) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The indices Tensor must have dtype int64 and shape [?, ?].
setInferShapes(boolean) - Method in class org.tensorflow.framework.GraphOptions.Builder
Annotate each Node with Op output shape data, to the extent it can be statically inferred.
setInitializerName(String) - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the initializer op.
setInitializerNameBytes(ByteString) - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the initializer op.
setInitialValueName(String) - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the tensor holding the variable's initial value.
setInitialValueNameBytes(ByteString) - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the tensor holding the variable's initial value.
setInput(int, String) - Method in class org.tensorflow.framework.NodeDef.Builder
Each input is "node:src_output" with "node" being a string name and "src_output" indicating which output tensor to use from "node".
setInputArg(int, OpDef.ArgDef) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
setInputArg(int, OpDef.ArgDef.Builder) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the input(s).
setInputCount(int) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 input_count = 6;
setInputInfo(int, CostGraphDef.Node.InputInfo) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
setInputInfo(int, CostGraphDef.Node.InputInfo.Builder) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.InputInfo input_info = 4;
setInt64List(Int64List) - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.Int64List int64_list = 3;
setInt64List(Int64List.Builder) - Method in class org.tensorflow.example.Feature.Builder
.tensorflow.Int64List int64_list = 3;
setInt64List(CollectionDef.Int64List) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.Int64List int64_list = 3;
setInt64List(CollectionDef.Int64List.Builder) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.Int64List int64_list = 3;
setInt64Val(int, long) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT64
setInterOpParallelismThreads(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
Nodes that perform blocking operations are enqueued on a pool of inter_op_parallelism_threads available in each process.
setInterOpThreadPool(int) - Method in class org.tensorflow.framework.RunOptions.Builder
The thread pool to use, if session_inter_op_thread_pool is configured.
setIntraOpParallelismThreads(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
The execution of an individual op (for some op types) can be parallelized on a pool of intra_op_parallelism_threads.
setIntVal(int, int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_INT32, DT_INT16, DT_INT8, DT_UINT8.
setIsAggregate(boolean) - Method in class org.tensorflow.framework.OpDef.Builder
If is_aggregate is true, then this operation accepts N >= 2 inputs and produces 1 output all of the same type.
setIsCommutative(boolean) - Method in class org.tensorflow.framework.OpDef.Builder
True if the operation is commutative ("op(a,b) == op(b,a)" for all inputs)
setIsFinal(boolean) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
If true, the output is permanent: it can't be discarded, because this node is part of the "final output".
setIsolateSessionState(boolean) - Method in class org.tensorflow.framework.ConfigProto.Builder
If true, any resources such as Variables used in the session will not be shared with other sessions.
setIsRef(boolean) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
For inputs: if true, the inputs are required to be refs.
setIsResource(boolean) - Method in class org.tensorflow.framework.VariableDef.Builder
Whether to represent this as a ResourceVariable.
setIsStateful(boolean) - Method in class org.tensorflow.framework.OpDef.Builder
Ops are marked as stateful if their behavior depends on some state beyond their input tensors (e.g.
setIters(long) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
If a benchmark, how many iterations it was run for
setJob(int, JobDef) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
setJob(int, JobDef.Builder) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
The jobs that comprise the cluster.
setJobName(String) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The name of the job of which this server is a member.
setJobNameBytes(ByteString) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The name of the job of which this server is a member.
setKeepCheckpointEveryNHours(float) - Method in class org.tensorflow.util.SaverDef.Builder
How often to keep an additional checkpoint.
setKernel(int, KernelDef) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
setKernel(int, KernelDef.Builder) - Method in class org.tensorflow.framework.KernelList.Builder
repeated .tensorflow.KernelDef kernel = 1;
setKernelName(String) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Name of the kernel making the allocation as set in GraphDef, e.g., "affine2/weights/Assign".
setKernelName(String) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Name of the kernel producing an output as set in GraphDef, e.g., "affine2/weights/Assign".
setKernelNameBytes(ByteString) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Name of the kernel making the allocation as set in GraphDef, e.g., "affine2/weights/Assign".
setKernelNameBytes(ByteString) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Name of the kernel producing an output as set in GraphDef, e.g., "affine2/weights/Assign".
setKeys(int, String) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
Keys for tensors in the VariantTensorDataProto.
setL1CacheSize(long) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
L1 cache size in bytes
setL2CacheSize(long) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
L2 cache size in bytes
setL3CacheSize(long) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
L3 cache size in bytes
setLabel(String) - Method in class org.tensorflow.framework.KernelDef.Builder
This allows experimental kernels to be registered for an op that won't be used unless the user specifies a "_kernel" attr with value matching this.
setLabelBytes(ByteString) - Method in class org.tensorflow.framework.KernelDef.Builder
This allows experimental kernels to be registered for an op that won't be used unless the user specifies a "_kernel" attr with value matching this.
setLastModified(long) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
The timestamp at which the source code file is last modified.
setLayoutOptimizer(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Optimize tensor layouts (default is ON) e.g.
setLayoutOptimizerValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Optimize tensor layouts (default is ON) e.g.
setLength(long) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
int64 length = 2;
setLengthFrames(long) - Method in class org.tensorflow.framework.Summary.Audio.Builder
Length of the audio in frames (samples per channel).
setLevel(LogMessage.Level) - Method in class org.tensorflow.util.LogMessage.Builder
.tensorflow.LogMessage.Level level = 1;
setLevelValue(int) - Method in class org.tensorflow.util.LogMessage.Builder
.tensorflow.LogMessage.Level level = 1;
setLibrary(FunctionDefLibrary) - Method in class org.tensorflow.framework.GraphDef.Builder
EXPERIMENTAL.
setLibrary(FunctionDefLibrary.Builder) - Method in class org.tensorflow.framework.GraphDef.Builder
EXPERIMENTAL.
setLines(int, String) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
Line-by-line content of the source code file.
setLink(int, InterconnectLink) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
setLink(int, InterconnectLink.Builder) - Method in class org.tensorflow.framework.LocalLinks.Builder
repeated .tensorflow.InterconnectLink link = 1;
setLinkage(String) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setLinkageBytes(ByteString) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setLinks(LocalLinks) - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional local interconnect links to other devices.
setLinks(LocalLinks.Builder) - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional local interconnect links to other devices.
setList(AttrValue.ListValue) - Method in class org.tensorflow.framework.AttrValue.Builder
any "list(...)"
setList(AttrValue.ListValue.Builder) - Method in class org.tensorflow.framework.AttrValue.Builder
any "list(...)"
setLiveBytes(long) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
The bytes that are not deallocated.
setLocality(DeviceLocality) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Platform-specific data about device that may be useful for supporting efficient data transfers.
setLocality(DeviceLocality.Builder) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Platform-specific data about device that may be useful for supporting efficient data transfers.
setLocalName(String) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
A user-provided name for the edge.
setLocalNameBytes(ByteString) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
A user-provided name for the edge.
setLogDevicePlacement(boolean) - Method in class org.tensorflow.framework.ConfigProto.Builder
Whether device placements should be logged.
setLogMessage(LogMessage) - Method in class org.tensorflow.util.Event.Builder
The user output a log message.
setLogMessage(LogMessage.Builder) - Method in class org.tensorflow.util.Event.Builder
The user output a log message.
setLoopEnterNames(int, String) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for enter tensors.
setLoopExitNames(int, String) - Method in class org.tensorflow.framework.WhileContextDef.Builder
List of names for exit tensors.
setLoopOptimization(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Loop optimizations (default is ON).
setLoopOptimizationValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Loop optimizations (default is ON).
setMachine(String) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setMachineBytes(ByteString) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setMachineConfiguration(MachineConfiguration) - Method in class org.tensorflow.util.testlog.TestResults.Builder
Machine-specific parameters (Platform and CPU info)
setMachineConfiguration(MachineConfiguration.Builder) - Method in class org.tensorflow.util.testlog.TestResults.Builder
Machine-specific parameters (Platform and CPU info)
setMax(double) - Method in class org.tensorflow.framework.HistogramProto.Builder
double max = 2;
setMaxByteSize(int, int) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
repeated int32 max_byte_size = 2;
setMaxFoldedConstantInBytes(long) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
Constant folding optimization replaces tensors whose values can be predetermined, with constant nodes.
setMaximumIterationsName(String) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Optional name of the maximum_iterations tensor.
setMaximumIterationsNameBytes(ByteString) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Optional name of the maximum_iterations tensor.
setMaxToKeep(int) - Method in class org.tensorflow.util.SaverDef.Builder
Maximum number of checkpoints to keep.
setMaybeTypeName(String) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
For debug-only, the name of the type pointed to by this handle, if available.
setMaybeTypeNameBytes(ByteString) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
For debug-only, the name of the type pointed to by this handle, if available.
setMemory(int, AllocatorMemoryUsed) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
setMemory(int, AllocatorMemoryUsed.Builder) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocatorMemoryUsed memory = 6;
setMemoryInfo(MemoryInfo) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
.tensorflow.MemoryInfo memory_info = 6;
setMemoryInfo(MemoryInfo.Builder) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
.tensorflow.MemoryInfo memory_info = 6;
setMemoryLimit(long) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Memory capacity of device in bytes.
setMemoryLimit(long) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Memory capacity in bytes.
setMemoryLimitMb(int, float) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
Per "virtual" device memory limit, in MB.
setMemoryOptimization(RewriterConfig.MemOptType) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures memory optimization passes through the meta-optimizer.
setMemoryOptimizationValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Configures memory optimization passes through the meta-optimizer.
setMemoryOptimizerTargetNodeNameScope(String) - Method in class org.tensorflow.framework.RewriterConfig.Builder
A node name scope for node names which are valid outputs of recompuations.
setMemoryOptimizerTargetNodeNameScopeBytes(ByteString) - Method in class org.tensorflow.framework.RewriterConfig.Builder
A node name scope for node names which are valid outputs of recompuations.
setMemorySize(long) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Memory size in bytes
setMemoryStats(MemoryStats) - Method in class org.tensorflow.framework.NodeExecStats.Builder
.tensorflow.MemoryStats memory_stats = 12;
setMemoryStats(MemoryStats.Builder) - Method in class org.tensorflow.framework.NodeExecStats.Builder
.tensorflow.MemoryStats memory_stats = 12;
setMemoryTime(long) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Analytical estimate of the memory access cost of this node, in microseconds.
setMessage(String) - Method in class org.tensorflow.util.LogMessage.Builder
string message = 2;
setMessageBytes(ByteString) - Method in class org.tensorflow.util.LogMessage.Builder
string message = 2;
setMeta(SavedTensorSliceMeta) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
setMeta(SavedTensorSliceMeta.Builder) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
This is only present at the first item of each checkpoint file and serves as a table of contents, listing all the tensor slices saved in this file.
setMetadata(SummaryMetadata) - Method in class org.tensorflow.framework.Summary.Value.Builder
Contains metadata on the summary value such as which plugins may use it.
setMetadata(SummaryMetadata.Builder) - Method in class org.tensorflow.framework.Summary.Value.Builder
Contains metadata on the summary value such as which plugins may use it.
setMetadata(ByteString) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Portions of the object that are not Tensors.
setMetaGraphDef(ByteString) - Method in class org.tensorflow.util.Event.Builder
An encoded version of a MetaGraphDef.
setMetaGraphs(int, MetaGraphDef) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
setMetaGraphs(int, MetaGraphDef.Builder) - Method in class org.tensorflow.framework.SavedModel.Builder
One or more MetaGraphs.
setMetaGraphVersion(String) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User specified Version string.
setMetaGraphVersionBytes(ByteString) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User specified Version string.
setMetaInfoDef(MetaGraphDef.MetaInfoDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
setMetaInfoDef(MetaGraphDef.MetaInfoDef.Builder) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
.tensorflow.MetaGraphDef.MetaInfoDef meta_info_def = 1;
setMetaOptimizerIterations(RewriterConfig.NumIterationsType) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Controls how many times we run the optimizers in meta optimizer (default is once).
setMetaOptimizerIterationsValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Controls how many times we run the optimizers in meta optimizer (default is once).
setMetaOptimizerTimeoutMs(long) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Maximum number of milliseconds to spend optimizing a single graph before timing out.
setMethodName(String) - Method in class org.tensorflow.framework.SignatureDef.Builder
Extensible method_name information enabling third-party users to mark a SignatureDef as supporting a particular method.
setMethodNameBytes(ByteString) - Method in class org.tensorflow.framework.SignatureDef.Builder
Extensible method_name information enabling third-party users to mark a SignatureDef as supporting a particular method.
setMhzPerCpu(double) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
How fast are these cpus?
setMin(double) - Method in class org.tensorflow.framework.HistogramProto.Builder
double min = 1;
setMinConsumer(int) - Method in class org.tensorflow.framework.VersionDef.Builder
Any consumer below this version is not allowed to consume this data.
setMinGraphNodes(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
The minimum number of nodes in a graph to optimizer.
setMinimum(long) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
int64 minimum = 6;
setMode(String) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
opt, dbg, etc
setModeBytes(ByteString) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
opt, dbg, etc
setModel(String) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
e.g.
setModel(String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Model (Haswell, K40, ...)
setModelBytes(ByteString) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
e.g.
setModelBytes(ByteString) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Model (Haswell, K40, ...)
setMsg(String) - Method in class org.tensorflow.util.SessionLog.Builder
string msg = 3;
setMsgBytes(ByteString) - Method in class org.tensorflow.util.SessionLog.Builder
string msg = 3;
setName(String) - Method in class org.tensorflow.distruntime.JobDef.Builder
The name of this job.
setName(String) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
string name = 1;
setName(String) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
string name = 1;
setName(String) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Name should be either like "CamelCaseName" or "Package.CamelCaseName".
setName(String) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The name of the node.
setName(String) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Fully specified name of the device within a cluster.
setName(String) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
string name = 1;
setName(String) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
string name = 1;
setName(String) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
string name = 1;
setName(String) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
string name = 1;
setName(String) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
Name of an attr from the Op.
setName(String) - Method in class org.tensorflow.framework.NameAttrList.Builder
string name = 1;
setName(String) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
Name of the tensor.
setName(String) - Method in class org.tensorflow.framework.NodeDef.Builder
The name given to this operator.
setName(String) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Name for the input/output.
setName(String) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A descriptive name for the argument.
setName(String) - Method in class org.tensorflow.framework.OpDef.Builder
Op names starting with an underscore are reserved for internal use.
setName(String) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Unique name of this resource.
setName(String) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
string name = 1;
setName(String) - Method in class org.tensorflow.framework.TensorInfo.Builder
For dense `Tensor`s, the name of the tensor in the graph.
setName(String) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
Optional name of the tensor dimension.
setName(String) - Method in class org.tensorflow.util.SavedSlice.Builder
Name of the tensor that this slice belongs to.
setName(String) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Name of the tensor.
setName(String) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Device name.
setName(String) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
The name of the specific benchmark or test (e.g.
setName(String) - Method in class org.tensorflow.util.testlog.TestResults.Builder
Benchmark target identifier.
setName(String) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
A name for the Tensor.
setName(String) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
string name = 1;
setName(String) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
string name = 2;
setNameBytes(ByteString) - Method in class org.tensorflow.distruntime.JobDef.Builder
The name of this job.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
string name = 1;
setNameBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
string name = 1;
setNameBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
Name should be either like "CamelCaseName" or "Package.CamelCaseName".
setNameBytes(ByteString) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
The name of the node.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
Fully specified name of the device within a cluster.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
string name = 1;
setNameBytes(ByteString) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
string name = 1;
setNameBytes(ByteString) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
string name = 1;
setNameBytes(ByteString) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
string name = 1;
setNameBytes(ByteString) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
Name of an attr from the Op.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.NameAttrList.Builder
string name = 1;
setNameBytes(ByteString) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
Name of the tensor.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.NodeDef.Builder
The name given to this operator.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Name for the input/output.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
A descriptive name for the argument.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.Builder
Op names starting with an underscore are reserved for internal use.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
Unique name of this resource.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
string name = 1;
setNameBytes(ByteString) - Method in class org.tensorflow.framework.TensorInfo.Builder
For dense `Tensor`s, the name of the tensor in the graph.
setNameBytes(ByteString) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
Optional name of the tensor dimension.
setNameBytes(ByteString) - Method in class org.tensorflow.util.SavedSlice.Builder
Name of the tensor that this slice belongs to.
setNameBytes(ByteString) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Name of the tensor.
setNameBytes(ByteString) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Device name.
setNameBytes(ByteString) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
The name of the specific benchmark or test (e.g.
setNameBytes(ByteString) - Method in class org.tensorflow.util.testlog.TestResults.Builder
Benchmark target identifier.
setNameBytes(ByteString) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
A name for the Tensor.
setNameBytes(ByteString) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
string name = 1;
setNameBytes(ByteString) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
string name = 2;
setNestedContexts(int, ControlFlowContextDef) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
setNestedContexts(int, ControlFlowContextDef.Builder) - Method in class org.tensorflow.framework.CondContextDef.Builder
Contexts contained inside this context (e.g.
setNestedContexts(int, ControlFlowContextDef) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
setNestedContexts(int, ControlFlowContextDef.Builder) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Contexts contained inside this context (e.g.
setNode(int, CostGraphDef.Node) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
setNode(int, CostGraphDef.Node.Builder) - Method in class org.tensorflow.framework.CostGraphDef.Builder
repeated .tensorflow.CostGraphDef.Node node = 1;
setNode(int, NodeDef) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
setNode(int, NodeDef.Builder) - Method in class org.tensorflow.framework.GraphDef.Builder
repeated .tensorflow.NodeDef node = 1;
setNodeDef(int, NodeDef) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
setNodeDef(int, NodeDef.Builder) - Method in class org.tensorflow.framework.FunctionDef.Builder
By convention, "op" in node_def is resolved by consulting with a user-defined library first.
setNodeId(int) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
int32 node_id = 2;
setNodeId(int) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 node_id = 2;
setNodeId(int) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
int32 node_id = 1;
setNodeId(int) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
int32 node_id = 1;
setNodeId(int) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
int32 node_id = 1;
setNodeId(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
An index into `CheckpointableObjectGraph.nodes`, indicating the object being referenced.
setNodeInfo(int, GraphTransferNodeInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
setNodeInfo(int, GraphTransferNodeInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInfo node_info = 1;
setNodeInput(int, GraphTransferNodeInput) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
setNodeInput(int, GraphTransferNodeInput.Builder) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
repeated .tensorflow.GraphTransferNodeInput node_input = 2;
setNodeInputInfo(int, GraphTransferNodeInputInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
setNodeInputInfo(int, GraphTransferNodeInputInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeInputInfo node_input_info = 3;
setNodeList(CollectionDef.NodeList) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.NodeList node_list = 1;
setNodeList(CollectionDef.NodeList.Builder) - Method in class org.tensorflow.framework.CollectionDef.Builder
.tensorflow.CollectionDef.NodeList node_list = 1;
setNodeName(String) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name of the node to watch.
setNodeName(String) - Method in class org.tensorflow.framework.NodeExecStats.Builder
TODO(tucker): Use some more compact form of node identity than the full string name.
setNodeName(String) - Method in class org.tensorflow.framework.Summary.Value.Builder
This field is deprecated and will not be set.
setNodeNameBytes(ByteString) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Name of the node to watch.
setNodeNameBytes(ByteString) - Method in class org.tensorflow.framework.NodeExecStats.Builder
TODO(tucker): Use some more compact form of node identity than the full string name.
setNodeNameBytes(ByteString) - Method in class org.tensorflow.framework.Summary.Value.Builder
This field is deprecated and will not be set.
setNodeOutputInfo(int, GraphTransferNodeOutputInfo) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
setNodeOutputInfo(int, GraphTransferNodeOutputInfo.Builder) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
repeated .tensorflow.GraphTransferNodeOutputInfo node_output_info = 4;
setNodes(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
setNodes(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
repeated .tensorflow.CheckpointableObjectGraph.CheckpointableObject nodes = 1;
setNodeStats(int, NodeExecStats) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
setNodeStats(int, NodeExecStats.Builder) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
repeated .tensorflow.NodeExecStats node_stats = 2;
setNum(double) - Method in class org.tensorflow.framework.HistogramProto.Builder
double num = 3;
setNumaNode(int) - Method in class org.tensorflow.framework.DeviceLocality.Builder
Optional NUMA locality of device.
setNumberAttr(String) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
if specified, attr must have type "int"
setNumberAttrBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
if specified, attr must have type "int"
setNumBytes(long) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Number of bytes in the allocation.
setNumChannels(long) - Method in class org.tensorflow.framework.Summary.Audio.Builder
Number of channels of audio.
setNumCores(long) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
int64 num_cores = 1;
setNumCores(long) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Number of cores
setNumCoresAllowed(long) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
int64 num_cores_allowed = 2;
setNumDevToDevCopyStreams(int) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If > 1, the number of device-to-device copy streams to create for each GPUDevice.
setNumRecordsProduced(long) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
int64 num_records_produced = 3;
setNumRegisters(long) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Number of registers per core.
setNumReplicas(int) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
int32 num_replicas = 2;
setNumShards(int) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Number of data files in the bundle.
setNumThreads(int) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
The number of threads in the pool.
setObsoleteOldStyleHistogram(ByteString) - Method in class org.tensorflow.framework.Summary.Value.Builder
bytes obsolete_old_style_histogram = 3;
setOffset(long) - Method in class org.tensorflow.util.BundleEntryProto.Builder
int64 offset = 4;
setOffset(long) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
uint64 offset = 1;
setOp(int, ApiDef) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
setOp(int, ApiDef.Builder) - Method in class org.tensorflow.framework.ApiDefs.Builder
repeated .tensorflow.ApiDef op = 1;
setOp(String) - Method in class org.tensorflow.framework.KernelDef.Builder
Must match the name of an Op.
setOp(String) - Method in class org.tensorflow.framework.NodeDef.Builder
The operation name.
setOp(int, OpDef) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
setOp(int, OpDef.Builder) - Method in class org.tensorflow.framework.OpList.Builder
repeated .tensorflow.OpDef op = 1;
setOpBytes(ByteString) - Method in class org.tensorflow.framework.KernelDef.Builder
Must match the name of an Op.
setOpBytes(ByteString) - Method in class org.tensorflow.framework.NodeDef.Builder
The operation name.
setOpEndRelMicros(long) - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_end_rel_micros = 4;
setOpEndRelNanos(long) - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_end_rel_nanos = 15;
setOperation(String) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Name of the operation making the allocation.
setOperation(String) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Name of the operation making the deallocation.
setOperationBytes(ByteString) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Name of the operation making the allocation.
setOperationBytes(ByteString) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Name of the operation making the deallocation.
setOperationTimeoutInMs(long) - Method in class org.tensorflow.framework.ConfigProto.Builder
Global timeout for all blocking operations in this session.
setOpStartRelMicros(long) - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_start_rel_micros = 3;
setOpStartRelNanos(long) - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 op_start_rel_nanos = 14;
setOptimizerOptions(OptimizerOptions) - Method in class org.tensorflow.framework.GraphOptions.Builder
Options controlling how graph is optimized.
setOptimizerOptions(OptimizerOptions.Builder) - Method in class org.tensorflow.framework.GraphOptions.Builder
Options controlling how graph is optimized.
setOptimizers(int, String) - Method in class org.tensorflow.framework.RewriterConfig.Builder
If non-empty, will use this as an alternative way to specify a list of optimizations to turn on and the order of the optimizations (replacing the meta-optimizer).
setOptLevel(OptimizerOptions.Level) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
Overall optimization level.
setOptLevelValue(int) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
Overall optimization level.
setOpts(int, String) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
Bazel compilation options, if known
setOriginalNodeNames(int, String) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
Opaque string inserted into error messages created by the runtime.
setOriginalVariableNodeId(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
An index into `CheckpointableObjectGraph.nodes`, indicating the variable object this slot was created for.
setOutArg(int, ApiDef.Arg) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
setOutArg(int, ApiDef.Arg.Builder) - Method in class org.tensorflow.framework.ApiDef.Builder
repeated .tensorflow.ApiDef.Arg out_arg = 5;
setOutput(int, NodeOutput) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
setOutput(int, NodeOutput.Builder) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.NodeOutput output = 7;
setOutputArg(int, OpDef.ArgDef) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
setOutputArg(int, OpDef.ArgDef.Builder) - Method in class org.tensorflow.framework.OpDef.Builder
Description of the output(s).
setOutputCount(int) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 output_count = 7;
setOutputInfo(int, CostGraphDef.Node.OutputInfo) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
setOutputInfo(int, CostGraphDef.Node.OutputInfo.Builder) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
repeated .tensorflow.CostGraphDef.Node.OutputInfo output_info = 5;
setOutputPartitionGraphs(boolean) - Method in class org.tensorflow.framework.RunOptions.Builder
Whether the partition graph(s) executed by the executor(s) should be outputted via RunMetadata.
setOutputPort(int) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
int32 output_port = 2;
setOutputSlot(int) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Output slot to watch.
setPaddingId(int) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 padding_id = 5;
setParallelIterations(int) - Method in class org.tensorflow.framework.WhileContextDef.Builder
The number of iterations allowed to run in parallel.
setPartitionGraphs(int, GraphDef) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
setPartitionGraphs(int, GraphDef.Builder) - Method in class org.tensorflow.framework.RunMetadata.Builder
Graphs of the partitions executed by executors.
setPeakBytes(long) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
int64 peak_bytes = 3;
setPendingChangelist(long) - Method in class org.tensorflow.util.testlog.CommitId.Builder
Changelist tested if the change list is not already submitted.
setPerProcessGpuMemoryFraction(double) - Method in class org.tensorflow.framework.GPUOptions.Builder
Fraction of the available GPU memory to allocate for each process.
setPersistentMemorySize(long) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Persistent memory used by this node.
setPersistentMemorySize(long) - Method in class org.tensorflow.framework.MemoryStats.Builder
int64 persistent_memory_size = 3;
setPersistentTensorAllocIds(int, long) - Method in class org.tensorflow.framework.MemoryStats.Builder
repeated int64 persistent_tensor_alloc_ids = 5;
setPhysicalDescription(String) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
The physical description of this device.
setPhysicalDescriptionBytes(ByteString) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
The physical description of this device.
setPhysicalDeviceDesc(String) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
String representation of the physical device that this device maps to.
setPhysicalDeviceDescBytes(ByteString) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
String representation of the physical device that this device maps to.
setPinToHostOptimization(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Force small ops onto the CPU (default is OFF).
setPinToHostOptimizationValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Force small ops onto the CPU (default is OFF).
setPivotForBodyName(String) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot_for_body tensor.
setPivotForBodyNameBytes(ByteString) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot_for_body tensor.
setPivotForPredName(String) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot_for_pred tensor.
setPivotForPredNameBytes(ByteString) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot_for_pred tensor.
setPivotName(String) - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the pivot tensor.
setPivotName(String) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot tensor.
setPivotNameBytes(ByteString) - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the pivot tensor.
setPivotNameBytes(ByteString) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Name of the pivot tensor.
setPlaceholder(String) - Method in class org.tensorflow.framework.AttrValue.Builder
This is a placeholder only used in nodes defined inside a function.
setPlaceholderBytes(ByteString) - Method in class org.tensorflow.framework.AttrValue.Builder
This is a placeholder only used in nodes defined inside a function.
setPlacementPeriod(int) - Method in class org.tensorflow.framework.ConfigProto.Builder
Assignment of Nodes to Devices is recomputed every placement_period steps until the system warms up (at which point the recomputation typically slows down automatically).
setPlacePrunedGraph(boolean) - Method in class org.tensorflow.framework.GraphOptions.Builder
Only place the subgraphs that are run, rather than the entire graph.
setPlatformInfo(PlatformInfo) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Additional platform information.
setPlatformInfo(PlatformInfo.Builder) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Additional platform information.
setPluginData(SummaryMetadata.PluginData) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Data that associates a summary with a certain plugin.
setPluginData(SummaryMetadata.PluginData.Builder) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Data that associates a summary with a certain plugin.
setPluginName(String) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
The name of the plugin this data pertains to.
setPluginNameBytes(ByteString) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
The name of the plugin this data pertains to.
setPollingActiveDelayUsecs(int) - Method in class org.tensorflow.framework.GPUOptions.Builder
In the event polling loop sleep this many microseconds between PollEvents calls, when the queue is not empty.
setPollingInactiveDelayMsecs(int) - Method in class org.tensorflow.framework.GPUOptions.Builder
This field is deprecated and ignored.
setPrecedingNode(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
int32 preceding_node = 1;
setPrecedingPort(int) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
int32 preceding_port = 2;
setPredName(String) - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the pred tensor.
setPredNameBytes(ByteString) - Method in class org.tensorflow.framework.CondContextDef.Builder
Name of the pred tensor.
setPriority(int) - Method in class org.tensorflow.framework.KernelDef.Builder
Prioritization of kernel amongst different devices.
setProducer(int) - Method in class org.tensorflow.framework.VersionDef.Builder
The version of the code that produced this data.
setProperties(DevicePropertiesProtos.DeviceProperties) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
.tensorflow.DeviceProperties properties = 2;
setProperties(DevicePropertiesProtos.DeviceProperties.Builder) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
.tensorflow.DeviceProperties properties = 2;
setProtocol(String) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The protocol to be used by this server.
setProtocolBytes(ByteString) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The protocol to be used by this server.
setPtr(long) - Method in class org.tensorflow.framework.AllocationDescription.Builder
Address of the allocation.
setPtr(long) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Address of the allocation.
setQueueClosedExceptionTypes(int, Code) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
setQueueClosedExceptionTypesValue(int, int) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
A list of exception types considered to signal a safely closed queue if raised during enqueue operations.
setQueueName(String) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
Queue name.
setQueueNameBytes(ByteString) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
Queue name.
setRecvBufMaxChunk(int) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
Guidance to formatting of large RecvBuf fields for transfer.
setReferencedTensor(int, AllocationDescription) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
setReferencedTensor(int, AllocationDescription.Builder) - Method in class org.tensorflow.framework.NodeExecStats.Builder
repeated .tensorflow.AllocationDescription referenced_tensor = 11;
setRelease(String) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setReleaseBytes(ByteString) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setRemapping(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Remapping (default is ON) Remap subgraphs onto more efficient implementations.
setRemappingValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Remapping (default is ON) Remap subgraphs onto more efficient implementations.
setRemoteGraph(GraphDef) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Definition of remote graph
setRemoteGraph(GraphDef.Builder) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Definition of remote graph
setRenameTo(String) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
Change the name used to access this arg in the API from what is used in the GraphDef.
setRenameTo(String) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Change the name used to access this attr in the API from what is used in the GraphDef.
setRenameToBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
Change the name used to access this arg in the API from what is used in the GraphDef.
setRenameToBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
Change the name used to access this attr in the API from what is used in the GraphDef.
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.BytesList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.Example.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.Feature.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.FeatureList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.FeatureLists.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.Features.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.FloatList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.Int64List.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.SequenceExample.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ApiDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ApiDefs.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.AttrValue.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CollectionDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CondContextDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.DebugOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GPUOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GradientDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GraphDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GraphOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.HistogramProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.KernelDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.KernelList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.LocalLinks.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.MemoryStats.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.NodeDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.NodeOutput.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.OpDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.OpList.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.RPCOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.RunMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.RunOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.SavedModel.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.StepStats.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.Summary.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.Summary.Image.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.Summary.Value.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.TensorConnection.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.TensorDescription.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.TensorInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.TensorProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.VariableDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.VersionDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.Event.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.LogMessage.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.SavedSlice.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.SaverDef.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.SessionLog.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
setReportTensorAllocationsUponOom(boolean) - Method in class org.tensorflow.framework.RunOptions.Builder
When enabled, causes tensor allocation information to be included in the error message when the Run() call fails because the allocator ran out of memory (OOM).
setRequestedBytes(long) - Method in class org.tensorflow.framework.AllocationDescription.Builder
Total number of bytes requested
setResetDiskByteUsage(boolean) - Method in class org.tensorflow.framework.DebugOptions.Builder
Whether the total disk usage of tfdbg is to be reset to zero in this Session.run call.
setResourceHandleVal(int, ResourceHandleProto) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
setResourceHandleVal(int, ResourceHandleProto.Builder) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_RESOURCE
setRestoreOpName(String) - Method in class org.tensorflow.util.SaverDef.Builder
The operation to run when restoring a model checkpoint.
setRestoreOpNameBytes(ByteString) - Method in class org.tensorflow.util.SaverDef.Builder
The operation to run when restoring a model checkpoint.
setRewriteOptions(RewriterConfig) - Method in class org.tensorflow.framework.GraphOptions.Builder
Options that control the type and amount of graph rewriting.
setRewriteOptions(RewriterConfig.Builder) - Method in class org.tensorflow.framework.GraphOptions.Builder
Options that control the type and amount of graph rewriting.
setRpcOptions(RPCOptions) - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply when this session uses the distributed runtime.
setRpcOptions(RPCOptions.Builder) - Method in class org.tensorflow.framework.ConfigProto.Builder
Options that apply when this session uses the distributed runtime.
setRunConfiguration(RunConfiguration) - Method in class org.tensorflow.util.testlog.TestResults.Builder
Run-specific parameters (arguments, etc)
setRunConfiguration(RunConfiguration.Builder) - Method in class org.tensorflow.util.testlog.TestResults.Builder
Run-specific parameters (arguments, etc)
setRunMetadata(ByteString) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
Byte-encoded version of the `RunMetadata` proto in order to allow lazy deserialization.
setRunMode(String) - Method in class org.tensorflow.util.testlog.TestResults.Builder
Used for differentiating between continuous and debug builds.
setRunModeBytes(ByteString) - Method in class org.tensorflow.util.testlog.TestResults.Builder
Used for differentiating between continuous and debug builds.
setRunOptions(RunOptions) - Method in class org.tensorflow.framework.CallableOptions.Builder
Options that will be applied to each run.
setRunOptions(RunOptions.Builder) - Method in class org.tensorflow.framework.CallableOptions.Builder
Options that will be applied to each run.
setRunTime(double) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The amount of time the total run took (wall time in seconds)
setS(ByteString) - Method in class org.tensorflow.framework.AttrValue.Builder
"string"
setS(int, ByteString) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(string)"
setSampleRate(float) - Method in class org.tensorflow.framework.Summary.Audio.Builder
Sample rate of the audio in Hz.
setSavedModelSchemaVersion(long) - Method in class org.tensorflow.framework.SavedModel.Builder
The schema version of the SavedModel instance.
setSaverDef(SaverDef) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
SaverDef.
setSaverDef(SaverDef.Builder) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
SaverDef.
setSaveSliceInfoDef(SaveSliceInfoDef) - Method in class org.tensorflow.framework.VariableDef.Builder
Support for saving variables as slices of a larger variable.
setSaveSliceInfoDef(SaveSliceInfoDef.Builder) - Method in class org.tensorflow.framework.VariableDef.Builder
Support for saving variables as slices of a larger variable.
setSaveTensorName(String) - Method in class org.tensorflow.util.SaverDef.Builder
The operation to run when saving a model checkpoint.
setSaveTensorNameBytes(ByteString) - Method in class org.tensorflow.util.SaverDef.Builder
The operation to run when saving a model checkpoint.
setScheduledMicros(long) - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 scheduled_micros = 9;
setScheduledNanos(long) - Method in class org.tensorflow.framework.NodeExecStats.Builder
int64 scheduled_nanos = 17;
setScomplexVal(int, float) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_COMPLEX64.
setScopedAllocatorOptimization(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Try to allocate some independent Op outputs contiguously in order to merge or eliminate downstream Ops (off by default).
setScopedAllocatorOptimizationValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Try to allocate some independent Op outputs contiguously in order to merge or eliminate downstream Ops (off by default).
setScopedAllocatorOpts(ScopedAllocatorOptions) - Method in class org.tensorflow.framework.RewriterConfig.Builder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
setScopedAllocatorOpts(ScopedAllocatorOptions.Builder) - Method in class org.tensorflow.framework.RewriterConfig.Builder
.tensorflow.ScopedAllocatorOptions scoped_allocator_opts = 16;
setSerialIdentifier(String) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Unique serial number of the machine.
setSerialIdentifierBytes(ByteString) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
Unique serial number of the machine.
setSerializedExecutorParameters(ByteString) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
Optional: Parameters given to the executor
setSessionInterOpThreadPool(int, ThreadPoolOptionProto) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
setSessionInterOpThreadPool(int, ThreadPoolOptionProto.Builder) - Method in class org.tensorflow.framework.ConfigProto.Builder
This option is experimental - it may be replaced with a different mechanism in the future.
setSessionLog(SessionLog) - Method in class org.tensorflow.util.Event.Builder
The state of the session which can be used for restarting after crashes.
setSessionLog(SessionLog.Builder) - Method in class org.tensorflow.util.Event.Builder
The state of the session which can be used for restarting after crashes.
setShape(TensorShapeProto) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorShapeProto shape = 2;
setShape(TensorShapeProto.Builder) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
.tensorflow.TensorShapeProto shape = 2;
setShape(TensorShapeProto) - Method in class org.tensorflow.framework.AttrValue.Builder
"shape"
setShape(TensorShapeProto.Builder) - Method in class org.tensorflow.framework.AttrValue.Builder
"shape"
setShape(int, TensorShapeProto) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
setShape(int, TensorShapeProto.Builder) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(shape)"
setShape(TensorShapeProto) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.TensorShapeProto shape = 3;
setShape(TensorShapeProto.Builder) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
.tensorflow.TensorShapeProto shape = 3;
setShape(int, long) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
repeated int64 shape = 3;
setShape(int, long) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
repeated int64 shape = 2;
setShape(int, long) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
repeated int64 shape = 2;
setShape(TensorShapeProto) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.TensorShapeProto shape = 2;
setShape(TensorShapeProto.Builder) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
.tensorflow.TensorShapeProto shape = 2;
setShape(TensorShapeProto) - Method in class org.tensorflow.framework.TensorDescription.Builder
Shape of the tensor.
setShape(TensorShapeProto.Builder) - Method in class org.tensorflow.framework.TensorDescription.Builder
Shape of the tensor.
setShape(TensorShapeProto) - Method in class org.tensorflow.util.BundleEntryProto.Builder
.tensorflow.TensorShapeProto shape = 2;
setShape(TensorShapeProto.Builder) - Method in class org.tensorflow.util.BundleEntryProto.Builder
.tensorflow.TensorShapeProto shape = 2;
setShape(TensorShapeProto) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Shape of the tensor
setShape(TensorShapeProto.Builder) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Shape of the tensor
setShapeOptimization(RewriterConfig.Toggle) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Shape optimizations (default is ON) Simplify computations made on shapes.
setShapeOptimizationValue(int) - Method in class org.tensorflow.framework.RewriterConfig.Builder
Shape optimizations (default is ON) Simplify computations made on shapes.
setShapesOutputTensorName(String) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string shapes_output_tensor_name = 4;
setShapesOutputTensorNameBytes(ByteString) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string shapes_output_tensor_name = 4;
setSharded(boolean) - Method in class org.tensorflow.util.SaverDef.Builder
Shard the save files, one per device that has Variable nodes.
setShardId(int) - Method in class org.tensorflow.util.BundleEntryProto.Builder
The binary content of the tensor lies in: File "shard_id": bytes [offset, offset + size).
setSharedMemorySizePerMultiprocessor(long) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Shared memory size per multiprocessor in bytes.
setShutdownMode(WorkerShutdownMode) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WorkerShutdownMode shutdown_mode = 1;
setShutdownModeValue(int) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WorkerShutdownMode shutdown_mode = 1;
setSignature(OpDef) - Method in class org.tensorflow.framework.FunctionDef.Builder
The definition of the function's name, arguments, return values, attrs etc.
setSignature(OpDef.Builder) - Method in class org.tensorflow.framework.FunctionDef.Builder
The definition of the function's name, arguments, return values, attrs etc.
setSimpleValue(float) - Method in class org.tensorflow.framework.Summary.Value.Builder
float simple_value = 2;
setSize(long) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
int64 size = 1;
setSize(long) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
Size of the tensor in that dimension.
setSize(long) - Method in class org.tensorflow.util.BundleEntryProto.Builder
int64 size = 5;
setSlice(TensorSliceProto) - Method in class org.tensorflow.util.SavedSlice.Builder
Extent of the slice.
setSlice(TensorSliceProto.Builder) - Method in class org.tensorflow.util.SavedSlice.Builder
Extent of the slice.
setSlice(int, TensorSliceProto) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
setSlice(int, TensorSliceProto.Builder) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Explicit list of slices saved in the checkpoint file.
setSlices(int, TensorSliceProto) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
setSlices(int, TensorSliceProto.Builder) - Method in class org.tensorflow.util.BundleEntryProto.Builder
Iff present, this entry represents a partitioned tensor.
setSlot(int) - Method in class org.tensorflow.framework.NodeOutput.Builder
int32 slot = 1;
setSlotName(String) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
The name of the slot (e.g.
setSlotNameBytes(ByteString) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
The name of the slot (e.g.
setSlotVariableNodeId(int) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
An index into `CheckpointableObjectGraph.nodes`, indicating the `Object` with the value of the slot variable.
setSlotVariables(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
setSlotVariables(int, CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
Slot variables owned by this object.
setSnapshot(String) - Method in class org.tensorflow.util.testlog.CommitId.Builder
Hash of intermediate change between hash/changelist and what was tested.
setSnapshotBytes(ByteString) - Method in class org.tensorflow.util.testlog.CommitId.Builder
Hash of intermediate change between hash/changelist and what was tested.
setSnapshotName(String) - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the snapshot tensor.
setSnapshotNameBytes(ByteString) - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the snapshot tensor.
setSocOpId(int) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
int32 soc_op_id = 4;
setSourceFiles(int, DebuggedSourceFile) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
setSourceFiles(int, DebuggedSourceFile.Builder) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
A collection of source code files.
setStart(long) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
Start index of the slice, starting at 0.
setStartTime(long) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The time the run started (in seconds of UTC time since Unix epoch)
setStatus(SessionLog.SessionStatus) - Method in class org.tensorflow.util.SessionLog.Builder
.tensorflow.SessionLog.SessionStatus status = 1;
setStatusValue(int) - Method in class org.tensorflow.util.SessionLog.Builder
.tensorflow.SessionLog.SessionStatus status = 1;
setStep(long) - Method in class org.tensorflow.util.Event.Builder
Global step of the event.
setStepId(long) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
Process-unique step id.
setStepId(long) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
Process-unique step id.
setStepId(long) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
Process-unique step id.
setStepId(long) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Process-unique step id.
setStepId(long) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Process-unique step id.
setStepStats(StepStats) - Method in class org.tensorflow.framework.RunMetadata.Builder
Statistics traced for this step.
setStepStats(StepStats.Builder) - Method in class org.tensorflow.framework.RunMetadata.Builder
Statistics traced for this step.
setStrength(int) - Method in class org.tensorflow.framework.InterconnectLink.Builder
int32 strength = 3;
setStringVal(int, ByteString) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_STRING
setStringValue(String) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
string string_value = 2;
setStringValueBytes(ByteString) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
string string_value = 2;
setStrippedDefaultAttrs(boolean) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A flag to denote whether default-valued attrs have been stripped from the nodes in this graph_def.
setStrippedOpList(OpList) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A copy of the OpDefs used by the producer of this graph_def.
setStrippedOpList(OpList.Builder) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
A copy of the OpDefs used by the producer of this graph_def.
setSum(double) - Method in class org.tensorflow.framework.HistogramProto.Builder
double sum = 4;
setSummary(String) - Method in class org.tensorflow.framework.ApiDef.Builder
One-line human-readable description of what the Op does.
setSummary(String) - Method in class org.tensorflow.framework.OpDef.Builder
One-line human-readable description of what the Op does.
setSummary(Summary) - Method in class org.tensorflow.util.Event.Builder
A summary was generated.
setSummary(Summary.Builder) - Method in class org.tensorflow.util.Event.Builder
A summary was generated.
setSummaryBytes(ByteString) - Method in class org.tensorflow.framework.ApiDef.Builder
One-line human-readable description of what the Op does.
setSummaryBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.Builder
One-line human-readable description of what the Op does.
setSummaryDescription(String) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Longform readable description of the summary sequence.
setSummaryDescriptionBytes(ByteString) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
Longform readable description of the summary sequence.
setSumSquares(double) - Method in class org.tensorflow.framework.HistogramProto.Builder
double sum_squares = 5;
setSwapMemory(boolean) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Whether GPU-CPU memory swap is enabled for this loop.
setSystem(String) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setSystemBytes(ByteString) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setTag(String) - Method in class org.tensorflow.framework.Summary.Value.Builder
Tag name for the data.
setTag(String) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
Tag name associated with this metadata.
setTagBytes(ByteString) - Method in class org.tensorflow.framework.Summary.Value.Builder
Tag name for the data.
setTagBytes(ByteString) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
Tag name associated with this metadata.
setTaggedRunMetadata(TaggedRunMetadata) - Method in class org.tensorflow.util.Event.Builder
The metadata returned by running a session.run() call.
setTaggedRunMetadata(TaggedRunMetadata.Builder) - Method in class org.tensorflow.util.Event.Builder
The metadata returned by running a session.run() call.
setTags(int, String) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
User supplied tag(s) on the meta_graph and included graph_def.
setTarget(int, String) - Method in class org.tensorflow.framework.CallableOptions.Builder
Target Nodes.
setTarget(String) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The target of the run, e.g.: //tensorflow/core:kernels_adjust_contrast_op_benchmark_test
setTargetBytes(ByteString) - Method in class org.tensorflow.util.testlog.TestResults.Builder
The target of the run, e.g.: //tensorflow/core:kernels_adjust_contrast_op_benchmark_test
setTaskIndex(int) - Method in class org.tensorflow.distruntime.ServerDef.Builder
The task index of this server in its job.
setTempMemorySize(long) - Method in class org.tensorflow.framework.MemoryStats.Builder
int64 temp_memory_size = 1;
setTemporaryMemorySize(long) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
Temporary memory used by this node.
setTensor(TensorProto) - Method in class org.tensorflow.framework.AttrValue.Builder
"tensor"
setTensor(TensorProto.Builder) - Method in class org.tensorflow.framework.AttrValue.Builder
"tensor"
setTensor(int, TensorProto) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
setTensor(int, TensorProto.Builder) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(tensor)"
setTensor(TensorDescription) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Allocated tensor details.
setTensor(TensorDescription.Builder) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
Allocated tensor details.
setTensor(TensorDescription) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Output tensor details.
setTensor(TensorDescription.Builder) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
Output tensor details.
setTensor(TensorProto) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
setTensor(TensorProto.Builder) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
The client can populate a TensorProto using a tensorflow::Tensor`, or directly using the protobuf field accessors.
setTensor(TensorProto) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.TensorProto tensor = 8;
setTensor(TensorProto.Builder) - Method in class org.tensorflow.framework.Summary.Value.Builder
.tensorflow.TensorProto tensor = 8;
setTensor(int, SavedSliceMeta) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
setTensor(int, SavedSliceMeta.Builder) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Each SavedSliceMeta describes the slices for one tensor.
setTensorConnection(int, TensorConnection) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
setTensorConnection(int, TensorConnection.Builder) - Method in class org.tensorflow.framework.CallableOptions.Builder
Tensors to be connected in the callable.
setTensorContent(ByteString) - Method in class org.tensorflow.framework.TensorProto.Builder
Serialized raw tensor content from either Tensor::AsProtoTensorContent or memcpy in tensorflow::grpc::EncodeTensorToByteBuffer.
setTensorContent(int, ByteString) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
repeated bytes tensor_content = 1;
setTensorDescription(TensorDescription) - Method in class org.tensorflow.framework.NodeOutput.Builder
.tensorflow.TensorDescription tensor_description = 3;
setTensorDescription(TensorDescription.Builder) - Method in class org.tensorflow.framework.NodeOutput.Builder
.tensorflow.TensorDescription tensor_description = 3;
setTensorflowGitVersion(String) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
The __git_version__ string of the tensorflow build used to write this graph.
setTensorflowGitVersionBytes(ByteString) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
The __git_version__ string of the tensorflow build used to write this graph.
setTensorflowVersion(String) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
The __version__ string of the tensorflow build used to write this graph.
setTensorflowVersionBytes(ByteString) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
The __version__ string of the tensorflow build used to write this graph.
setTensorInfo(TensorInfo) - Method in class org.tensorflow.framework.AssetFileDef.Builder
The tensor to bind the asset filename to.
setTensorInfo(TensorInfo.Builder) - Method in class org.tensorflow.framework.AssetFileDef.Builder
The tensor to bind the asset filename to.
setTensors(int, TensorProto) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
setTensors(int, TensorProto.Builder) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Tensors contained within objects being serialized.
setTensorShape(TensorShapeProto) - Method in class org.tensorflow.framework.TensorInfo.Builder
The static shape should be recorded here, to the extent that it can be known in advance.
setTensorShape(TensorShapeProto.Builder) - Method in class org.tensorflow.framework.TensorInfo.Builder
The static shape should be recorded here, to the extent that it can be known in advance.
setTensorShape(TensorShapeProto) - Method in class org.tensorflow.framework.TensorProto.Builder
Shape of the tensor.
setTensorShape(TensorShapeProto.Builder) - Method in class org.tensorflow.framework.TensorProto.Builder
Shape of the tensor.
setThreadId(int) - Method in class org.tensorflow.framework.NodeExecStats.Builder
uint32 thread_id = 10;
setThroughput(double) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Throughput (in MB/s)
setTimelineLabel(String) - Method in class org.tensorflow.framework.NodeExecStats.Builder
string timeline_label = 8;
setTimelineLabelBytes(ByteString) - Method in class org.tensorflow.framework.NodeExecStats.Builder
string timeline_label = 8;
setTimelineStep(int) - Method in class org.tensorflow.framework.GraphOptions.Builder
If > 0, record a timeline every this many steps.
setTimeoutInMs(long) - Method in class org.tensorflow.framework.RunOptions.Builder
Time to wait for operation to complete in milliseconds.
setTimeoutMs(long) - Method in class org.tensorflow.util.WatchdogConfig.Builder
int64 timeout_ms = 1;
setTolerateDebugOpCreationFailures(boolean) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
Do not error out if debug op creation fails (e.g., due to dtype incompatibility).
setTotal(long) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
Total virtual memory in bytes
setTotalBytes(long) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
These are per-node allocator memory stats.
setToTensor(String) - Method in class org.tensorflow.framework.TensorConnection.Builder
A tensor name.
setToTensorBytes(ByteString) - Method in class org.tensorflow.framework.TensorConnection.Builder
A tensor name.
setTraceLevel(RunOptions.TraceLevel) - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.TraceLevel trace_level = 1;
setTraceLevelValue(int) - Method in class org.tensorflow.framework.RunOptions.Builder
.tensorflow.RunOptions.TraceLevel trace_level = 1;
setTrainable(boolean) - Method in class org.tensorflow.framework.VariableDef.Builder
Whether this variable should be trained.
setType(DataType) - Method in class org.tensorflow.framework.AttrValue.Builder
"type"
setType(int, DataType) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
setType(String) - Method in class org.tensorflow.framework.InterconnectLink.Builder
string type = 2;
setType(DataType) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Describes the type of one or more tensors that are accepted/produced by this input/output arg.
setType(String) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
One of the type names from attr_value.proto ("string", "list(string)", "int", etc.).
setType(DataType) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Type of the tensor
setType(String) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Device type, e.g.
setType(String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Device type (CPU, GPU, ...)
setTypeAttr(String) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
if specified, attr must have type "type"
setTypeAttrBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
if specified, attr must have type "type"
setTypeBytes(ByteString) - Method in class org.tensorflow.framework.InterconnectLink.Builder
string type = 2;
setTypeBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
One of the type names from attr_value.proto ("string", "list(string)", "int", etc.).
setTypeBytes(ByteString) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
Device type, e.g.
setTypeBytes(ByteString) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Device type (CPU, GPU, ...)
setTypeHint(String) - Method in class org.tensorflow.framework.SummaryDescription.Builder
Hint on how plugins should process the data in this series.
setTypeHintBytes(ByteString) - Method in class org.tensorflow.framework.SummaryDescription.Builder
Hint on how plugins should process the data in this series.
setTypeListAttr(String) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
If specified, attr must have type "list(type)", and none of type, type_attr, and number_attr may be specified.
setTypeListAttrBytes(ByteString) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
If specified, attr must have type "list(type)", and none of type, type_attr, and number_attr may be specified.
setTypeName(String) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
string type_name = 3;
setTypeName(String) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Name of the type of objects being serialized.
setTypeNameBytes(ByteString) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
string type_name = 3;
setTypeNameBytes(ByteString) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
Name of the type of objects being serialized.
setTypeValue(int) - Method in class org.tensorflow.framework.AttrValue.Builder
"type"
setTypeValue(int, int) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
"list(type)"
setTypeValue(int) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
Describes the type of one or more tensors that are accepted/produced by this input/output arg.
setTypeValue(int) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
Type of the tensor
setUint32Val(int, int) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT32
setUint64Val(int, long) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_UINT64
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.distruntime.ClusterDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.distruntime.JobDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.distruntime.ServerDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.BytesList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.Example.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.ExampleParserConfiguration.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.Feature.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.FeatureList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.FeatureLists.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.Features.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.FloatList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.Int64List.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.SequenceExample.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AllocationDescription.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AllocationRecord.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AllocatorMemoryUsed.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ApiDef.Arg.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ApiDef.Attr.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ApiDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ApiDef.Endpoint.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ApiDefs.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AssetFileDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AttrValue.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AttrValue.ListValue.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.AutoParallelOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CallableOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CondContextDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ConfigProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CostGraphDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CostGraphDef.Node.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DebuggedSourceFile.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DebuggedSourceFiles.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DebugOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DebugTensorWatch.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DeviceAttributes.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DeviceLocality.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.DeviceStepStats.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.FunctionDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.FunctionDefLibrary.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GPUOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GradientDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferNodeInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferNodeInput.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.HistogramProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.InterconnectLink.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.KernelDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.KernelList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.LocalLinks.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogRawAllocation.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogStep.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryLogTensorOutput.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MemoryStats.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MetaGraphDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NameAttrList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NamedTensorProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NodeDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NodeExecStats.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.NodeOutput.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OpDef.ArgDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OpDef.AttrDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OpDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OpDeprecation.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OpList.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.OptimizerOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.QueueRunnerDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ResourceHandleProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RewriterConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RPCOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RunMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RunOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SavedModel.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ScopedAllocatorOptions.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SignatureDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.StepStats.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.Summary.Audio.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.Summary.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.Summary.Image.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.Summary.Value.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SummaryDescription.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SummaryMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorConnection.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorDescription.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorShapeProto.Dim.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorSliceProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.TensorSliceProto.Extent.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ThreadPoolOptionProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.ValuesDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.VariableDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.VariantTensorDataProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.VersionDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.framework.WhileContextDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.BundleEntryProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.Event.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.LogMessage.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SavedSlice.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SavedSliceMeta.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SavedTensorSlices.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SaverDef.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.SessionLog.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.TaggedRunMetadata.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.BenchmarkEntries.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.BuildConfiguration.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.CommitId.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.CPUInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.EntryValue.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.MachineConfiguration.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.MemoryInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.RunConfiguration.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.testlog.TestResults.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.WatchdogConfig.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class tensorflow.TransportOptions.RecvBufRespExtra.Builder
 
setUnknownRank(boolean) - Method in class org.tensorflow.framework.TensorShapeProto.Builder
If true, the number of dimensions in the shape is unknown.
setUseNumaAffinity(boolean) - Method in class org.tensorflow.framework.ConfigProto.Experimental.Builder
If true, and supported by the platform, the runtime will attempt to use NUMA affinity where applicable.
setUsePerSessionThreads(boolean) - Method in class org.tensorflow.framework.ConfigProto.Builder
If true, use a new set of threads for this session rather than the global pool of threads.
setUseRpcForInprocessMaster(boolean) - Method in class org.tensorflow.framework.RPCOptions.Builder
If true, always use RPC to contact the session target.
setUseRunHandlerPool(boolean) - Method in class org.tensorflow.framework.RunOptions.Experimental.Builder
If true, then operations (using the inter-op pool) across all session::run() calls will be centrally scheduled, optimizing for (median and tail) latency.
setUseUnifiedMemory(boolean) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
If true, uses CUDA unified memory for memory allocations.
setUuid(String) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
Final entry in output of "nvidia-smi -L"
setUuidBytes(ByteString) - Method in class org.tensorflow.util.testlog.GPUInfo.Builder
Final entry in output of "nvidia-smi -L"
setValue(int, ByteString) - Method in class org.tensorflow.example.BytesList.Builder
repeated bytes value = 1;
setValue(int, float) - Method in class org.tensorflow.example.FloatList.Builder
repeated float value = 1 [packed = true];
setValue(int, long) - Method in class org.tensorflow.example.Int64List.Builder
repeated int64 value = 1 [packed = true];
setValue(int, Any) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
setValue(int, Any.Builder) - Method in class org.tensorflow.framework.CollectionDef.AnyList.Builder
repeated .google.protobuf.Any value = 1;
setValue(int, ByteString) - Method in class org.tensorflow.framework.CollectionDef.BytesList.Builder
repeated bytes value = 1;
setValue(int, float) - Method in class org.tensorflow.framework.CollectionDef.FloatList.Builder
repeated float value = 1 [packed = true];
setValue(int, long) - Method in class org.tensorflow.framework.CollectionDef.Int64List.Builder
repeated int64 value = 1 [packed = true];
setValue(int, String) - Method in class org.tensorflow.framework.CollectionDef.NodeList.Builder
repeated string value = 1;
setValue(int, Summary.Value) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
setValue(int, Summary.Value.Builder) - Method in class org.tensorflow.framework.Summary.Builder
Set of values for the summary.
setValues(int, String) - Method in class org.tensorflow.framework.ValuesDef.Builder
Value names that have been seen in this context.
setValuesDef(ValuesDef) - Method in class org.tensorflow.framework.CondContextDef.Builder
Values and external values in control flow context.
setValuesDef(ValuesDef.Builder) - Method in class org.tensorflow.framework.CondContextDef.Builder
Values and external values in control flow context.
setValuesDef(ValuesDef) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Values and external values in control flow context.
setValuesDef(ValuesDef.Builder) - Method in class org.tensorflow.framework.WhileContextDef.Builder
Values and external values in control flow context.
setValuesOutputTensorName(String) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
string values_output_tensor_name = 4;
setValuesOutputTensorName(String) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string values_output_tensor_name = 2;
setValuesOutputTensorNameBytes(ByteString) - Method in class org.tensorflow.example.FixedLenFeatureProto.Builder
string values_output_tensor_name = 4;
setValuesOutputTensorNameBytes(ByteString) - Method in class org.tensorflow.example.VarLenFeatureProto.Builder
string values_output_tensor_name = 2;
setValuesTensorName(String) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The shape of the values Tensor is [?].
setValuesTensorNameBytes(ByteString) - Method in class org.tensorflow.framework.TensorInfo.CooSparse.Builder
The shape of the values Tensor is [?].
setVariableName(String) - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the variable tensor.
setVariableNameBytes(ByteString) - Method in class org.tensorflow.framework.VariableDef.Builder
Name of the variable tensor.
setVariantVal(int, VariantTensorDataProto) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
setVariantVal(int, VariantTensorDataProto.Builder) - Method in class org.tensorflow.framework.TensorProto.Builder
DT_VARIANT
setVarLenFeature(VarLenFeatureProto) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
setVarLenFeature(VarLenFeatureProto.Builder) - Method in class org.tensorflow.example.FeatureConfiguration.Builder
.tensorflow.VarLenFeatureProto var_len_feature = 2;
setVarOffset(int, long) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Offset of this variable into the full variable.
setVarShape(int, long) - Method in class org.tensorflow.framework.SaveSliceInfoDef.Builder
Shape of this variable.
setVendor(String) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Vendor (Intel, nvidia, ...)
setVendorBytes(ByteString) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties.Builder
Vendor (Intel, nvidia, ...)
setVersion(int) - Method in class org.tensorflow.framework.GraphDef.Builder
Deprecated.
setVersion(int) - Method in class org.tensorflow.framework.OpDeprecation.Builder
First GraphDef version at which the op is disallowed.
setVersion(VersionDef) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Versioning of the tensor bundle format.
setVersion(VersionDef.Builder) - Method in class org.tensorflow.util.BundleHeaderProto.Builder
Versioning of the tensor bundle format.
setVersion(String) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
A user-specified version string.
setVersion(SaverDef.CheckpointFormatVersion) - Method in class org.tensorflow.util.SaverDef.Builder
.tensorflow.SaverDef.CheckpointFormatVersion version = 7;
setVersion(String) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setVersionBytes(ByteString) - Method in class org.tensorflow.util.IteratorStateMetadata.Builder
A user-specified version string.
setVersionBytes(ByteString) - Method in class org.tensorflow.util.testlog.PlatformInfo.Builder
e.g.
setVersionNumber(int) - Method in class org.tensorflow.framework.TensorProto.Builder
Version number.
setVersions(VersionDef) - Method in class org.tensorflow.framework.GraphDef.Builder
Compatibility versions of the graph.
setVersions(VersionDef.Builder) - Method in class org.tensorflow.framework.GraphDef.Builder
Compatibility versions of the graph.
setVersions(VersionDef) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Compatibility version of this checkpoint.
setVersions(VersionDef.Builder) - Method in class org.tensorflow.util.SavedTensorSliceMeta.Builder
Compatibility version of this checkpoint.
setVersionValue(int) - Method in class org.tensorflow.util.SaverDef.Builder
.tensorflow.SaverDef.CheckpointFormatVersion version = 7;
setVirtualDevices(int, GPUOptions.Experimental.VirtualDevices) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
setVirtualDevices(int, GPUOptions.Experimental.VirtualDevices.Builder) - Method in class org.tensorflow.framework.GPUOptions.Experimental.Builder
The multi virtual device settings.
setVisibility(ApiDef.Visibility) - Method in class org.tensorflow.framework.ApiDef.Builder
.tensorflow.ApiDef.Visibility visibility = 2;
setVisibilityValue(int) - Method in class org.tensorflow.framework.ApiDef.Builder
.tensorflow.ApiDef.Visibility visibility = 2;
setVisibleDeviceList(String) - Method in class org.tensorflow.framework.GPUOptions.Builder
A comma-separated list of GPU ids that determines the 'visible' to 'virtual' mapping of GPU devices.
setVisibleDeviceListBytes(ByteString) - Method in class org.tensorflow.framework.GPUOptions.Builder
A comma-separated list of GPU ids that determines the 'visible' to 'virtual' mapping of GPU devices.
setWallTime(double) - Method in class org.tensorflow.util.Event.Builder
Timestamp of the event.
setWallTime(double) - Method in class org.tensorflow.util.testlog.BenchmarkEntry.Builder
Total wall time used for all iterations (in seconds)
setWatchdogConfig(WatchdogConfig) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WatchdogConfig watchdog_config = 2;
setWatchdogConfig(WatchdogConfig.Builder) - Method in class org.tensorflow.util.WorkerHeartbeatRequest.Builder
.tensorflow.WatchdogConfig watchdog_config = 2;
setWhileCtxt(WhileContextDef) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.WhileContextDef while_ctxt = 2;
setWhileCtxt(WhileContextDef.Builder) - Method in class org.tensorflow.framework.ControlFlowContextDef.Builder
.tensorflow.WhileContextDef while_ctxt = 2;
setWidth(int) - Method in class org.tensorflow.framework.Summary.Image.Builder
int32 width = 2;
setWorkerLog(int, Event) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
setWorkerLog(int, Event.Builder) - Method in class org.tensorflow.util.WorkerHeartbeatResponse.Builder
repeated .tensorflow.Event worker_log = 2;
setWorkFinished(long) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
int64 work_finished = 2;
setWorkStarted(long) - Method in class org.tensorflow.framework.ReaderBaseState.Builder
int64 work_started = 1;
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.example.FixedLenFeatureProto
 
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue.ListValue
 
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue
 
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorDescription
 
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.util.BundleEntryProto
 
SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedSliceMeta
 
SHAPE_OPTIMIZATION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RewriterConfig
 
SHAPES_OUTPUT_TENSOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.example.VarLenFeatureProto
 
SHARD_ID_FIELD_NUMBER - Static variable in class org.tensorflow.util.BundleEntryProto
 
SHARDED_FIELD_NUMBER - Static variable in class org.tensorflow.util.SaverDef
 
SHARED_MEMORY_SIZE_PER_MULTIPROCESSOR_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
SHUTDOWN_IMMEDIATELY_VALUE - Static variable in enum org.tensorflow.util.WorkerShutdownMode
SHUTDOWN_IMMEDIATELY = 1;
SHUTDOWN_MODE_FIELD_NUMBER - Static variable in class org.tensorflow.util.WorkerHeartbeatRequest
 
SIGNATURE_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef
 
SIGNATURE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.FunctionDef
 
SignatureDef - Class in org.tensorflow.framework
SignatureDef defines the signature of a computation supported by a TensorFlow graph.
SignatureDef.Builder - Class in org.tensorflow.framework
SignatureDef defines the signature of a computation supported by a TensorFlow graph.
SignatureDefOrBuilder - Interface in org.tensorflow.framework
 
SIMPLE_VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Value
 
SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorShapeProto.Dim
 
SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.util.BundleEntryProto
 
SKIP_VALUE - Static variable in enum org.tensorflow.framework.ApiDef.Visibility
Do not include this op in the generated API.
SLICE_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedSlice
 
SLICE_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedSliceMeta
 
SLICES_FIELD_NUMBER - Static variable in class org.tensorflow.util.BundleEntryProto
 
SLOT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeOutput
 
SLOT_NAME_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
SLOT_VARIABLE_NODE_ID_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
SLOT_VARIABLES_FIELD_NUMBER - Static variable in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
SNAPSHOT_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.CommitId
 
SNAPSHOT_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VariableDef
 
SOC_OP_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInfo
 
SOFTWARE_TRACE_VALUE - Static variable in enum org.tensorflow.framework.RunOptions.TraceLevel
SOFTWARE_TRACE = 1;
SOURCE_FILES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebuggedSourceFiles
 
START_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorSliceProto.Extent
 
START_TIME_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
START_VALUE - Static variable in enum org.tensorflow.util.SessionLog.SessionStatus
START = 1;
STATUS_FIELD_NUMBER - Static variable in class org.tensorflow.util.SessionLog
 
STATUS_UNSPECIFIED_VALUE - Static variable in enum org.tensorflow.util.SessionLog.SessionStatus
STATUS_UNSPECIFIED = 0;
STEP_FIELD_NUMBER - Static variable in class org.tensorflow.util.Event
 
STEP_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawAllocation
 
STEP_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogRawDeallocation
 
STEP_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogStep
 
STEP_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogTensorAllocation
 
STEP_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogTensorOutput
 
STEP_STATS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunMetadata
 
StepStats - Class in org.tensorflow.framework
Protobuf type tensorflow.StepStats
StepStats.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.StepStats
StepStatsOrBuilder - Interface in org.tensorflow.framework
 
StepStatsProtos - Class in org.tensorflow.framework
 
STOP_VALUE - Static variable in enum org.tensorflow.util.SessionLog.SessionStatus
STOP = 2;
STRENGTH_FIELD_NUMBER - Static variable in class org.tensorflow.framework.InterconnectLink
 
STRING_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
STRING_VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.EntryValue
 
STRIPPED_DEFAULT_ATTRS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
STRIPPED_OP_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
SUM_FIELD_NUMBER - Static variable in class org.tensorflow.framework.HistogramProto
 
SUM_SQUARES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.HistogramProto
 
Summary - Class in org.tensorflow.framework
A Summary is a set of named values to be displayed by the visualizer.
Summary.Audio - Class in org.tensorflow.framework
Protobuf type tensorflow.Summary.Audio
Summary.Audio.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.Summary.Audio
Summary.AudioOrBuilder - Interface in org.tensorflow.framework
 
Summary.Builder - Class in org.tensorflow.framework
A Summary is a set of named values to be displayed by the visualizer.
Summary.Image - Class in org.tensorflow.framework
Protobuf type tensorflow.Summary.Image
Summary.Image.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.Summary.Image
Summary.ImageOrBuilder - Interface in org.tensorflow.framework
 
Summary.Value - Class in org.tensorflow.framework
Protobuf type tensorflow.Summary.Value
Summary.Value.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.Summary.Value
Summary.Value.ValueCase - Enum in org.tensorflow.framework
 
Summary.ValueOrBuilder - Interface in org.tensorflow.framework
 
SUMMARY_DESCRIPTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SummaryMetadata
 
SUMMARY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
SUMMARY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef
 
SUMMARY_FIELD_NUMBER - Static variable in class org.tensorflow.util.Event
 
SummaryDescription - Class in org.tensorflow.framework
Metadata associated with a series of Summary data
SummaryDescription.Builder - Class in org.tensorflow.framework
Metadata associated with a series of Summary data
SummaryDescriptionOrBuilder - Interface in org.tensorflow.framework
 
SummaryMetadata - Class in org.tensorflow.framework
A SummaryMetadata encapsulates information on which plugins are able to make use of a certain summary value.
SummaryMetadata.Builder - Class in org.tensorflow.framework
A SummaryMetadata encapsulates information on which plugins are able to make use of a certain summary value.
SummaryMetadata.PluginData - Class in org.tensorflow.framework
Protobuf type tensorflow.SummaryMetadata.PluginData
SummaryMetadata.PluginData.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.SummaryMetadata.PluginData
SummaryMetadata.PluginDataOrBuilder - Interface in org.tensorflow.framework
 
SummaryMetadataOrBuilder - Interface in org.tensorflow.framework
 
SummaryOrBuilder - Interface in org.tensorflow.framework
 
SummaryProtos - Class in org.tensorflow.framework
 
SWAP_MEMORY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
SWAPPING_HEURISTICS_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.MemOptType
Swapping heuristic will move a tensor from the GPU to the CPU and move it back when needed to reduce peak memory usage.
SYSTEM_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.PlatformInfo
 

T

TAG_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Value
 
TAG_FIELD_NUMBER - Static variable in class org.tensorflow.util.TaggedRunMetadata
 
TAGGED_RUN_METADATA_FIELD_NUMBER - Static variable in class org.tensorflow.util.Event
 
TaggedRunMetadata - Class in org.tensorflow.util
For logging the metadata output for a single session.run() call.
TaggedRunMetadata.Builder - Class in org.tensorflow.util
For logging the metadata output for a single session.run() call.
TaggedRunMetadataOrBuilder - Interface in org.tensorflow.util
 
TAGS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
TARGET_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CallableOptions
 
TARGET_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.TestResults
 
TASK_INDEX_FIELD_NUMBER - Static variable in class org.tensorflow.distruntime.ServerDef
 
TASKS_FIELD_NUMBER - Static variable in class org.tensorflow.distruntime.JobDef
 
TEMP_MEMORY_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryStats
 
TEMPORARY_MEMORY_SIZE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CostGraphDef.Node
 
TENSOR_CONNECTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CallableOptions
 
TENSOR_CONTENT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
TENSOR_CONTENT_FIELD_NUMBER - Static variable in class tensorflow.TransportOptions.RecvBufRespExtra
 
TENSOR_DESCRIPTION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeOutput
 
TENSOR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue.ListValue
 
TENSOR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue
 
TENSOR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogTensorAllocation
 
TENSOR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MemoryLogTensorOutput
 
TENSOR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NamedTensorProto
 
TENSOR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Value
 
TENSOR_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedTensorSliceMeta
 
TENSOR_INFO_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AssetFileDef
 
TENSOR_SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorInfo
 
TENSOR_SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
TensorBundleProtos - Class in org.tensorflow.util
 
TensorConnection - Class in org.tensorflow.framework
Defines a connection between two tensors in a `GraphDef`.
TensorConnection.Builder - Class in org.tensorflow.framework
Defines a connection between two tensors in a `GraphDef`.
TensorConnectionOrBuilder - Interface in org.tensorflow.framework
 
TensorDescription - Class in org.tensorflow.framework
Protobuf type tensorflow.TensorDescription
TensorDescription.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.TensorDescription
TensorDescriptionOrBuilder - Interface in org.tensorflow.framework
 
TensorDescriptionProtos - Class in org.tensorflow.framework
 
tensorflow - package tensorflow
 
TENSORFLOW_GIT_VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
TENSORFLOW_VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
TensorInfo - Class in org.tensorflow.framework
Information about a Tensor necessary for feeding or retrieval.
TensorInfo.Builder - Class in org.tensorflow.framework
Information about a Tensor necessary for feeding or retrieval.
TensorInfo.CooSparse - Class in org.tensorflow.framework
For sparse tensors, The COO encoding stores a triple of values, indices, and shape.
TensorInfo.CooSparse.Builder - Class in org.tensorflow.framework
For sparse tensors, The COO encoding stores a triple of values, indices, and shape.
TensorInfo.CooSparseOrBuilder - Interface in org.tensorflow.framework
 
TensorInfo.EncodingCase - Enum in org.tensorflow.framework
 
TensorInfoOrBuilder - Interface in org.tensorflow.framework
 
TensorProto - Class in org.tensorflow.framework
Protocol buffer representing a tensor.
TensorProto.Builder - Class in org.tensorflow.framework
Protocol buffer representing a tensor.
TensorProtoOrBuilder - Interface in org.tensorflow.framework
 
TensorProtos - Class in org.tensorflow.framework
 
TENSORS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VariantTensorDataProto
 
TensorShapeProto - Class in org.tensorflow.framework
Dimensions of a tensor.
TensorShapeProto.Builder - Class in org.tensorflow.framework
Dimensions of a tensor.
TensorShapeProto.Dim - Class in org.tensorflow.framework
One dimension of the tensor.
TensorShapeProto.Dim.Builder - Class in org.tensorflow.framework
One dimension of the tensor.
TensorShapeProto.DimOrBuilder - Interface in org.tensorflow.framework
 
TensorShapeProtoOrBuilder - Interface in org.tensorflow.framework
 
TensorShapeProtos - Class in org.tensorflow.framework
 
TensorSliceProto - Class in org.tensorflow.framework
Can only be interpreted if you know the corresponding TensorShape.
TensorSliceProto.Builder - Class in org.tensorflow.framework
Can only be interpreted if you know the corresponding TensorShape.
TensorSliceProto.Extent - Class in org.tensorflow.framework
Extent of the slice in one dimension.
TensorSliceProto.Extent.Builder - Class in org.tensorflow.framework
Extent of the slice in one dimension.
TensorSliceProto.Extent.HasLengthCase - Enum in org.tensorflow.framework
 
TensorSliceProto.ExtentOrBuilder - Interface in org.tensorflow.framework
 
TensorSliceProtoOrBuilder - Interface in org.tensorflow.framework
 
TensorSliceProtos - Class in org.tensorflow.framework
 
TestLogProtos - Class in org.tensorflow.util.testlog
 
TestResults - Class in org.tensorflow.util.testlog
The output of one benchmark / test run.
TestResults.BenchmarkType - Enum in org.tensorflow.util.testlog
The type of benchmark.
TestResults.Builder - Class in org.tensorflow.util.testlog
The output of one benchmark / test run.
TestResultsOrBuilder - Interface in org.tensorflow.util.testlog
 
THREAD_ID_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
ThreadPoolOptionProto - Class in org.tensorflow.framework
Protobuf type tensorflow.ThreadPoolOptionProto
ThreadPoolOptionProto.Builder - Class in org.tensorflow.framework
Protobuf type tensorflow.ThreadPoolOptionProto
ThreadPoolOptionProtoOrBuilder - Interface in org.tensorflow.framework
 
THROUGHPUT_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.BenchmarkEntry
 
TIMELINE_LABEL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.NodeExecStats
 
TIMELINE_STEP_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphOptions
 
TIMEOUT_IN_MS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunOptions
 
TIMEOUT_MS_FIELD_NUMBER - Static variable in class org.tensorflow.util.WatchdogConfig
 
TO_TENSOR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorConnection
 
toBuilder() - Method in class org.tensorflow.distruntime.ClusterDef
 
toBuilder() - Method in class org.tensorflow.distruntime.JobDef
 
toBuilder() - Method in class org.tensorflow.distruntime.ServerDef
 
toBuilder() - Method in class org.tensorflow.example.BytesList
 
toBuilder() - Method in class org.tensorflow.example.Example
 
toBuilder() - Method in class org.tensorflow.example.ExampleParserConfiguration
 
toBuilder() - Method in class org.tensorflow.example.Feature
 
toBuilder() - Method in class org.tensorflow.example.FeatureConfiguration
 
toBuilder() - Method in class org.tensorflow.example.FeatureList
 
toBuilder() - Method in class org.tensorflow.example.FeatureLists
 
toBuilder() - Method in class org.tensorflow.example.Features
 
toBuilder() - Method in class org.tensorflow.example.FixedLenFeatureProto
 
toBuilder() - Method in class org.tensorflow.example.FloatList
 
toBuilder() - Method in class org.tensorflow.example.Int64List
 
toBuilder() - Method in class org.tensorflow.example.SequenceExample
 
toBuilder() - Method in class org.tensorflow.example.VarLenFeatureProto
 
toBuilder() - Method in class org.tensorflow.framework.AllocationDescription
 
toBuilder() - Method in class org.tensorflow.framework.AllocationRecord
 
toBuilder() - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
toBuilder() - Method in class org.tensorflow.framework.ApiDef.Arg
 
toBuilder() - Method in class org.tensorflow.framework.ApiDef.Attr
 
toBuilder() - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
toBuilder() - Method in class org.tensorflow.framework.ApiDef
 
toBuilder() - Method in class org.tensorflow.framework.ApiDefs
 
toBuilder() - Method in class org.tensorflow.framework.AssetFileDef
 
toBuilder() - Method in class org.tensorflow.framework.AttrValue.ListValue
 
toBuilder() - Method in class org.tensorflow.framework.AttrValue
 
toBuilder() - Method in class org.tensorflow.framework.AutoParallelOptions
 
toBuilder() - Method in class org.tensorflow.framework.CallableOptions
 
toBuilder() - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
toBuilder() - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
toBuilder() - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
toBuilder() - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
toBuilder() - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
toBuilder() - Method in class org.tensorflow.framework.CollectionDef
 
toBuilder() - Method in class org.tensorflow.framework.CondContextDef
 
toBuilder() - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
toBuilder() - Method in class org.tensorflow.framework.ConfigProto
 
toBuilder() - Method in class org.tensorflow.framework.ControlFlowContextDef
 
toBuilder() - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
toBuilder() - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
toBuilder() - Method in class org.tensorflow.framework.CostGraphDef.Node
 
toBuilder() - Method in class org.tensorflow.framework.CostGraphDef
 
toBuilder() - Method in class org.tensorflow.framework.DebuggedSourceFile
 
toBuilder() - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
toBuilder() - Method in class org.tensorflow.framework.DebugOptions
 
toBuilder() - Method in class org.tensorflow.framework.DebugTensorWatch
 
toBuilder() - Method in class org.tensorflow.framework.DeviceAttributes
 
toBuilder() - Method in class org.tensorflow.framework.DeviceLocality
 
toBuilder() - Method in class org.tensorflow.framework.DeviceStepStats
 
toBuilder() - Method in class org.tensorflow.framework.FunctionDef
 
toBuilder() - Method in class org.tensorflow.framework.FunctionDefLibrary
 
toBuilder() - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
toBuilder() - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
toBuilder() - Method in class org.tensorflow.framework.GPUOptions
 
toBuilder() - Method in class org.tensorflow.framework.GradientDef
 
toBuilder() - Method in class org.tensorflow.framework.GraphDef
 
toBuilder() - Method in class org.tensorflow.framework.GraphOptions
 
toBuilder() - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
toBuilder() - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
toBuilder() - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
toBuilder() - Method in class org.tensorflow.framework.GraphTransferInfo
 
toBuilder() - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
toBuilder() - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
toBuilder() - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
toBuilder() - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
toBuilder() - Method in class org.tensorflow.framework.HistogramProto
 
toBuilder() - Method in class org.tensorflow.framework.InterconnectLink
 
toBuilder() - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
toBuilder() - Method in class org.tensorflow.framework.KernelDef
 
toBuilder() - Method in class org.tensorflow.framework.KernelList
 
toBuilder() - Method in class org.tensorflow.framework.LocalLinks
 
toBuilder() - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
toBuilder() - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
toBuilder() - Method in class org.tensorflow.framework.MemoryLogStep
 
toBuilder() - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
toBuilder() - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
toBuilder() - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
toBuilder() - Method in class org.tensorflow.framework.MemoryStats
 
toBuilder() - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
toBuilder() - Method in class org.tensorflow.framework.MetaGraphDef
 
toBuilder() - Method in class org.tensorflow.framework.NameAttrList
 
toBuilder() - Method in class org.tensorflow.framework.NamedTensorProto
 
toBuilder() - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
toBuilder() - Method in class org.tensorflow.framework.NodeDef
 
toBuilder() - Method in class org.tensorflow.framework.NodeExecStats
 
toBuilder() - Method in class org.tensorflow.framework.NodeOutput
 
toBuilder() - Method in class org.tensorflow.framework.OpDef.ArgDef
 
toBuilder() - Method in class org.tensorflow.framework.OpDef.AttrDef
 
toBuilder() - Method in class org.tensorflow.framework.OpDef
 
toBuilder() - Method in class org.tensorflow.framework.OpDeprecation
 
toBuilder() - Method in class org.tensorflow.framework.OpList
 
toBuilder() - Method in class org.tensorflow.framework.OptimizerOptions
 
toBuilder() - Method in class org.tensorflow.framework.QueueRunnerDef
 
toBuilder() - Method in class org.tensorflow.framework.ReaderBaseState
 
toBuilder() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
toBuilder() - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
toBuilder() - Method in class org.tensorflow.framework.ResourceHandleProto
 
toBuilder() - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
toBuilder() - Method in class org.tensorflow.framework.RewriterConfig
 
toBuilder() - Method in class org.tensorflow.framework.RPCOptions
 
toBuilder() - Method in class org.tensorflow.framework.RunMetadata
 
toBuilder() - Method in class org.tensorflow.framework.RunOptions.Experimental
 
toBuilder() - Method in class org.tensorflow.framework.RunOptions
 
toBuilder() - Method in class org.tensorflow.framework.SavedModel
 
toBuilder() - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
toBuilder() - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
toBuilder() - Method in class org.tensorflow.framework.SignatureDef
 
toBuilder() - Method in class org.tensorflow.framework.StepStats
 
toBuilder() - Method in class org.tensorflow.framework.Summary.Audio
 
toBuilder() - Method in class org.tensorflow.framework.Summary.Image
 
toBuilder() - Method in class org.tensorflow.framework.Summary
 
toBuilder() - Method in class org.tensorflow.framework.Summary.Value
 
toBuilder() - Method in class org.tensorflow.framework.SummaryDescription
 
toBuilder() - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
toBuilder() - Method in class org.tensorflow.framework.SummaryMetadata
 
toBuilder() - Method in class org.tensorflow.framework.TensorConnection
 
toBuilder() - Method in class org.tensorflow.framework.TensorDescription
 
toBuilder() - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
toBuilder() - Method in class org.tensorflow.framework.TensorInfo
 
toBuilder() - Method in class org.tensorflow.framework.TensorProto
 
toBuilder() - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
toBuilder() - Method in class org.tensorflow.framework.TensorShapeProto
 
toBuilder() - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
toBuilder() - Method in class org.tensorflow.framework.TensorSliceProto
 
toBuilder() - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
toBuilder() - Method in class org.tensorflow.framework.ValuesDef
 
toBuilder() - Method in class org.tensorflow.framework.VariableDef
 
toBuilder() - Method in class org.tensorflow.framework.VariantTensorDataProto
 
toBuilder() - Method in class org.tensorflow.framework.VersionDef
 
toBuilder() - Method in class org.tensorflow.framework.WhileContextDef
 
toBuilder() - Method in class org.tensorflow.util.BundleEntryProto
 
toBuilder() - Method in class org.tensorflow.util.BundleHeaderProto
 
toBuilder() - Method in class org.tensorflow.util.Event
 
toBuilder() - Method in class org.tensorflow.util.IteratorStateMetadata
 
toBuilder() - Method in class org.tensorflow.util.LogMessage
 
toBuilder() - Method in class org.tensorflow.util.SavedSlice
 
toBuilder() - Method in class org.tensorflow.util.SavedSliceMeta
 
toBuilder() - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
toBuilder() - Method in class org.tensorflow.util.SavedTensorSlices
 
toBuilder() - Method in class org.tensorflow.util.SaverDef
 
toBuilder() - Method in class org.tensorflow.util.SessionLog
 
toBuilder() - Method in class org.tensorflow.util.TaggedRunMetadata
 
toBuilder() - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
toBuilder() - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
toBuilder() - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
toBuilder() - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
toBuilder() - Method in class org.tensorflow.util.testlog.CommitId
 
toBuilder() - Method in class org.tensorflow.util.testlog.CPUInfo
 
toBuilder() - Method in class org.tensorflow.util.testlog.EntryValue
 
toBuilder() - Method in class org.tensorflow.util.testlog.GPUInfo
 
toBuilder() - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
toBuilder() - Method in class org.tensorflow.util.testlog.MemoryInfo
 
toBuilder() - Method in class org.tensorflow.util.testlog.PlatformInfo
 
toBuilder() - Method in class org.tensorflow.util.testlog.RunConfiguration
 
toBuilder() - Method in class org.tensorflow.util.testlog.TestResults
 
toBuilder() - Method in class org.tensorflow.util.WatchdogConfig
 
toBuilder() - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
toBuilder() - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
toBuilder() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
toBuilder() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
toBuilder() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
toBuilder() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
toBuilder() - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
toBuilder() - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
toBuilder() - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
toBuilder() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
toBuilder() - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
toBuilder() - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
TOLERATE_DEBUG_OP_CREATION_FAILURES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.DebugTensorWatch
 
TOTAL_BYTES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AllocatorMemoryUsed
 
TOTAL_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.MemoryInfo
 
TRACE_LEVEL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunOptions
 
TRAINABLE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VariableDef
 
TransportOptions - Class in tensorflow
 
TransportOptions.RecvBufRespExtra - Class in tensorflow
Extra data needed on a non-RDMA RecvBufResponse.
TransportOptions.RecvBufRespExtra.Builder - Class in tensorflow
Extra data needed on a non-RDMA RecvBufResponse.
TransportOptions.RecvBufRespExtraOrBuilder - Interface in tensorflow
 
TWO_VALUE - Static variable in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
TWO = 2;
TYPE_ATTR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.ArgDef
 
TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue.ListValue
 
TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.AttrValue
 
TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.InterconnectLink
 
TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.ArgDef
 
TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.AttrDef
 
TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedSliceMeta
 
TYPE_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
TYPE_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
TYPE_HINT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SummaryDescription
 
TYPE_LIST_ATTR_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDef.ArgDef
 
TYPE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphTransferNodeInfo
 
TYPE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VariantTensorDataProto
 
TypesProtos - Class in org.tensorflow.framework
 

U

UINT32_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
UINT64_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
UNAUTHENTICATED_VALUE - Static variable in enum org.tensorflow.framework.Code
The request does not have valid authentication credentials for the operation.
UNAVAILABLE_VALUE - Static variable in enum org.tensorflow.framework.Code
The service is currently unavailable.
UNIMPLEMENTED_VALUE - Static variable in enum org.tensorflow.framework.Code
Operation is not implemented or not supported/enabled in this service.
UNKNOWN_RANK_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorShapeProto
 
UNKNOWN_VALUE - Static variable in enum org.tensorflow.framework.Code
Unknown error.
UNKNOWN_VALUE - Static variable in enum org.tensorflow.util.LogMessage.Level
UNKNOWN = 0;
UNKNOWN_VALUE - Static variable in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
Fallback for protos written before Type was introduced.
USE_NUMA_AFFINITY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto.Experimental
 
USE_PER_SESSION_THREADS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ConfigProto
 
USE_RPC_FOR_INPROCESS_MASTER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RPCOptions
 
USE_RUN_HANDLER_POOL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.RunOptions.Experimental
 
USE_UNIFIED_MEMORY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions.Experimental
 
UUID_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.GPUInfo
 

V

V1_VALUE - Static variable in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
Deprecated format: tf.Saver() which works with tensorflow::table::Table.
V2_VALUE - Static variable in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
Current format: more efficient.
VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.example.BytesList
 
VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.example.FloatList
 
VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.example.Int64List
 
VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CollectionDef.AnyList
 
VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CollectionDef.BytesList
 
VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CollectionDef.FloatList
 
VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CollectionDef.Int64List
 
VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CollectionDef.NodeList
 
VALUE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary
 
valueOf(String) - Static method in enum org.tensorflow.example.Feature.KindCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.example.Feature.KindCase
Deprecated.
valueOf(String) - Static method in enum org.tensorflow.example.FeatureConfiguration.ConfigCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.example.FeatureConfiguration.ConfigCase
valueOf(String) - Static method in enum org.tensorflow.framework.ApiDef.Visibility
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.ApiDef.Visibility
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.framework.ApiDef.Visibility
 
valueOf(String) - Static method in enum org.tensorflow.framework.AttrValue.ValueCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.AttrValue.ValueCase
Deprecated.
valueOf(String) - Static method in enum org.tensorflow.framework.Code
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.Code
Deprecated.
Use Code.forNumber(int) instead.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.framework.Code
 
valueOf(String) - Static method in enum org.tensorflow.framework.CollectionDef.KindCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.CollectionDef.KindCase
Deprecated.
valueOf(String) - Static method in enum org.tensorflow.framework.ControlFlowContextDef.CtxtCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.ControlFlowContextDef.CtxtCase
valueOf(String) - Static method in enum org.tensorflow.framework.DataType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.DataType
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.framework.DataType
 
valueOf(String) - Static method in enum org.tensorflow.framework.GraphTransferInfo.Destination
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.GraphTransferInfo.Destination
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.framework.GraphTransferInfo.Destination
 
valueOf(String) - Static method in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
 
valueOf(String) - Static method in enum org.tensorflow.framework.OptimizerOptions.Level
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.OptimizerOptions.Level
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.framework.OptimizerOptions.Level
 
valueOf(String) - Static method in enum org.tensorflow.framework.RewriterConfig.MemOptType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.RewriterConfig.MemOptType
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.framework.RewriterConfig.MemOptType
 
valueOf(String) - Static method in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
 
valueOf(String) - Static method in enum org.tensorflow.framework.RewriterConfig.Toggle
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.RewriterConfig.Toggle
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.framework.RewriterConfig.Toggle
 
valueOf(String) - Static method in enum org.tensorflow.framework.RunOptions.TraceLevel
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.RunOptions.TraceLevel
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.framework.RunOptions.TraceLevel
 
valueOf(String) - Static method in enum org.tensorflow.framework.Summary.Value.ValueCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.Summary.Value.ValueCase
Deprecated.
valueOf(String) - Static method in enum org.tensorflow.framework.TensorInfo.EncodingCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.TensorInfo.EncodingCase
Deprecated.
valueOf(String) - Static method in enum org.tensorflow.framework.TensorSliceProto.Extent.HasLengthCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.framework.TensorSliceProto.Extent.HasLengthCase
valueOf(String) - Static method in enum org.tensorflow.util.BundleHeaderProto.Endianness
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.util.BundleHeaderProto.Endianness
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.util.BundleHeaderProto.Endianness
 
valueOf(String) - Static method in enum org.tensorflow.util.Event.WhatCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.util.Event.WhatCase
Deprecated.
valueOf(String) - Static method in enum org.tensorflow.util.LogMessage.Level
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.util.LogMessage.Level
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.util.LogMessage.Level
 
valueOf(String) - Static method in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
 
valueOf(String) - Static method in enum org.tensorflow.util.SessionLog.SessionStatus
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.util.SessionLog.SessionStatus
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.util.SessionLog.SessionStatus
 
valueOf(String) - Static method in enum org.tensorflow.util.testlog.CommitId.KindCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.util.testlog.CommitId.KindCase
Deprecated.
valueOf(String) - Static method in enum org.tensorflow.util.testlog.EntryValue.KindCase
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.util.testlog.EntryValue.KindCase
Deprecated.
valueOf(String) - Static method in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
 
valueOf(String) - Static method in enum org.tensorflow.util.WorkerHealth
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.util.WorkerHealth
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.util.WorkerHealth
 
valueOf(String) - Static method in enum org.tensorflow.util.WorkerShutdownMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum org.tensorflow.util.WorkerShutdownMode
Deprecated.
valueOf(Descriptors.EnumValueDescriptor) - Static method in enum org.tensorflow.util.WorkerShutdownMode
 
values() - Static method in enum org.tensorflow.example.Feature.KindCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.example.FeatureConfiguration.ConfigCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.ApiDef.Visibility
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.AttrValue.ValueCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.Code
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.CollectionDef.KindCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.ControlFlowContextDef.CtxtCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.DataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.GraphTransferInfo.Destination
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.OptimizerOptions.GlobalJitLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.OptimizerOptions.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.RewriterConfig.MemOptType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.RewriterConfig.NumIterationsType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.RewriterConfig.Toggle
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.RunOptions.TraceLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.Summary.Value.ValueCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.TensorInfo.EncodingCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.framework.TensorSliceProto.Extent.HasLengthCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.util.BundleHeaderProto.Endianness
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.util.Event.WhatCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.util.LogMessage.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.util.SaverDef.CheckpointFormatVersion
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.util.SessionLog.SessionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.util.testlog.CommitId.KindCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.util.testlog.EntryValue.KindCase
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.util.testlog.TestResults.BenchmarkType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.util.WorkerHealth
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.tensorflow.util.WorkerShutdownMode
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.CondContextDef
 
VALUES_DEF_FIELD_NUMBER - Static variable in class org.tensorflow.framework.WhileContextDef
 
VALUES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ValuesDef
 
VALUES_OUTPUT_TENSOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.example.FixedLenFeatureProto
 
VALUES_OUTPUT_TENSOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.example.VarLenFeatureProto
 
VALUES_TENSOR_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorInfo.CooSparse
 
ValuesDef - Class in org.tensorflow.framework
Protocol buffer representing the values in ControlFlowContext.
ValuesDef.Builder - Class in org.tensorflow.framework
Protocol buffer representing the values in ControlFlowContext.
ValuesDefOrBuilder - Interface in org.tensorflow.framework
 
VAR_LEN_FEATURE_FIELD_NUMBER - Static variable in class org.tensorflow.example.FeatureConfiguration
 
VAR_OFFSET_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SaveSliceInfoDef
 
VAR_SHAPE_FIELD_NUMBER - Static variable in class org.tensorflow.framework.SaveSliceInfoDef
 
VARIABLE_NAME_FIELD_NUMBER - Static variable in class org.tensorflow.framework.VariableDef
 
VariableDef - Class in org.tensorflow.framework
Protocol buffer representing a Variable.
VariableDef.Builder - Class in org.tensorflow.framework
Protocol buffer representing a Variable.
VariableDefOrBuilder - Interface in org.tensorflow.framework
 
VariableProtos - Class in org.tensorflow.framework
 
VARIANT_VAL_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
VariantTensorDataProto - Class in org.tensorflow.framework
Protocol buffer representing the serialization format of DT_VARIANT tensors.
VariantTensorDataProto.Builder - Class in org.tensorflow.framework
Protocol buffer representing the serialization format of DT_VARIANT tensors.
VariantTensorDataProtoOrBuilder - Interface in org.tensorflow.framework
 
VarLenFeatureProto - Class in org.tensorflow.example
Protobuf type tensorflow.VarLenFeatureProto
VarLenFeatureProto.Builder - Class in org.tensorflow.example
Protobuf type tensorflow.VarLenFeatureProto
VarLenFeatureProtoOrBuilder - Interface in org.tensorflow.example
 
VENDOR_FIELD_NUMBER - Static variable in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphDef
 
VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.framework.OpDeprecation
 
VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.util.BundleHeaderProto
 
VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.util.IteratorStateMetadata
 
VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.util.SaverDef
 
VERSION_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.PlatformInfo
 
VERSION_NUMBER_FIELD_NUMBER - Static variable in class org.tensorflow.framework.TensorProto
 
VersionDef - Class in org.tensorflow.framework
Version information for a piece of serialized data There are different types of versions for each type of data (GraphDef, etc.), but they all have the same common shape described here.
VersionDef.Builder - Class in org.tensorflow.framework
Version information for a piece of serialized data There are different types of versions for each type of data (GraphDef, etc.), but they all have the same common shape described here.
VersionDefOrBuilder - Interface in org.tensorflow.framework
 
VERSIONS_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GraphDef
 
VERSIONS_FIELD_NUMBER - Static variable in class org.tensorflow.util.SavedTensorSliceMeta
 
VersionsProtos - Class in org.tensorflow.framework
 
VIRTUAL_DEVICES_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions.Experimental
 
VISIBILITY_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ApiDef
 
VISIBLE_DEVICE_LIST_FIELD_NUMBER - Static variable in class org.tensorflow.framework.GPUOptions
 
VISIBLE_VALUE - Static variable in enum org.tensorflow.framework.ApiDef.Visibility
Publicly visible in the API.

W

WAIT_FOR_COORDINATOR_VALUE - Static variable in enum org.tensorflow.util.WorkerShutdownMode
WAIT_FOR_COORDINATOR = 2;
WALL_TIME_FIELD_NUMBER - Static variable in class org.tensorflow.util.Event
 
WALL_TIME_FIELD_NUMBER - Static variable in class org.tensorflow.util.testlog.BenchmarkEntry
 
WARN_VALUE - Static variable in enum org.tensorflow.util.LogMessage.Level
WARN = 30;
WATCHDOG_CONFIG_FIELD_NUMBER - Static variable in class org.tensorflow.util.WorkerHeartbeatRequest
 
WatchdogConfig - Class in org.tensorflow.util
Protobuf type tensorflow.WatchdogConfig
WatchdogConfig.Builder - Class in org.tensorflow.util
Protobuf type tensorflow.WatchdogConfig
WatchdogConfigOrBuilder - Interface in org.tensorflow.util
 
WHILE_CTXT_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ControlFlowContextDef
 
WhileContextDef - Class in org.tensorflow.framework
Protocol buffer representing a WhileContext object.
WhileContextDef.Builder - Class in org.tensorflow.framework
Protocol buffer representing a WhileContext object.
WhileContextDefOrBuilder - Interface in org.tensorflow.framework
 
WIDTH_FIELD_NUMBER - Static variable in class org.tensorflow.framework.Summary.Image
 
WORK_FINISHED_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ReaderBaseState
 
WORK_STARTED_FIELD_NUMBER - Static variable in class org.tensorflow.framework.ReaderBaseState
 
WORKER_LOG_FIELD_NUMBER - Static variable in class org.tensorflow.util.WorkerHeartbeatResponse
 
WorkerHealth - Enum in org.tensorflow.util
Current health status of a worker.
WorkerHeartbeatRequest - Class in org.tensorflow.util
Protobuf type tensorflow.WorkerHeartbeatRequest
WorkerHeartbeatRequest.Builder - Class in org.tensorflow.util
Protobuf type tensorflow.WorkerHeartbeatRequest
WorkerHeartbeatRequestOrBuilder - Interface in org.tensorflow.util
 
WorkerHeartbeatResponse - Class in org.tensorflow.util
Protobuf type tensorflow.WorkerHeartbeatResponse
WorkerHeartbeatResponse.Builder - Class in org.tensorflow.util
Protobuf type tensorflow.WorkerHeartbeatResponse
WorkerHeartbeatResponseOrBuilder - Interface in org.tensorflow.util
 
WorkerShutdownMode - Enum in org.tensorflow.util
Indicates the behavior of the worker when an internal error or shutdown signal is received.
writeTo(CodedOutputStream) - Method in class org.tensorflow.distruntime.ClusterDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.distruntime.JobDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.distruntime.ServerDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.BytesList
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.Example
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.ExampleParserConfiguration
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.Feature
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.FeatureConfiguration
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.FeatureList
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.FeatureLists
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.Features
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.FixedLenFeatureProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.FloatList
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.Int64List
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.SequenceExample
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.example.VarLenFeatureProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.AllocationDescription
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.AllocationRecord
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.AllocatorMemoryUsed
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ApiDef.Arg
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ApiDef.Attr
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ApiDef.Endpoint
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ApiDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ApiDefs
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.AssetFileDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.AttrValue.ListValue
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.AttrValue
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.AutoParallelOptions
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CallableOptions
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CollectionDef.AnyList
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CollectionDef.BytesList
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CollectionDef.FloatList
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CollectionDef.Int64List
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CollectionDef.NodeList
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CollectionDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CondContextDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ConfigProto.Experimental
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ConfigProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ControlFlowContextDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CostGraphDef.Node.InputInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CostGraphDef.Node.OutputInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CostGraphDef.Node
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.CostGraphDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.DebuggedSourceFile
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.DebuggedSourceFiles
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.DebugOptions
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.DebugTensorWatch
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.DeviceAttributes
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.DeviceLocality
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.DeviceStepStats
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.FunctionDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.FunctionDefLibrary
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GPUOptions.Experimental.VirtualDevices
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GPUOptions.Experimental
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GPUOptions
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GradientDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GraphDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GraphOptions
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GraphTransferConstNodeInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GraphTransferGraphInputNodeInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GraphTransferGraphOutputNodeInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GraphTransferInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GraphTransferNodeInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GraphTransferNodeInput
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GraphTransferNodeInputInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.GraphTransferNodeOutputInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.HistogramProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.InterconnectLink
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.KernelDef.AttrConstraint
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.KernelDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.KernelList
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.LocalLinks
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.MemoryLogRawAllocation
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.MemoryLogRawDeallocation
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.MemoryLogStep
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.MemoryLogTensorAllocation
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.MemoryLogTensorDeallocation
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.MemoryLogTensorOutput
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.MemoryStats
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.MetaGraphDef.MetaInfoDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.MetaGraphDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.NameAttrList
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.NamedTensorProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.NodeDef.ExperimentalDebugInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.NodeDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.NodeExecStats
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.NodeOutput
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.OpDef.ArgDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.OpDef.AttrDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.OpDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.OpDeprecation
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.OpList
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.OptimizerOptions
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.QueueRunnerDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ReaderBaseState
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo.TensorShapeTypeProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.RemoteFusedGraphExecuteInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ResourceHandleProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.RewriterConfig.CustomGraphOptimizer
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.RewriterConfig
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.RPCOptions
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.RunMetadata
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.RunOptions.Experimental
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.RunOptions
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.SavedModel
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.SaveSliceInfoDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ScopedAllocatorOptions
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.SignatureDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.StepStats
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.Summary.Audio
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.Summary.Image
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.Summary.Value
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.Summary
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.SummaryDescription
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.SummaryMetadata.PluginData
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.SummaryMetadata
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.TensorConnection
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.TensorDescription
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.TensorInfo.CooSparse
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.TensorInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.TensorProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.TensorShapeProto.Dim
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.TensorShapeProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.TensorSliceProto.Extent
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.TensorSliceProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ThreadPoolOptionProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.ValuesDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.VariableDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.VariantTensorDataProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.VersionDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.framework.WhileContextDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.BundleEntryProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.BundleHeaderProto
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.Event
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.IteratorStateMetadata
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.LogMessage
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.SavedSlice
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.SavedSliceMeta
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.SavedTensorSliceMeta
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.SavedTensorSlices
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.SaverDef
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.SessionLog
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.TaggedRunMetadata
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.AvailableDeviceInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.BenchmarkEntries
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.BenchmarkEntry
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.BuildConfiguration
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.CommitId
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.CPUInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.EntryValue
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.GPUInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.MachineConfiguration
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.MemoryInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.PlatformInfo
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.RunConfiguration
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.testlog.TestResults
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.WatchdogConfig
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.WorkerHeartbeatRequest
 
writeTo(CodedOutputStream) - Method in class org.tensorflow.util.WorkerHeartbeatResponse
 
writeTo(CodedOutputStream) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.ObjectReference
 
writeTo(CodedOutputStream) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SerializedTensor
 
writeTo(CodedOutputStream) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject.SlotVariableReference
 
writeTo(CodedOutputStream) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph.CheckpointableObject
 
writeTo(CodedOutputStream) - Method in class tensorflow.CheckpointableObjectGraphOuterClass.CheckpointableObjectGraph
 
writeTo(CodedOutputStream) - Method in class tensorflow.DevicePropertiesProtos.DeviceProperties
 
writeTo(CodedOutputStream) - Method in class tensorflow.DevicePropertiesProtos.NamedDevice
 
writeTo(CodedOutputStream) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectory
 
writeTo(CodedOutputStream) - Method in class tensorflow.MemmappedFileSystem.MemmappedFileSystemDirectoryElement
 
writeTo(CodedOutputStream) - Method in class tensorflow.TransportOptions.RecvBufRespExtra
 
A B C D E F G H I J K L M N O P Q R S T U V W 
Skip navigation links

Copyright © 2015–2019. All rights reserved.