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> 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 |
BatchDataset |
Ops.batchDataset(Operand<?> inputDataset,
Operand<Long> batchSize,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
BatchDataset operation to the graph |
BytesProducedStatsDataset |
Ops.bytesProducedStatsDataset(Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
BytesProducedStatsDataset operation to the graph |
CacheDataset |
Ops.cacheDataset(Operand<?> inputDataset,
Operand<String> filename,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
CacheDataset operation to the graph |
ConcatenateDataset |
Ops.concatenateDataset(Operand<?> inputDataset,
Operand<?> anotherDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
ConcatenateDataset operation to the graph |
DatasetToSingleElement |
Ops.datasetToSingleElement(Operand<?> dataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
DatasetToSingleElement operation to the graph |
DenseToSparseBatchDataset |
Ops.denseToSparseBatchDataset(Operand<?> inputDataset,
Operand<Long> batchSize,
Operand<Long> rowShape,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
DenseToSparseBatchDataset operation to the graph |
FeatureStatsDataset |
Ops.featureStatsDataset(Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
FeatureStatsDataset 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 |
IteratorGetNextSync |
Ops.iteratorGetNextSync(Operand<?> iterator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
IteratorGetNextSync operation to the graph |
LatencyStatsDataset |
Ops.latencyStatsDataset(Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
LatencyStatsDataset operation to the graph |
PaddedBatchDataset |
Ops.paddedBatchDataset(Operand<?> inputDataset,
Operand<Long> batchSize,
Iterable<Operand<Long>> paddedShapes,
Iterable<Operand<?>> paddingValues,
List<Shape> outputShapes)
Adds an
PaddedBatchDataset 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 |
PrefetchDataset |
Ops.prefetchDataset(Operand<?> inputDataset,
Operand<Long> bufferSize,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
PrefetchDataset operation to the graph |
PrependFromQueueAndPaddedBatchDataset |
Ops.prependFromQueueAndPaddedBatchDataset(Operand<?> inputDataset,
Operand<Long> batchSize,
Iterable<Operand<Long>> paddedShapes,
Iterable<Operand<?>> paddingValues,
List<Shape> outputShapes)
Adds an
PrependFromQueueAndPaddedBatchDataset operation to the graph |
PriorityQueue |
Ops.priorityQueue(List<Class<?>> componentTypes,
List<Shape> shapes,
PriorityQueue.Options... options)
Adds an
PriorityQueue operation to the graph |
RandomDataset |
Ops.randomDataset(Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
RandomDataset operation to the graph |
RangeDataset |
Ops.rangeDataset(Operand<Long> start,
Operand<Long> stop,
Operand<Long> step,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
RangeDataset operation to the graph |
RepeatDataset |
Ops.repeatDataset(Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
RepeatDataset operation to the graph |
SetStatsAggregatorDataset |
Ops.setStatsAggregatorDataset(Operand<?> inputDataset,
Operand<?> statsAggregator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
SetStatsAggregatorDataset operation to the graph |
ShuffleAndRepeatDataset |
Ops.shuffleAndRepeatDataset(Operand<?> inputDataset,
Operand<Long> bufferSize,
Operand<Long> seed,
Operand<Long> seed2,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
ShuffleAndRepeatDataset operation to the graph |
ShuffleDataset |
Ops.shuffleDataset(Operand<?> inputDataset,
Operand<Long> bufferSize,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
ShuffleDataset.Options... options)
Adds an
ShuffleDataset operation to the graph |
SkipDataset |
Ops.skipDataset(Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
SkipDataset operation to the graph |
SlideDataset |
Ops.slideDataset(Operand<?> inputDataset,
Operand<Long> windowSize,
Operand<Long> stride,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
SlideDataset operation to the graph |
SqlDataset |
Ops.sqlDataset(Operand<String> driverName,
Operand<String> dataSourceName,
Operand<String> query,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
SqlDataset operation to the graph |
TakeDataset |
Ops.takeDataset(Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
TakeDataset operation to the graph |
TensorDataset |
Ops.tensorDataset(Iterable<Operand<?>> components,
List<Shape> outputShapes)
Adds an
TensorDataset operation to the graph |
TensorSliceDataset |
Ops.tensorSliceDataset(Iterable<Operand<?>> components,
List<Shape> outputShapes)
Adds an
TensorSliceDataset operation to the graph |
UnbatchDataset |
Ops.unbatchDataset(Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
UnbatchDataset operation to the graph |
ZipDataset |
Ops.zipDataset(Iterable<Operand<?>> inputDatasets,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Adds an
ZipDataset 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> 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> 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> 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> 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 TensorArrayPack.Options |
TensorArrayPack.elementShape(Shape elementShape) |
TensorArrayPack.Options |
TensorArrayPack.Options.elementShape(Shape elementShape) |
static TensorArray.Options |
TensorArray.elementShape(Shape elementShape) |
TensorArray.Options |
TensorArray.Options.elementShape(Shape elementShape) |
static TensorArrayGather.Options |
TensorArrayGather.elementShape(Shape elementShape) |
TensorArrayGather.Options |
TensorArrayGather.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 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 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 UnbatchDataset |
UnbatchDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new UnbatchDataset 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 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 SetStatsAggregatorDataset |
SetStatsAggregatorDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<?> statsAggregator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new SetStatsAggregatorDataset 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 PrependFromQueueAndPaddedBatchDataset |
PrependFromQueueAndPaddedBatchDataset.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 PrependFromQueueAndPaddedBatchDataset 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 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 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 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 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 WindowDataset |
WindowDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> windowSize,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new WindowDataset 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 SlideDataset |
SlideDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> windowSize,
Operand<Long> stride,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new SlideDataset operation to the graph.
|
static DenseToSparseBatchDataset |
DenseToSparseBatchDataset.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 DenseToSparseBatchDataset 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 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 LatencyStatsDataset |
LatencyStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new LatencyStatsDataset 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 BytesProducedStatsDataset |
BytesProducedStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new BytesProducedStatsDataset 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 FeatureStatsDataset |
FeatureStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class to wrap a new FeatureStatsDataset operation to the graph.
|
static RandomDataset |
RandomDataset.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 RandomDataset 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 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 SqlDataset |
SqlDataset.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 SqlDataset 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 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 ParseSingleSequenceExample.Options |
ParseSingleSequenceExample.featureListDenseShapes(List<Shape> featureListDenseShapes) |
ParseSingleSequenceExample.Options |
ParseSingleSequenceExample.Options.featureListDenseShapes(List<Shape> featureListDenseShapes) |
static IteratorFromStringHandleV2.Options |
IteratorFromStringHandleV2.outputShapes(List<Shape> outputShapes) |
IteratorFromStringHandleV2.Options |
IteratorFromStringHandleV2.Options.outputShapes(List<Shape> outputShapes) |
static IteratorFromStringHandle.Options |
IteratorFromStringHandle.outputShapes(List<Shape> outputShapes) |
IteratorFromStringHandle.Options |
IteratorFromStringHandle.Options.outputShapes(List<Shape> outputShapes) |
static RandomShuffleQueue.Options |
RandomShuffleQueue.shapes(List<Shape> shapes) |
RandomShuffleQueue.Options |
RandomShuffleQueue.Options.shapes(List<Shape> shapes) |
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 PaddingFIFOQueue.Options |
PaddingFIFOQueue.shapes(List<Shape> shapes) |
PaddingFIFOQueue.Options |
PaddingFIFOQueue.Options.shapes(List<Shape> shapes) |
Copyright © 2015–2018. All rights reserved.