Package | Description |
---|---|
org.tensorflow |
Defines classes to build, save, load and execute TensorFlow models.
|
org.tensorflow.op | |
org.tensorflow.op.core |
Modifier and Type | Method and Description |
---|---|
static Shape |
Shape.make(long firstDimensionSize,
long... otherDimensionSizes)
Create a Shape representing an N-dimensional value.
|
static Shape |
Shape.scalar()
Create a Shape representing a scalar value.
|
Shape |
Output.shape()
Returns the (possibly partially known) shape of the tensor referred to by this Output.
|
static Shape |
Shape.unknown()
Create a Shape representing an unknown number of dimensions.
|
Modifier and Type | Method and Description |
---|---|
OperationBuilder |
OperationBuilder.setAttr(String name,
Shape value) |
OperationBuilder |
OperationBuilder.setAttr(String name,
Shape[] value) |
Modifier and Type | Method and Description |
---|---|
<T> AccumulateNV2<T> |
Ops.accumulateNV2(Operand<T> inputs,
Shape shape)
Adds an
AccumulateNV2 operation to the graph |
<T> ConditionalAccumulator |
Ops.conditionalAccumulator(Class<T> dtype,
Shape shape,
ConditionalAccumulator.Options... options)
Adds an
ConditionalAccumulator operation to the graph |
<T> EnsureShape<T> |
Ops.ensureShape(Operand<T> input,
Shape shape)
Adds an
EnsureShape operation to the graph |
<T> ImmutableConst<T> |
Ops.immutableConst(Class<T> dtype,
Shape shape,
String memoryRegionName)
Adds an
ImmutableConst operation to the graph |
<T> ParallelConcat<T> |
Ops.parallelConcat(Operand<T> values,
Shape shape)
Adds an
ParallelConcat operation to the graph |
<T> PlaceholderV2<T> |
Ops.placeholderV2(Class<T> dtype,
Shape shape)
Adds an
PlaceholderV2 operation to the graph |
<T> PlaceholderWithDefault<T> |
Ops.placeholderWithDefault(Operand<T> input,
Shape shape)
Adds an
PlaceholderWithDefault operation to the graph |
<T> SparseConditionalAccumulator |
Ops.sparseConditionalAccumulator(Class<T> dtype,
Shape shape,
SparseConditionalAccumulator.Options... options)
Adds an
SparseConditionalAccumulator operation to the graph |
<T> TemporaryVariable<T> |
Ops.temporaryVariable(Shape shape,
Class<T> dtype,
TemporaryVariable.Options... options)
Adds an
TemporaryVariable operation to the graph |
<T> VarHandleOp |
Ops.varHandleOp(Class<T> dtype,
Shape shape,
VarHandleOp.Options... options)
Adds an
VarHandleOp operation to the graph |
<T> Variable<T> |
Ops.variable(Shape shape,
Class<T> dtype,
Variable.Options... options)
Adds an
Variable operation to the graph |
Modifier and Type | Method and Description |
---|---|
AnonymousIterator |
Ops.anonymousIterator(List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
AnonymousIterator operation to the graph |
Iterator |
Ops.iterator(String sharedName,
String container,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
Iterator operation to the graph |
IteratorGetNext |
Ops.iteratorGetNext(Operand<?> iterator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
IteratorGetNext operation to the graph |
IteratorGetNextAsOptional |
Ops.iteratorGetNextAsOptional(Operand<?> iterator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
IteratorGetNextAsOptional operation to the graph |
IteratorGetNextSync |
Ops.iteratorGetNextSync(Operand<?> iterator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
IteratorGetNextSync operation to the graph |
OptionalGetValue |
Ops.optionalGetValue(Operand<?> optional,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
OptionalGetValue operation to the graph |
ParseExample |
Ops.parseExample(Operand<String> serialized,
Operand<String> names,
Iterable<Operand<String>> sparseKeys,
Iterable<Operand<String>> denseKeys,
Iterable<Operand<?>> denseDefaults,
List<Class<?>> sparseTypes,
List<Shape> denseShapes)
Adds an
ParseExample operation to the graph |
ParseSingleExample |
Ops.parseSingleExample(Operand<String> serialized,
Iterable<Operand<?>> denseDefaults,
Long numSparse,
List<String> sparseKeys,
List<String> denseKeys,
List<Class<?>> sparseTypes,
List<Shape> denseShapes)
Adds an
ParseSingleExample operation to the graph |
PriorityQueue |
Ops.priorityQueue(List<Class<?>> componentTypes,
List<Shape> shapes,
PriorityQueue.Options... options)
Adds an
PriorityQueue operation to the graph |
Modifier and Type | Method and Description |
---|---|
static <T extends Number> |
CollectiveBcastRecv.create(Scope scope,
Class<T> T,
Long groupSize,
Long groupKey,
Long instanceKey,
Shape shape)
Factory method to create a class to wrap a new CollectiveBcastRecv operation to the graph.
|
static <T> PlaceholderV2<T> |
PlaceholderV2.create(Scope scope,
Class<T> dtype,
Shape shape)
Factory method to create a class to wrap a new PlaceholderV2 operation to the graph.
|
static <T> ConditionalAccumulator |
ConditionalAccumulator.create(Scope scope,
Class<T> dtype,
Shape shape,
ConditionalAccumulator.Options... options)
Factory method to create a class to wrap a new ConditionalAccumulator operation to the graph.
|
static <T> SparseConditionalAccumulator |
SparseConditionalAccumulator.create(Scope scope,
Class<T> dtype,
Shape shape,
SparseConditionalAccumulator.Options... options)
Factory method to create a class to wrap a new SparseConditionalAccumulator operation to the graph.
|
static <T> ImmutableConst<T> |
ImmutableConst.create(Scope scope,
Class<T> dtype,
Shape shape,
String memoryRegionName)
Factory method to create a class to wrap a new ImmutableConst operation to the graph.
|
static <T> VarHandleOp |
VarHandleOp.create(Scope scope,
Class<T> dtype,
Shape shape,
VarHandleOp.Options... options)
Factory method to create a class to wrap a new VarHandleOp operation to the graph.
|
static <T extends Number> |
CollectiveBcastSend.create(Scope scope,
Operand<T> input,
Long groupSize,
Long groupKey,
Long instanceKey,
Shape shape)
Factory method to create a class to wrap a new CollectiveBcastSend operation to the graph.
|
static <T> EnsureShape<T> |
EnsureShape.create(Scope scope,
Operand<T> input,
Shape shape)
Factory method to create a class to wrap a new EnsureShape operation to the graph.
|
static <T> AccumulateNV2<T> |
AccumulateNV2.create(Scope scope,
Operand<T> inputs,
Shape shape)
Factory method to create a class to wrap a new AccumulateNV2 operation to the graph.
|
static <T> ParallelConcat<T> |
ParallelConcat.create(Scope scope,
Operand<T> values,
Shape shape)
Factory method to create a class to wrap a new ParallelConcat operation to the graph.
|
static <T> PlaceholderWithDefault<T> |
PlaceholderWithDefault.create(Scope scope,
Operand<T> input,
Shape shape)
Factory method to create a class to wrap a new PlaceholderWithDefault operation to the graph.
|
static <T extends Number> |
NcclBroadcast.create(Scope scope,
Operand<T> input,
Shape shape)
Factory method to create a class to wrap a new NcclBroadcast operation to the graph.
|
static <T> TemporaryVariable<T> |
TemporaryVariable.create(Scope scope,
Shape shape,
Class<T> dtype,
TemporaryVariable.Options... options)
Factory method to create a class to wrap a new TemporaryVariable operation to the graph.
|
static <T> Variable<T> |
Variable.create(Scope scope,
Shape shape,
Class<T> dtype,
Variable.Options... options)
Factory method to create a class to wrap a new Variable operation to the graph.
|
static TensorArrayGather.Options |
TensorArrayGather.elementShape(Shape elementShape) |
TensorArrayGather.Options |
TensorArrayGather.Options.elementShape(Shape elementShape) |
static TensorArray.Options |
TensorArray.elementShape(Shape elementShape) |
TensorArray.Options |
TensorArray.Options.elementShape(Shape elementShape) |
static TensorArrayPack.Options |
TensorArrayPack.elementShape(Shape elementShape) |
TensorArrayPack.Options |
TensorArrayPack.Options.elementShape(Shape elementShape) |
static TensorArrayConcat.Options |
TensorArrayConcat.elementShapeExcept0(Shape elementShapeExcept0) |
TensorArrayConcat.Options |
TensorArrayConcat.Options.elementShapeExcept0(Shape elementShapeExcept0) |
static Placeholder.Options |
Placeholder.shape(Shape shape) |
Placeholder.Options |
Placeholder.Options.shape(Shape shape) |
static MutableDenseHashTable.Options |
MutableDenseHashTable.valueShape(Shape valueShape) |
MutableDenseHashTable.Options |
MutableDenseHashTable.Options.valueShape(Shape valueShape) |
static MutableHashTableOfTensors.Options |
MutableHashTableOfTensors.valueShape(Shape valueShape) |
MutableHashTableOfTensors.Options |
MutableHashTableOfTensors.Options.valueShape(Shape valueShape) |
Modifier and Type | Method and Description |
---|---|
static ParseSingleSequenceExample.Options |
ParseSingleSequenceExample.contextDenseShapes(List<Shape> contextDenseShapes) |
ParseSingleSequenceExample.Options |
ParseSingleSequenceExample.Options.contextDenseShapes(List<Shape> contextDenseShapes) |
static ParseSequenceExample.Options |
ParseSequenceExample.contextDenseShapes(List<Shape> contextDenseShapes) |
ParseSequenceExample.Options |
ParseSequenceExample.Options.contextDenseShapes(List<Shape> contextDenseShapes) |
static ZipDataset |
ZipDataset.create(Scope scope,
Iterable<Operand<?>> inputDatasets,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ZipDataset operation to the graph.
|
static TensorSliceDataset |
TensorSliceDataset.create(Scope scope,
Iterable<Operand<?>> components,
List<Shape> outputShapes)
Factory method to create a class to wrap a new TensorSliceDataset operation to the graph.
|
static TensorDataset |
TensorDataset.create(Scope scope,
Iterable<Operand<?>> components,
List<Shape> outputShapes)
Factory method to create a class to wrap a new TensorDataset operation to the graph.
|
static AnonymousIterator |
AnonymousIterator.create(Scope scope,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new AnonymousIterator operation to the graph.
|
static PriorityQueue |
PriorityQueue.create(Scope scope,
List<Class<?>> componentTypes,
List<Shape> shapes,
PriorityQueue.Options... options)
Factory method to create a class to wrap a new PriorityQueue operation to the graph.
|
static MultiDeviceIterator |
MultiDeviceIterator.create(Scope scope,
List<String> devices,
String sharedName,
String container,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new MultiDeviceIterator operation to the graph.
|
static ExperimentalDirectedInterleaveDataset |
ExperimentalDirectedInterleaveDataset.create(Scope scope,
Operand<?> selectorInputDataset,
Iterable<Operand<?>> dataInputDatasets,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalDirectedInterleaveDataset operation to the graph.
|
static ExperimentalNonSerializableDataset |
ExperimentalNonSerializableDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalNonSerializableDataset operation to the graph.
|
static DatasetToSingleElement |
DatasetToSingleElement.create(Scope scope,
Operand<?> dataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new DatasetToSingleElement operation to the graph.
|
static IteratorGetNextSync |
IteratorGetNextSync.create(Scope scope,
Operand<?> iterator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new IteratorGetNextSync operation to the graph.
|
static IteratorGetNext |
IteratorGetNext.create(Scope scope,
Operand<?> iterator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new IteratorGetNext operation to the graph.
|
static ModelDataset |
ModelDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ModelDataset operation to the graph.
|
static IteratorGetNextAsOptional |
IteratorGetNextAsOptional.create(Scope scope,
Operand<?> iterator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new IteratorGetNextAsOptional operation to the graph.
|
static ExperimentalUniqueDataset |
ExperimentalUniqueDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalUniqueDataset operation to the graph.
|
static OptionalGetValue |
OptionalGetValue.create(Scope scope,
Operand<?> optional,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new OptionalGetValue operation to the graph.
|
static ExperimentalUnbatchDataset |
ExperimentalUnbatchDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalUnbatchDataset operation to the graph.
|
static ExperimentalIgnoreErrorsDataset |
ExperimentalIgnoreErrorsDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalIgnoreErrorsDataset operation to the graph.
|
static FilterByLastComponentDataset |
FilterByLastComponentDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new FilterByLastComponentDataset operation to the graph.
|
static ExperimentalThreadPoolDataset |
ExperimentalThreadPoolDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<?> threadPool,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalThreadPoolDataset operation to the graph.
|
static ExperimentalIndexedDatasetGet |
ExperimentalIndexedDatasetGet.create(Scope scope,
Operand<?> materialized,
Operand<?> index,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalIndexedDatasetGet operation to the graph.
|
static ConcatenateDataset |
ConcatenateDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<?> anotherDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ConcatenateDataset operation to the graph.
|
static ExperimentalSetStatsAggregatorDataset |
ExperimentalSetStatsAggregatorDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<?> statsAggregator,
Operand<String> tag,
Operand<String> counterPrefix,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalSetStatsAggregatorDataset operation to the graph.
|
static MultiDeviceIteratorGetNextFromShard |
MultiDeviceIteratorGetNextFromShard.create(Scope scope,
Operand<?> multiDeviceIterator,
Operand<Integer> shardNum,
Operand<Long> incarnationId,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new MultiDeviceIteratorGetNextFromShard operation to the graph.
|
static ExperimentalParseExampleDataset |
ExperimentalParseExampleDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numParallelCalls,
Iterable<Operand<?>> denseDefaults,
List<String> sparseKeys,
List<String> denseKeys,
List<Class<?>> sparseTypes,
List<Shape> denseShapes,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
ExperimentalParseExampleDataset.Options... options)
Factory method to create a class to wrap a new ExperimentalParseExampleDataset operation to the graph.
|
static ExperimentalParseExampleDataset |
ExperimentalParseExampleDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numParallelCalls,
Iterable<Operand<?>> denseDefaults,
List<String> sparseKeys,
List<String> denseKeys,
List<Class<?>> sparseTypes,
List<Shape> denseShapes,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
ExperimentalParseExampleDataset.Options... options)
Factory method to create a class to wrap a new ExperimentalParseExampleDataset operation to the graph.
|
static PaddedBatchDataset |
PaddedBatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Iterable<Operand<Long>> paddedShapes,
Iterable<Operand<?>> paddingValues,
List<Shape> outputShapes)
Factory method to create a class to wrap a new PaddedBatchDataset operation to the graph.
|
static PaddedBatchDatasetV2 |
PaddedBatchDatasetV2.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Iterable<Operand<Long>> paddedShapes,
Iterable<Operand<?>> paddingValues,
Operand<Boolean> dropRemainder,
List<Shape> outputShapes)
Factory method to create a class to wrap a new PaddedBatchDatasetV2 operation to the graph.
|
static ExperimentalMaxIntraOpParallelismDataset |
ExperimentalMaxIntraOpParallelismDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> maxIntraOpParallelism,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalMaxIntraOpParallelismDataset operation to the graph.
|
static RepeatDataset |
RepeatDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new RepeatDataset operation to the graph.
|
static PrefetchDataset |
PrefetchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> bufferSize,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new PrefetchDataset operation to the graph.
|
static SkipDataset |
SkipDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new SkipDataset operation to the graph.
|
static ExperimentalPrivateThreadPoolDataset |
ExperimentalPrivateThreadPoolDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numThreads,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalPrivateThreadPoolDataset operation to the graph.
|
static ExperimentalSleepDataset |
ExperimentalSleepDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> sleepMicroseconds,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalSleepDataset operation to the graph.
|
static BatchDataset |
BatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new BatchDataset operation to the graph.
|
static TakeDataset |
TakeDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new TakeDataset operation to the graph.
|
static BatchDatasetV2 |
BatchDatasetV2.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Operand<Boolean> dropRemainder,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new BatchDatasetV2 operation to the graph.
|
static ExperimentalDenseToSparseBatchDataset |
ExperimentalDenseToSparseBatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Operand<Long> rowShape,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalDenseToSparseBatchDataset operation to the graph.
|
static ExperimentalSlidingWindowDataset |
ExperimentalSlidingWindowDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> windowSize,
Operand<Long> windowShift,
Operand<Long> windowStride,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalSlidingWindowDataset operation to the graph.
|
static ShuffleDataset |
ShuffleDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> bufferSize,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
ShuffleDataset.Options... options)
Factory method to create a class to wrap a new ShuffleDataset operation to the graph.
|
static WindowDataset |
WindowDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> size,
Operand<Long> shift,
Operand<Long> stride,
Operand<Boolean> dropRemainder,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new WindowDataset operation to the graph.
|
static ShuffleAndRepeatDataset |
ShuffleAndRepeatDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> bufferSize,
Operand<Long> seed,
Operand<Long> seed2,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ShuffleAndRepeatDataset operation to the graph.
|
static ExperimentalBytesProducedStatsDataset |
ExperimentalBytesProducedStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalBytesProducedStatsDataset operation to the graph.
|
static ExperimentalLatencyStatsDataset |
ExperimentalLatencyStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalLatencyStatsDataset operation to the graph.
|
static OptimizeDataset |
OptimizeDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> optimizations,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new OptimizeDataset operation to the graph.
|
static CacheDataset |
CacheDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new CacheDataset operation to the graph.
|
static ExperimentalAssertNextDataset |
ExperimentalAssertNextDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> transformations,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalAssertNextDataset operation to the graph.
|
static ExperimentalRandomDataset |
ExperimentalRandomDataset.create(Scope scope,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalRandomDataset operation to the graph.
|
static RangeDataset |
RangeDataset.create(Scope scope,
Operand<Long> start,
Operand<Long> stop,
Operand<Long> step,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new RangeDataset operation to the graph.
|
static ParseSingleExample |
ParseSingleExample.create(Scope scope,
Operand<String> serialized,
Iterable<Operand<?>> denseDefaults,
Long numSparse,
List<String> sparseKeys,
List<String> denseKeys,
List<Class<?>> sparseTypes,
List<Shape> denseShapes)
Factory method to create a class to wrap a new ParseSingleExample operation to the graph.
|
static ExperimentalLMDBDataset |
ExperimentalLMDBDataset.create(Scope scope,
Operand<String> filenames,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalLMDBDataset operation to the graph.
|
static ParseExample |
ParseExample.create(Scope scope,
Operand<String> serialized,
Operand<String> names,
Iterable<Operand<String>> sparseKeys,
Iterable<Operand<String>> denseKeys,
Iterable<Operand<?>> denseDefaults,
List<Class<?>> sparseTypes,
List<Shape> denseShapes)
Factory method to create a class to wrap a new ParseExample operation to the graph.
|
static ExperimentalCSVDataset |
ExperimentalCSVDataset.create(Scope scope,
Operand<String> filenames,
Operand<String> compressionType,
Operand<Long> bufferSize,
Operand<Boolean> header,
Operand<String> fieldDelim,
Operand<Boolean> useQuoteDelim,
Operand<String> naValue,
Operand<Long> selectCols,
Iterable<Operand<?>> recordDefaults,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalCSVDataset operation to the graph.
|
static ExperimentalSqlDataset |
ExperimentalSqlDataset.create(Scope scope,
Operand<String> driverName,
Operand<String> dataSourceName,
Operand<String> query,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalSqlDataset operation to the graph.
|
static Iterator |
Iterator.create(Scope scope,
String sharedName,
String container,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new Iterator operation to the graph.
|
static IteratorV2 |
IteratorV2.create(Scope scope,
String sharedName,
String container,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new IteratorV2 operation to the graph.
|
static ExperimentalMaterializedIndexDatasetHandle |
ExperimentalMaterializedIndexDatasetHandle.create(Scope scope,
String container,
String sharedName,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new ExperimentalMaterializedIndexDatasetHandle operation to the graph.
|
static ParseSingleSequenceExample.Options |
ParseSingleSequenceExample.featureListDenseShapes(List<Shape> featureListDenseShapes) |
ParseSingleSequenceExample.Options |
ParseSingleSequenceExample.Options.featureListDenseShapes(List<Shape> featureListDenseShapes) |
static ParseSequenceExample.Options |
ParseSequenceExample.featureListDenseShapes(List<Shape> featureListDenseShapes) |
ParseSequenceExample.Options |
ParseSequenceExample.Options.featureListDenseShapes(List<Shape> featureListDenseShapes) |
static IteratorFromStringHandle.Options |
IteratorFromStringHandle.outputShapes(List<Shape> outputShapes) |
IteratorFromStringHandle.Options |
IteratorFromStringHandle.Options.outputShapes(List<Shape> outputShapes) |
static IteratorFromStringHandleV2.Options |
IteratorFromStringHandleV2.outputShapes(List<Shape> outputShapes) |
IteratorFromStringHandleV2.Options |
IteratorFromStringHandleV2.Options.outputShapes(List<Shape> outputShapes) |
static MultiDeviceIteratorFromStringHandle.Options |
MultiDeviceIteratorFromStringHandle.outputShapes(List<Shape> outputShapes) |
MultiDeviceIteratorFromStringHandle.Options |
MultiDeviceIteratorFromStringHandle.Options.outputShapes(List<Shape> outputShapes) |
static FIFOQueue.Options |
FIFOQueue.shapes(List<Shape> shapes) |
FIFOQueue.Options |
FIFOQueue.Options.shapes(List<Shape> shapes) |
static Barrier.Options |
Barrier.shapes(List<Shape> shapes) |
Barrier.Options |
Barrier.Options.shapes(List<Shape> shapes) |
static RandomShuffleQueue.Options |
RandomShuffleQueue.shapes(List<Shape> shapes) |
RandomShuffleQueue.Options |
RandomShuffleQueue.Options.shapes(List<Shape> shapes) |
static PaddingFIFOQueue.Options |
PaddingFIFOQueue.shapes(List<Shape> shapes) |
PaddingFIFOQueue.Options |
PaddingFIFOQueue.Options.shapes(List<Shape> shapes) |
Copyright © 2015–2019. All rights reserved.