Package | Description |
---|---|
org.tensorflow |
Defines classes to build, save, load and execute TensorFlow models.
|
org.tensorflow.op | |
org.tensorflow.op.audio | |
org.tensorflow.op.bitwise | |
org.tensorflow.op.collective | |
org.tensorflow.op.core | |
org.tensorflow.op.data | |
org.tensorflow.op.dtypes | |
org.tensorflow.op.image | |
org.tensorflow.op.io | |
org.tensorflow.op.linalg | |
org.tensorflow.op.math | |
org.tensorflow.op.nn | |
org.tensorflow.op.quantization | |
org.tensorflow.op.random | |
org.tensorflow.op.signal | |
org.tensorflow.op.sparse | |
org.tensorflow.op.strings | |
org.tensorflow.op.summary | |
org.tensorflow.op.train |
Modifier and Type | Class and Description |
---|---|
class |
Output<T>
A symbolic handle to a tensor produced by an
Operation . |
Modifier and Type | Method and Description |
---|---|
Session.Runner |
Session.Runner.addTarget(Operand<?> operand)
|
Session.Runner |
Session.Runner.feed(Operand<?> operand,
Tensor<?> t)
Use
t instead of the Tensor referred to by executing the operation referred to by
operand . |
Session.Runner |
Session.Runner.fetch(Operand<?> operand)
Makes
Session.Runner.run() return the Tensor referred to by the output of operand . |
Modifier and Type | Method and Description |
---|---|
<T> AccumulateN<T> |
MathOps.accumulateN(Iterable<Operand<T>> inputs,
Shape shape)
Builds an
AccumulateN operation |
<T> AddN<T> |
MathOps.addN(Iterable<Operand<T>> inputs)
Builds an
AddN operation |
static Output<?>[] |
Operands.asOutputs(Iterable<? extends Operand<?>> inputs)
|
AssertThat |
Ops.assertThat(Operand<Boolean> condition,
Iterable<Operand<?>> data,
AssertThat.Options... options)
Builds an
AssertThat operation |
Batch |
Ops.batch(Iterable<Operand<?>> inTensors,
Long numBatchThreads,
Long maxBatchSize,
Long batchTimeoutMicros,
Long gradTimeoutMicros,
Batch.Options... options)
Builds an
Batch operation |
<T,U extends Number> |
Ops.concat(Iterable<Operand<T>> values,
Operand<U> axis)
Builds an
Concat operation |
<T extends Number> |
NnOps.cudnnRnnCanonicalToParams(Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRnnCanonicalToParams.Options... options)
Builds an
CudnnRnnCanonicalToParams operation |
<T extends Number> |
NnOps.cudnnRnnCanonicalToParams(Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRnnCanonicalToParams.Options... options)
Builds an
CudnnRnnCanonicalToParams operation |
<T extends Number> |
Ops.cudnnRNNCanonicalToParamsV2(Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRNNCanonicalToParamsV2.Options... options)
Builds an
CudnnRNNCanonicalToParamsV2 operation |
<T extends Number> |
Ops.cudnnRNNCanonicalToParamsV2(Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRNNCanonicalToParamsV2.Options... options)
Builds an
CudnnRNNCanonicalToParamsV2 operation |
DecodeCsv |
IoOps.decodeCsv(Operand<String> records,
Iterable<Operand<?>> recordDefaults,
DecodeCsv.Options... options)
Builds an
DecodeCsv operation |
<T> DynamicStitch<T> |
Ops.dynamicStitch(Iterable<Operand<Integer>> indices,
Iterable<Operand<T>> data)
Builds an
DynamicStitch operation |
<T> DynamicStitch<T> |
Ops.dynamicStitch(Iterable<Operand<Integer>> indices,
Iterable<Operand<T>> data)
Builds an
DynamicStitch operation |
<T> Einsum<T> |
Ops.einsum(Iterable<Operand<T>> inputs,
String equation)
Builds an
Einsum operation |
Gradients |
Ops.gradients(Iterable<? extends Operand<?>> y,
Iterable<? extends Operand<?>> x,
Gradients.Options... options)
Builds an
Gradients operation |
Gradients |
Ops.gradients(Iterable<? extends Operand<?>> y,
Iterable<? extends Operand<?>> x,
Gradients.Options... options)
Builds an
Gradients operation |
Gradients |
Ops.gradients(Operand<?> y,
Iterable<? extends Operand<?>> x,
Gradients.Options... options)
Builds an
Gradients operation |
IdentityN |
Ops.identityN(Iterable<Operand<?>> input)
Builds an
IdentityN operation |
Join |
StringsOps.join(Iterable<Operand<String>> inputs,
Join.Options... options)
Builds an
Join operation |
MapStage |
Ops.mapStage(Operand<Long> key,
Operand<Integer> indices,
Iterable<Operand<?>> values,
List<Class<?>> dtypes,
MapStage.Options... options)
Builds an
MapStage operation |
<T> Merge<T> |
Ops.merge(Iterable<Operand<T>> inputs)
Builds an
Merge operation |
MergeSummary |
SummaryOps.mergeSummary(Iterable<Operand<String>> inputs)
Builds an
MergeSummary operation |
OptionalFromValue |
DataOps.optionalFromValue(Iterable<Operand<?>> components)
Builds an
OptionalFromValue operation |
OrderedMapStage |
Ops.orderedMapStage(Operand<Long> key,
Operand<Integer> indices,
Iterable<Operand<?>> values,
List<Class<?>> dtypes,
OrderedMapStage.Options... options)
Builds an
OrderedMapStage operation |
<T> ParallelConcat<T> |
Ops.parallelConcat(Iterable<Operand<T>> values,
Shape shape)
Builds an
ParallelConcat operation |
<T> ParallelDynamicStitch<T> |
Ops.parallelDynamicStitch(Iterable<Operand<Integer>> indices,
Iterable<Operand<T>> data)
Builds an
ParallelDynamicStitch operation |
<T> ParallelDynamicStitch<T> |
Ops.parallelDynamicStitch(Iterable<Operand<Integer>> indices,
Iterable<Operand<T>> data)
Builds an
ParallelDynamicStitch operation |
ParseExample |
IoOps.parseExample(Operand<String> serialized,
Operand<String> names,
Iterable<Operand<String>> sparseKeys,
Iterable<Operand<String>> denseKeys,
Iterable<Operand<?>> denseDefaults,
List<Class<?>> sparseTypes,
List<Shape> denseShapes)
Builds an
ParseExample operation |
ParseExample |
IoOps.parseExample(Operand<String> serialized,
Operand<String> names,
Iterable<Operand<String>> sparseKeys,
Iterable<Operand<String>> denseKeys,
Iterable<Operand<?>> denseDefaults,
List<Class<?>> sparseTypes,
List<Shape> denseShapes)
Builds an
ParseExample operation |
ParseExample |
IoOps.parseExample(Operand<String> serialized,
Operand<String> names,
Iterable<Operand<String>> sparseKeys,
Iterable<Operand<String>> denseKeys,
Iterable<Operand<?>> denseDefaults,
List<Class<?>> sparseTypes,
List<Shape> denseShapes)
Builds an
ParseExample operation |
ParseSequenceExample |
IoOps.parseSequenceExample(Operand<String> serialized,
Operand<String> debugName,
Iterable<Operand<?>> contextDenseDefaults,
List<String> featureListDenseMissingAssumedEmpty,
List<String> contextSparseKeys,
List<String> contextDenseKeys,
List<String> featureListSparseKeys,
List<String> featureListDenseKeys,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSequenceExample.Options... options)
Builds an
ParseSequenceExample operation |
ParseSingleExample |
IoOps.parseSingleExample(Operand<String> serialized,
Iterable<Operand<?>> denseDefaults,
Long numSparse,
List<String> sparseKeys,
List<String> denseKeys,
List<Class<?>> sparseTypes,
List<Shape> denseShapes)
Builds an
ParseSingleExample operation |
ParseSingleSequenceExample |
IoOps.parseSingleSequenceExample(Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Builds an
ParseSingleSequenceExample operation |
ParseSingleSequenceExample |
IoOps.parseSingleSequenceExample(Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Builds an
ParseSingleSequenceExample operation |
ParseSingleSequenceExample |
IoOps.parseSingleSequenceExample(Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Builds an
ParseSingleSequenceExample operation |
ParseSingleSequenceExample |
IoOps.parseSingleSequenceExample(Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Builds an
ParseSingleSequenceExample operation |
ParseSingleSequenceExample |
IoOps.parseSingleSequenceExample(Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Builds an
ParseSingleSequenceExample operation |
<T> QuantizedConcat<T> |
Ops.quantizedConcat(Operand<Integer> concatDim,
Iterable<Operand<T>> values,
Iterable<Operand<Float>> inputMins,
Iterable<Operand<Float>> inputMaxes)
Builds an
QuantizedConcat operation |
<T> QuantizedConcat<T> |
Ops.quantizedConcat(Operand<Integer> concatDim,
Iterable<Operand<T>> values,
Iterable<Operand<Float>> inputMins,
Iterable<Operand<Float>> inputMaxes)
Builds an
QuantizedConcat operation |
<T> QuantizedConcat<T> |
Ops.quantizedConcat(Operand<Integer> concatDim,
Iterable<Operand<T>> values,
Iterable<Operand<Float>> inputMins,
Iterable<Operand<Float>> inputMaxes)
Builds an
QuantizedConcat operation |
QueueEnqueue |
IoOps.queueEnqueue(Operand<?> handle,
Iterable<Operand<?>> components,
QueueEnqueue.Options... options)
Builds an
QueueEnqueue operation |
QueueEnqueueMany |
IoOps.queueEnqueueMany(Operand<?> handle,
Iterable<Operand<?>> components,
QueueEnqueueMany.Options... options)
Builds an
QueueEnqueueMany operation |
<T> RefSelect<T> |
Ops.refSelect(Operand<Integer> index,
Iterable<Operand<T>> inputs)
Builds an
RefSelect operation |
RemoteFusedGraphExecute |
Ops.remoteFusedGraphExecute(Iterable<Operand<?>> inputs,
List<Class<?>> Toutputs,
String serializedRemoteFusedGraphExecuteInfo)
Builds an
RemoteFusedGraphExecute operation |
Save |
TrainOps.save(Operand<String> prefix,
Operand<String> tensorNames,
Operand<String> shapeAndSlices,
Iterable<Operand<?>> tensors)
Builds an
Save operation |
SaveSlices |
TrainOps.saveSlices(Operand<String> filename,
Operand<String> tensorNames,
Operand<String> shapesAndSlices,
Iterable<Operand<?>> data)
Builds an
SaveSlices operation |
SdcaShrinkL1 |
TrainOps.sdcaShrinkL1(Iterable<Operand<Float>> weights,
Float l1,
Float l2)
Builds an
SdcaShrinkL1 operation |
<T> ShapeN<Integer> |
Ops.shapeN(Iterable<Operand<T>> input)
Builds an
ShapeN operation |
<U extends Number,T> |
Ops.shapeN(Iterable<Operand<T>> input,
Class<U> outType)
Builds an
ShapeN operation |
<T> SparseConcat<T> |
SparseOps.sparseConcat(Iterable<Operand<Long>> indices,
Iterable<Operand<T>> values,
Iterable<Operand<Long>> shapes,
Long concatDim)
Builds an
SparseConcat operation |
<T> SparseConcat<T> |
SparseOps.sparseConcat(Iterable<Operand<Long>> indices,
Iterable<Operand<T>> values,
Iterable<Operand<Long>> shapes,
Long concatDim)
Builds an
SparseConcat operation |
<T> SparseConcat<T> |
SparseOps.sparseConcat(Iterable<Operand<Long>> indices,
Iterable<Operand<T>> values,
Iterable<Operand<Long>> shapes,
Long concatDim)
Builds an
SparseConcat operation |
<T,U> SparseCross<T> |
SparseOps.sparseCross(Iterable<Operand<Long>> indices,
Iterable<Operand<?>> values,
Iterable<Operand<Long>> shapes,
Iterable<Operand<?>> denseInputs,
Boolean hashedOutput,
Long numBuckets,
Long hashKey,
Class<T> outType,
Class<U> internalType)
Builds an
SparseCross operation |
<T,U> SparseCross<T> |
SparseOps.sparseCross(Iterable<Operand<Long>> indices,
Iterable<Operand<?>> values,
Iterable<Operand<Long>> shapes,
Iterable<Operand<?>> denseInputs,
Boolean hashedOutput,
Long numBuckets,
Long hashKey,
Class<T> outType,
Class<U> internalType)
Builds an
SparseCross operation |
<T,U> SparseCross<T> |
SparseOps.sparseCross(Iterable<Operand<Long>> indices,
Iterable<Operand<?>> values,
Iterable<Operand<Long>> shapes,
Iterable<Operand<?>> denseInputs,
Boolean hashedOutput,
Long numBuckets,
Long hashKey,
Class<T> outType,
Class<U> internalType)
Builds an
SparseCross operation |
<T,U> SparseCross<T> |
SparseOps.sparseCross(Iterable<Operand<Long>> indices,
Iterable<Operand<?>> values,
Iterable<Operand<Long>> shapes,
Iterable<Operand<?>> denseInputs,
Boolean hashedOutput,
Long numBuckets,
Long hashKey,
Class<T> outType,
Class<U> internalType)
Builds an
SparseCross operation |
<T> Stack<T> |
Ops.stack(Iterable<Operand<T>> values,
Stack.Options... options)
Builds an
Stack operation |
Stage |
Ops.stage(Iterable<Operand<?>> values,
Stage.Options... options)
Builds an
Stage operation |
StringFormat |
StringsOps.stringFormat(Iterable<Operand<?>> inputs,
StringFormat.Options... options)
Builds an
StringFormat operation |
Ops |
Ops.withControlDependencies(Iterable<Operand<?>> controls)
Returns an API that adds operations to the graph with the provided control dependencies.
|
Scope |
Scope.withControlDependencies(Iterable<Operand<?>> controls)
Returns a new scope where added operations will have the provided control dependencies.
|
Modifier and Type | Class and Description |
---|---|
class |
AudioSpectrogram
Produces a visualization of audio data over time.
|
class |
EncodeWav
Encode audio data using the WAV file format.
|
class |
Mfcc
Transforms a spectrogram into a form that's useful for speech recognition.
|
Modifier and Type | Method and Description |
---|---|
static AudioSpectrogram |
AudioSpectrogram.create(Scope scope,
Operand<Float> input,
Long windowSize,
Long stride,
AudioSpectrogram.Options... options)
Factory method to create a class wrapping a new AudioSpectrogram operation.
|
static EncodeWav |
EncodeWav.create(Scope scope,
Operand<Float> audio,
Operand<Integer> sampleRate)
Factory method to create a class wrapping a new EncodeWav operation.
|
static EncodeWav |
EncodeWav.create(Scope scope,
Operand<Float> audio,
Operand<Integer> sampleRate)
Factory method to create a class wrapping a new EncodeWav operation.
|
static Mfcc |
Mfcc.create(Scope scope,
Operand<Float> spectrogram,
Operand<Integer> sampleRate,
Mfcc.Options... options)
Factory method to create a class wrapping a new Mfcc operation.
|
static Mfcc |
Mfcc.create(Scope scope,
Operand<Float> spectrogram,
Operand<Integer> sampleRate,
Mfcc.Options... options)
Factory method to create a class wrapping a new Mfcc operation.
|
static DecodeWav |
DecodeWav.create(Scope scope,
Operand<String> contents,
DecodeWav.Options... options)
Factory method to create a class wrapping a new DecodeWav operation.
|
Modifier and Type | Class and Description |
---|---|
class |
BitwiseAnd<T extends Number>
Elementwise computes the bitwise AND of `x` and `y`.
|
class |
BitwiseOr<T extends Number>
Elementwise computes the bitwise OR of `x` and `y`.
|
class |
BitwiseXor<T extends Number>
Elementwise computes the bitwise XOR of `x` and `y`.
|
class |
Invert<T extends Number>
Invert (flip) each bit of supported types; for example, type `uint8` value 01010101 becomes 10101010.
|
class |
LeftShift<T extends Number>
Elementwise computes the bitwise left-shift of `x` and `y`.
|
class |
RightShift<T extends Number>
Elementwise computes the bitwise right-shift of `x` and `y`.
|
Modifier and Type | Method and Description |
---|---|
static <T extends Number> |
Invert.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Invert operation.
|
static <T extends Number> |
BitwiseOr.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new BitwiseOr operation.
|
static <T extends Number> |
BitwiseOr.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new BitwiseOr operation.
|
static <T extends Number> |
BitwiseXor.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new BitwiseXor operation.
|
static <T extends Number> |
BitwiseXor.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new BitwiseXor operation.
|
static <T extends Number> |
RightShift.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new RightShift operation.
|
static <T extends Number> |
RightShift.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new RightShift operation.
|
static <T extends Number> |
BitwiseAnd.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new BitwiseAnd operation.
|
static <T extends Number> |
BitwiseAnd.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new BitwiseAnd operation.
|
static <T extends Number> |
LeftShift.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new LeftShift operation.
|
static <T extends Number> |
LeftShift.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new LeftShift operation.
|
Modifier and Type | Class and Description |
---|---|
class |
AllReduce<T extends Number>
Mutually reduces multiple tensors of identical type and shape.
|
class |
BroadcastRecv<T extends Number>
Receives a tensor value broadcast from another device.
|
class |
BroadcastSend<T extends Number>
Broadcasts a tensor value to one or more other devices.
|
Modifier and Type | Method and Description |
---|---|
static <T extends Number> |
BroadcastSend.create(Scope scope,
Operand<T> input,
Long groupSize,
Long groupKey,
Long instanceKey,
Shape shape,
BroadcastSend.Options... options)
Factory method to create a class wrapping a new BroadcastSend operation.
|
static <T extends Number> |
AllReduce.create(Scope scope,
Operand<T> input,
Long groupSize,
Long groupKey,
Long instanceKey,
String mergeOp,
String finalOp,
List<Long> subdivOffsets,
AllReduce.Options... options)
Factory method to create a class wrapping a new AllReduce operation.
|
Modifier and Type | Class and Description |
---|---|
class |
All
Computes the "logical and" of elements across dimensions of a tensor.
|
class |
AllToAll<T>
An Op to exchange data across TPU replicas.
|
class |
Any
Computes the "logical or" of elements across dimensions of a tensor.
|
class |
ApplyAdagradV2<T>
Update '*var' according to the adagrad scheme.
|
class |
AssertNextDataset
A transformation that asserts which transformations happen next.
|
class |
Assign<T>
Update 'ref' by assigning 'value' to it.
|
class |
AssignAdd<T>
Update 'ref' by adding 'value' to it.
|
class |
AssignSub<T>
Update 'ref' by subtracting 'value' from it.
|
class |
AutoShardDataset
Creates a dataset that shards the input dataset.
|
class |
Barrier
Defines a barrier that persists across different graph executions.
|
class |
BarrierIncompleteSize
Computes the number of incomplete elements in the given barrier.
|
class |
BarrierReadySize
Computes the number of complete elements in the given barrier.
|
class |
BatchMatMulV2<T>
Multiplies slices of two tensors in batches.
|
class |
BatchToSpace<T>
BatchToSpace for 4-D tensors of type T.
|
class |
BatchToSpaceNd<T>
BatchToSpace for N-D tensors of type T.
|
class |
Bitcast<U>
Bitcasts a tensor from one type to another without copying data.
|
class |
BoostedTreesAggregateStats
Aggregates the summary of accumulated stats for the batch.
|
class |
BoostedTreesCenterBias
Calculates the prior from the training data (the bias) and fills in the first node with the logits' prior.
|
class |
BoostedTreesEnsembleResourceHandleOp
Creates a handle to a BoostedTreesEnsembleResource
|
class |
BoostedTreesExampleDebugOutputs
Debugging/model interpretability outputs for each example.
|
class |
BoostedTreesMakeStatsSummary
Makes the summary of accumulated stats for the batch.
|
class |
BoostedTreesPredict
Runs multiple additive regression ensemble predictors on input instances and
|
class |
BoostedTreesQuantileStreamResourceHandleOp
Creates a handle to a BoostedTreesQuantileStreamResource.
|
class |
BroadcastDynamicShape<T extends Number>
Return the shape of s0 op s1 with broadcast.
|
class |
BroadcastTo<T>
Broadcast an array for a compatible shape.
|
class |
Bucketize
Bucketizes 'input' based on 'boundaries'.
|
class |
CacheDatasetV2 |
class |
ChooseFastestDataset |
class |
ClipByValue<T>
Clips tensor values to a specified min and max.
|
class |
CollectiveGather<T extends Number>
Mutually accumulates multiple tensors of identical type and shape.
|
class |
CollectivePermute<T>
An Op to permute tensors across replicated TPU instances.
|
class |
Concat<T>
Concatenates tensors along one dimension.
|
class |
ConfigureDistributedTPU
Sets up the centralized structures for a distributed TPU system.
|
class |
Constant<T>
An operator producing a constant value.
|
class |
CountUpTo<T extends Number>
Increments 'ref' until it reaches 'limit'.
|
class |
CrossReplicaSum<T extends Number>
An Op to sum inputs across replicated TPU instances.
|
class |
CSVDataset |
class |
CudnnRNNCanonicalToParamsV2<T extends Number>
Converts CudnnRNN params from canonical form to usable form.
|
class |
CumulativeLogsumexp<T extends Number>
Compute the cumulative product of the tensor `x` along `axis`.
|
class |
DatasetCardinality
Returns the cardinality of `input_dataset`.
|
class |
DatasetFromGraph
Creates a dataset from the given `graph_def`.
|
class |
DebugGradientIdentity<T>
Identity op for gradient debugging.
|
class |
DebugGradientRefIdentity<T>
Identity op for gradient debugging.
|
class |
DecodePaddedRaw<T extends Number>
Reinterpret the bytes of a string as a vector of numbers.
|
class |
DeepCopy<T>
Makes a copy of `x`.
|
class |
DestroyTemporaryVariable<T>
Destroys the temporary variable and returns its final value.
|
class |
DirectedInterleaveDataset
A substitute for `InterleaveDataset` on a fixed list of `N` datasets.
|
class |
DrawBoundingBoxesV2<T extends Number>
Draw bounding boxes on a batch of images.
|
class |
DynamicStitch<T>
Interleave the values from the `data` tensors into a single tensor.
|
class |
EditDistance
Computes the (possibly normalized) Levenshtein Edit Distance.
|
class |
Einsum<T>
Tensor contraction according to Einstein summation convention.
|
class |
Empty<T>
Creates a tensor with the given shape.
|
class |
EmptyTensorList
Creates and returns an empty tensor list.
|
class |
EncodeProto
The op serializes protobuf messages provided in the input tensors.
|
class |
EnsureShape<T>
Ensures that the tensor's shape matches the expected shape.
|
class |
Enter<T>
Creates or finds a child frame, and makes `data` available to the child frame.
|
class |
EuclideanNorm<T>
Computes the euclidean norm of elements across dimensions of a tensor.
|
class |
Exit<T>
Exits the current frame to its parent frame.
|
class |
ExpandDims<T>
Inserts a dimension of 1 into a tensor's shape.
|
class |
ExperimentalAutoShardDataset
Creates a dataset that shards the input dataset.
|
class |
ExperimentalBytesProducedStatsDataset
Records the bytes size of each element of `input_dataset` in a StatsAggregator.
|
class |
ExperimentalChooseFastestDataset |
class |
ExperimentalDatasetCardinality
Returns the cardinality of `input_dataset`.
|
class |
ExperimentalDenseToSparseBatchDataset
Creates a dataset that batches input elements into a SparseTensor.
|
class |
ExperimentalLatencyStatsDataset
Records the latency of producing `input_dataset` elements in a StatsAggregator.
|
class |
ExperimentalMatchingFilesDataset |
class |
ExperimentalMaxIntraOpParallelismDataset
Creates a dataset that overrides the maximum intra-op parallelism.
|
class |
ExperimentalParseExampleDataset
Transforms `input_dataset` containing `Example` protos as vectors of DT_STRING into a dataset of `Tensor` or `SparseTensor` objects representing the parsed features.
|
class |
ExperimentalPrivateThreadPoolDataset
Creates a dataset that uses a custom thread pool to compute `input_dataset`.
|
class |
ExperimentalRandomDataset
Creates a Dataset that returns pseudorandom numbers.
|
class |
ExperimentalRebatchDataset
Creates a dataset that changes the batch size.
|
class |
ExperimentalSetStatsAggregatorDataset |
class |
ExperimentalSlidingWindowDataset
Creates a dataset that passes a sliding window over `input_dataset`.
|
class |
ExperimentalSqlDataset
Creates a dataset that executes a SQL query and emits rows of the result set.
|
class |
ExperimentalStatsAggregatorHandle
Creates a statistics manager resource.
|
class |
ExperimentalStatsAggregatorSummary
Produces a summary of any statistics recorded by the given statistics manager.
|
class |
ExperimentalUnbatchDataset
A dataset that splits the elements of its input into multiple elements.
|
class |
ExtractVolumePatches<T extends Number>
Extract `patches` from `input` and put them in the "depth" output dimension.
|
class |
Fill<U>
Creates a tensor filled with a scalar value.
|
class |
Fingerprint
Generates fingerprint values.
|
class |
Gather<T>
Gather slices from `params` axis `axis` according to `indices`.
|
class |
GatherNd<T>
Gather slices from `params` into a Tensor with shape specified by `indices`.
|
class |
GenerateBigQueryReaderPartitions
Generates serialized partition messages suitable for batch reads.
|
class |
GetSessionHandle
Store the input tensor in the state of the current session.
|
class |
GetSessionTensor<T>
Get the value of the tensor specified by its handle.
|
class |
GuaranteeConst<T>
Gives a guarantee to the TF runtime that the input tensor is a constant.
|
class |
HashTable
Creates a non-initialized hash table.
|
class |
HistogramFixedWidth<U extends Number>
Return histogram of values.
|
class |
Identity<T>
Return a tensor with the same shape and contents as the input tensor or value.
|
class |
IgnoreErrorsDataset
Creates a dataset that contains the elements of `input_dataset` ignoring errors.
|
class |
ImmutableConst<T>
Returns immutable tensor from memory region.
|
class |
InfeedDequeue<T>
A placeholder op for a value that will be fed into the computation.
|
class |
InplaceAdd<T>
Adds v into specified rows of x.
|
class |
InplaceSub<T>
Subtracts `v` into specified rows of `x`.
|
class |
InplaceUpdate<T>
Updates specified rows with values in `v`.
|
class |
IsBoostedTreesEnsembleInitialized
Checks whether a tree ensemble has been initialized.
|
class |
IsBoostedTreesQuantileStreamResourceInitialized
Checks whether a quantile stream has been initialized.
|
class |
IsVariableInitialized
Checks whether a tensor has been initialized.
|
class |
IteratorGetDevice
Returns the name of the device on which `resource` has been placed.
|
class |
KMC2ChainInitialization
Returns the index of a data point that should be added to the seed set.
|
class |
KmeansPlusPlusInitialization
Selects num_to_sample rows of input using the KMeans++ criterion.
|
class |
LinSpace<T extends Number>
Generates values in an interval.
|
class |
LMDBDataset |
class |
LookupTableFind<U>
Looks up keys in a table, outputs the corresponding values.
|
class |
LookupTableSize
Computes the number of elements in the given table.
|
class |
LoopCond
Forwards the input to the output.
|
class |
LowerBound<U extends Number>
Applies lower_bound(sorted_search_values, values) along each row.
|
class |
MapIncompleteSize
Op returns the number of incomplete elements in the underlying container.
|
class |
MapSize
Op returns the number of elements in the underlying container.
|
class |
MatrixDiagPartV2<T>
Returns the batched diagonal part of a batched tensor.
|
class |
MatrixDiagV2<T>
Returns a batched diagonal tensor with given batched diagonal values.
|
class |
MatrixSetDiagV2<T>
Returns a batched matrix tensor with new batched diagonal values.
|
class |
Max<T>
Computes the maximum of elements across dimensions of a tensor.
|
class |
MaxIntraOpParallelismDataset
Creates a dataset that overrides the maximum intra-op parallelism.
|
class |
Min<T>
Computes the minimum of elements across dimensions of a tensor.
|
class |
MirrorPad<T>
Pads a tensor with mirrored values.
|
class |
MirrorPadGrad<T>
Gradient op for `MirrorPad` op.
|
class |
MulNoNan<T>
Returns x * y element-wise.
|
class |
MutableDenseHashTable
Creates an empty hash table that uses tensors as the backing store.
|
class |
MutableHashTable
Creates an empty hash table.
|
class |
MutableHashTableOfTensors
Creates an empty hash table.
|
class |
Mutex
Creates a Mutex resource that can be locked by `MutexLock`.
|
class |
MutexLock
Locks a mutex resource.
|
class |
NcclAllReduce<T extends Number>
Outputs a tensor containing the reduction across all input tensors.
|
class |
NcclBroadcast<T extends Number>
Sends `input` to all devices that are connected to the output.
|
class |
NcclReduce<T extends Number>
Reduces `input` from `num_devices` using `reduction` to a single device.
|
class |
NextAfter<T extends Number>
Returns the next representable value of `x1` in the direction of `x2`, element-wise.
|
class |
NextIteration<T>
Makes its input available to the next iteration.
|
class |
NonDeterministicInts<U>
Non-deterministically generates some integers.
|
class |
NonSerializableDataset |
class |
OneHot<U>
Returns a one-hot tensor.
|
class |
OnesLike<T>
Returns a tensor of ones with the same shape and type as x.
|
class |
OrderedMapIncompleteSize
Op returns the number of incomplete elements in the underlying container.
|
class |
OrderedMapSize
Op returns the number of elements in the underlying container.
|
class |
OutfeedDequeue<T>
Retrieves a single tensor from the computation outfeed.
|
class |
Pad<T>
Pads a tensor.
|
class |
ParallelConcat<T>
Concatenates a list of `N` tensors along the first dimension.
|
class |
ParallelDynamicStitch<T>
Interleave the values from the `data` tensors into a single tensor.
|
class |
Placeholder<T>
A placeholder op for a value that will be fed into the computation.
|
class |
PlaceholderWithDefault<T>
A placeholder op that passes through `input` when its output is not fed.
|
class |
Prelinearize
An op which linearizes one Tensor value to an opaque variant tensor.
|
class |
PrelinearizeTuple
An op which linearizes multiple Tensor values to an opaque variant tensor.
|
class |
PrivateThreadPoolDataset
Creates a dataset that uses a custom thread pool to compute `input_dataset`.
|
class |
Prod<T>
Computes the product of elements across dimensions of a tensor.
|
class |
RaggedTensorToTensor<U>
Create a dense tensor from a ragged tensor, possibly altering its shape.
|
class |
RaggedTensorToVariant
Encodes a `RaggedTensor` into a `variant` Tensor.
|
class |
Range<T extends Number>
Creates a sequence of numbers.
|
class |
Rank
Returns the rank of a tensor.
|
class |
ReadVariableOp<T>
Reads the value of a variable.
|
class |
RebatchDataset
Creates a dataset that changes the batch size.
|
class |
ReduceAll
Computes the "logical and" of elements across dimensions of a tensor.
|
class |
ReduceAny
Computes the "logical or" of elements across dimensions of a tensor.
|
class |
ReduceMax<T>
Computes the maximum of elements across dimensions of a tensor.
|
class |
ReduceMin<T>
Computes the minimum of elements across dimensions of a tensor.
|
class |
ReduceProd<T>
Computes the product of elements across dimensions of a tensor.
|
class |
ReduceSum<T>
Computes the sum of elements across dimensions of a tensor.
|
class |
RefEnter<T>
Creates or finds a child frame, and makes `data` available to the child frame.
|
class |
RefExit<T>
Exits the current frame to its parent frame.
|
class |
RefIdentity<T>
Return the same ref tensor as the input ref tensor.
|
class |
RefNextIteration<T>
Makes its input available to the next iteration.
|
class |
RefSelect<T>
Forwards the `index`th element of `inputs` to `output`.
|
class |
Reshape<T>
Reshapes a tensor.
|
class |
ResourceAccumulatorNumAccumulated
Returns the number of gradients aggregated in the given accumulators.
|
class |
ResourceAccumulatorTakeGradient<T>
Extracts the average gradient in the given ConditionalAccumulator.
|
class |
ResourceConditionalAccumulator
A conditional accumulator for aggregating gradients.
|
class |
ResourceCountUpTo<T extends Number>
Increments variable pointed to by 'resource' until it reaches 'limit'.
|
class |
ResourceGather<U>
Gather slices from the variable pointed to by `resource` according to `indices`.
|
class |
ResourceGatherNd<U> |
class |
RetrieveTPUEmbeddingStochasticGradientDescentParameters
Retrieve SGD embedding parameters.
|
class |
Reverse<T>
Reverses specific dimensions of a tensor.
|
class |
ReverseSequence<T>
Reverses variable length slices.
|
class |
Roll<T>
Rolls the elements of a tensor along an axis.
|
class |
Rpc
Perform batches of RPC requests.
|
class |
SamplingDataset
Creates a dataset that takes a Bernoulli sample of the contents of another dataset.
|
class |
ScaleAndTranslate |
class |
ScaleAndTranslateGrad<T extends Number> |
class |
ScatterAdd<T>
Adds sparse updates to a variable reference.
|
class |
ScatterDiv<T>
Divides a variable reference by sparse updates.
|
class |
ScatterMax<T extends Number>
Reduces sparse updates into a variable reference using the `max` operation.
|
class |
ScatterMin<T extends Number>
Reduces sparse updates into a variable reference using the `min` operation.
|
class |
ScatterMul<T>
Multiplies sparse updates into a variable reference.
|
class |
ScatterNd<U>
Scatter `updates` into a new tensor according to `indices`.
|
class |
ScatterNdAdd<T>
Applies sparse addition to individual values or slices in a Variable.
|
class |
ScatterNdNonAliasingAdd<T>
Applies sparse addition to `input` using individual values or slices
|
class |
ScatterNdSub<T>
Applies sparse subtraction to individual values or slices in a Variable.
|
class |
ScatterNdUpdate<T>
Applies sparse `updates` to individual values or slices within a given
|
class |
ScatterSub<T>
Subtracts sparse updates to a variable reference.
|
class |
ScatterUpdate<T>
Applies sparse updates to a variable reference.
|
class |
SelectV2<T> |
class |
SetSize
Number of unique elements along last dimension of input `set`.
|
class |
Shape<U extends Number>
Returns the shape of a tensor.
|
class |
ShardDataset
Creates a `Dataset` that includes only 1/`num_shards` of this dataset.
|
class |
ShuffleDatasetV2 |
class |
Size<U extends Number>
Returns the size of a tensor.
|
class |
SleepDataset |
class |
Slice<T>
Return a slice from 'input'.
|
class |
SlidingWindowDataset
Creates a dataset that passes a sliding window over `input_dataset`.
|
class |
Snapshot<T>
Returns a copy of the input tensor.
|
class |
SnapshotDataset
Creates a dataset that will write to / read from a snapshot.
|
class |
SpaceToBatchNd<T>
SpaceToBatch for N-D tensors of type T.
|
class |
SparseApplyAdagradV2<T>
Update relevant entries in '*var' and '*accum' according to the adagrad scheme.
|
class |
Squeeze<T>
Removes dimensions of size 1 from the shape of a tensor.
|
class |
Stack<T>
Packs a list of `N` rank-`R` tensors into one rank-`(R+1)` tensor.
|
class |
StageSize
Op returns the number of elements in the underlying container.
|
class |
StatefulRandomBinomial<V extends Number> |
class |
StatefulStandardNormal<U>
Outputs random values from a normal distribution.
|
class |
StatefulStandardNormalV2<U>
Outputs random values from a normal distribution.
|
class |
StatefulTruncatedNormal<U>
Outputs random values from a truncated normal distribution.
|
class |
StatefulUniform<U>
Outputs random values from a uniform distribution.
|
class |
StatefulUniformFullInt<U>
Outputs random integers from a uniform distribution.
|
class |
StatefulUniformInt<U>
Outputs random integers from a uniform distribution.
|
class |
StatsAggregatorHandleV2 |
class |
StopGradient<T>
Stops gradient computation.
|
class |
StridedSlice<T>
Return a strided slice from `input`.
|
class |
StridedSliceAssign<T>
Assign `value` to the sliced l-value reference of `ref`.
|
class |
StridedSliceGrad<U>
Returns the gradient of `StridedSlice`.
|
class |
StringLower |
class |
StringUpper |
class |
Sum<T>
Computes the sum of elements across dimensions of a tensor.
|
class |
TemporaryVariable<T>
Returns a tensor that may be mutated, but only persists within a single step.
|
class |
TensorArrayGather<T>
Gather specific elements from the TensorArray into output `value`.
|
class |
TensorArrayPack<T> |
class |
TensorArrayRead<T>
Read an element from the TensorArray into output `value`.
|
class |
TensorArrayScatter
Scatter the data from the input value into specific TensorArray elements.
|
class |
TensorArraySize
Get the current size of the TensorArray.
|
class |
TensorArraySplit
Split the data from the input value into TensorArray elements.
|
class |
TensorArrayUnpack |
class |
TensorArrayWrite
Push an element onto the tensor_array.
|
class |
TensorForestTreeIsInitializedOp
Checks whether a tree has been initialized.
|
class |
TensorForestTreePredict
Output the logits for the given input data
|
class |
TensorForestTreeResourceHandleOp
Creates a handle to a TensorForestTreeResource
|
class |
TensorForestTreeSerialize
Serializes the tree handle to a proto
|
class |
TensorForestTreeSize
Get the number of nodes in a tree
|
class |
TensorListConcatLists |
class |
TensorListElementShape<T extends Number>
The shape of the elements of the given list, as a tensor.
|
class |
TensorListFromTensor
Creates a TensorList which, when stacked, has the value of `tensor`.
|
class |
TensorListGather<T>
Creates a Tensor by indexing into the TensorList.
|
class |
TensorListGetItem<T> |
class |
TensorListLength
Returns the number of tensors in the input tensor list.
|
class |
TensorListPushBack
Returns a list which has the passed-in `Tensor` as last element and the other elements of the given list in `input_handle`.
|
class |
TensorListPushBackBatch |
class |
TensorListReserve
List of the given size with empty elements.
|
class |
TensorListResize
Resizes the list.
|
class |
TensorListScatter
Creates a TensorList by indexing into a Tensor.
|
class |
TensorListScatterIntoExistingList
Scatters tensor at indices in an input list.
|
class |
TensorListScatterV2
Creates a TensorList by indexing into a Tensor.
|
class |
TensorListSetItem |
class |
TensorListSplit
Splits a tensor into a list.
|
class |
TensorListStack<T>
Stacks all tensors in the list.
|
class |
TensorScatterAdd<T>
Adds sparse `updates` to an existing tensor according to `indices`.
|
class |
TensorScatterSub<T>
Subtracts sparse `updates` from an existing tensor according to `indices`.
|
class |
TensorScatterUpdate<T>
Scatter `updates` into an existing tensor according to `indices`.
|
class |
TensorStridedSliceUpdate<T>
Assign `value` to the sliced l-value reference of `input`.
|
class |
ThreadPoolDataset
Creates a dataset that uses a custom thread pool to compute `input_dataset`.
|
class |
ThreadPoolHandle
Creates a dataset that uses a custom thread pool to compute `input_dataset`.
|
class |
Tile<T>
Constructs a tensor by tiling a given tensor.
|
class |
Timestamp
Provides the time since epoch in seconds.
|
class |
TPUCompilationResult
CompilationResultProto indicating the status of the TPU compilation.
|
class |
TPUEmbeddingActivations
An op enabling differentiation of TPU Embeddings.
|
class |
TPUOrdinalSelector
A TPU core selector Op.
|
class |
TPUReplicatedInput<T>
Connects N inputs to an N-way replicated TPU computation.
|
class |
TridiagonalMatMul<T>
Calculate product with tridiagonal matrix.
|
class |
TridiagonalSolve<T>
Solves tridiagonal systems of equations.
|
class |
Unbatch<T>
Reverses the operation of Batch for a single output Tensor.
|
class |
UnbatchGrad<T>
Gradient of Unbatch.
|
class |
UnicodeEncode
Encode a tensor of ints into unicode strings.
|
class |
UniqueDataset
Creates a dataset that contains the unique elements of `input_dataset`.
|
class |
UnravelIndex<T extends Number>
Converts an array of flat indices into a tuple of coordinate arrays.
|
class |
UnsortedSegmentJoin
Joins the elements of `inputs` based on `segment_ids`.
|
class |
UnwrapDatasetVariant |
class |
UpperBound<U extends Number>
Applies upper_bound(sorted_search_values, values) along each row.
|
class |
VarHandleOp
Creates a handle to a Variable resource.
|
class |
Variable<T>
Holds state in the form of a tensor that persists across steps.
|
class |
VariableShape<T extends Number>
Returns the shape of the variable pointed to by `resource`.
|
class |
VarIsInitializedOp
Checks whether a resource handle-based variable has been initialized.
|
class |
Where
Returns locations of nonzero / true values in a tensor.
|
class |
Where3<T>
Selects elements from `x` or `y`, depending on `condition`.
|
class |
WorkerHeartbeat
Worker heartbeat op.
|
class |
WrapDatasetVariant |
class |
Zeros<T>
An operator creating a constant initialized with zeros of the shape given by `dims`.
|
class |
ZerosLike<T>
Returns a tensor of zeros with the same shape and type as x.
|
Modifier and Type | Method and Description |
---|---|
Iterator<Operand<?>> |
Gradients.iterator() |
Iterator<Operand<Float>> |
BoostedTreesFlushQuantileSummaries.iterator() |
Iterator<Operand<Object>> |
OrderedMapUnstage.iterator() |
Iterator<Operand<T>> |
Split.iterator() |
Iterator<Operand<Object>> |
OrderedMapPeek.iterator() |
Iterator<Operand<Integer>> |
BoostedTreesBucketize.iterator() |
Iterator<Operand<Object>> |
Unstage.iterator() |
Iterator<Operand<T>> |
TPUReplicatedOutput.iterator() |
Iterator<Operand<T>> |
Unstack.iterator() |
Iterator<Operand<Float>> |
BoostedTreesMakeQuantileSummaries.iterator() |
Iterator<Operand<Object>> |
StagePeek.iterator() |
Iterator<Operand<Object>> |
OutfeedDequeueTuple.iterator() |
Iterator<Operand<Object>> |
IdentityN.iterator() |
Iterator<Operand<Float>> |
BoostedTreesQuantileStreamResourceGetBucketBoundaries.iterator() |
Iterator<Operand<T>> |
SplitV.iterator() |
Iterator<Operand<Object>> |
RemoteFusedGraphExecute.iterator() |
Iterator<Operand<Object>> |
MapUnstage.iterator() |
Iterator<Operand<U>> |
ShapeN.iterator() |
Iterator<Operand<T>> |
DynamicPartition.iterator() |
Iterator<Operand<Float>> |
RecvTPUEmbeddingActivations.iterator() |
Iterator<Operand<Object>> |
MapPeek.iterator() |
Iterator<Operand<Object>> |
InfeedDequeueTuple.iterator() |
Modifier and Type | Method and Description |
---|---|
static BoostedTreesMakeQuantileSummaries |
BoostedTreesMakeQuantileSummaries.create(Scope scope,
Iterable<Operand<Float>> floatValues,
Operand<Float> exampleWeights,
Operand<Float> epsilon)
Factory method to create a class wrapping a new BoostedTreesMakeQuantileSummaries operation.
|
static BoostedTreesMakeQuantileSummaries |
BoostedTreesMakeQuantileSummaries.create(Scope scope,
Iterable<Operand<Float>> floatValues,
Operand<Float> exampleWeights,
Operand<Float> epsilon)
Factory method to create a class wrapping a new BoostedTreesMakeQuantileSummaries operation.
|
static EnqueueTPUEmbeddingIntegerBatch |
EnqueueTPUEmbeddingIntegerBatch.create(Scope scope,
Iterable<Operand<Integer>> batch,
Operand<String> modeOverride,
EnqueueTPUEmbeddingIntegerBatch.Options... options)
Factory method to create a class wrapping a new EnqueueTPUEmbeddingIntegerBatch operation.
|
static <T extends Number,U extends Number,V extends Number> |
EnqueueTPUEmbeddingSparseBatch.create(Scope scope,
Iterable<Operand<T>> sampleIndices,
Iterable<Operand<U>> embeddingIndices,
Iterable<Operand<V>> aggregationWeights,
Operand<String> modeOverride,
EnqueueTPUEmbeddingSparseBatch.Options... options)
Factory method to create a class wrapping a new EnqueueTPUEmbeddingSparseBatch operation.
|
static <T extends Number,U extends Number,V extends Number> |
EnqueueTPUEmbeddingSparseTensorBatch.create(Scope scope,
Iterable<Operand<T>> sampleIndices,
Iterable<Operand<U>> embeddingIndices,
Iterable<Operand<V>> aggregationWeights,
Operand<String> modeOverride,
List<Long> tableIds,
EnqueueTPUEmbeddingSparseTensorBatch.Options... options)
Factory method to create a class wrapping a new EnqueueTPUEmbeddingSparseTensorBatch operation.
|
static <T,U extends Number> |
Concat.create(Scope scope,
Iterable<Operand<T>> values,
Operand<U> axis)
Factory method to create a class wrapping a new Concat operation.
|
static <U,T extends Number> |
RaggedTensorToSparse.create(Scope scope,
Iterable<Operand<T>> rtNestedSplits,
Operand<U> rtDenseValues)
Factory method to create a class wrapping a new RaggedTensorToSparse operation.
|
static <T extends Number,U> |
RaggedTensorToVariant.create(Scope scope,
Iterable<Operand<T>> rtNestedSplits,
Operand<U> rtDenseValues,
Boolean batchedInput)
Factory method to create a class wrapping a new RaggedTensorToVariant operation.
|
static <T extends Number,U,V extends Number> |
RaggedGather.create(Scope scope,
Iterable<Operand<T>> paramsNestedSplits,
Operand<U> paramsDenseValues,
Operand<V> indices,
Long OUTPUTRAGGEDRANK)
Factory method to create a class wrapping a new RaggedGather operation.
|
static <T extends Number,U,V extends Number> |
RaggedGather.create(Scope scope,
Iterable<Operand<T>> paramsNestedSplits,
Operand<U> paramsDenseValues,
Operand<V> indices,
Long OUTPUTRAGGEDRANK)
Factory method to create a class wrapping a new RaggedGather operation.
|
static IsBoostedTreesEnsembleInitialized |
IsBoostedTreesEnsembleInitialized.create(Scope scope,
Operand<?> treeEnsembleHandle)
Factory method to create a class wrapping a new IsBoostedTreesEnsembleInitialized operation.
|
static BoostedTreesSerializeEnsemble |
BoostedTreesSerializeEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle)
Factory method to create a class wrapping a new BoostedTreesSerializeEnsemble operation.
|
static TensorForestTreeIsInitializedOp |
TensorForestTreeIsInitializedOp.create(Scope scope,
Operand<?> treeHandle)
Factory method to create a class wrapping a new TensorForestTreeIsInitializedOp operation.
|
static IteratorGetDevice |
IteratorGetDevice.create(Scope scope,
Operand<?> resource)
Factory method to create a class wrapping a new IteratorGetDevice operation.
|
static DatasetCardinality |
DatasetCardinality.create(Scope scope,
Operand<?> inputDataset)
Factory method to create a class wrapping a new DatasetCardinality operation.
|
static ResourceAccumulatorNumAccumulated |
ResourceAccumulatorNumAccumulated.create(Scope scope,
Operand<?> handle)
Factory method to create a class wrapping a new ResourceAccumulatorNumAccumulated operation.
|
static TensorForestTreeSize |
TensorForestTreeSize.create(Scope scope,
Operand<?> treeHandle)
Factory method to create a class wrapping a new TensorForestTreeSize operation.
|
static TensorForestTreeSerialize |
TensorForestTreeSerialize.create(Scope scope,
Operand<?> treeHandle)
Factory method to create a class wrapping a new TensorForestTreeSerialize operation.
|
static LookupTableSize |
LookupTableSize.create(Scope scope,
Operand<?> tableHandle)
Factory method to create a class wrapping a new LookupTableSize operation.
|
static WrapDatasetVariant |
WrapDatasetVariant.create(Scope scope,
Operand<?> inputHandle)
Factory method to create a class wrapping a new WrapDatasetVariant operation.
|
static TensorArrayClose |
TensorArrayClose.create(Scope scope,
Operand<?> handle)
Factory method to create a class wrapping a new TensorArrayClose operation.
|
static UnwrapDatasetVariant |
UnwrapDatasetVariant.create(Scope scope,
Operand<?> inputHandle)
Factory method to create a class wrapping a new UnwrapDatasetVariant operation.
|
static ConsumeMutexLock |
ConsumeMutexLock.create(Scope scope,
Operand<?> mutexLock)
Factory method to create a class wrapping a new ConsumeMutexLock operation.
|
static MutexLock |
MutexLock.create(Scope scope,
Operand<?> mutex)
Factory method to create a class wrapping a new MutexLock operation.
|
static VarIsInitializedOp |
VarIsInitializedOp.create(Scope scope,
Operand<?> resource)
Factory method to create a class wrapping a new VarIsInitializedOp operation.
|
static TensorListLength |
TensorListLength.create(Scope scope,
Operand<?> inputHandle)
Factory method to create a class wrapping a new TensorListLength operation.
|
static ExperimentalDatasetCardinality |
ExperimentalDatasetCardinality.create(Scope scope,
Operand<?> inputDataset)
Factory method to create a class wrapping a new ExperimentalDatasetCardinality operation.
|
static IsBoostedTreesQuantileStreamResourceInitialized |
IsBoostedTreesQuantileStreamResourceInitialized.create(Scope scope,
Operand<?> quantileStreamResourceHandle)
Factory method to create a class wrapping a new IsBoostedTreesQuantileStreamResourceInitialized operation.
|
static BoostedTreesGetEnsembleStates |
BoostedTreesGetEnsembleStates.create(Scope scope,
Operand<?> treeEnsembleHandle)
Factory method to create a class wrapping a new BoostedTreesGetEnsembleStates operation.
|
static ExperimentalStatsAggregatorSummary |
ExperimentalStatsAggregatorSummary.create(Scope scope,
Operand<?> iterator)
Factory method to create a class wrapping a new ExperimentalStatsAggregatorSummary operation.
|
static VariableShape<Integer> |
VariableShape.create(Scope scope,
Operand<?> input)
Factory method to create a class wrapping a new VariableShape operation using default output types.
|
static <T> ReadVariableOp<T> |
ReadVariableOp.create(Scope scope,
Operand<?> resource,
Class<T> dtype)
Factory method to create a class wrapping a new ReadVariableOp operation.
|
static <T extends Number> |
TensorListElementShape.create(Scope scope,
Operand<?> inputHandle,
Class<T> shapeType)
Factory method to create a class wrapping a new TensorListElementShape operation.
|
static <T extends Number> |
VariableShape.create(Scope scope,
Operand<?> input,
Class<T> outType)
Factory method to create a class wrapping a new VariableShape operation.
|
static <T,U> LookupTableExport<T,U> |
LookupTableExport.create(Scope scope,
Operand<?> tableHandle,
Class<T> Tkeys,
Class<U> Tvalues)
Factory method to create a class wrapping a new LookupTableExport operation.
|
static <T> TensorListConcat<T> |
TensorListConcat.create(Scope scope,
Operand<?> inputHandle,
Class<T> elementDtype,
TensorListConcat.Options... options)
Factory method to create a class wrapping a new TensorListConcat operation.
|
static DestroyResourceOp |
DestroyResourceOp.create(Scope scope,
Operand<?> resource,
DestroyResourceOp.Options... options)
Factory method to create a class wrapping a new DestroyResourceOp operation.
|
static InfeedEnqueuePrelinearizedBuffer |
InfeedEnqueuePrelinearizedBuffer.create(Scope scope,
Operand<?> input,
InfeedEnqueuePrelinearizedBuffer.Options... options)
Factory method to create a class wrapping a new InfeedEnqueuePrelinearizedBuffer operation.
|
static Gradients |
Gradients.create(Scope scope,
Operand<?> y,
Iterable<? extends Operand<?>> x,
Gradients.Options... options)
Adds gradients computation ops to the graph according to scope.
|
static DirectedInterleaveDataset |
DirectedInterleaveDataset.create(Scope scope,
Operand<?> selectorInputDataset,
Iterable<Operand<?>> dataInputDatasets,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new DirectedInterleaveDataset operation.
|
static DeleteMultiDeviceIterator |
DeleteMultiDeviceIterator.create(Scope scope,
Operand<?> multiDeviceIterator,
Iterable<Operand<?>> iterators,
Operand<?> deleter)
Factory method to create a class wrapping a new DeleteMultiDeviceIterator operation.
|
static DeleteMultiDeviceIterator |
DeleteMultiDeviceIterator.create(Scope scope,
Operand<?> multiDeviceIterator,
Iterable<Operand<?>> iterators,
Operand<?> deleter)
Factory method to create a class wrapping a new DeleteMultiDeviceIterator operation.
|
static BoostedTreesQuantileStreamResourceDeserialize |
BoostedTreesQuantileStreamResourceDeserialize.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Iterable<Operand<Float>> bucketBoundaries)
Factory method to create a class wrapping a new BoostedTreesQuantileStreamResourceDeserialize operation.
|
static BoostedTreesQuantileStreamResourceAddSummaries |
BoostedTreesQuantileStreamResourceAddSummaries.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Iterable<Operand<Float>> summaries)
Factory method to create a class wrapping a new BoostedTreesQuantileStreamResourceAddSummaries operation.
|
static BoostedTreesPredict |
BoostedTreesPredict.create(Scope scope,
Operand<?> treeEnsembleHandle,
Iterable<Operand<Integer>> bucketizedFeatures,
Long logitsDimension)
Factory method to create a class wrapping a new BoostedTreesPredict operation.
|
static BoostedTreesExampleDebugOutputs |
BoostedTreesExampleDebugOutputs.create(Scope scope,
Operand<?> treeEnsembleHandle,
Iterable<Operand<Integer>> bucketizedFeatures,
Long logitsDimension)
Factory method to create a class wrapping a new BoostedTreesExampleDebugOutputs operation.
|
static NonSerializableDataset |
NonSerializableDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new NonSerializableDataset operation.
|
static UniqueDataset |
UniqueDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new UniqueDataset operation.
|
static ExperimentalUnbatchDataset |
ExperimentalUnbatchDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalUnbatchDataset operation.
|
static IgnoreErrorsDataset |
IgnoreErrorsDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new IgnoreErrorsDataset operation.
|
static BoostedTreesFlushQuantileSummaries |
BoostedTreesFlushQuantileSummaries.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Long numFeatures)
Factory method to create a class wrapping a new BoostedTreesFlushQuantileSummaries operation.
|
static BoostedTreesQuantileStreamResourceGetBucketBoundaries |
BoostedTreesQuantileStreamResourceGetBucketBoundaries.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Long numFeatures)
Factory method to create a class wrapping a new BoostedTreesQuantileStreamResourceGetBucketBoundaries operation.
|
static <T extends Number> |
ResourceCountUpTo.create(Scope scope,
Operand<?> resource,
Long limit,
Class<T> T)
Factory method to create a class wrapping a new ResourceCountUpTo operation.
|
static <U extends Number,T> |
RaggedTensorFromVariant.create(Scope scope,
Operand<?> encodedRagged,
Long inputRaggedRank,
Long outputRaggedRank,
Class<T> Tvalues,
Class<U> Tsplits)
Factory method to create a class wrapping a new RaggedTensorFromVariant operation.
|
static DeleteIterator |
DeleteIterator.create(Scope scope,
Operand<?> handle,
Operand<?> deleter)
Factory method to create a class wrapping a new DeleteIterator operation.
|
static DeleteIterator |
DeleteIterator.create(Scope scope,
Operand<?> handle,
Operand<?> deleter)
Factory method to create a class wrapping a new DeleteIterator operation.
|
static StatsAggregatorSetSummaryWriter |
StatsAggregatorSetSummaryWriter.create(Scope scope,
Operand<?> statsAggregator,
Operand<?> summary)
Factory method to create a class wrapping a new StatsAggregatorSetSummaryWriter operation.
|
static StatsAggregatorSetSummaryWriter |
StatsAggregatorSetSummaryWriter.create(Scope scope,
Operand<?> statsAggregator,
Operand<?> summary)
Factory method to create a class wrapping a new StatsAggregatorSetSummaryWriter operation.
|
static DeleteRandomSeedGenerator |
DeleteRandomSeedGenerator.create(Scope scope,
Operand<?> handle,
Operand<?> deleter)
Factory method to create a class wrapping a new DeleteRandomSeedGenerator operation.
|
static DeleteRandomSeedGenerator |
DeleteRandomSeedGenerator.create(Scope scope,
Operand<?> handle,
Operand<?> deleter)
Factory method to create a class wrapping a new DeleteRandomSeedGenerator operation.
|
static DeleteMemoryCache |
DeleteMemoryCache.create(Scope scope,
Operand<?> handle,
Operand<?> deleter)
Factory method to create a class wrapping a new DeleteMemoryCache operation.
|
static DeleteMemoryCache |
DeleteMemoryCache.create(Scope scope,
Operand<?> handle,
Operand<?> deleter)
Factory method to create a class wrapping a new DeleteMemoryCache operation.
|
static <T> TensorListConcatLists |
TensorListConcatLists.create(Scope scope,
Operand<?> inputA,
Operand<?> inputB,
Class<T> elementDtype)
Factory method to create a class wrapping a new TensorListConcatLists operation.
|
static <T> TensorListConcatLists |
TensorListConcatLists.create(Scope scope,
Operand<?> inputA,
Operand<?> inputB,
Class<T> elementDtype)
Factory method to create a class wrapping a new TensorListConcatLists operation.
|
static ThreadPoolDataset |
ThreadPoolDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<?> threadPool,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ThreadPoolDataset operation.
|
static ThreadPoolDataset |
ThreadPoolDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<?> threadPool,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ThreadPoolDataset operation.
|
static GcsConfigureBlockCache |
GcsConfigureBlockCache.create(Scope scope,
Operand<?> maxCacheSize,
Operand<?> blockSize,
Operand<?> maxStaleness)
Factory method to create a class wrapping a new GcsConfigureBlockCache operation.
|
static GcsConfigureBlockCache |
GcsConfigureBlockCache.create(Scope scope,
Operand<?> maxCacheSize,
Operand<?> blockSize,
Operand<?> maxStaleness)
Factory method to create a class wrapping a new GcsConfigureBlockCache operation.
|
static GcsConfigureBlockCache |
GcsConfigureBlockCache.create(Scope scope,
Operand<?> maxCacheSize,
Operand<?> blockSize,
Operand<?> maxStaleness)
Factory method to create a class wrapping a new GcsConfigureBlockCache operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
static <T> ResourceApplyAdamWithAmsgrad |
ResourceApplyAdamWithAmsgrad.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<?> vhat,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdamWithAmsgrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdamWithAmsgrad operation.
|
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 wrapping a new ExperimentalSetStatsAggregatorDataset operation.
|
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 wrapping a new ExperimentalSetStatsAggregatorDataset operation.
|
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 wrapping a new ExperimentalSetStatsAggregatorDataset operation.
|
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 wrapping a new ExperimentalSetStatsAggregatorDataset operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradV2 operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradV2 operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradV2 operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradV2 operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradV2 operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradV2 operation.
|
static <T> ResourceApplyAdagradV2 |
ResourceApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradV2 operation.
|
static <T> ResourceApplyAdagradV2 |
ResourceApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradV2 operation.
|
static <T> ResourceApplyAdagradV2 |
ResourceApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradV2 operation.
|
static <T> ResourceApplyAdagradV2 |
ResourceApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradV2 operation.
|
static <T> ResourceApplyAdagradV2 |
ResourceApplyAdagradV2.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradV2 operation.
|
static <T> ResourceApplyKerasMomentum |
ResourceApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ResourceApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceApplyKerasMomentum operation.
|
static <T> ResourceApplyKerasMomentum |
ResourceApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ResourceApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceApplyKerasMomentum operation.
|
static <T> ResourceApplyKerasMomentum |
ResourceApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ResourceApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceApplyKerasMomentum operation.
|
static <T> ResourceApplyKerasMomentum |
ResourceApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ResourceApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceApplyKerasMomentum operation.
|
static <T> ResourceApplyKerasMomentum |
ResourceApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ResourceApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceApplyKerasMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyKerasMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyKerasMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyKerasMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyKerasMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyKerasMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyKerasMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyKerasMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyKerasMomentum operation.
|
static TensorArraySize |
TensorArraySize.create(Scope scope,
Operand<?> handle,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArraySize operation.
|
static TensorArraySize |
TensorArraySize.create(Scope scope,
Operand<?> handle,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArraySize operation.
|
static <T> TensorArrayConcat<T> |
TensorArrayConcat.create(Scope scope,
Operand<?> handle,
Operand<Float> flowIn,
Class<T> dtype,
TensorArrayConcat.Options... options)
Factory method to create a class wrapping a new TensorArrayConcat operation.
|
static <T> TensorArrayConcat<T> |
TensorArrayConcat.create(Scope scope,
Operand<?> handle,
Operand<Float> flowIn,
Class<T> dtype,
TensorArrayConcat.Options... options)
Factory method to create a class wrapping a new TensorArrayConcat operation.
|
static TensorForestTreePredict |
TensorForestTreePredict.create(Scope scope,
Operand<?> treeHandle,
Operand<Float> denseFeatures,
Long logitsDimension)
Factory method to create a class wrapping a new TensorForestTreePredict operation.
|
static TensorForestTreePredict |
TensorForestTreePredict.create(Scope scope,
Operand<?> treeHandle,
Operand<Float> denseFeatures,
Long logitsDimension)
Factory method to create a class wrapping a new TensorForestTreePredict operation.
|
static BoostedTreesCenterBias |
BoostedTreesCenterBias.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Float> meanGradients,
Operand<Float> meanHessians,
Operand<Float> l1,
Operand<Float> l2)
Factory method to create a class wrapping a new BoostedTreesCenterBias operation.
|
static BoostedTreesCenterBias |
BoostedTreesCenterBias.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Float> meanGradients,
Operand<Float> meanHessians,
Operand<Float> l1,
Operand<Float> l2)
Factory method to create a class wrapping a new BoostedTreesCenterBias operation.
|
static BoostedTreesCenterBias |
BoostedTreesCenterBias.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Float> meanGradients,
Operand<Float> meanHessians,
Operand<Float> l1,
Operand<Float> l2)
Factory method to create a class wrapping a new BoostedTreesCenterBias operation.
|
static BoostedTreesCenterBias |
BoostedTreesCenterBias.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Float> meanGradients,
Operand<Float> meanHessians,
Operand<Float> l1,
Operand<Float> l2)
Factory method to create a class wrapping a new BoostedTreesCenterBias operation.
|
static BoostedTreesCenterBias |
BoostedTreesCenterBias.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Float> meanGradients,
Operand<Float> meanHessians,
Operand<Float> l1,
Operand<Float> l2)
Factory method to create a class wrapping a new BoostedTreesCenterBias operation.
|
static TensorArrayGradWithShape |
TensorArrayGradWithShape.create(Scope scope,
Operand<?> handle,
Operand<Float> flowIn,
Operand<Integer> shapeToPrepend,
String source)
Factory method to create a class wrapping a new TensorArrayGradWithShape operation.
|
static TensorArrayGradWithShape |
TensorArrayGradWithShape.create(Scope scope,
Operand<?> handle,
Operand<Float> flowIn,
Operand<Integer> shapeToPrepend,
String source)
Factory method to create a class wrapping a new TensorArrayGradWithShape operation.
|
static TensorArrayGradWithShape |
TensorArrayGradWithShape.create(Scope scope,
Operand<?> handle,
Operand<Float> flowIn,
Operand<Integer> shapeToPrepend,
String source)
Factory method to create a class wrapping a new TensorArrayGradWithShape operation.
|
static BoostedTreesCreateQuantileStreamResource |
BoostedTreesCreateQuantileStreamResource.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Operand<Float> epsilon,
Operand<Long> numStreams,
BoostedTreesCreateQuantileStreamResource.Options... options)
Factory method to create a class wrapping a new BoostedTreesCreateQuantileStreamResource operation.
|
static BoostedTreesCreateQuantileStreamResource |
BoostedTreesCreateQuantileStreamResource.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Operand<Float> epsilon,
Operand<Long> numStreams,
BoostedTreesCreateQuantileStreamResource.Options... options)
Factory method to create a class wrapping a new BoostedTreesCreateQuantileStreamResource operation.
|
static BoostedTreesCreateQuantileStreamResource |
BoostedTreesCreateQuantileStreamResource.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Operand<Float> epsilon,
Operand<Long> numStreams,
BoostedTreesCreateQuantileStreamResource.Options... options)
Factory method to create a class wrapping a new BoostedTreesCreateQuantileStreamResource operation.
|
static SamplingDataset |
SamplingDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Float> rate,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new SamplingDataset operation.
|
static SamplingDataset |
SamplingDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Float> rate,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new SamplingDataset operation.
|
static SamplingDataset |
SamplingDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Float> rate,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new SamplingDataset operation.
|
static SamplingDataset |
SamplingDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Float> rate,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new SamplingDataset operation.
|
static TensorArrayGrad |
TensorArrayGrad.create(Scope scope,
Operand<?> handle,
Operand<Float> flowIn,
String source)
Factory method to create a class wrapping a new TensorArrayGrad operation.
|
static TensorArrayGrad |
TensorArrayGrad.create(Scope scope,
Operand<?> handle,
Operand<Float> flowIn,
String source)
Factory method to create a class wrapping a new TensorArrayGrad operation.
|
static TensorListResize |
TensorListResize.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> size)
Factory method to create a class wrapping a new TensorListResize operation.
|
static TensorListResize |
TensorListResize.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> size)
Factory method to create a class wrapping a new TensorListResize operation.
|
static <T> TensorListPopBack<T> |
TensorListPopBack.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> elementShape,
Class<T> elementDtype)
Factory method to create a class wrapping a new TensorListPopBack operation.
|
static <T> TensorListPopBack<T> |
TensorListPopBack.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> elementShape,
Class<T> elementDtype)
Factory method to create a class wrapping a new TensorListPopBack operation.
|
static <T> ResourceAccumulatorTakeGradient<T> |
ResourceAccumulatorTakeGradient.create(Scope scope,
Operand<?> handle,
Operand<Integer> numRequired,
Class<T> dtype)
Factory method to create a class wrapping a new ResourceAccumulatorTakeGradient operation.
|
static <T> ResourceAccumulatorTakeGradient<T> |
ResourceAccumulatorTakeGradient.create(Scope scope,
Operand<?> handle,
Operand<Integer> numRequired,
Class<T> dtype)
Factory method to create a class wrapping a new ResourceAccumulatorTakeGradient operation.
|
static <T> TensorListStack<T> |
TensorListStack.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> elementShape,
Class<T> elementDtype,
TensorListStack.Options... options)
Factory method to create a class wrapping a new TensorListStack operation.
|
static <T> TensorListStack<T> |
TensorListStack.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> elementShape,
Class<T> elementDtype,
TensorListStack.Options... options)
Factory method to create a class wrapping a new TensorListStack operation.
|
static BoostedTreesUpdateEnsemble |
BoostedTreesUpdateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Long pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsemble operation.
|
static BoostedTreesUpdateEnsemble |
BoostedTreesUpdateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Long pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsemble operation.
|
static BoostedTreesUpdateEnsemble |
BoostedTreesUpdateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Long pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsemble operation.
|
static BoostedTreesUpdateEnsemble |
BoostedTreesUpdateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Long pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsemble operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static <T> TensorArrayRead<T> |
TensorArrayRead.create(Scope scope,
Operand<?> handle,
Operand<Integer> index,
Operand<Float> flowIn,
Class<T> dtype)
Factory method to create a class wrapping a new TensorArrayRead operation.
|
static <T> TensorArrayRead<T> |
TensorArrayRead.create(Scope scope,
Operand<?> handle,
Operand<Integer> index,
Operand<Float> flowIn,
Class<T> dtype)
Factory method to create a class wrapping a new TensorArrayRead operation.
|
static <T> TensorArrayRead<T> |
TensorArrayRead.create(Scope scope,
Operand<?> handle,
Operand<Integer> index,
Operand<Float> flowIn,
Class<T> dtype)
Factory method to create a class wrapping a new TensorArrayRead operation.
|
static <T> TensorArrayGather<T> |
TensorArrayGather.create(Scope scope,
Operand<?> handle,
Operand<Integer> indices,
Operand<Float> flowIn,
Class<T> dtype,
TensorArrayGather.Options... options)
Factory method to create a class wrapping a new TensorArrayGather operation.
|
static <T> TensorArrayGather<T> |
TensorArrayGather.create(Scope scope,
Operand<?> handle,
Operand<Integer> indices,
Operand<Float> flowIn,
Class<T> dtype,
TensorArrayGather.Options... options)
Factory method to create a class wrapping a new TensorArrayGather operation.
|
static <T> TensorArrayGather<T> |
TensorArrayGather.create(Scope scope,
Operand<?> handle,
Operand<Integer> indices,
Operand<Float> flowIn,
Class<T> dtype,
TensorArrayGather.Options... options)
Factory method to create a class wrapping a new TensorArrayGather operation.
|
static <T> TensorListGetItem<T> |
TensorListGetItem.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> index,
Operand<Integer> elementShape,
Class<T> elementDtype)
Factory method to create a class wrapping a new TensorListGetItem operation.
|
static <T> TensorListGetItem<T> |
TensorListGetItem.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> index,
Operand<Integer> elementShape,
Class<T> elementDtype)
Factory method to create a class wrapping a new TensorListGetItem operation.
|
static <T> TensorListGetItem<T> |
TensorListGetItem.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> index,
Operand<Integer> elementShape,
Class<T> elementDtype)
Factory method to create a class wrapping a new TensorListGetItem operation.
|
static <T> TensorListGather<T> |
TensorListGather.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> indices,
Operand<Integer> elementShape,
Class<T> elementDtype)
Factory method to create a class wrapping a new TensorListGather operation.
|
static <T> TensorListGather<T> |
TensorListGather.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> indices,
Operand<Integer> elementShape,
Class<T> elementDtype)
Factory method to create a class wrapping a new TensorListGather operation.
|
static <T> TensorListGather<T> |
TensorListGather.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> indices,
Operand<Integer> elementShape,
Class<T> elementDtype)
Factory method to create a class wrapping a new TensorListGather operation.
|
static BoostedTreesTrainingPredict |
BoostedTreesTrainingPredict.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> cachedTreeIds,
Operand<Integer> cachedNodeIds,
Iterable<Operand<Integer>> bucketizedFeatures,
Long logitsDimension)
Factory method to create a class wrapping a new BoostedTreesTrainingPredict operation.
|
static BoostedTreesTrainingPredict |
BoostedTreesTrainingPredict.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> cachedTreeIds,
Operand<Integer> cachedNodeIds,
Iterable<Operand<Integer>> bucketizedFeatures,
Long logitsDimension)
Factory method to create a class wrapping a new BoostedTreesTrainingPredict operation.
|
static BoostedTreesTrainingPredict |
BoostedTreesTrainingPredict.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> cachedTreeIds,
Operand<Integer> cachedNodeIds,
Iterable<Operand<Integer>> bucketizedFeatures,
Long logitsDimension)
Factory method to create a class wrapping a new BoostedTreesTrainingPredict operation.
|
static <T> TensorListSetItem |
TensorListSetItem.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> index,
Operand<T> item)
Factory method to create a class wrapping a new TensorListSetItem operation.
|
static <T> TensorListSetItem |
TensorListSetItem.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> index,
Operand<T> item)
Factory method to create a class wrapping a new TensorListSetItem operation.
|
static <T> TensorListSetItem |
TensorListSetItem.create(Scope scope,
Operand<?> inputHandle,
Operand<Integer> index,
Operand<T> item)
Factory method to create a class wrapping a new TensorListSetItem operation.
|
static <T> TensorArrayWrite |
TensorArrayWrite.create(Scope scope,
Operand<?> handle,
Operand<Integer> index,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayWrite operation.
|
static <T> TensorArrayWrite |
TensorArrayWrite.create(Scope scope,
Operand<?> handle,
Operand<Integer> index,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayWrite operation.
|
static <T> TensorArrayWrite |
TensorArrayWrite.create(Scope scope,
Operand<?> handle,
Operand<Integer> index,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayWrite operation.
|
static <T> TensorArrayWrite |
TensorArrayWrite.create(Scope scope,
Operand<?> handle,
Operand<Integer> index,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayWrite operation.
|
static <T> TensorArrayScatter |
TensorArrayScatter.create(Scope scope,
Operand<?> handle,
Operand<Integer> indices,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayScatter operation.
|
static <T> TensorArrayScatter |
TensorArrayScatter.create(Scope scope,
Operand<?> handle,
Operand<Integer> indices,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayScatter operation.
|
static <T> TensorArrayScatter |
TensorArrayScatter.create(Scope scope,
Operand<?> handle,
Operand<Integer> indices,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayScatter operation.
|
static <T> TensorArrayScatter |
TensorArrayScatter.create(Scope scope,
Operand<?> handle,
Operand<Integer> indices,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayScatter operation.
|
static ResourceAccumulatorSetGlobalStep |
ResourceAccumulatorSetGlobalStep.create(Scope scope,
Operand<?> handle,
Operand<Long> newGlobalStep)
Factory method to create a class wrapping a new ResourceAccumulatorSetGlobalStep operation.
|
static ResourceAccumulatorSetGlobalStep |
ResourceAccumulatorSetGlobalStep.create(Scope scope,
Operand<?> handle,
Operand<Long> newGlobalStep)
Factory method to create a class wrapping a new ResourceAccumulatorSetGlobalStep operation.
|
static BoostedTreesQuantileStreamResourceFlush |
BoostedTreesQuantileStreamResourceFlush.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Operand<Long> numBuckets,
BoostedTreesQuantileStreamResourceFlush.Options... options)
Factory method to create a class wrapping a new BoostedTreesQuantileStreamResourceFlush operation.
|
static BoostedTreesQuantileStreamResourceFlush |
BoostedTreesQuantileStreamResourceFlush.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Operand<Long> numBuckets,
BoostedTreesQuantileStreamResourceFlush.Options... options)
Factory method to create a class wrapping a new BoostedTreesQuantileStreamResourceFlush operation.
|
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 wrapping a new ExperimentalParseExampleDataset operation.
|
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 wrapping a new ExperimentalParseExampleDataset operation.
|
static ExperimentalMaxIntraOpParallelismDataset |
ExperimentalMaxIntraOpParallelismDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> maxIntraOpParallelism,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalMaxIntraOpParallelismDataset operation.
|
static ExperimentalMaxIntraOpParallelismDataset |
ExperimentalMaxIntraOpParallelismDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> maxIntraOpParallelism,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalMaxIntraOpParallelismDataset operation.
|
static ExperimentalPrivateThreadPoolDataset |
ExperimentalPrivateThreadPoolDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numThreads,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalPrivateThreadPoolDataset operation.
|
static ExperimentalPrivateThreadPoolDataset |
ExperimentalPrivateThreadPoolDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numThreads,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalPrivateThreadPoolDataset operation.
|
static PrivateThreadPoolDataset |
PrivateThreadPoolDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numThreads,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new PrivateThreadPoolDataset operation.
|
static PrivateThreadPoolDataset |
PrivateThreadPoolDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numThreads,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new PrivateThreadPoolDataset operation.
|
static SleepDataset |
SleepDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> sleepMicroseconds,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new SleepDataset operation.
|
static SleepDataset |
SleepDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> sleepMicroseconds,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new SleepDataset operation.
|
static MaxIntraOpParallelismDataset |
MaxIntraOpParallelismDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> maxIntraOpParallelism,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new MaxIntraOpParallelismDataset operation.
|
static MaxIntraOpParallelismDataset |
MaxIntraOpParallelismDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> maxIntraOpParallelism,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new MaxIntraOpParallelismDataset operation.
|
static ExperimentalRebatchDataset |
ExperimentalRebatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numReplicas,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
ExperimentalRebatchDataset.Options... options)
Factory method to create a class wrapping a new ExperimentalRebatchDataset operation.
|
static ExperimentalRebatchDataset |
ExperimentalRebatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numReplicas,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
ExperimentalRebatchDataset.Options... options)
Factory method to create a class wrapping a new ExperimentalRebatchDataset operation.
|
static RebatchDataset |
RebatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numReplicas,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
RebatchDataset.Options... options)
Factory method to create a class wrapping a new RebatchDataset operation.
|
static RebatchDataset |
RebatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numReplicas,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
RebatchDataset.Options... options)
Factory method to create a class wrapping a new RebatchDataset operation.
|
static ShuffleDatasetV2 |
ShuffleDatasetV2.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> bufferSize,
Operand<?> seedGenerator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ShuffleDatasetV2 operation.
|
static ShuffleDatasetV2 |
ShuffleDatasetV2.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> bufferSize,
Operand<?> seedGenerator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ShuffleDatasetV2 operation.
|
static ShuffleDatasetV2 |
ShuffleDatasetV2.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> bufferSize,
Operand<?> seedGenerator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ShuffleDatasetV2 operation.
|
static RngSkip |
RngSkip.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<Long> delta)
Factory method to create a class wrapping a new RngSkip operation.
|
static RngSkip |
RngSkip.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<Long> delta)
Factory method to create a class wrapping a new RngSkip operation.
|
static RngSkip |
RngSkip.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<Long> delta)
Factory method to create a class wrapping a new RngSkip operation.
|
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 wrapping a new ExperimentalDenseToSparseBatchDataset operation.
|
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 wrapping a new ExperimentalDenseToSparseBatchDataset operation.
|
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 wrapping a new ExperimentalDenseToSparseBatchDataset operation.
|
static AutoShardDataset |
AutoShardDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numWorkers,
Operand<Long> index,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new AutoShardDataset operation.
|
static AutoShardDataset |
AutoShardDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numWorkers,
Operand<Long> index,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new AutoShardDataset operation.
|
static AutoShardDataset |
AutoShardDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numWorkers,
Operand<Long> index,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new AutoShardDataset operation.
|
static ExperimentalAutoShardDataset |
ExperimentalAutoShardDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numWorkers,
Operand<Long> index,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalAutoShardDataset operation.
|
static ExperimentalAutoShardDataset |
ExperimentalAutoShardDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numWorkers,
Operand<Long> index,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalAutoShardDataset operation.
|
static ExperimentalAutoShardDataset |
ExperimentalAutoShardDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numWorkers,
Operand<Long> index,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalAutoShardDataset operation.
|
static ShardDataset |
ShardDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numShards,
Operand<Long> index,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
ShardDataset.Options... options)
Factory method to create a class wrapping a new ShardDataset operation.
|
static ShardDataset |
ShardDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numShards,
Operand<Long> index,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
ShardDataset.Options... options)
Factory method to create a class wrapping a new ShardDataset operation.
|
static ShardDataset |
ShardDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> numShards,
Operand<Long> index,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
ShardDataset.Options... options)
Factory method to create a class wrapping a new ShardDataset operation.
|
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 wrapping a new ExperimentalSlidingWindowDataset operation.
|
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 wrapping a new ExperimentalSlidingWindowDataset operation.
|
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 wrapping a new ExperimentalSlidingWindowDataset operation.
|
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 wrapping a new ExperimentalSlidingWindowDataset operation.
|
static SlidingWindowDataset |
SlidingWindowDataset.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 wrapping a new SlidingWindowDataset operation.
|
static SlidingWindowDataset |
SlidingWindowDataset.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 wrapping a new SlidingWindowDataset operation.
|
static SlidingWindowDataset |
SlidingWindowDataset.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 wrapping a new SlidingWindowDataset operation.
|
static SlidingWindowDataset |
SlidingWindowDataset.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 wrapping a new SlidingWindowDataset operation.
|
static WriteRawProtoSummary |
WriteRawProtoSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tensor)
Factory method to create a class wrapping a new WriteRawProtoSummary operation.
|
static WriteRawProtoSummary |
WriteRawProtoSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tensor)
Factory method to create a class wrapping a new WriteRawProtoSummary operation.
|
static WriteRawProtoSummary |
WriteRawProtoSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tensor)
Factory method to create a class wrapping a new WriteRawProtoSummary operation.
|
static BoostedTreesDeserializeEnsemble |
BoostedTreesDeserializeEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Long> stampToken,
Operand<String> treeEnsembleSerialized)
Factory method to create a class wrapping a new BoostedTreesDeserializeEnsemble operation.
|
static BoostedTreesDeserializeEnsemble |
BoostedTreesDeserializeEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Long> stampToken,
Operand<String> treeEnsembleSerialized)
Factory method to create a class wrapping a new BoostedTreesDeserializeEnsemble operation.
|
static BoostedTreesDeserializeEnsemble |
BoostedTreesDeserializeEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Long> stampToken,
Operand<String> treeEnsembleSerialized)
Factory method to create a class wrapping a new BoostedTreesDeserializeEnsemble operation.
|
static BoostedTreesCreateEnsemble |
BoostedTreesCreateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Long> stampToken,
Operand<String> treeEnsembleSerialized)
Factory method to create a class wrapping a new BoostedTreesCreateEnsemble operation.
|
static BoostedTreesCreateEnsemble |
BoostedTreesCreateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Long> stampToken,
Operand<String> treeEnsembleSerialized)
Factory method to create a class wrapping a new BoostedTreesCreateEnsemble operation.
|
static BoostedTreesCreateEnsemble |
BoostedTreesCreateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Long> stampToken,
Operand<String> treeEnsembleSerialized)
Factory method to create a class wrapping a new BoostedTreesCreateEnsemble operation.
|
static <T> StatefulStandardNormalV2<Float> |
StatefulStandardNormalV2.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulStandardNormalV2 operation using default output types.
|
static <T> StatefulStandardNormalV2<Float> |
StatefulStandardNormalV2.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulStandardNormalV2 operation using default output types.
|
static <T> StatefulStandardNormalV2<Float> |
StatefulStandardNormalV2.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulStandardNormalV2 operation using default output types.
|
static <T> ResourceAccumulatorApplyGradient |
ResourceAccumulatorApplyGradient.create(Scope scope,
Operand<?> handle,
Operand<Long> localStep,
Operand<T> gradient)
Factory method to create a class wrapping a new ResourceAccumulatorApplyGradient operation.
|
static <T> ResourceAccumulatorApplyGradient |
ResourceAccumulatorApplyGradient.create(Scope scope,
Operand<?> handle,
Operand<Long> localStep,
Operand<T> gradient)
Factory method to create a class wrapping a new ResourceAccumulatorApplyGradient operation.
|
static <T> ResourceAccumulatorApplyGradient |
ResourceAccumulatorApplyGradient.create(Scope scope,
Operand<?> handle,
Operand<Long> localStep,
Operand<T> gradient)
Factory method to create a class wrapping a new ResourceAccumulatorApplyGradient operation.
|
static <T> StatefulUniform<Float> |
StatefulUniform.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulUniform operation using default output types.
|
static <T> StatefulUniform<Float> |
StatefulUniform.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulUniform operation using default output types.
|
static <T> StatefulUniform<Float> |
StatefulUniform.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulUniform operation using default output types.
|
static <T> StatefulTruncatedNormal<Float> |
StatefulTruncatedNormal.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulTruncatedNormal operation using default output types.
|
static <T> StatefulTruncatedNormal<Float> |
StatefulTruncatedNormal.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulTruncatedNormal operation using default output types.
|
static <T> StatefulTruncatedNormal<Float> |
StatefulTruncatedNormal.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulTruncatedNormal operation using default output types.
|
static <U,T> StatefulStandardNormalV2<U> |
StatefulStandardNormalV2.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulStandardNormalV2 operation.
|
static <U,T> StatefulStandardNormalV2<U> |
StatefulStandardNormalV2.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulStandardNormalV2 operation.
|
static <U,T> StatefulStandardNormalV2<U> |
StatefulStandardNormalV2.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulStandardNormalV2 operation.
|
static <U,T> StatefulUniform<U> |
StatefulUniform.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulUniform operation.
|
static <U,T> StatefulUniform<U> |
StatefulUniform.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulUniform operation.
|
static <U,T> StatefulUniform<U> |
StatefulUniform.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulUniform operation.
|
static <U,T> StatefulUniformFullInt<U> |
StatefulUniformFullInt.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulUniformFullInt operation.
|
static <U,T> StatefulUniformFullInt<U> |
StatefulUniformFullInt.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulUniformFullInt operation.
|
static <U,T> StatefulUniformFullInt<U> |
StatefulUniformFullInt.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulUniformFullInt operation.
|
static <U,T> StatefulTruncatedNormal<U> |
StatefulTruncatedNormal.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulTruncatedNormal operation.
|
static <U,T> StatefulTruncatedNormal<U> |
StatefulTruncatedNormal.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulTruncatedNormal operation.
|
static <U,T> StatefulTruncatedNormal<U> |
StatefulTruncatedNormal.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulTruncatedNormal operation.
|
static <T extends Number,U extends Number> |
StatefulRandomBinomial.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> counts,
Operand<U> probs)
Factory method to create a class wrapping a new StatefulRandomBinomial operation using default output types.
|
static <T extends Number,U extends Number> |
StatefulRandomBinomial.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> counts,
Operand<U> probs)
Factory method to create a class wrapping a new StatefulRandomBinomial operation using default output types.
|
static <T extends Number,U extends Number> |
StatefulRandomBinomial.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> counts,
Operand<U> probs)
Factory method to create a class wrapping a new StatefulRandomBinomial operation using default output types.
|
static <T extends Number,U extends Number> |
StatefulRandomBinomial.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> counts,
Operand<U> probs)
Factory method to create a class wrapping a new StatefulRandomBinomial operation using default output types.
|
static <T extends Number,U extends Number> |
StatefulRandomBinomial.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> counts,
Operand<U> probs)
Factory method to create a class wrapping a new StatefulRandomBinomial operation using default output types.
|
static <U,T> StatefulUniformInt<U> |
StatefulUniformInt.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> minval,
Operand<U> maxval)
Factory method to create a class wrapping a new StatefulUniformInt operation.
|
static <U,T> StatefulUniformInt<U> |
StatefulUniformInt.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> minval,
Operand<U> maxval)
Factory method to create a class wrapping a new StatefulUniformInt operation.
|
static <U,T> StatefulUniformInt<U> |
StatefulUniformInt.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> minval,
Operand<U> maxval)
Factory method to create a class wrapping a new StatefulUniformInt operation.
|
static <U,T> StatefulUniformInt<U> |
StatefulUniformInt.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> minval,
Operand<U> maxval)
Factory method to create a class wrapping a new StatefulUniformInt operation.
|
static <U,T> StatefulUniformInt<U> |
StatefulUniformInt.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> minval,
Operand<U> maxval)
Factory method to create a class wrapping a new StatefulUniformInt operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatefulRandomBinomial.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> counts,
Operand<U> probs,
Class<V> dtype)
Factory method to create a class wrapping a new StatefulRandomBinomial operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatefulRandomBinomial.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> counts,
Operand<U> probs,
Class<V> dtype)
Factory method to create a class wrapping a new StatefulRandomBinomial operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatefulRandomBinomial.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> counts,
Operand<U> probs,
Class<V> dtype)
Factory method to create a class wrapping a new StatefulRandomBinomial operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatefulRandomBinomial.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> counts,
Operand<U> probs,
Class<V> dtype)
Factory method to create a class wrapping a new StatefulRandomBinomial operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatefulRandomBinomial.create(Scope scope,
Operand<?> resource,
Operand<Long> algorithm,
Operand<T> shape,
Operand<U> counts,
Operand<U> probs,
Class<V> dtype)
Factory method to create a class wrapping a new StatefulRandomBinomial operation.
|
static TensorForestCreateTreeVariable |
TensorForestCreateTreeVariable.create(Scope scope,
Operand<?> treeHandle,
Operand<String> treeConfig)
Factory method to create a class wrapping a new TensorForestCreateTreeVariable operation.
|
static TensorForestCreateTreeVariable |
TensorForestCreateTreeVariable.create(Scope scope,
Operand<?> treeHandle,
Operand<String> treeConfig)
Factory method to create a class wrapping a new TensorForestCreateTreeVariable operation.
|
static TensorForestTreeDeserialize |
TensorForestTreeDeserialize.create(Scope scope,
Operand<?> treeHandle,
Operand<String> treeConfig)
Factory method to create a class wrapping a new TensorForestTreeDeserialize operation.
|
static TensorForestTreeDeserialize |
TensorForestTreeDeserialize.create(Scope scope,
Operand<?> treeHandle,
Operand<String> treeConfig)
Factory method to create a class wrapping a new TensorForestTreeDeserialize operation.
|
static ExperimentalBytesProducedStatsDataset |
ExperimentalBytesProducedStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalBytesProducedStatsDataset operation.
|
static ExperimentalBytesProducedStatsDataset |
ExperimentalBytesProducedStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalBytesProducedStatsDataset operation.
|
static ExperimentalLatencyStatsDataset |
ExperimentalLatencyStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalLatencyStatsDataset operation.
|
static ExperimentalLatencyStatsDataset |
ExperimentalLatencyStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalLatencyStatsDataset operation.
|
static AssertNextDataset |
AssertNextDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> transformations,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new AssertNextDataset operation.
|
static AssertNextDataset |
AssertNextDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> transformations,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new AssertNextDataset operation.
|
static SnapshotDataset |
SnapshotDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> path,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
SnapshotDataset.Options... options)
Factory method to create a class wrapping a new SnapshotDataset operation.
|
static SnapshotDataset |
SnapshotDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> path,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
SnapshotDataset.Options... options)
Factory method to create a class wrapping a new SnapshotDataset operation.
|
static InitializeTableFromTextFile |
InitializeTableFromTextFile.create(Scope scope,
Operand<?> tableHandle,
Operand<String> filename,
Long keyIndex,
Long valueIndex,
InitializeTableFromTextFile.Options... options)
Factory method to create a class wrapping a new InitializeTableFromTextFile operation.
|
static InitializeTableFromTextFile |
InitializeTableFromTextFile.create(Scope scope,
Operand<?> tableHandle,
Operand<String> filename,
Long keyIndex,
Long valueIndex,
InitializeTableFromTextFile.Options... options)
Factory method to create a class wrapping a new InitializeTableFromTextFile operation.
|
static CacheDatasetV2 |
CacheDatasetV2.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
Operand<?> cache,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new CacheDatasetV2 operation.
|
static CacheDatasetV2 |
CacheDatasetV2.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
Operand<?> cache,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new CacheDatasetV2 operation.
|
static CacheDatasetV2 |
CacheDatasetV2.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
Operand<?> cache,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new CacheDatasetV2 operation.
|
static ExperimentalDatasetToTFRecord |
ExperimentalDatasetToTFRecord.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
Operand<String> compressionType)
Factory method to create a class wrapping a new ExperimentalDatasetToTFRecord operation.
|
static ExperimentalDatasetToTFRecord |
ExperimentalDatasetToTFRecord.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
Operand<String> compressionType)
Factory method to create a class wrapping a new ExperimentalDatasetToTFRecord operation.
|
static ExperimentalDatasetToTFRecord |
ExperimentalDatasetToTFRecord.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
Operand<String> compressionType)
Factory method to create a class wrapping a new ExperimentalDatasetToTFRecord operation.
|
static <T> LookupTableRemove |
LookupTableRemove.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys)
Factory method to create a class wrapping a new LookupTableRemove operation.
|
static <T> LookupTableRemove |
LookupTableRemove.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys)
Factory method to create a class wrapping a new LookupTableRemove operation.
|
static <T> AssignSubVariableOp |
AssignSubVariableOp.create(Scope scope,
Operand<?> resource,
Operand<T> value)
Factory method to create a class wrapping a new AssignSubVariableOp operation.
|
static <T> AssignSubVariableOp |
AssignSubVariableOp.create(Scope scope,
Operand<?> resource,
Operand<T> value)
Factory method to create a class wrapping a new AssignSubVariableOp operation.
|
static <T> StatefulStandardNormal<Float> |
StatefulStandardNormal.create(Scope scope,
Operand<?> resource,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulStandardNormal operation using default output types.
|
static <T> StatefulStandardNormal<Float> |
StatefulStandardNormal.create(Scope scope,
Operand<?> resource,
Operand<T> shape)
Factory method to create a class wrapping a new StatefulStandardNormal operation using default output types.
|
static <T> AssignVariableOp |
AssignVariableOp.create(Scope scope,
Operand<?> resource,
Operand<T> value)
Factory method to create a class wrapping a new AssignVariableOp operation.
|
static <T> AssignVariableOp |
AssignVariableOp.create(Scope scope,
Operand<?> resource,
Operand<T> value)
Factory method to create a class wrapping a new AssignVariableOp operation.
|
static <T> TensorListPushBack |
TensorListPushBack.create(Scope scope,
Operand<?> inputHandle,
Operand<T> tensor)
Factory method to create a class wrapping a new TensorListPushBack operation.
|
static <T> TensorListPushBack |
TensorListPushBack.create(Scope scope,
Operand<?> inputHandle,
Operand<T> tensor)
Factory method to create a class wrapping a new TensorListPushBack operation.
|
static <T> TensorListPushBackBatch |
TensorListPushBackBatch.create(Scope scope,
Operand<?> inputHandles,
Operand<T> tensor)
Factory method to create a class wrapping a new TensorListPushBackBatch operation.
|
static <T> TensorListPushBackBatch |
TensorListPushBackBatch.create(Scope scope,
Operand<?> inputHandles,
Operand<T> tensor)
Factory method to create a class wrapping a new TensorListPushBackBatch operation.
|
static <T> AssignAddVariableOp |
AssignAddVariableOp.create(Scope scope,
Operand<?> resource,
Operand<T> value)
Factory method to create a class wrapping a new AssignAddVariableOp operation.
|
static <T> AssignAddVariableOp |
AssignAddVariableOp.create(Scope scope,
Operand<?> resource,
Operand<T> value)
Factory method to create a class wrapping a new AssignAddVariableOp operation.
|
static <U,T> StatefulStandardNormal<U> |
StatefulStandardNormal.create(Scope scope,
Operand<?> resource,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulStandardNormal operation.
|
static <U,T> StatefulStandardNormal<U> |
StatefulStandardNormal.create(Scope scope,
Operand<?> resource,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new StatefulStandardNormal operation.
|
static <U,T extends Number> |
ResourceGatherNd.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Class<U> dtype)
Factory method to create a class wrapping a new ResourceGatherNd operation.
|
static <U,T extends Number> |
ResourceGatherNd.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Class<U> dtype)
Factory method to create a class wrapping a new ResourceGatherNd operation.
|
static <U,T extends Number> |
ResourceGather.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Class<U> dtype,
ResourceGather.Options... options)
Factory method to create a class wrapping a new ResourceGather operation.
|
static <U,T extends Number> |
ResourceGather.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Class<U> dtype,
ResourceGather.Options... options)
Factory method to create a class wrapping a new ResourceGather operation.
|
static <T> TensorListScatterIntoExistingList |
TensorListScatterIntoExistingList.create(Scope scope,
Operand<?> inputHandle,
Operand<T> tensor,
Operand<Integer> indices)
Factory method to create a class wrapping a new TensorListScatterIntoExistingList operation.
|
static <T> TensorListScatterIntoExistingList |
TensorListScatterIntoExistingList.create(Scope scope,
Operand<?> inputHandle,
Operand<T> tensor,
Operand<Integer> indices)
Factory method to create a class wrapping a new TensorListScatterIntoExistingList operation.
|
static <T> TensorListScatterIntoExistingList |
TensorListScatterIntoExistingList.create(Scope scope,
Operand<?> inputHandle,
Operand<T> tensor,
Operand<Integer> indices)
Factory method to create a class wrapping a new TensorListScatterIntoExistingList operation.
|
static <U,T extends Number> |
TensorListConcatV2.create(Scope scope,
Operand<?> inputHandle,
Operand<T> elementShape,
Operand<Long> leadingDims,
Class<U> elementDtype)
Factory method to create a class wrapping a new TensorListConcatV2 operation.
|
static <U,T extends Number> |
TensorListConcatV2.create(Scope scope,
Operand<?> inputHandle,
Operand<T> elementShape,
Operand<Long> leadingDims,
Class<U> elementDtype)
Factory method to create a class wrapping a new TensorListConcatV2 operation.
|
static <U,T extends Number> |
TensorListConcatV2.create(Scope scope,
Operand<?> inputHandle,
Operand<T> elementShape,
Operand<Long> leadingDims,
Class<U> elementDtype)
Factory method to create a class wrapping a new TensorListConcatV2 operation.
|
static <T> TensorArraySplit |
TensorArraySplit.create(Scope scope,
Operand<?> handle,
Operand<T> value,
Operand<Long> lengths,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArraySplit operation.
|
static <T> TensorArraySplit |
TensorArraySplit.create(Scope scope,
Operand<?> handle,
Operand<T> value,
Operand<Long> lengths,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArraySplit operation.
|
static <T> TensorArraySplit |
TensorArraySplit.create(Scope scope,
Operand<?> handle,
Operand<T> value,
Operand<Long> lengths,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArraySplit operation.
|
static <T> TensorArraySplit |
TensorArraySplit.create(Scope scope,
Operand<?> handle,
Operand<T> value,
Operand<Long> lengths,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArraySplit operation.
|
static <T extends Number,U> |
ResourceStridedSliceAssign.create(Scope scope,
Operand<?> ref,
Operand<T> begin,
Operand<T> end,
Operand<T> strides,
Operand<U> value,
ResourceStridedSliceAssign.Options... options)
Factory method to create a class wrapping a new ResourceStridedSliceAssign operation.
|
static <T extends Number,U> |
ResourceStridedSliceAssign.create(Scope scope,
Operand<?> ref,
Operand<T> begin,
Operand<T> end,
Operand<T> strides,
Operand<U> value,
ResourceStridedSliceAssign.Options... options)
Factory method to create a class wrapping a new ResourceStridedSliceAssign operation.
|
static <T extends Number,U> |
ResourceStridedSliceAssign.create(Scope scope,
Operand<?> ref,
Operand<T> begin,
Operand<T> end,
Operand<T> strides,
Operand<U> value,
ResourceStridedSliceAssign.Options... options)
Factory method to create a class wrapping a new ResourceStridedSliceAssign operation.
|
static <T extends Number,U> |
ResourceStridedSliceAssign.create(Scope scope,
Operand<?> ref,
Operand<T> begin,
Operand<T> end,
Operand<T> strides,
Operand<U> value,
ResourceStridedSliceAssign.Options... options)
Factory method to create a class wrapping a new ResourceStridedSliceAssign operation.
|
static <T extends Number,U> |
ResourceStridedSliceAssign.create(Scope scope,
Operand<?> ref,
Operand<T> begin,
Operand<T> end,
Operand<T> strides,
Operand<U> value,
ResourceStridedSliceAssign.Options... options)
Factory method to create a class wrapping a new ResourceStridedSliceAssign operation.
|
static <T extends Number,U> |
ResourceScatterSub.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterSub operation.
|
static <T extends Number,U> |
ResourceScatterSub.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterSub operation.
|
static <T extends Number,U> |
ResourceScatterSub.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterSub operation.
|
static <T extends Number,U> |
ResourceScatterMax.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterMax operation.
|
static <T extends Number,U> |
ResourceScatterMax.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterMax operation.
|
static <T extends Number,U> |
ResourceScatterMax.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterMax operation.
|
static <T extends Number,U> |
ResourceScatterUpdate.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterUpdate operation.
|
static <T extends Number,U> |
ResourceScatterUpdate.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterUpdate operation.
|
static <T extends Number,U> |
ResourceScatterUpdate.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterUpdate operation.
|
static <T extends Number,U> |
ResourceScatterDiv.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterDiv operation.
|
static <T extends Number,U> |
ResourceScatterDiv.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterDiv operation.
|
static <T extends Number,U> |
ResourceScatterDiv.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterDiv operation.
|
static <T extends Number,U> |
ResourceScatterMin.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterMin operation.
|
static <T extends Number,U> |
ResourceScatterMin.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterMin operation.
|
static <T extends Number,U> |
ResourceScatterMin.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterMin operation.
|
static <T extends Number,U> |
ResourceScatterAdd.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterAdd operation.
|
static <T extends Number,U> |
ResourceScatterAdd.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterAdd operation.
|
static <T extends Number,U> |
ResourceScatterAdd.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterAdd operation.
|
static <T extends Number,U> |
ResourceScatterMul.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterMul operation.
|
static <T extends Number,U> |
ResourceScatterMul.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterMul operation.
|
static <T extends Number,U> |
ResourceScatterMul.create(Scope scope,
Operand<?> resource,
Operand<T> indices,
Operand<U> updates)
Factory method to create a class wrapping a new ResourceScatterMul operation.
|
static <T,U> LookupTableImport |
LookupTableImport.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> values)
Factory method to create a class wrapping a new LookupTableImport operation.
|
static <T,U> LookupTableImport |
LookupTableImport.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> values)
Factory method to create a class wrapping a new LookupTableImport operation.
|
static <T,U> LookupTableImport |
LookupTableImport.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> values)
Factory method to create a class wrapping a new LookupTableImport operation.
|
static <T,U> InitializeTable |
InitializeTable.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> values)
Factory method to create a class wrapping a new InitializeTable operation.
|
static <T,U> InitializeTable |
InitializeTable.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> values)
Factory method to create a class wrapping a new InitializeTable operation.
|
static <T,U> InitializeTable |
InitializeTable.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> values)
Factory method to create a class wrapping a new InitializeTable operation.
|
static <T,U> LookupTableInsert |
LookupTableInsert.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> values)
Factory method to create a class wrapping a new LookupTableInsert operation.
|
static <T,U> LookupTableInsert |
LookupTableInsert.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> values)
Factory method to create a class wrapping a new LookupTableInsert operation.
|
static <T,U> LookupTableInsert |
LookupTableInsert.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> values)
Factory method to create a class wrapping a new LookupTableInsert operation.
|
static <U,T> LookupTableFind<U> |
LookupTableFind.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> defaultValue)
Factory method to create a class wrapping a new LookupTableFind operation.
|
static <U,T> LookupTableFind<U> |
LookupTableFind.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> defaultValue)
Factory method to create a class wrapping a new LookupTableFind operation.
|
static <U,T> LookupTableFind<U> |
LookupTableFind.create(Scope scope,
Operand<?> tableHandle,
Operand<T> keys,
Operand<U> defaultValue)
Factory method to create a class wrapping a new LookupTableFind operation.
|
static <T extends Number,U> |
ResourceScatterNdAdd.create(Scope scope,
Operand<?> ref,
Operand<T> indices,
Operand<U> updates,
ResourceScatterNdAdd.Options... options)
Factory method to create a class wrapping a new ResourceScatterNdAdd operation.
|
static <T extends Number,U> |
ResourceScatterNdAdd.create(Scope scope,
Operand<?> ref,
Operand<T> indices,
Operand<U> updates,
ResourceScatterNdAdd.Options... options)
Factory method to create a class wrapping a new ResourceScatterNdAdd operation.
|
static <T extends Number,U> |
ResourceScatterNdAdd.create(Scope scope,
Operand<?> ref,
Operand<T> indices,
Operand<U> updates,
ResourceScatterNdAdd.Options... options)
Factory method to create a class wrapping a new ResourceScatterNdAdd operation.
|
static <T extends Number,U> |
ResourceScatterNdSub.create(Scope scope,
Operand<?> ref,
Operand<T> indices,
Operand<U> updates,
ResourceScatterNdSub.Options... options)
Factory method to create a class wrapping a new ResourceScatterNdSub operation.
|
static <T extends Number,U> |
ResourceScatterNdSub.create(Scope scope,
Operand<?> ref,
Operand<T> indices,
Operand<U> updates,
ResourceScatterNdSub.Options... options)
Factory method to create a class wrapping a new ResourceScatterNdSub operation.
|
static <T extends Number,U> |
ResourceScatterNdSub.create(Scope scope,
Operand<?> ref,
Operand<T> indices,
Operand<U> updates,
ResourceScatterNdSub.Options... options)
Factory method to create a class wrapping a new ResourceScatterNdSub operation.
|
static <T extends Number,U> |
ResourceScatterNdUpdate.create(Scope scope,
Operand<?> ref,
Operand<T> indices,
Operand<U> updates,
ResourceScatterNdUpdate.Options... options)
Factory method to create a class wrapping a new ResourceScatterNdUpdate operation.
|
static <T extends Number,U> |
ResourceScatterNdUpdate.create(Scope scope,
Operand<?> ref,
Operand<T> indices,
Operand<U> updates,
ResourceScatterNdUpdate.Options... options)
Factory method to create a class wrapping a new ResourceScatterNdUpdate operation.
|
static <T extends Number,U> |
ResourceScatterNdUpdate.create(Scope scope,
Operand<?> ref,
Operand<T> indices,
Operand<U> updates,
ResourceScatterNdUpdate.Options... options)
Factory method to create a class wrapping a new ResourceScatterNdUpdate operation.
|
static LoopCond |
LoopCond.create(Scope scope,
Operand<Boolean> input)
Factory method to create a class wrapping a new LoopCond operation.
|
static AssertThat |
AssertThat.create(Scope scope,
Operand<Boolean> condition,
Iterable<Operand<?>> data,
AssertThat.Options... options)
Factory method to create a class wrapping a new AssertThat operation.
|
static <T extends Number> |
All.create(Scope scope,
Operand<Boolean> input,
Operand<T> axis,
All.Options... options)
Factory method to create a class wrapping a new All operation.
|
static <T extends Number> |
All.create(Scope scope,
Operand<Boolean> input,
Operand<T> axis,
All.Options... options)
Factory method to create a class wrapping a new All operation.
|
static <T extends Number> |
Any.create(Scope scope,
Operand<Boolean> input,
Operand<T> axis,
Any.Options... options)
Factory method to create a class wrapping a new Any operation.
|
static <T extends Number> |
Any.create(Scope scope,
Operand<Boolean> input,
Operand<T> axis,
Any.Options... options)
Factory method to create a class wrapping a new Any operation.
|
static <T> Where3<T> |
Where3.create(Scope scope,
Operand<Boolean> condition,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Where3 operation.
|
static <T> Where3<T> |
Where3.create(Scope scope,
Operand<Boolean> condition,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Where3 operation.
|
static <T> Where3<T> |
Where3.create(Scope scope,
Operand<Boolean> condition,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Where3 operation.
|
static <T> SelectV2<T> |
SelectV2.create(Scope scope,
Operand<Boolean> condition,
Operand<T> t,
Operand<T> e)
Factory method to create a class wrapping a new SelectV2 operation.
|
static <T> SelectV2<T> |
SelectV2.create(Scope scope,
Operand<Boolean> condition,
Operand<T> t,
Operand<T> e)
Factory method to create a class wrapping a new SelectV2 operation.
|
static <T> SelectV2<T> |
SelectV2.create(Scope scope,
Operand<Boolean> condition,
Operand<T> t,
Operand<T> e)
Factory method to create a class wrapping a new SelectV2 operation.
|
static <T extends Number> |
ReduceAll.create(Scope scope,
Operand<Boolean> input,
Operand<T> axis,
ReduceAll.Options... options)
Factory method to create a class wrapping a new ReduceAll operation.
|
static <T extends Number> |
ReduceAll.create(Scope scope,
Operand<Boolean> input,
Operand<T> axis,
ReduceAll.Options... options)
Factory method to create a class wrapping a new ReduceAll operation.
|
static <T extends Number> |
ReduceAny.create(Scope scope,
Operand<Boolean> input,
Operand<T> axis,
ReduceAny.Options... options)
Factory method to create a class wrapping a new ReduceAny operation.
|
static <T extends Number> |
ReduceAny.create(Scope scope,
Operand<Boolean> input,
Operand<T> axis,
ReduceAny.Options... options)
Factory method to create a class wrapping a new ReduceAny operation.
|
static LoadTPUEmbeddingStochasticGradientDescentParameters |
LoadTPUEmbeddingStochasticGradientDescentParameters.create(Scope scope,
Operand<Float> parameters,
Long numShards,
Long shardId,
LoadTPUEmbeddingStochasticGradientDescentParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingStochasticGradientDescentParameters operation.
|
static TPUEmbeddingActivations |
TPUEmbeddingActivations.create(Scope scope,
Operand<Float> embeddingVariable,
Operand<Float> slicedActivations,
Long tableId,
Long lookupId)
Factory method to create a class wrapping a new TPUEmbeddingActivations operation.
|
static TPUEmbeddingActivations |
TPUEmbeddingActivations.create(Scope scope,
Operand<Float> embeddingVariable,
Operand<Float> slicedActivations,
Long tableId,
Long lookupId)
Factory method to create a class wrapping a new TPUEmbeddingActivations operation.
|
static LoadTPUEmbeddingAdagradParameters |
LoadTPUEmbeddingAdagradParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdagradParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdagradParameters operation.
|
static LoadTPUEmbeddingAdagradParameters |
LoadTPUEmbeddingAdagradParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdagradParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdagradParameters operation.
|
static LoadTPUEmbeddingMomentumParameters |
LoadTPUEmbeddingMomentumParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Long numShards,
Long shardId,
LoadTPUEmbeddingMomentumParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingMomentumParameters operation.
|
static LoadTPUEmbeddingMomentumParameters |
LoadTPUEmbeddingMomentumParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Long numShards,
Long shardId,
LoadTPUEmbeddingMomentumParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingMomentumParameters operation.
|
static LoadTPUEmbeddingProximalAdagradParameters |
LoadTPUEmbeddingProximalAdagradParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingProximalAdagradParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingProximalAdagradParameters operation.
|
static LoadTPUEmbeddingProximalAdagradParameters |
LoadTPUEmbeddingProximalAdagradParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingProximalAdagradParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingProximalAdagradParameters operation.
|
static LoadTPUEmbeddingAdadeltaParameters |
LoadTPUEmbeddingAdadeltaParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> updates,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdadeltaParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdadeltaParameters operation.
|
static LoadTPUEmbeddingAdadeltaParameters |
LoadTPUEmbeddingAdadeltaParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> updates,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdadeltaParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdadeltaParameters operation.
|
static LoadTPUEmbeddingAdadeltaParameters |
LoadTPUEmbeddingAdadeltaParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> updates,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdadeltaParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdadeltaParameters operation.
|
static LoadTPUEmbeddingAdagradParametersGradAccumDebug |
LoadTPUEmbeddingAdagradParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdagradParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdagradParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingAdagradParametersGradAccumDebug |
LoadTPUEmbeddingAdagradParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdagradParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdagradParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingAdagradParametersGradAccumDebug |
LoadTPUEmbeddingAdagradParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdagradParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdagradParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingADAMParameters |
LoadTPUEmbeddingADAMParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Operand<Float> velocities,
Long numShards,
Long shardId,
LoadTPUEmbeddingADAMParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingADAMParameters operation.
|
static LoadTPUEmbeddingADAMParameters |
LoadTPUEmbeddingADAMParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Operand<Float> velocities,
Long numShards,
Long shardId,
LoadTPUEmbeddingADAMParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingADAMParameters operation.
|
static LoadTPUEmbeddingADAMParameters |
LoadTPUEmbeddingADAMParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Operand<Float> velocities,
Long numShards,
Long shardId,
LoadTPUEmbeddingADAMParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingADAMParameters operation.
|
static LoadTPUEmbeddingFTRLParameters |
LoadTPUEmbeddingFTRLParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> linears,
Long numShards,
Long shardId,
LoadTPUEmbeddingFTRLParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingFTRLParameters operation.
|
static LoadTPUEmbeddingFTRLParameters |
LoadTPUEmbeddingFTRLParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> linears,
Long numShards,
Long shardId,
LoadTPUEmbeddingFTRLParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingFTRLParameters operation.
|
static LoadTPUEmbeddingFTRLParameters |
LoadTPUEmbeddingFTRLParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> linears,
Long numShards,
Long shardId,
LoadTPUEmbeddingFTRLParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingFTRLParameters operation.
|
static LoadTPUEmbeddingMomentumParametersGradAccumDebug |
LoadTPUEmbeddingMomentumParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingMomentumParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingMomentumParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingMomentumParametersGradAccumDebug |
LoadTPUEmbeddingMomentumParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingMomentumParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingMomentumParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingMomentumParametersGradAccumDebug |
LoadTPUEmbeddingMomentumParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingMomentumParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingMomentumParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug |
LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug |
LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug |
LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingProximalAdagradParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingRMSPropParameters |
LoadTPUEmbeddingRMSPropParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Long numShards,
Long shardId,
LoadTPUEmbeddingRMSPropParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingRMSPropParameters operation.
|
static LoadTPUEmbeddingRMSPropParameters |
LoadTPUEmbeddingRMSPropParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Long numShards,
Long shardId,
LoadTPUEmbeddingRMSPropParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingRMSPropParameters operation.
|
static LoadTPUEmbeddingRMSPropParameters |
LoadTPUEmbeddingRMSPropParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Long numShards,
Long shardId,
LoadTPUEmbeddingRMSPropParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingRMSPropParameters operation.
|
static LoadTPUEmbeddingAdadeltaParametersGradAccumDebug |
LoadTPUEmbeddingAdadeltaParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> updates,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdadeltaParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdadeltaParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingAdadeltaParametersGradAccumDebug |
LoadTPUEmbeddingAdadeltaParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> updates,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdadeltaParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdadeltaParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingAdadeltaParametersGradAccumDebug |
LoadTPUEmbeddingAdadeltaParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> updates,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdadeltaParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdadeltaParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingAdadeltaParametersGradAccumDebug |
LoadTPUEmbeddingAdadeltaParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> updates,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingAdadeltaParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingAdadeltaParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingADAMParametersGradAccumDebug |
LoadTPUEmbeddingADAMParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Operand<Float> velocities,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingADAMParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingADAMParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingADAMParametersGradAccumDebug |
LoadTPUEmbeddingADAMParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Operand<Float> velocities,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingADAMParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingADAMParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingADAMParametersGradAccumDebug |
LoadTPUEmbeddingADAMParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Operand<Float> velocities,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingADAMParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingADAMParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingADAMParametersGradAccumDebug |
LoadTPUEmbeddingADAMParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> momenta,
Operand<Float> velocities,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingADAMParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingADAMParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingCenteredRMSPropParameters |
LoadTPUEmbeddingCenteredRMSPropParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Operand<Float> mg,
Long numShards,
Long shardId,
LoadTPUEmbeddingCenteredRMSPropParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingCenteredRMSPropParameters operation.
|
static LoadTPUEmbeddingCenteredRMSPropParameters |
LoadTPUEmbeddingCenteredRMSPropParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Operand<Float> mg,
Long numShards,
Long shardId,
LoadTPUEmbeddingCenteredRMSPropParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingCenteredRMSPropParameters operation.
|
static LoadTPUEmbeddingCenteredRMSPropParameters |
LoadTPUEmbeddingCenteredRMSPropParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Operand<Float> mg,
Long numShards,
Long shardId,
LoadTPUEmbeddingCenteredRMSPropParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingCenteredRMSPropParameters operation.
|
static LoadTPUEmbeddingCenteredRMSPropParameters |
LoadTPUEmbeddingCenteredRMSPropParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Operand<Float> mg,
Long numShards,
Long shardId,
LoadTPUEmbeddingCenteredRMSPropParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingCenteredRMSPropParameters operation.
|
static LoadTPUEmbeddingFTRLParametersGradAccumDebug |
LoadTPUEmbeddingFTRLParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> linears,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingFTRLParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingFTRLParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingFTRLParametersGradAccumDebug |
LoadTPUEmbeddingFTRLParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> linears,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingFTRLParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingFTRLParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingFTRLParametersGradAccumDebug |
LoadTPUEmbeddingFTRLParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> linears,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingFTRLParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingFTRLParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingFTRLParametersGradAccumDebug |
LoadTPUEmbeddingFTRLParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> linears,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingFTRLParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingFTRLParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingMDLAdagradLightParameters |
LoadTPUEmbeddingMDLAdagradLightParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> weights,
Operand<Float> benefits,
Long numShards,
Long shardId,
LoadTPUEmbeddingMDLAdagradLightParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingMDLAdagradLightParameters operation.
|
static LoadTPUEmbeddingMDLAdagradLightParameters |
LoadTPUEmbeddingMDLAdagradLightParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> weights,
Operand<Float> benefits,
Long numShards,
Long shardId,
LoadTPUEmbeddingMDLAdagradLightParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingMDLAdagradLightParameters operation.
|
static LoadTPUEmbeddingMDLAdagradLightParameters |
LoadTPUEmbeddingMDLAdagradLightParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> weights,
Operand<Float> benefits,
Long numShards,
Long shardId,
LoadTPUEmbeddingMDLAdagradLightParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingMDLAdagradLightParameters operation.
|
static LoadTPUEmbeddingMDLAdagradLightParameters |
LoadTPUEmbeddingMDLAdagradLightParameters.create(Scope scope,
Operand<Float> parameters,
Operand<Float> accumulators,
Operand<Float> weights,
Operand<Float> benefits,
Long numShards,
Long shardId,
LoadTPUEmbeddingMDLAdagradLightParameters.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingMDLAdagradLightParameters operation.
|
static LoadTPUEmbeddingRMSPropParametersGradAccumDebug |
LoadTPUEmbeddingRMSPropParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingRMSPropParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingRMSPropParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingRMSPropParametersGradAccumDebug |
LoadTPUEmbeddingRMSPropParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingRMSPropParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingRMSPropParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingRMSPropParametersGradAccumDebug |
LoadTPUEmbeddingRMSPropParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingRMSPropParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingRMSPropParametersGradAccumDebug operation.
|
static LoadTPUEmbeddingRMSPropParametersGradAccumDebug |
LoadTPUEmbeddingRMSPropParametersGradAccumDebug.create(Scope scope,
Operand<Float> parameters,
Operand<Float> ms,
Operand<Float> mom,
Operand<Float> gradientAccumulators,
Long numShards,
Long shardId,
LoadTPUEmbeddingRMSPropParametersGradAccumDebug.Options... options)
Factory method to create a class wrapping a new LoadTPUEmbeddingRMSPropParametersGradAccumDebug operation.
|
static CombinedNonMaxSuppression |
CombinedNonMaxSuppression.create(Scope scope,
Operand<Float> boxes,
Operand<Float> scores,
Operand<Integer> maxOutputSizePerClass,
Operand<Integer> maxTotalSize,
Operand<Float> iouThreshold,
Operand<Float> scoreThreshold,
CombinedNonMaxSuppression.Options... options)
Factory method to create a class wrapping a new CombinedNonMaxSuppression operation.
|
static CombinedNonMaxSuppression |
CombinedNonMaxSuppression.create(Scope scope,
Operand<Float> boxes,
Operand<Float> scores,
Operand<Integer> maxOutputSizePerClass,
Operand<Integer> maxTotalSize,
Operand<Float> iouThreshold,
Operand<Float> scoreThreshold,
CombinedNonMaxSuppression.Options... options)
Factory method to create a class wrapping a new CombinedNonMaxSuppression operation.
|
static CombinedNonMaxSuppression |
CombinedNonMaxSuppression.create(Scope scope,
Operand<Float> boxes,
Operand<Float> scores,
Operand<Integer> maxOutputSizePerClass,
Operand<Integer> maxTotalSize,
Operand<Float> iouThreshold,
Operand<Float> scoreThreshold,
CombinedNonMaxSuppression.Options... options)
Factory method to create a class wrapping a new CombinedNonMaxSuppression operation.
|
static CombinedNonMaxSuppression |
CombinedNonMaxSuppression.create(Scope scope,
Operand<Float> boxes,
Operand<Float> scores,
Operand<Integer> maxOutputSizePerClass,
Operand<Integer> maxTotalSize,
Operand<Float> iouThreshold,
Operand<Float> scoreThreshold,
CombinedNonMaxSuppression.Options... options)
Factory method to create a class wrapping a new CombinedNonMaxSuppression operation.
|
static CombinedNonMaxSuppression |
CombinedNonMaxSuppression.create(Scope scope,
Operand<Float> boxes,
Operand<Float> scores,
Operand<Integer> maxOutputSizePerClass,
Operand<Integer> maxTotalSize,
Operand<Float> iouThreshold,
Operand<Float> scoreThreshold,
CombinedNonMaxSuppression.Options... options)
Factory method to create a class wrapping a new CombinedNonMaxSuppression operation.
|
static CombinedNonMaxSuppression |
CombinedNonMaxSuppression.create(Scope scope,
Operand<Float> boxes,
Operand<Float> scores,
Operand<Integer> maxOutputSizePerClass,
Operand<Integer> maxTotalSize,
Operand<Float> iouThreshold,
Operand<Float> scoreThreshold,
CombinedNonMaxSuppression.Options... options)
Factory method to create a class wrapping a new CombinedNonMaxSuppression operation.
|
static NearestNeighbors |
NearestNeighbors.create(Scope scope,
Operand<Float> points,
Operand<Float> centers,
Operand<Long> k)
Factory method to create a class wrapping a new NearestNeighbors operation.
|
static NearestNeighbors |
NearestNeighbors.create(Scope scope,
Operand<Float> points,
Operand<Float> centers,
Operand<Long> k)
Factory method to create a class wrapping a new NearestNeighbors operation.
|
static NearestNeighbors |
NearestNeighbors.create(Scope scope,
Operand<Float> points,
Operand<Float> centers,
Operand<Long> k)
Factory method to create a class wrapping a new NearestNeighbors operation.
|
static KMC2ChainInitialization |
KMC2ChainInitialization.create(Scope scope,
Operand<Float> distances,
Operand<Long> seed)
Factory method to create a class wrapping a new KMC2ChainInitialization operation.
|
static KMC2ChainInitialization |
KMC2ChainInitialization.create(Scope scope,
Operand<Float> distances,
Operand<Long> seed)
Factory method to create a class wrapping a new KMC2ChainInitialization operation.
|
static KmeansPlusPlusInitialization |
KmeansPlusPlusInitialization.create(Scope scope,
Operand<Float> points,
Operand<Long> numToSample,
Operand<Long> seed,
Operand<Long> numRetriesPerSample)
Factory method to create a class wrapping a new KmeansPlusPlusInitialization operation.
|
static KmeansPlusPlusInitialization |
KmeansPlusPlusInitialization.create(Scope scope,
Operand<Float> points,
Operand<Long> numToSample,
Operand<Long> seed,
Operand<Long> numRetriesPerSample)
Factory method to create a class wrapping a new KmeansPlusPlusInitialization operation.
|
static KmeansPlusPlusInitialization |
KmeansPlusPlusInitialization.create(Scope scope,
Operand<Float> points,
Operand<Long> numToSample,
Operand<Long> seed,
Operand<Long> numRetriesPerSample)
Factory method to create a class wrapping a new KmeansPlusPlusInitialization operation.
|
static KmeansPlusPlusInitialization |
KmeansPlusPlusInitialization.create(Scope scope,
Operand<Float> points,
Operand<Long> numToSample,
Operand<Long> seed,
Operand<Long> numRetriesPerSample)
Factory method to create a class wrapping a new KmeansPlusPlusInitialization operation.
|
static <T> Empty<T> |
Empty.create(Scope scope,
Operand<Integer> shape,
Class<T> dtype,
Empty.Options... options)
Factory method to create a class wrapping a new Empty operation.
|
static <T> TensorArray |
TensorArray.create(Scope scope,
Operand<Integer> size,
Class<T> dtype,
TensorArray.Options... options)
Factory method to create a class wrapping a new TensorArray operation.
|
static EncodeProto |
EncodeProto.create(Scope scope,
Operand<Integer> sizes,
Iterable<Operand<?>> values,
List<String> fieldNames,
String messageType,
EncodeProto.Options... options)
Factory method to create a class wrapping a new EncodeProto operation.
|
static BoostedTreesCalculateBestGainsPerFeature |
BoostedTreesCalculateBestGainsPerFeature.create(Scope scope,
Operand<Integer> nodeIdRange,
Iterable<Operand<Float>> statsSummaryList,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long maxSplits)
Factory method to create a class wrapping a new BoostedTreesCalculateBestGainsPerFeature operation.
|
static BoostedTreesCalculateBestGainsPerFeature |
BoostedTreesCalculateBestGainsPerFeature.create(Scope scope,
Operand<Integer> nodeIdRange,
Iterable<Operand<Float>> statsSummaryList,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long maxSplits)
Factory method to create a class wrapping a new BoostedTreesCalculateBestGainsPerFeature operation.
|
static BoostedTreesCalculateBestGainsPerFeature |
BoostedTreesCalculateBestGainsPerFeature.create(Scope scope,
Operand<Integer> nodeIdRange,
Iterable<Operand<Float>> statsSummaryList,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long maxSplits)
Factory method to create a class wrapping a new BoostedTreesCalculateBestGainsPerFeature operation.
|
static BoostedTreesCalculateBestGainsPerFeature |
BoostedTreesCalculateBestGainsPerFeature.create(Scope scope,
Operand<Integer> nodeIdRange,
Iterable<Operand<Float>> statsSummaryList,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long maxSplits)
Factory method to create a class wrapping a new BoostedTreesCalculateBestGainsPerFeature operation.
|
static BoostedTreesCalculateBestGainsPerFeature |
BoostedTreesCalculateBestGainsPerFeature.create(Scope scope,
Operand<Integer> nodeIdRange,
Iterable<Operand<Float>> statsSummaryList,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long maxSplits)
Factory method to create a class wrapping a new BoostedTreesCalculateBestGainsPerFeature operation.
|
static <T> RefSelect<T> |
RefSelect.create(Scope scope,
Operand<Integer> index,
Iterable<Operand<T>> inputs)
Factory method to create a class wrapping a new RefSelect operation.
|
static <T> QuantizedConcat<T> |
QuantizedConcat.create(Scope scope,
Operand<Integer> concatDim,
Iterable<Operand<T>> values,
Iterable<Operand<Float>> inputMins,
Iterable<Operand<Float>> inputMaxes)
Factory method to create a class wrapping a new QuantizedConcat operation.
|
static MapUnstageNoKey |
MapUnstageNoKey.create(Scope scope,
Operand<Integer> indices,
List<Class<?>> dtypes,
MapUnstageNoKey.Options... options)
Factory method to create a class wrapping a new MapUnstageNoKey operation.
|
static OrderedMapUnstageNoKey |
OrderedMapUnstageNoKey.create(Scope scope,
Operand<Integer> indices,
List<Class<?>> dtypes,
OrderedMapUnstageNoKey.Options... options)
Factory method to create a class wrapping a new OrderedMapUnstageNoKey operation.
|
static StagePeek |
StagePeek.create(Scope scope,
Operand<Integer> index,
List<Class<?>> dtypes,
StagePeek.Options... options)
Factory method to create a class wrapping a new StagePeek operation.
|
static BoostedTreesMakeStatsSummary |
BoostedTreesMakeStatsSummary.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Iterable<Operand<Integer>> bucketizedFeaturesList,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesMakeStatsSummary operation.
|
static BoostedTreesMakeStatsSummary |
BoostedTreesMakeStatsSummary.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Iterable<Operand<Integer>> bucketizedFeaturesList,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesMakeStatsSummary operation.
|
static BoostedTreesMakeStatsSummary |
BoostedTreesMakeStatsSummary.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Iterable<Operand<Integer>> bucketizedFeaturesList,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesMakeStatsSummary operation.
|
static BoostedTreesCalculateBestFeatureSplit |
BoostedTreesCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Float> statsSummary,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesCalculateBestFeatureSplit operation.
|
static BoostedTreesCalculateBestFeatureSplit |
BoostedTreesCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Float> statsSummary,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesCalculateBestFeatureSplit operation.
|
static BoostedTreesCalculateBestFeatureSplit |
BoostedTreesCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Float> statsSummary,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesCalculateBestFeatureSplit operation.
|
static BoostedTreesCalculateBestFeatureSplit |
BoostedTreesCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Float> statsSummary,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesCalculateBestFeatureSplit operation.
|
static BoostedTreesCalculateBestFeatureSplit |
BoostedTreesCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Float> statsSummary,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesCalculateBestFeatureSplit operation.
|
static BoostedTreesCalculateBestFeatureSplit |
BoostedTreesCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Float> statsSummary,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesCalculateBestFeatureSplit operation.
|
static BoostedTreesAggregateStats |
BoostedTreesAggregateStats.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Operand<Integer> feature,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesAggregateStats operation.
|
static BoostedTreesAggregateStats |
BoostedTreesAggregateStats.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Operand<Integer> feature,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesAggregateStats operation.
|
static BoostedTreesAggregateStats |
BoostedTreesAggregateStats.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Operand<Integer> feature,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesAggregateStats operation.
|
static BoostedTreesAggregateStats |
BoostedTreesAggregateStats.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Operand<Integer> feature,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesAggregateStats operation.
|
static BoostedTreesSparseAggregateStats |
BoostedTreesSparseAggregateStats.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Operand<Integer> featureIndices,
Operand<Integer> featureValues,
Operand<Integer> featureShape,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesSparseAggregateStats operation.
|
static BoostedTreesSparseAggregateStats |
BoostedTreesSparseAggregateStats.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Operand<Integer> featureIndices,
Operand<Integer> featureValues,
Operand<Integer> featureShape,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesSparseAggregateStats operation.
|
static BoostedTreesSparseAggregateStats |
BoostedTreesSparseAggregateStats.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Operand<Integer> featureIndices,
Operand<Integer> featureValues,
Operand<Integer> featureShape,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesSparseAggregateStats operation.
|
static BoostedTreesSparseAggregateStats |
BoostedTreesSparseAggregateStats.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Operand<Integer> featureIndices,
Operand<Integer> featureValues,
Operand<Integer> featureShape,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesSparseAggregateStats operation.
|
static BoostedTreesSparseAggregateStats |
BoostedTreesSparseAggregateStats.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Operand<Integer> featureIndices,
Operand<Integer> featureValues,
Operand<Integer> featureShape,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesSparseAggregateStats operation.
|
static BoostedTreesSparseAggregateStats |
BoostedTreesSparseAggregateStats.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Operand<Integer> featureIndices,
Operand<Integer> featureValues,
Operand<Integer> featureShape,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesSparseAggregateStats operation.
|
static BoostedTreesSparseCalculateBestFeatureSplit |
BoostedTreesSparseCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Integer> statsSummaryIndices,
Operand<Float> statsSummaryValues,
Operand<Integer> statsSummaryShape,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesSparseCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesSparseCalculateBestFeatureSplit operation.
|
static BoostedTreesSparseCalculateBestFeatureSplit |
BoostedTreesSparseCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Integer> statsSummaryIndices,
Operand<Float> statsSummaryValues,
Operand<Integer> statsSummaryShape,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesSparseCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesSparseCalculateBestFeatureSplit operation.
|
static BoostedTreesSparseCalculateBestFeatureSplit |
BoostedTreesSparseCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Integer> statsSummaryIndices,
Operand<Float> statsSummaryValues,
Operand<Integer> statsSummaryShape,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesSparseCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesSparseCalculateBestFeatureSplit operation.
|
static BoostedTreesSparseCalculateBestFeatureSplit |
BoostedTreesSparseCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Integer> statsSummaryIndices,
Operand<Float> statsSummaryValues,
Operand<Integer> statsSummaryShape,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesSparseCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesSparseCalculateBestFeatureSplit operation.
|
static BoostedTreesSparseCalculateBestFeatureSplit |
BoostedTreesSparseCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Integer> statsSummaryIndices,
Operand<Float> statsSummaryValues,
Operand<Integer> statsSummaryShape,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesSparseCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesSparseCalculateBestFeatureSplit operation.
|
static BoostedTreesSparseCalculateBestFeatureSplit |
BoostedTreesSparseCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Integer> statsSummaryIndices,
Operand<Float> statsSummaryValues,
Operand<Integer> statsSummaryShape,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesSparseCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesSparseCalculateBestFeatureSplit operation.
|
static BoostedTreesSparseCalculateBestFeatureSplit |
BoostedTreesSparseCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Integer> statsSummaryIndices,
Operand<Float> statsSummaryValues,
Operand<Integer> statsSummaryShape,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesSparseCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesSparseCalculateBestFeatureSplit operation.
|
static BoostedTreesSparseCalculateBestFeatureSplit |
BoostedTreesSparseCalculateBestFeatureSplit.create(Scope scope,
Operand<Integer> nodeIdRange,
Operand<Integer> statsSummaryIndices,
Operand<Float> statsSummaryValues,
Operand<Integer> statsSummaryShape,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long logitsDimension,
BoostedTreesSparseCalculateBestFeatureSplit.Options... options)
Factory method to create a class wrapping a new BoostedTreesSparseCalculateBestFeatureSplit operation.
|
static <T extends Number> |
CudnnRNNCanonicalToParamsV2.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRNNCanonicalToParamsV2.Options... options)
Factory method to create a class wrapping a new CudnnRNNCanonicalToParamsV2 operation.
|
static <T extends Number> |
CudnnRNNCanonicalToParamsV2.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRNNCanonicalToParamsV2.Options... options)
Factory method to create a class wrapping a new CudnnRNNCanonicalToParamsV2 operation.
|
static <T extends Number> |
CudnnRNNCanonicalToParamsV2.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRNNCanonicalToParamsV2.Options... options)
Factory method to create a class wrapping a new CudnnRNNCanonicalToParamsV2 operation.
|
static <T extends Number> |
CudnnRNNParamsToCanonicalV2.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Operand<T> params,
Long numParamsWeights,
Long numParamsBiases,
CudnnRNNParamsToCanonicalV2.Options... options)
Factory method to create a class wrapping a new CudnnRNNParamsToCanonicalV2 operation.
|
static <T extends Number> |
CudnnRNNParamsToCanonicalV2.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Operand<T> params,
Long numParamsWeights,
Long numParamsBiases,
CudnnRNNParamsToCanonicalV2.Options... options)
Factory method to create a class wrapping a new CudnnRNNParamsToCanonicalV2 operation.
|
static <T extends Number> |
CudnnRNNParamsToCanonicalV2.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Operand<T> params,
Long numParamsWeights,
Long numParamsBiases,
CudnnRNNParamsToCanonicalV2.Options... options)
Factory method to create a class wrapping a new CudnnRNNParamsToCanonicalV2 operation.
|
static <T extends Number> |
CudnnRNNParamsToCanonicalV2.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Operand<T> params,
Long numParamsWeights,
Long numParamsBiases,
CudnnRNNParamsToCanonicalV2.Options... options)
Factory method to create a class wrapping a new CudnnRNNParamsToCanonicalV2 operation.
|
static <T> Split<T> |
Split.create(Scope scope,
Operand<Integer> axis,
Operand<T> value,
Long numSplit)
Factory method to create a class wrapping a new Split operation.
|
static <T> Split<T> |
Split.create(Scope scope,
Operand<Integer> axis,
Operand<T> value,
Long numSplit)
Factory method to create a class wrapping a new Split operation.
|
static <T extends Number> |
UnicodeEncode.create(Scope scope,
Operand<Integer> inputValues,
Operand<T> inputSplits,
String outputEncoding,
UnicodeEncode.Options... options)
Factory method to create a class wrapping a new UnicodeEncode operation.
|
static <T extends Number> |
UnicodeEncode.create(Scope scope,
Operand<Integer> inputValues,
Operand<T> inputSplits,
String outputEncoding,
UnicodeEncode.Options... options)
Factory method to create a class wrapping a new UnicodeEncode operation.
|
static MapStage |
MapStage.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
Iterable<Operand<?>> values,
List<Class<?>> dtypes,
MapStage.Options... options)
Factory method to create a class wrapping a new MapStage operation.
|
static MapStage |
MapStage.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
Iterable<Operand<?>> values,
List<Class<?>> dtypes,
MapStage.Options... options)
Factory method to create a class wrapping a new MapStage operation.
|
static OrderedMapStage |
OrderedMapStage.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
Iterable<Operand<?>> values,
List<Class<?>> dtypes,
OrderedMapStage.Options... options)
Factory method to create a class wrapping a new OrderedMapStage operation.
|
static OrderedMapStage |
OrderedMapStage.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
Iterable<Operand<?>> values,
List<Class<?>> dtypes,
OrderedMapStage.Options... options)
Factory method to create a class wrapping a new OrderedMapStage operation.
|
static MapPeek |
MapPeek.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
List<Class<?>> dtypes,
MapPeek.Options... options)
Factory method to create a class wrapping a new MapPeek operation.
|
static MapPeek |
MapPeek.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
List<Class<?>> dtypes,
MapPeek.Options... options)
Factory method to create a class wrapping a new MapPeek operation.
|
static MapUnstage |
MapUnstage.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
List<Class<?>> dtypes,
MapUnstage.Options... options)
Factory method to create a class wrapping a new MapUnstage operation.
|
static MapUnstage |
MapUnstage.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
List<Class<?>> dtypes,
MapUnstage.Options... options)
Factory method to create a class wrapping a new MapUnstage operation.
|
static OrderedMapPeek |
OrderedMapPeek.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
List<Class<?>> dtypes,
OrderedMapPeek.Options... options)
Factory method to create a class wrapping a new OrderedMapPeek operation.
|
static OrderedMapPeek |
OrderedMapPeek.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
List<Class<?>> dtypes,
OrderedMapPeek.Options... options)
Factory method to create a class wrapping a new OrderedMapPeek operation.
|
static OrderedMapUnstage |
OrderedMapUnstage.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
List<Class<?>> dtypes,
OrderedMapUnstage.Options... options)
Factory method to create a class wrapping a new OrderedMapUnstage operation.
|
static OrderedMapUnstage |
OrderedMapUnstage.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
List<Class<?>> dtypes,
OrderedMapUnstage.Options... options)
Factory method to create a class wrapping a new OrderedMapUnstage operation.
|
static AnonymousRandomSeedGenerator |
AnonymousRandomSeedGenerator.create(Scope scope,
Operand<Long> seed,
Operand<Long> seed2)
Factory method to create a class wrapping a new AnonymousRandomSeedGenerator operation.
|
static AnonymousRandomSeedGenerator |
AnonymousRandomSeedGenerator.create(Scope scope,
Operand<Long> seed,
Operand<Long> seed2)
Factory method to create a class wrapping a new AnonymousRandomSeedGenerator operation.
|
static ExperimentalRandomDataset |
ExperimentalRandomDataset.create(Scope scope,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalRandomDataset operation.
|
static ExperimentalRandomDataset |
ExperimentalRandomDataset.create(Scope scope,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalRandomDataset operation.
|
static <T> EditDistance |
EditDistance.create(Scope scope,
Operand<Long> hypothesisIndices,
Operand<T> hypothesisValues,
Operand<Long> hypothesisShape,
Operand<Long> truthIndices,
Operand<T> truthValues,
Operand<Long> truthShape,
EditDistance.Options... options)
Factory method to create a class wrapping a new EditDistance operation.
|
static <T> EditDistance |
EditDistance.create(Scope scope,
Operand<Long> hypothesisIndices,
Operand<T> hypothesisValues,
Operand<Long> hypothesisShape,
Operand<Long> truthIndices,
Operand<T> truthValues,
Operand<Long> truthShape,
EditDistance.Options... options)
Factory method to create a class wrapping a new EditDistance operation.
|
static <T> EditDistance |
EditDistance.create(Scope scope,
Operand<Long> hypothesisIndices,
Operand<T> hypothesisValues,
Operand<Long> hypothesisShape,
Operand<Long> truthIndices,
Operand<T> truthValues,
Operand<Long> truthShape,
EditDistance.Options... options)
Factory method to create a class wrapping a new EditDistance operation.
|
static <T> EditDistance |
EditDistance.create(Scope scope,
Operand<Long> hypothesisIndices,
Operand<T> hypothesisValues,
Operand<Long> hypothesisShape,
Operand<Long> truthIndices,
Operand<T> truthValues,
Operand<Long> truthShape,
EditDistance.Options... options)
Factory method to create a class wrapping a new EditDistance operation.
|
static <T> EditDistance |
EditDistance.create(Scope scope,
Operand<Long> hypothesisIndices,
Operand<T> hypothesisValues,
Operand<Long> hypothesisShape,
Operand<Long> truthIndices,
Operand<T> truthValues,
Operand<Long> truthShape,
EditDistance.Options... options)
Factory method to create a class wrapping a new EditDistance operation.
|
static <T> EditDistance |
EditDistance.create(Scope scope,
Operand<Long> hypothesisIndices,
Operand<T> hypothesisValues,
Operand<Long> hypothesisShape,
Operand<Long> truthIndices,
Operand<T> truthValues,
Operand<Long> truthShape,
EditDistance.Options... options)
Factory method to create a class wrapping a new EditDistance operation.
|
static <T> SetSize |
SetSize.create(Scope scope,
Operand<Long> setIndices,
Operand<T> setValues,
Operand<Long> setShape,
SetSize.Options... options)
Factory method to create a class wrapping a new SetSize operation.
|
static <T> SetSize |
SetSize.create(Scope scope,
Operand<Long> setIndices,
Operand<T> setValues,
Operand<Long> setShape,
SetSize.Options... options)
Factory method to create a class wrapping a new SetSize operation.
|
static <T> SetSize |
SetSize.create(Scope scope,
Operand<Long> setIndices,
Operand<T> setValues,
Operand<Long> setShape,
SetSize.Options... options)
Factory method to create a class wrapping a new SetSize operation.
|
static <T extends Number> |
BlockLSTM.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTM.Options... options)
Factory method to create a class wrapping a new BlockLSTM operation.
|
static <T extends Number> |
BlockLSTM.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTM.Options... options)
Factory method to create a class wrapping a new BlockLSTM operation.
|
static <T extends Number> |
BlockLSTM.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTM.Options... options)
Factory method to create a class wrapping a new BlockLSTM operation.
|
static <T extends Number> |
BlockLSTM.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTM.Options... options)
Factory method to create a class wrapping a new BlockLSTM operation.
|
static <T extends Number> |
BlockLSTM.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTM.Options... options)
Factory method to create a class wrapping a new BlockLSTM operation.
|
static <T extends Number> |
BlockLSTM.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTM.Options... options)
Factory method to create a class wrapping a new BlockLSTM operation.
|
static <T extends Number> |
BlockLSTM.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTM.Options... options)
Factory method to create a class wrapping a new BlockLSTM operation.
|
static <T extends Number> |
BlockLSTM.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTM.Options... options)
Factory method to create a class wrapping a new BlockLSTM operation.
|
static <T extends Number> |
BlockLSTM.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTM.Options... options)
Factory method to create a class wrapping a new BlockLSTM operation.
|
static <T extends Number> |
BlockLSTMV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTMV2.Options... options)
Factory method to create a class wrapping a new BlockLSTMV2 operation.
|
static <T extends Number> |
BlockLSTMV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTMV2.Options... options)
Factory method to create a class wrapping a new BlockLSTMV2 operation.
|
static <T extends Number> |
BlockLSTMV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTMV2.Options... options)
Factory method to create a class wrapping a new BlockLSTMV2 operation.
|
static <T extends Number> |
BlockLSTMV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTMV2.Options... options)
Factory method to create a class wrapping a new BlockLSTMV2 operation.
|
static <T extends Number> |
BlockLSTMV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTMV2.Options... options)
Factory method to create a class wrapping a new BlockLSTMV2 operation.
|
static <T extends Number> |
BlockLSTMV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTMV2.Options... options)
Factory method to create a class wrapping a new BlockLSTMV2 operation.
|
static <T extends Number> |
BlockLSTMV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTMV2.Options... options)
Factory method to create a class wrapping a new BlockLSTMV2 operation.
|
static <T extends Number> |
BlockLSTMV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTMV2.Options... options)
Factory method to create a class wrapping a new BlockLSTMV2 operation.
|
static <T extends Number> |
BlockLSTMV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
BlockLSTMV2.Options... options)
Factory method to create a class wrapping a new BlockLSTMV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGradV2.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGradV2 operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static <T extends Number> |
BlockLSTMGrad.create(Scope scope,
Operand<Long> seqLenMax,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> h,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new BlockLSTMGrad operation.
|
static WorkerHeartbeat |
WorkerHeartbeat.create(Scope scope,
Operand<String> request)
Factory method to create a class wrapping a new WorkerHeartbeat operation.
|
static BarrierReadySize |
BarrierReadySize.create(Scope scope,
Operand<String> handle)
Factory method to create a class wrapping a new BarrierReadySize operation.
|
static ExperimentalMatchingFilesDataset |
ExperimentalMatchingFilesDataset.create(Scope scope,
Operand<String> patterns)
Factory method to create a class wrapping a new ExperimentalMatchingFilesDataset operation.
|
static DatasetFromGraph |
DatasetFromGraph.create(Scope scope,
Operand<String> graphDef)
Factory method to create a class wrapping a new DatasetFromGraph operation.
|
static GcsConfigureCredentials |
GcsConfigureCredentials.create(Scope scope,
Operand<String> json)
Factory method to create a class wrapping a new GcsConfigureCredentials operation.
|
static DeleteSessionTensor |
DeleteSessionTensor.create(Scope scope,
Operand<String> handle)
Factory method to create a class wrapping a new DeleteSessionTensor operation.
|
static BarrierIncompleteSize |
BarrierIncompleteSize.create(Scope scope,
Operand<String> handle)
Factory method to create a class wrapping a new BarrierIncompleteSize operation.
|
static BarrierClose |
BarrierClose.create(Scope scope,
Operand<String> handle,
BarrierClose.Options... options)
Factory method to create a class wrapping a new BarrierClose operation.
|
static <T> GetSessionTensor<T> |
GetSessionTensor.create(Scope scope,
Operand<String> handle,
Class<T> dtype)
Factory method to create a class wrapping a new GetSessionTensor operation.
|
static LMDBDataset |
LMDBDataset.create(Scope scope,
Operand<String> filenames,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new LMDBDataset operation.
|
static <T> TensorArrayPack<T> |
TensorArrayPack.create(Scope scope,
Operand<String> handle,
Operand<Float> flowIn,
Class<T> dtype,
TensorArrayPack.Options... options)
Factory method to create a class wrapping a new TensorArrayPack operation.
|
static <T> TensorArrayPack<T> |
TensorArrayPack.create(Scope scope,
Operand<String> handle,
Operand<Float> flowIn,
Class<T> dtype,
TensorArrayPack.Options... options)
Factory method to create a class wrapping a new TensorArrayPack operation.
|
static <T extends Number> |
DecodePaddedRaw.create(Scope scope,
Operand<String> inputBytes,
Operand<Integer> fixedLength,
Class<T> outType,
DecodePaddedRaw.Options... options)
Factory method to create a class wrapping a new DecodePaddedRaw operation.
|
static <T extends Number> |
DecodePaddedRaw.create(Scope scope,
Operand<String> inputBytes,
Operand<Integer> fixedLength,
Class<T> outType,
DecodePaddedRaw.Options... options)
Factory method to create a class wrapping a new DecodePaddedRaw operation.
|
static BarrierTakeMany |
BarrierTakeMany.create(Scope scope,
Operand<String> handle,
Operand<Integer> numElements,
List<Class<?>> componentTypes,
BarrierTakeMany.Options... options)
Factory method to create a class wrapping a new BarrierTakeMany operation.
|
static BarrierTakeMany |
BarrierTakeMany.create(Scope scope,
Operand<String> handle,
Operand<Integer> numElements,
List<Class<?>> componentTypes,
BarrierTakeMany.Options... options)
Factory method to create a class wrapping a new BarrierTakeMany operation.
|
static CSVDataset |
CSVDataset.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 wrapping a new CSVDataset operation.
|
static CSVDataset |
CSVDataset.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 wrapping a new CSVDataset operation.
|
static CSVDataset |
CSVDataset.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 wrapping a new CSVDataset operation.
|
static CSVDataset |
CSVDataset.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 wrapping a new CSVDataset operation.
|
static CSVDataset |
CSVDataset.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 wrapping a new CSVDataset operation.
|
static CSVDataset |
CSVDataset.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 wrapping a new CSVDataset operation.
|
static CSVDataset |
CSVDataset.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 wrapping a new CSVDataset operation.
|
static CSVDataset |
CSVDataset.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 wrapping a new CSVDataset operation.
|
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 wrapping a new ExperimentalSqlDataset operation.
|
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 wrapping a new ExperimentalSqlDataset operation.
|
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 wrapping a new ExperimentalSqlDataset operation.
|
static Rpc |
Rpc.create(Scope scope,
Operand<String> address,
Operand<String> method,
Operand<String> request,
Rpc.Options... options)
Factory method to create a class wrapping a new Rpc operation.
|
static Rpc |
Rpc.create(Scope scope,
Operand<String> address,
Operand<String> method,
Operand<String> request,
Rpc.Options... options)
Factory method to create a class wrapping a new Rpc operation.
|
static Rpc |
Rpc.create(Scope scope,
Operand<String> address,
Operand<String> method,
Operand<String> request,
Rpc.Options... options)
Factory method to create a class wrapping a new Rpc operation.
|
static TryRpc |
TryRpc.create(Scope scope,
Operand<String> address,
Operand<String> method,
Operand<String> request,
TryRpc.Options... options)
Factory method to create a class wrapping a new TryRpc operation.
|
static TryRpc |
TryRpc.create(Scope scope,
Operand<String> address,
Operand<String> method,
Operand<String> request,
TryRpc.Options... options)
Factory method to create a class wrapping a new TryRpc operation.
|
static TryRpc |
TryRpc.create(Scope scope,
Operand<String> address,
Operand<String> method,
Operand<String> request,
TryRpc.Options... options)
Factory method to create a class wrapping a new TryRpc operation.
|
static <T> BarrierInsertMany |
BarrierInsertMany.create(Scope scope,
Operand<String> handle,
Operand<String> keys,
Operand<T> values,
Long componentIndex)
Factory method to create a class wrapping a new BarrierInsertMany operation.
|
static <T> BarrierInsertMany |
BarrierInsertMany.create(Scope scope,
Operand<String> handle,
Operand<String> keys,
Operand<T> values,
Long componentIndex)
Factory method to create a class wrapping a new BarrierInsertMany operation.
|
static <T> BarrierInsertMany |
BarrierInsertMany.create(Scope scope,
Operand<String> handle,
Operand<String> keys,
Operand<T> values,
Long componentIndex)
Factory method to create a class wrapping a new BarrierInsertMany operation.
|
static <T> TensorArrayUnpack |
TensorArrayUnpack.create(Scope scope,
Operand<String> handle,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayUnpack operation.
|
static <T> TensorArrayUnpack |
TensorArrayUnpack.create(Scope scope,
Operand<String> handle,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayUnpack operation.
|
static <T> TensorArrayUnpack |
TensorArrayUnpack.create(Scope scope,
Operand<String> handle,
Operand<T> value,
Operand<Float> flowIn)
Factory method to create a class wrapping a new TensorArrayUnpack operation.
|
static <T extends Number,U extends Number> |
UnsortedSegmentJoin.create(Scope scope,
Operand<String> inputs,
Operand<T> segmentIds,
Operand<U> numSegments,
UnsortedSegmentJoin.Options... options)
Factory method to create a class wrapping a new UnsortedSegmentJoin operation.
|
static <T extends Number,U extends Number> |
UnsortedSegmentJoin.create(Scope scope,
Operand<String> inputs,
Operand<T> segmentIds,
Operand<U> numSegments,
UnsortedSegmentJoin.Options... options)
Factory method to create a class wrapping a new UnsortedSegmentJoin operation.
|
static <T extends Number,U extends Number> |
UnsortedSegmentJoin.create(Scope scope,
Operand<String> inputs,
Operand<T> segmentIds,
Operand<U> numSegments,
UnsortedSegmentJoin.Options... options)
Factory method to create a class wrapping a new UnsortedSegmentJoin operation.
|
static <T extends Number> |
StringNGrams.create(Scope scope,
Operand<String> data,
Operand<T> dataSplits,
String separator,
List<Long> ngramWidths,
String leftPad,
String rightPad,
Long padWidth,
Boolean preserveShortSequences)
Factory method to create a class wrapping a new StringNGrams operation.
|
static <T extends Number> |
StringNGrams.create(Scope scope,
Operand<String> data,
Operand<T> dataSplits,
String separator,
List<Long> ngramWidths,
String leftPad,
String rightPad,
Long padWidth,
Boolean preserveShortSequences)
Factory method to create a class wrapping a new StringNGrams operation.
|
static Print |
Print.create(Scope scope,
Operand<String> input,
Print.Options... options)
Factory method to create a class wrapping a new Print operation.
|
static <T extends Number> |
UnicodeDecode.create(Scope scope,
Operand<String> input,
String inputEncoding,
Class<T> Tsplits,
UnicodeDecode.Options... options)
Factory method to create a class wrapping a new UnicodeDecode operation.
|
static DecodeProto |
DecodeProto.create(Scope scope,
Operand<String> bytes,
String messageType,
List<String> fieldNames,
List<Class<?>> outputTypes,
DecodeProto.Options... options)
Factory method to create a class wrapping a new DecodeProto operation.
|
static StringLower |
StringLower.create(Scope scope,
Operand<String> input,
StringLower.Options... options)
Factory method to create a class wrapping a new StringLower operation.
|
static UnicodeDecode<Long> |
UnicodeDecode.create(Scope scope,
Operand<String> input,
String inputEncoding,
UnicodeDecode.Options... options)
Factory method to create a class wrapping a new UnicodeDecode operation using default output types.
|
static StringUpper |
StringUpper.create(Scope scope,
Operand<String> input,
StringUpper.Options... options)
Factory method to create a class wrapping a new StringUpper operation.
|
static <T> Shape<Integer> |
Shape.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Shape operation using default output types.
|
static <T> Identity<T> |
Identity.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Identity operation.
|
static <T> Lu<T,Integer> |
Lu.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Lu operation using default output types.
|
static <T> GuaranteeConst<T> |
GuaranteeConst.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new GuaranteeConst operation.
|
static <T> DebugGradientRefIdentity<T> |
DebugGradientRefIdentity.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new DebugGradientRefIdentity operation.
|
static <T> RefIdentity<T> |
RefIdentity.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new RefIdentity operation.
|
static <T> DebugGradientIdentity<T> |
DebugGradientIdentity.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new DebugGradientIdentity operation.
|
static <T> Exit<T> |
Exit.create(Scope scope,
Operand<T> data)
Factory method to create a class wrapping a new Exit operation.
|
static <T> Rank |
Rank.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Rank operation.
|
static <T> ZerosLike<T> |
ZerosLike.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new ZerosLike operation.
|
static <T> Where |
Where.create(Scope scope,
Operand<T> condition)
Factory method to create a class wrapping a new Where operation.
|
static <T> RefNextIteration<T> |
RefNextIteration.create(Scope scope,
Operand<T> data)
Factory method to create a class wrapping a new RefNextIteration operation.
|
static <T> Snapshot<T> |
Snapshot.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Snapshot operation.
|
static <T> NextIteration<T> |
NextIteration.create(Scope scope,
Operand<T> data)
Factory method to create a class wrapping a new NextIteration operation.
|
static <T> Size<Integer> |
Size.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Size operation using default output types.
|
static <T> OnesLike<T> |
OnesLike.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new OnesLike operation.
|
static <T> NonDeterministicInts<Long> |
NonDeterministicInts.create(Scope scope,
Operand<T> shape)
Factory method to create a class wrapping a new NonDeterministicInts operation using default output types.
|
static <T> StopGradient<T> |
StopGradient.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new StopGradient operation.
|
static <T> IsVariableInitialized |
IsVariableInitialized.create(Scope scope,
Operand<T> ref)
Factory method to create a class wrapping a new IsVariableInitialized operation.
|
static <T> DeepCopy<T> |
DeepCopy.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new DeepCopy operation.
|
static <T> GetSessionHandle |
GetSessionHandle.create(Scope scope,
Operand<T> value)
Factory method to create a class wrapping a new GetSessionHandle operation.
|
static <T> RefExit<T> |
RefExit.create(Scope scope,
Operand<T> data)
Factory method to create a class wrapping a new RefExit operation.
|
static <T> OutfeedEnqueue |
OutfeedEnqueue.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new OutfeedEnqueue operation.
|
static <T,U extends Number> |
Lu.create(Scope scope,
Operand<T> input,
Class<U> outputIdxType)
Factory method to create a class wrapping a new Lu operation.
|
static <U extends Number,T> |
Shape.create(Scope scope,
Operand<T> input,
Class<U> outType)
Factory method to create a class wrapping a new Shape operation.
|
static <U extends Number,T> |
Size.create(Scope scope,
Operand<T> input,
Class<U> outType)
Factory method to create a class wrapping a new Size operation.
|
static <U,T> NonDeterministicInts<U> |
NonDeterministicInts.create(Scope scope,
Operand<T> shape,
Class<U> dtype)
Factory method to create a class wrapping a new NonDeterministicInts operation.
|
static <U,T> Bitcast<U> |
Bitcast.create(Scope scope,
Operand<T> input,
Class<U> type)
Factory method to create a class wrapping a new Bitcast operation.
|
static <T> InfeedEnqueue |
InfeedEnqueue.create(Scope scope,
Operand<T> input,
InfeedEnqueue.Options... options)
Factory method to create a class wrapping a new InfeedEnqueue operation.
|
static <T extends Number> |
Bucketize.create(Scope scope,
Operand<T> input,
List<Float> boundaries)
Factory method to create a class wrapping a new Bucketize operation.
|
static <T extends Number> |
ExtractVolumePatches.create(Scope scope,
Operand<T> input,
List<Long> ksizes,
List<Long> strides,
String padding)
Factory method to create a class wrapping a new ExtractVolumePatches operation.
|
static <T> TPUReplicatedOutput<T> |
TPUReplicatedOutput.create(Scope scope,
Operand<T> input,
Long numReplicas)
Factory method to create a class wrapping a new TPUReplicatedOutput operation.
|
static <T extends Number> |
CountUpTo.create(Scope scope,
Operand<T> ref,
Long limit)
Factory method to create a class wrapping a new CountUpTo operation.
|
static <T extends Number> |
CollectiveGather.create(Scope scope,
Operand<T> input,
Long groupSize,
Long groupKey,
Long instanceKey,
Shape shape,
CollectiveGather.Options... options)
Factory method to create a class wrapping a new CollectiveGather operation.
|
static <T> Unstack<T> |
Unstack.create(Scope scope,
Operand<T> value,
Long num,
Unstack.Options... options)
Factory method to create a class wrapping a new Unstack operation.
|
static <T> RefSwitch<T> |
RefSwitch.create(Scope scope,
Operand<T> data,
Operand<Boolean> pred)
Factory method to create a class wrapping a new RefSwitch operation.
|
static <T> RefSwitch<T> |
RefSwitch.create(Scope scope,
Operand<T> data,
Operand<Boolean> pred)
Factory method to create a class wrapping a new RefSwitch operation.
|
static <T> SwitchCond<T> |
SwitchCond.create(Scope scope,
Operand<T> data,
Operand<Boolean> pred)
Factory method to create a class wrapping a new SwitchCond operation.
|
static <T> SwitchCond<T> |
SwitchCond.create(Scope scope,
Operand<T> data,
Operand<Boolean> pred)
Factory method to create a class wrapping a new SwitchCond operation.
|
static <T extends Number> |
DrawBoundingBoxesV2.create(Scope scope,
Operand<T> images,
Operand<Float> boxes,
Operand<Float> colors)
Factory method to create a class wrapping a new DrawBoundingBoxesV2 operation.
|
static <T extends Number> |
DrawBoundingBoxesV2.create(Scope scope,
Operand<T> images,
Operand<Float> boxes,
Operand<Float> colors)
Factory method to create a class wrapping a new DrawBoundingBoxesV2 operation.
|
static <T extends Number> |
DrawBoundingBoxesV2.create(Scope scope,
Operand<T> images,
Operand<Float> boxes,
Operand<Float> colors)
Factory method to create a class wrapping a new DrawBoundingBoxesV2 operation.
|
static <T> RequantizationRangePerChannel |
RequantizationRangePerChannel.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Float clipValueMax)
Factory method to create a class wrapping a new RequantizationRangePerChannel operation.
|
static <T> RequantizationRangePerChannel |
RequantizationRangePerChannel.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Float clipValueMax)
Factory method to create a class wrapping a new RequantizationRangePerChannel operation.
|
static <T> RequantizationRangePerChannel |
RequantizationRangePerChannel.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Float clipValueMax)
Factory method to create a class wrapping a new RequantizationRangePerChannel operation.
|
static <U,T> RequantizePerChannel<U> |
RequantizePerChannel.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Operand<Float> requestedOutputMin,
Operand<Float> requestedOutputMax,
Class<U> outType)
Factory method to create a class wrapping a new RequantizePerChannel operation.
|
static <U,T> RequantizePerChannel<U> |
RequantizePerChannel.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Operand<Float> requestedOutputMin,
Operand<Float> requestedOutputMax,
Class<U> outType)
Factory method to create a class wrapping a new RequantizePerChannel operation.
|
static <U,T> RequantizePerChannel<U> |
RequantizePerChannel.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Operand<Float> requestedOutputMin,
Operand<Float> requestedOutputMax,
Class<U> outType)
Factory method to create a class wrapping a new RequantizePerChannel operation.
|
static <U,T> RequantizePerChannel<U> |
RequantizePerChannel.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Operand<Float> requestedOutputMin,
Operand<Float> requestedOutputMax,
Class<U> outType)
Factory method to create a class wrapping a new RequantizePerChannel operation.
|
static <U,T> RequantizePerChannel<U> |
RequantizePerChannel.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Operand<Float> requestedOutputMin,
Operand<Float> requestedOutputMax,
Class<U> outType)
Factory method to create a class wrapping a new RequantizePerChannel operation.
|
static <T> CollectivePermute<T> |
CollectivePermute.create(Scope scope,
Operand<T> input,
Operand<Integer> sourceTargetPairs)
Factory method to create a class wrapping a new CollectivePermute operation.
|
static <T> CollectivePermute<T> |
CollectivePermute.create(Scope scope,
Operand<T> input,
Operand<Integer> sourceTargetPairs)
Factory method to create a class wrapping a new CollectivePermute operation.
|
static <T extends Number> |
CrossReplicaSum.create(Scope scope,
Operand<T> input,
Operand<Integer> groupAssignment)
Factory method to create a class wrapping a new CrossReplicaSum operation.
|
static <T extends Number> |
CrossReplicaSum.create(Scope scope,
Operand<T> input,
Operand<Integer> groupAssignment)
Factory method to create a class wrapping a new CrossReplicaSum operation.
|
static <T extends Number,U> |
TensorListReserve.create(Scope scope,
Operand<T> elementShape,
Operand<Integer> numElements,
Class<U> elementDtype)
Factory method to create a class wrapping a new TensorListReserve operation.
|
static <T extends Number,U> |
TensorListReserve.create(Scope scope,
Operand<T> elementShape,
Operand<Integer> numElements,
Class<U> elementDtype)
Factory method to create a class wrapping a new TensorListReserve operation.
|
static <T extends Number,U> |
EmptyTensorList.create(Scope scope,
Operand<T> elementShape,
Operand<Integer> maxNumElements,
Class<U> elementDtype)
Factory method to create a class wrapping a new EmptyTensorList operation.
|
static <T extends Number,U> |
EmptyTensorList.create(Scope scope,
Operand<T> elementShape,
Operand<Integer> maxNumElements,
Class<U> elementDtype)
Factory method to create a class wrapping a new EmptyTensorList operation.
|
static <T> DynamicPartition<T> |
DynamicPartition.create(Scope scope,
Operand<T> data,
Operand<Integer> partitions,
Long numPartitions)
Factory method to create a class wrapping a new DynamicPartition operation.
|
static <T> DynamicPartition<T> |
DynamicPartition.create(Scope scope,
Operand<T> data,
Operand<Integer> partitions,
Long numPartitions)
Factory method to create a class wrapping a new DynamicPartition operation.
|
static <T> AllToAll<T> |
AllToAll.create(Scope scope,
Operand<T> input,
Operand<Integer> groupAssignment,
Long concatDimension,
Long splitDimension,
Long splitCount)
Factory method to create a class wrapping a new AllToAll operation.
|
static <T> AllToAll<T> |
AllToAll.create(Scope scope,
Operand<T> input,
Operand<Integer> groupAssignment,
Long concatDimension,
Long splitDimension,
Long splitCount)
Factory method to create a class wrapping a new AllToAll operation.
|
static <T extends Number> |
ScaleAndTranslate.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
Operand<Float> scale,
Operand<Float> translation,
ScaleAndTranslate.Options... options)
Factory method to create a class wrapping a new ScaleAndTranslate operation.
|
static <T extends Number> |
ScaleAndTranslate.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
Operand<Float> scale,
Operand<Float> translation,
ScaleAndTranslate.Options... options)
Factory method to create a class wrapping a new ScaleAndTranslate operation.
|
static <T extends Number> |
ScaleAndTranslate.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
Operand<Float> scale,
Operand<Float> translation,
ScaleAndTranslate.Options... options)
Factory method to create a class wrapping a new ScaleAndTranslate operation.
|
static <T extends Number> |
ScaleAndTranslate.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
Operand<Float> scale,
Operand<Float> translation,
ScaleAndTranslate.Options... options)
Factory method to create a class wrapping a new ScaleAndTranslate operation.
|
static <T> MatrixDiagV2<T> |
MatrixDiagV2.create(Scope scope,
Operand<T> diagonal,
Operand<Integer> k,
Operand<Integer> numRows,
Operand<Integer> numCols,
Operand<T> paddingValue)
Factory method to create a class wrapping a new MatrixDiagV2 operation.
|
static <T> MatrixDiagV2<T> |
MatrixDiagV2.create(Scope scope,
Operand<T> diagonal,
Operand<Integer> k,
Operand<Integer> numRows,
Operand<Integer> numCols,
Operand<T> paddingValue)
Factory method to create a class wrapping a new MatrixDiagV2 operation.
|
static <T> MatrixDiagV2<T> |
MatrixDiagV2.create(Scope scope,
Operand<T> diagonal,
Operand<Integer> k,
Operand<Integer> numRows,
Operand<Integer> numCols,
Operand<T> paddingValue)
Factory method to create a class wrapping a new MatrixDiagV2 operation.
|
static <T> MatrixDiagV2<T> |
MatrixDiagV2.create(Scope scope,
Operand<T> diagonal,
Operand<Integer> k,
Operand<Integer> numRows,
Operand<Integer> numCols,
Operand<T> paddingValue)
Factory method to create a class wrapping a new MatrixDiagV2 operation.
|
static <T> MatrixDiagV2<T> |
MatrixDiagV2.create(Scope scope,
Operand<T> diagonal,
Operand<Integer> k,
Operand<Integer> numRows,
Operand<Integer> numCols,
Operand<T> paddingValue)
Factory method to create a class wrapping a new MatrixDiagV2 operation.
|
static <T> InplaceSub<T> |
InplaceSub.create(Scope scope,
Operand<T> x,
Operand<Integer> i,
Operand<T> v)
Factory method to create a class wrapping a new InplaceSub operation.
|
static <T> InplaceSub<T> |
InplaceSub.create(Scope scope,
Operand<T> x,
Operand<Integer> i,
Operand<T> v)
Factory method to create a class wrapping a new InplaceSub operation.
|
static <T> InplaceSub<T> |
InplaceSub.create(Scope scope,
Operand<T> x,
Operand<Integer> i,
Operand<T> v)
Factory method to create a class wrapping a new InplaceSub operation.
|
static <T> InplaceAdd<T> |
InplaceAdd.create(Scope scope,
Operand<T> x,
Operand<Integer> i,
Operand<T> v)
Factory method to create a class wrapping a new InplaceAdd operation.
|
static <T> InplaceAdd<T> |
InplaceAdd.create(Scope scope,
Operand<T> x,
Operand<Integer> i,
Operand<T> v)
Factory method to create a class wrapping a new InplaceAdd operation.
|
static <T> InplaceAdd<T> |
InplaceAdd.create(Scope scope,
Operand<T> x,
Operand<Integer> i,
Operand<T> v)
Factory method to create a class wrapping a new InplaceAdd operation.
|
static <T> MatrixDiagPartV2<T> |
MatrixDiagPartV2.create(Scope scope,
Operand<T> input,
Operand<Integer> k,
Operand<T> paddingValue)
Factory method to create a class wrapping a new MatrixDiagPartV2 operation.
|
static <T> MatrixDiagPartV2<T> |
MatrixDiagPartV2.create(Scope scope,
Operand<T> input,
Operand<Integer> k,
Operand<T> paddingValue)
Factory method to create a class wrapping a new MatrixDiagPartV2 operation.
|
static <T> MatrixDiagPartV2<T> |
MatrixDiagPartV2.create(Scope scope,
Operand<T> input,
Operand<Integer> k,
Operand<T> paddingValue)
Factory method to create a class wrapping a new MatrixDiagPartV2 operation.
|
static <T> InplaceUpdate<T> |
InplaceUpdate.create(Scope scope,
Operand<T> x,
Operand<Integer> i,
Operand<T> v)
Factory method to create a class wrapping a new InplaceUpdate operation.
|
static <T> InplaceUpdate<T> |
InplaceUpdate.create(Scope scope,
Operand<T> x,
Operand<Integer> i,
Operand<T> v)
Factory method to create a class wrapping a new InplaceUpdate operation.
|
static <T> InplaceUpdate<T> |
InplaceUpdate.create(Scope scope,
Operand<T> x,
Operand<Integer> i,
Operand<T> v)
Factory method to create a class wrapping a new InplaceUpdate operation.
|
static <T,U extends Number> |
TensorListScatter.create(Scope scope,
Operand<T> tensor,
Operand<Integer> indices,
Operand<U> elementShape)
Factory method to create a class wrapping a new TensorListScatter operation.
|
static <T,U extends Number> |
TensorListScatter.create(Scope scope,
Operand<T> tensor,
Operand<Integer> indices,
Operand<U> elementShape)
Factory method to create a class wrapping a new TensorListScatter operation.
|
static <T,U extends Number> |
TensorListScatter.create(Scope scope,
Operand<T> tensor,
Operand<Integer> indices,
Operand<U> elementShape)
Factory method to create a class wrapping a new TensorListScatter operation.
|
static <T,U extends Number> |
TensorListScatterV2.create(Scope scope,
Operand<T> tensor,
Operand<Integer> indices,
Operand<U> elementShape,
Operand<Integer> numElements)
Factory method to create a class wrapping a new TensorListScatterV2 operation.
|
static <T,U extends Number> |
TensorListScatterV2.create(Scope scope,
Operand<T> tensor,
Operand<Integer> indices,
Operand<U> elementShape,
Operand<Integer> numElements)
Factory method to create a class wrapping a new TensorListScatterV2 operation.
|
static <T,U extends Number> |
TensorListScatterV2.create(Scope scope,
Operand<T> tensor,
Operand<Integer> indices,
Operand<U> elementShape,
Operand<Integer> numElements)
Factory method to create a class wrapping a new TensorListScatterV2 operation.
|
static <T,U extends Number> |
TensorListScatterV2.create(Scope scope,
Operand<T> tensor,
Operand<Integer> indices,
Operand<U> elementShape,
Operand<Integer> numElements)
Factory method to create a class wrapping a new TensorListScatterV2 operation.
|
static <U,T extends Number> |
OneHot.create(Scope scope,
Operand<T> indices,
Operand<Integer> depth,
Operand<U> onValue,
Operand<U> offValue,
OneHot.Options... options)
Factory method to create a class wrapping a new OneHot operation.
|
static <U,T extends Number> |
OneHot.create(Scope scope,
Operand<T> indices,
Operand<Integer> depth,
Operand<U> onValue,
Operand<U> offValue,
OneHot.Options... options)
Factory method to create a class wrapping a new OneHot operation.
|
static <U,T extends Number> |
OneHot.create(Scope scope,
Operand<T> indices,
Operand<Integer> depth,
Operand<U> onValue,
Operand<U> offValue,
OneHot.Options... options)
Factory method to create a class wrapping a new OneHot operation.
|
static <U,T extends Number> |
OneHot.create(Scope scope,
Operand<T> indices,
Operand<Integer> depth,
Operand<U> onValue,
Operand<U> offValue,
OneHot.Options... options)
Factory method to create a class wrapping a new OneHot operation.
|
static <T> Unbatch<T> |
Unbatch.create(Scope scope,
Operand<T> batchedTensor,
Operand<Long> batchIndex,
Operand<Long> id,
Long timeoutMicros,
Unbatch.Options... options)
Factory method to create a class wrapping a new Unbatch operation.
|
static <T> Unbatch<T> |
Unbatch.create(Scope scope,
Operand<T> batchedTensor,
Operand<Long> batchIndex,
Operand<Long> id,
Long timeoutMicros,
Unbatch.Options... options)
Factory method to create a class wrapping a new Unbatch operation.
|
static <T> Unbatch<T> |
Unbatch.create(Scope scope,
Operand<T> batchedTensor,
Operand<Long> batchIndex,
Operand<Long> id,
Long timeoutMicros,
Unbatch.Options... options)
Factory method to create a class wrapping a new Unbatch operation.
|
static <T> UnbatchGrad<T> |
UnbatchGrad.create(Scope scope,
Operand<T> originalInput,
Operand<Long> batchIndex,
Operand<T> grad,
Operand<Long> id,
UnbatchGrad.Options... options)
Factory method to create a class wrapping a new UnbatchGrad operation.
|
static <T> UnbatchGrad<T> |
UnbatchGrad.create(Scope scope,
Operand<T> originalInput,
Operand<Long> batchIndex,
Operand<T> grad,
Operand<Long> id,
UnbatchGrad.Options... options)
Factory method to create a class wrapping a new UnbatchGrad operation.
|
static <T> UnbatchGrad<T> |
UnbatchGrad.create(Scope scope,
Operand<T> originalInput,
Operand<Long> batchIndex,
Operand<T> grad,
Operand<Long> id,
UnbatchGrad.Options... options)
Factory method to create a class wrapping a new UnbatchGrad operation.
|
static <T> UnbatchGrad<T> |
UnbatchGrad.create(Scope scope,
Operand<T> originalInput,
Operand<Long> batchIndex,
Operand<T> grad,
Operand<Long> id,
UnbatchGrad.Options... options)
Factory method to create a class wrapping a new UnbatchGrad operation.
|
static <T> Fingerprint |
Fingerprint.create(Scope scope,
Operand<T> data,
Operand<String> method)
Factory method to create a class wrapping a new Fingerprint operation.
|
static <T> Fingerprint |
Fingerprint.create(Scope scope,
Operand<T> data,
Operand<String> method)
Factory method to create a class wrapping a new Fingerprint operation.
|
static <T> MulNoNan<T> |
MulNoNan.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new MulNoNan operation.
|
static <T> MulNoNan<T> |
MulNoNan.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new MulNoNan operation.
|
static <T> SetDiff1d<T,Integer> |
SetDiff1d.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new SetDiff1d operation using default output types.
|
static <T> SetDiff1d<T,Integer> |
SetDiff1d.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new SetDiff1d operation using default output types.
|
static <T> UpperBound<Integer> |
UpperBound.create(Scope scope,
Operand<T> sortedInputs,
Operand<T> values)
Factory method to create a class wrapping a new UpperBound operation using default output types.
|
static <T> UpperBound<Integer> |
UpperBound.create(Scope scope,
Operand<T> sortedInputs,
Operand<T> values)
Factory method to create a class wrapping a new UpperBound operation using default output types.
|
static <T> LowerBound<Integer> |
LowerBound.create(Scope scope,
Operand<T> sortedInputs,
Operand<T> values)
Factory method to create a class wrapping a new LowerBound operation using default output types.
|
static <T> LowerBound<Integer> |
LowerBound.create(Scope scope,
Operand<T> sortedInputs,
Operand<T> values)
Factory method to create a class wrapping a new LowerBound operation using default output types.
|
static <T extends Number> |
BroadcastDynamicShape.create(Scope scope,
Operand<T> s0,
Operand<T> s1)
Factory method to create a class wrapping a new BroadcastDynamicShape operation.
|
static <T extends Number> |
BroadcastDynamicShape.create(Scope scope,
Operand<T> s0,
Operand<T> s1)
Factory method to create a class wrapping a new BroadcastDynamicShape operation.
|
static <T extends Number> |
UnravelIndex.create(Scope scope,
Operand<T> indices,
Operand<T> dims)
Factory method to create a class wrapping a new UnravelIndex operation.
|
static <T extends Number> |
UnravelIndex.create(Scope scope,
Operand<T> indices,
Operand<T> dims)
Factory method to create a class wrapping a new UnravelIndex operation.
|
static <T extends Number> |
NextAfter.create(Scope scope,
Operand<T> x1,
Operand<T> x2)
Factory method to create a class wrapping a new NextAfter operation.
|
static <T extends Number> |
NextAfter.create(Scope scope,
Operand<T> x1,
Operand<T> x2)
Factory method to create a class wrapping a new NextAfter operation.
|
static <T extends Number> |
BroadcastGradientArgs.create(Scope scope,
Operand<T> s0,
Operand<T> s1)
Factory method to create a class wrapping a new BroadcastGradientArgs operation.
|
static <T extends Number> |
BroadcastGradientArgs.create(Scope scope,
Operand<T> s0,
Operand<T> s1)
Factory method to create a class wrapping a new BroadcastGradientArgs operation.
|
static <T> Assign<T> |
Assign.create(Scope scope,
Operand<T> ref,
Operand<T> value,
Assign.Options... options)
Factory method to create a class wrapping a new Assign operation.
|
static <T> Assign<T> |
Assign.create(Scope scope,
Operand<T> ref,
Operand<T> value,
Assign.Options... options)
Factory method to create a class wrapping a new Assign operation.
|
static <T> AssignAdd<T> |
AssignAdd.create(Scope scope,
Operand<T> ref,
Operand<T> value,
AssignAdd.Options... options)
Factory method to create a class wrapping a new AssignAdd operation.
|
static <T> AssignAdd<T> |
AssignAdd.create(Scope scope,
Operand<T> ref,
Operand<T> value,
AssignAdd.Options... options)
Factory method to create a class wrapping a new AssignAdd operation.
|
static <T> AssignSub<T> |
AssignSub.create(Scope scope,
Operand<T> ref,
Operand<T> value,
AssignSub.Options... options)
Factory method to create a class wrapping a new AssignSub operation.
|
static <T> AssignSub<T> |
AssignSub.create(Scope scope,
Operand<T> ref,
Operand<T> value,
AssignSub.Options... options)
Factory method to create a class wrapping a new AssignSub operation.
|
static <T> BatchMatMulV2<T> |
BatchMatMulV2.create(Scope scope,
Operand<T> x,
Operand<T> y,
BatchMatMulV2.Options... options)
Factory method to create a class wrapping a new BatchMatMulV2 operation.
|
static <T> BatchMatMulV2<T> |
BatchMatMulV2.create(Scope scope,
Operand<T> x,
Operand<T> y,
BatchMatMulV2.Options... options)
Factory method to create a class wrapping a new BatchMatMulV2 operation.
|
static <T,U extends Number> |
SetDiff1d.create(Scope scope,
Operand<T> x,
Operand<T> y,
Class<U> outIdx)
Factory method to create a class wrapping a new SetDiff1d operation.
|
static <T,U extends Number> |
SetDiff1d.create(Scope scope,
Operand<T> x,
Operand<T> y,
Class<U> outIdx)
Factory method to create a class wrapping a new SetDiff1d operation.
|
static <U extends Number,T> |
UpperBound.create(Scope scope,
Operand<T> sortedInputs,
Operand<T> values,
Class<U> outType)
Factory method to create a class wrapping a new UpperBound operation.
|
static <U extends Number,T> |
UpperBound.create(Scope scope,
Operand<T> sortedInputs,
Operand<T> values,
Class<U> outType)
Factory method to create a class wrapping a new UpperBound operation.
|
static <U extends Number,T> |
LowerBound.create(Scope scope,
Operand<T> sortedInputs,
Operand<T> values,
Class<U> outType)
Factory method to create a class wrapping a new LowerBound operation.
|
static <U extends Number,T> |
LowerBound.create(Scope scope,
Operand<T> sortedInputs,
Operand<T> values,
Class<U> outType)
Factory method to create a class wrapping a new LowerBound operation.
|
static <T,U> MutableDenseHashTable |
MutableDenseHashTable.create(Scope scope,
Operand<T> emptyKey,
Operand<T> deletedKey,
Class<U> valueDtype,
MutableDenseHashTable.Options... options)
Factory method to create a class wrapping a new MutableDenseHashTable operation.
|
static <T,U> MutableDenseHashTable |
MutableDenseHashTable.create(Scope scope,
Operand<T> emptyKey,
Operand<T> deletedKey,
Class<U> valueDtype,
MutableDenseHashTable.Options... options)
Factory method to create a class wrapping a new MutableDenseHashTable operation.
|
static <T extends Number> |
ScaleAndTranslateGrad.create(Scope scope,
Operand<T> grads,
Operand<T> originalImage,
Operand<Float> scale,
Operand<Float> translation,
ScaleAndTranslateGrad.Options... options)
Factory method to create a class wrapping a new ScaleAndTranslateGrad operation.
|
static <T extends Number> |
ScaleAndTranslateGrad.create(Scope scope,
Operand<T> grads,
Operand<T> originalImage,
Operand<Float> scale,
Operand<Float> translation,
ScaleAndTranslateGrad.Options... options)
Factory method to create a class wrapping a new ScaleAndTranslateGrad operation.
|
static <T extends Number> |
ScaleAndTranslateGrad.create(Scope scope,
Operand<T> grads,
Operand<T> originalImage,
Operand<Float> scale,
Operand<Float> translation,
ScaleAndTranslateGrad.Options... options)
Factory method to create a class wrapping a new ScaleAndTranslateGrad operation.
|
static <T extends Number> |
ScaleAndTranslateGrad.create(Scope scope,
Operand<T> grads,
Operand<T> originalImage,
Operand<Float> scale,
Operand<Float> translation,
ScaleAndTranslateGrad.Options... options)
Factory method to create a class wrapping a new ScaleAndTranslateGrad operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGradV3.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
Operand<U> reserveSpace3,
FusedBatchNormGradV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGradV3 operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGradV3.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
Operand<U> reserveSpace3,
FusedBatchNormGradV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGradV3 operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGradV3.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
Operand<U> reserveSpace3,
FusedBatchNormGradV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGradV3 operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGradV3.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
Operand<U> reserveSpace3,
FusedBatchNormGradV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGradV3 operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGradV3.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
Operand<U> reserveSpace3,
FusedBatchNormGradV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGradV3 operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGradV3.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
Operand<U> reserveSpace3,
FusedBatchNormGradV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGradV3 operation.
|
static <T> MatrixSetDiagV2<T> |
MatrixSetDiagV2.create(Scope scope,
Operand<T> input,
Operand<T> diagonal,
Operand<Integer> k)
Factory method to create a class wrapping a new MatrixSetDiagV2 operation.
|
static <T> MatrixSetDiagV2<T> |
MatrixSetDiagV2.create(Scope scope,
Operand<T> input,
Operand<T> diagonal,
Operand<Integer> k)
Factory method to create a class wrapping a new MatrixSetDiagV2 operation.
|
static <T> MatrixSetDiagV2<T> |
MatrixSetDiagV2.create(Scope scope,
Operand<T> input,
Operand<T> diagonal,
Operand<Integer> k)
Factory method to create a class wrapping a new MatrixSetDiagV2 operation.
|
static <T extends Number> |
HistogramFixedWidth.create(Scope scope,
Operand<T> values,
Operand<T> valueRange,
Operand<Integer> nbins)
Factory method to create a class wrapping a new HistogramFixedWidth operation using default output types.
|
static <T extends Number> |
HistogramFixedWidth.create(Scope scope,
Operand<T> values,
Operand<T> valueRange,
Operand<Integer> nbins)
Factory method to create a class wrapping a new HistogramFixedWidth operation using default output types.
|
static <T extends Number> |
HistogramFixedWidth.create(Scope scope,
Operand<T> values,
Operand<T> valueRange,
Operand<Integer> nbins)
Factory method to create a class wrapping a new HistogramFixedWidth operation using default output types.
|
static <U extends Number,T extends Number> |
HistogramFixedWidth.create(Scope scope,
Operand<T> values,
Operand<T> valueRange,
Operand<Integer> nbins,
Class<U> dtype)
Factory method to create a class wrapping a new HistogramFixedWidth operation.
|
static <U extends Number,T extends Number> |
HistogramFixedWidth.create(Scope scope,
Operand<T> values,
Operand<T> valueRange,
Operand<Integer> nbins,
Class<U> dtype)
Factory method to create a class wrapping a new HistogramFixedWidth operation.
|
static <U extends Number,T extends Number> |
HistogramFixedWidth.create(Scope scope,
Operand<T> values,
Operand<T> valueRange,
Operand<Integer> nbins,
Class<U> dtype)
Factory method to create a class wrapping a new HistogramFixedWidth operation.
|
static <T extends Number> |
NonMaxSuppressionV5.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<T> iouThreshold,
Operand<T> scoreThreshold,
Operand<T> softNmsSigma,
NonMaxSuppressionV5.Options... options)
Factory method to create a class wrapping a new NonMaxSuppressionV5 operation.
|
static <T extends Number> |
NonMaxSuppressionV5.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<T> iouThreshold,
Operand<T> scoreThreshold,
Operand<T> softNmsSigma,
NonMaxSuppressionV5.Options... options)
Factory method to create a class wrapping a new NonMaxSuppressionV5 operation.
|
static <T extends Number> |
NonMaxSuppressionV5.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<T> iouThreshold,
Operand<T> scoreThreshold,
Operand<T> softNmsSigma,
NonMaxSuppressionV5.Options... options)
Factory method to create a class wrapping a new NonMaxSuppressionV5 operation.
|
static <T extends Number> |
NonMaxSuppressionV5.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<T> iouThreshold,
Operand<T> scoreThreshold,
Operand<T> softNmsSigma,
NonMaxSuppressionV5.Options... options)
Factory method to create a class wrapping a new NonMaxSuppressionV5 operation.
|
static <T extends Number> |
NonMaxSuppressionV5.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<T> iouThreshold,
Operand<T> scoreThreshold,
Operand<T> softNmsSigma,
NonMaxSuppressionV5.Options... options)
Factory method to create a class wrapping a new NonMaxSuppressionV5 operation.
|
static <T extends Number> |
NonMaxSuppressionV5.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<T> iouThreshold,
Operand<T> scoreThreshold,
Operand<T> softNmsSigma,
NonMaxSuppressionV5.Options... options)
Factory method to create a class wrapping a new NonMaxSuppressionV5 operation.
|
static <T> ClipByValue<T> |
ClipByValue.create(Scope scope,
Operand<T> t,
Operand<T> clipValueMin,
Operand<T> clipValueMax)
Factory method to create a class wrapping a new ClipByValue operation.
|
static <T> ClipByValue<T> |
ClipByValue.create(Scope scope,
Operand<T> t,
Operand<T> clipValueMin,
Operand<T> clipValueMax)
Factory method to create a class wrapping a new ClipByValue operation.
|
static <T> ClipByValue<T> |
ClipByValue.create(Scope scope,
Operand<T> t,
Operand<T> clipValueMin,
Operand<T> clipValueMax)
Factory method to create a class wrapping a new ClipByValue operation.
|
static <T extends Number> |
Range.create(Scope scope,
Operand<T> start,
Operand<T> limit,
Operand<T> delta)
Factory method to create a class wrapping a new Range operation.
|
static <T extends Number> |
Range.create(Scope scope,
Operand<T> start,
Operand<T> limit,
Operand<T> delta)
Factory method to create a class wrapping a new Range operation.
|
static <T extends Number> |
Range.create(Scope scope,
Operand<T> start,
Operand<T> limit,
Operand<T> delta)
Factory method to create a class wrapping a new Range operation.
|
static <T extends Number> |
RaggedRange.create(Scope scope,
Operand<T> starts,
Operand<T> limits,
Operand<T> deltas)
Factory method to create a class wrapping a new RaggedRange operation using default output types.
|
static <T extends Number> |
RaggedRange.create(Scope scope,
Operand<T> starts,
Operand<T> limits,
Operand<T> deltas)
Factory method to create a class wrapping a new RaggedRange operation using default output types.
|
static <T extends Number> |
RaggedRange.create(Scope scope,
Operand<T> starts,
Operand<T> limits,
Operand<T> deltas)
Factory method to create a class wrapping a new RaggedRange operation using default output types.
|
static <U extends Number,T extends Number> |
RaggedRange.create(Scope scope,
Operand<T> starts,
Operand<T> limits,
Operand<T> deltas,
Class<U> Tsplits)
Factory method to create a class wrapping a new RaggedRange operation.
|
static <U extends Number,T extends Number> |
RaggedRange.create(Scope scope,
Operand<T> starts,
Operand<T> limits,
Operand<T> deltas,
Class<U> Tsplits)
Factory method to create a class wrapping a new RaggedRange operation.
|
static <U extends Number,T extends Number> |
RaggedRange.create(Scope scope,
Operand<T> starts,
Operand<T> limits,
Operand<T> deltas,
Class<U> Tsplits)
Factory method to create a class wrapping a new RaggedRange operation.
|
static <T> TridiagonalMatMul<T> |
TridiagonalMatMul.create(Scope scope,
Operand<T> superdiag,
Operand<T> maindiag,
Operand<T> subdiag,
Operand<T> rhs)
Factory method to create a class wrapping a new TridiagonalMatMul operation.
|
static <T> TridiagonalMatMul<T> |
TridiagonalMatMul.create(Scope scope,
Operand<T> superdiag,
Operand<T> maindiag,
Operand<T> subdiag,
Operand<T> rhs)
Factory method to create a class wrapping a new TridiagonalMatMul operation.
|
static <T> TridiagonalMatMul<T> |
TridiagonalMatMul.create(Scope scope,
Operand<T> superdiag,
Operand<T> maindiag,
Operand<T> subdiag,
Operand<T> rhs)
Factory method to create a class wrapping a new TridiagonalMatMul operation.
|
static <T> TridiagonalMatMul<T> |
TridiagonalMatMul.create(Scope scope,
Operand<T> superdiag,
Operand<T> maindiag,
Operand<T> subdiag,
Operand<T> rhs)
Factory method to create a class wrapping a new TridiagonalMatMul operation.
|
static <T extends Number> |
CudnnRNNV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
CudnnRNNV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNV3 operation.
|
static <T extends Number> |
CudnnRNNV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
CudnnRNNV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNV3 operation.
|
static <T extends Number> |
CudnnRNNV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
CudnnRNNV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNV3 operation.
|
static <T extends Number> |
CudnnRNNV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
CudnnRNNV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNV3 operation.
|
static <T extends Number> |
CudnnRNNV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
CudnnRNNV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T extends Number> |
CudnnRNNBackpropV3.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<Integer> sequenceLengths,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRNNBackpropV3.Options... options)
Factory method to create a class wrapping a new CudnnRNNBackpropV3 operation.
|
static <T> ApplyAdagradV2<T> |
ApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ApplyAdagradV2 operation.
|
static <T> ApplyAdagradV2<T> |
ApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ApplyAdagradV2 operation.
|
static <T> ApplyAdagradV2<T> |
ApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ApplyAdagradV2 operation.
|
static <T> ApplyAdagradV2<T> |
ApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ApplyAdagradV2 operation.
|
static <T> ApplyAdagradV2<T> |
ApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new ApplyAdagradV2 operation.
|
static <T extends Number> |
GRUBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC)
Factory method to create a class wrapping a new GRUBlockCell operation.
|
static <T extends Number> |
GRUBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC)
Factory method to create a class wrapping a new GRUBlockCell operation.
|
static <T extends Number> |
GRUBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC)
Factory method to create a class wrapping a new GRUBlockCell operation.
|
static <T extends Number> |
GRUBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC)
Factory method to create a class wrapping a new GRUBlockCell operation.
|
static <T extends Number> |
GRUBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC)
Factory method to create a class wrapping a new GRUBlockCell operation.
|
static <T extends Number> |
GRUBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC)
Factory method to create a class wrapping a new GRUBlockCell operation.
|
static <T extends Number> |
LSTMBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
LSTMBlockCell.Options... options)
Factory method to create a class wrapping a new LSTMBlockCell operation.
|
static <T extends Number> |
LSTMBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
LSTMBlockCell.Options... options)
Factory method to create a class wrapping a new LSTMBlockCell operation.
|
static <T extends Number> |
LSTMBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
LSTMBlockCell.Options... options)
Factory method to create a class wrapping a new LSTMBlockCell operation.
|
static <T extends Number> |
LSTMBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
LSTMBlockCell.Options... options)
Factory method to create a class wrapping a new LSTMBlockCell operation.
|
static <T extends Number> |
LSTMBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
LSTMBlockCell.Options... options)
Factory method to create a class wrapping a new LSTMBlockCell operation.
|
static <T extends Number> |
LSTMBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
LSTMBlockCell.Options... options)
Factory method to create a class wrapping a new LSTMBlockCell operation.
|
static <T extends Number> |
LSTMBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
LSTMBlockCell.Options... options)
Factory method to create a class wrapping a new LSTMBlockCell operation.
|
static <T extends Number> |
LSTMBlockCell.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
LSTMBlockCell.Options... options)
Factory method to create a class wrapping a new LSTMBlockCell operation.
|
static <T extends Number> |
GRUBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC,
Operand<T> r,
Operand<T> u,
Operand<T> c,
Operand<T> dH)
Factory method to create a class wrapping a new GRUBlockCellGrad operation.
|
static <T extends Number> |
GRUBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC,
Operand<T> r,
Operand<T> u,
Operand<T> c,
Operand<T> dH)
Factory method to create a class wrapping a new GRUBlockCellGrad operation.
|
static <T extends Number> |
GRUBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC,
Operand<T> r,
Operand<T> u,
Operand<T> c,
Operand<T> dH)
Factory method to create a class wrapping a new GRUBlockCellGrad operation.
|
static <T extends Number> |
GRUBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC,
Operand<T> r,
Operand<T> u,
Operand<T> c,
Operand<T> dH)
Factory method to create a class wrapping a new GRUBlockCellGrad operation.
|
static <T extends Number> |
GRUBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC,
Operand<T> r,
Operand<T> u,
Operand<T> c,
Operand<T> dH)
Factory method to create a class wrapping a new GRUBlockCellGrad operation.
|
static <T extends Number> |
GRUBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC,
Operand<T> r,
Operand<T> u,
Operand<T> c,
Operand<T> dH)
Factory method to create a class wrapping a new GRUBlockCellGrad operation.
|
static <T extends Number> |
GRUBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC,
Operand<T> r,
Operand<T> u,
Operand<T> c,
Operand<T> dH)
Factory method to create a class wrapping a new GRUBlockCellGrad operation.
|
static <T extends Number> |
GRUBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC,
Operand<T> r,
Operand<T> u,
Operand<T> c,
Operand<T> dH)
Factory method to create a class wrapping a new GRUBlockCellGrad operation.
|
static <T extends Number> |
GRUBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC,
Operand<T> r,
Operand<T> u,
Operand<T> c,
Operand<T> dH)
Factory method to create a class wrapping a new GRUBlockCellGrad operation.
|
static <T extends Number> |
GRUBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> hPrev,
Operand<T> wRu,
Operand<T> wC,
Operand<T> bRu,
Operand<T> bC,
Operand<T> r,
Operand<T> u,
Operand<T> c,
Operand<T> dH)
Factory method to create a class wrapping a new GRUBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T extends Number> |
LSTMBlockCellGrad.create(Scope scope,
Operand<T> x,
Operand<T> csPrev,
Operand<T> hPrev,
Operand<T> w,
Operand<T> wci,
Operand<T> wcf,
Operand<T> wco,
Operand<T> b,
Operand<T> i,
Operand<T> cs,
Operand<T> f,
Operand<T> o,
Operand<T> ci,
Operand<T> co,
Operand<T> csGrad,
Operand<T> hGrad,
Boolean usePeephole)
Factory method to create a class wrapping a new LSTMBlockCellGrad operation.
|
static <T,U extends Number> |
SparseApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradV2 operation.
|
static <T,U extends Number> |
SparseApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradV2 operation.
|
static <T,U extends Number> |
SparseApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradV2 operation.
|
static <T,U extends Number> |
SparseApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradV2 operation.
|
static <T,U extends Number> |
SparseApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradV2 operation.
|
static <T,U extends Number> |
SparseApplyAdagradV2.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagradV2.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradV2 operation.
|
static <U,T extends Number> |
StridedSliceGrad.create(Scope scope,
Operand<T> shape,
Operand<T> begin,
Operand<T> end,
Operand<T> strides,
Operand<U> dy,
StridedSliceGrad.Options... options)
Factory method to create a class wrapping a new StridedSliceGrad operation.
|
static <U,T extends Number> |
StridedSliceGrad.create(Scope scope,
Operand<T> shape,
Operand<T> begin,
Operand<T> end,
Operand<T> strides,
Operand<U> dy,
StridedSliceGrad.Options... options)
Factory method to create a class wrapping a new StridedSliceGrad operation.
|
static <U,T extends Number> |
StridedSliceGrad.create(Scope scope,
Operand<T> shape,
Operand<T> begin,
Operand<T> end,
Operand<T> strides,
Operand<U> dy,
StridedSliceGrad.Options... options)
Factory method to create a class wrapping a new StridedSliceGrad operation.
|
static <U,T extends Number> |
StridedSliceGrad.create(Scope scope,
Operand<T> shape,
Operand<T> begin,
Operand<T> end,
Operand<T> strides,
Operand<U> dy,
StridedSliceGrad.Options... options)
Factory method to create a class wrapping a new StridedSliceGrad operation.
|
static <U,T extends Number> |
StridedSliceGrad.create(Scope scope,
Operand<T> shape,
Operand<T> begin,
Operand<T> end,
Operand<T> strides,
Operand<U> dy,
StridedSliceGrad.Options... options)
Factory method to create a class wrapping a new StridedSliceGrad operation.
|
static <T extends Number,U extends Number> |
LinSpace.create(Scope scope,
Operand<T> start,
Operand<T> stop,
Operand<U> num)
Factory method to create a class wrapping a new LinSpace operation.
|
static <T extends Number,U extends Number> |
LinSpace.create(Scope scope,
Operand<T> start,
Operand<T> stop,
Operand<U> num)
Factory method to create a class wrapping a new LinSpace operation.
|
static <T extends Number,U extends Number> |
LinSpace.create(Scope scope,
Operand<T> start,
Operand<T> stop,
Operand<U> num)
Factory method to create a class wrapping a new LinSpace operation.
|
static <T> TridiagonalSolve<T> |
TridiagonalSolve.create(Scope scope,
Operand<T> diagonals,
Operand<T> rhs,
TridiagonalSolve.Options... options)
Factory method to create a class wrapping a new TridiagonalSolve operation.
|
static <T> TridiagonalSolve<T> |
TridiagonalSolve.create(Scope scope,
Operand<T> diagonals,
Operand<T> rhs,
TridiagonalSolve.Options... options)
Factory method to create a class wrapping a new TridiagonalSolve operation.
|
static <T,U extends Number> |
Reshape.create(Scope scope,
Operand<T> tensor,
Operand<U> shape)
Factory method to create a class wrapping a new Reshape operation.
|
static <T,U extends Number> |
Reshape.create(Scope scope,
Operand<T> tensor,
Operand<U> shape)
Factory method to create a class wrapping a new Reshape operation.
|
static <T,U extends Number> |
BroadcastTo.create(Scope scope,
Operand<T> input,
Operand<U> shape)
Factory method to create a class wrapping a new BroadcastTo operation.
|
static <T,U extends Number> |
BroadcastTo.create(Scope scope,
Operand<T> input,
Operand<U> shape)
Factory method to create a class wrapping a new BroadcastTo operation.
|
static <T,U extends Number> |
ExpandDims.create(Scope scope,
Operand<T> input,
Operand<U> axis)
Factory method to create a class wrapping a new ExpandDims operation.
|
static <T,U extends Number> |
ExpandDims.create(Scope scope,
Operand<T> input,
Operand<U> axis)
Factory method to create a class wrapping a new ExpandDims operation.
|
static <T,U extends Number> |
Unique.create(Scope scope,
Operand<T> x,
Operand<U> axis)
Factory method to create a class wrapping a new Unique operation using default output types.
|
static <T,U extends Number> |
Unique.create(Scope scope,
Operand<T> x,
Operand<U> axis)
Factory method to create a class wrapping a new Unique operation using default output types.
|
static <T,U extends Number> |
UniqueWithCounts.create(Scope scope,
Operand<T> x,
Operand<U> axis)
Factory method to create a class wrapping a new UniqueWithCounts operation using default output types.
|
static <T,U extends Number> |
UniqueWithCounts.create(Scope scope,
Operand<T> x,
Operand<U> axis)
Factory method to create a class wrapping a new UniqueWithCounts operation using default output types.
|
static <T,U extends Number> |
TensorListFromTensor.create(Scope scope,
Operand<T> tensor,
Operand<U> elementShape)
Factory method to create a class wrapping a new TensorListFromTensor operation.
|
static <T,U extends Number> |
TensorListFromTensor.create(Scope scope,
Operand<T> tensor,
Operand<U> elementShape)
Factory method to create a class wrapping a new TensorListFromTensor operation.
|
static <T,U extends Number> |
Tile.create(Scope scope,
Operand<T> input,
Operand<U> multiples)
Factory method to create a class wrapping a new Tile operation.
|
static <T,U extends Number> |
Tile.create(Scope scope,
Operand<T> input,
Operand<U> multiples)
Factory method to create a class wrapping a new Tile operation.
|
static <T,U extends Number> |
GatherNd.create(Scope scope,
Operand<T> params,
Operand<U> indices)
Factory method to create a class wrapping a new GatherNd operation.
|
static <T,U extends Number> |
GatherNd.create(Scope scope,
Operand<T> params,
Operand<U> indices)
Factory method to create a class wrapping a new GatherNd operation.
|
static <T,U extends Number> |
Reverse.create(Scope scope,
Operand<T> tensor,
Operand<U> axis)
Factory method to create a class wrapping a new Reverse operation.
|
static <T,U extends Number> |
Reverse.create(Scope scope,
Operand<T> tensor,
Operand<U> axis)
Factory method to create a class wrapping a new Reverse operation.
|
static <U,T extends Number> |
Fill.create(Scope scope,
Operand<T> dims,
Operand<U> value)
Factory method to create a class wrapping a new Fill operation.
|
static <U,T extends Number> |
Fill.create(Scope scope,
Operand<T> dims,
Operand<U> value)
Factory method to create a class wrapping a new Fill operation.
|
static <T,V extends Number,U extends Number> |
Unique.create(Scope scope,
Operand<T> x,
Operand<U> axis,
Class<V> outIdx)
Factory method to create a class wrapping a new Unique operation.
|
static <T,V extends Number,U extends Number> |
Unique.create(Scope scope,
Operand<T> x,
Operand<U> axis,
Class<V> outIdx)
Factory method to create a class wrapping a new Unique operation.
|
static <T,V extends Number,U extends Number> |
UniqueWithCounts.create(Scope scope,
Operand<T> x,
Operand<U> axis,
Class<V> outIdx)
Factory method to create a class wrapping a new UniqueWithCounts operation.
|
static <T,V extends Number,U extends Number> |
UniqueWithCounts.create(Scope scope,
Operand<T> x,
Operand<U> axis,
Class<V> outIdx)
Factory method to create a class wrapping a new UniqueWithCounts operation.
|
static <T extends Number,U extends Number> |
CumulativeLogsumexp.create(Scope scope,
Operand<T> x,
Operand<U> axis,
CumulativeLogsumexp.Options... options)
Factory method to create a class wrapping a new CumulativeLogsumexp operation.
|
static <T extends Number,U extends Number> |
CumulativeLogsumexp.create(Scope scope,
Operand<T> x,
Operand<U> axis,
CumulativeLogsumexp.Options... options)
Factory method to create a class wrapping a new CumulativeLogsumexp operation.
|
static <T,U extends Number> |
EuclideanNorm.create(Scope scope,
Operand<T> input,
Operand<U> axis,
EuclideanNorm.Options... options)
Factory method to create a class wrapping a new EuclideanNorm operation.
|
static <T,U extends Number> |
EuclideanNorm.create(Scope scope,
Operand<T> input,
Operand<U> axis,
EuclideanNorm.Options... options)
Factory method to create a class wrapping a new EuclideanNorm operation.
|
static <T,U extends Number> |
BatchToSpace.create(Scope scope,
Operand<T> input,
Operand<U> crops,
Long blockSize)
Factory method to create a class wrapping a new BatchToSpace operation.
|
static <T,U extends Number> |
BatchToSpace.create(Scope scope,
Operand<T> input,
Operand<U> crops,
Long blockSize)
Factory method to create a class wrapping a new BatchToSpace operation.
|
static <T,U extends Number> |
ReverseSequence.create(Scope scope,
Operand<T> input,
Operand<U> seqLengths,
Long seqDim,
ReverseSequence.Options... options)
Factory method to create a class wrapping a new ReverseSequence operation.
|
static <T,U extends Number> |
ReverseSequence.create(Scope scope,
Operand<T> input,
Operand<U> seqLengths,
Long seqDim,
ReverseSequence.Options... options)
Factory method to create a class wrapping a new ReverseSequence operation.
|
static <T,U extends Number> |
Max.create(Scope scope,
Operand<T> input,
Operand<U> axis,
Max.Options... options)
Factory method to create a class wrapping a new Max operation.
|
static <T,U extends Number> |
Max.create(Scope scope,
Operand<T> input,
Operand<U> axis,
Max.Options... options)
Factory method to create a class wrapping a new Max operation.
|
static <T,U extends Number> |
Min.create(Scope scope,
Operand<T> input,
Operand<U> axis,
Min.Options... options)
Factory method to create a class wrapping a new Min operation.
|
static <T,U extends Number> |
Min.create(Scope scope,
Operand<T> input,
Operand<U> axis,
Min.Options... options)
Factory method to create a class wrapping a new Min operation.
|
static <T,U extends Number> |
QuantizedReshape.create(Scope scope,
Operand<T> tensor,
Operand<U> shape,
Operand<Float> inputMin,
Operand<Float> inputMax)
Factory method to create a class wrapping a new QuantizedReshape operation.
|
static <T,U extends Number> |
QuantizedReshape.create(Scope scope,
Operand<T> tensor,
Operand<U> shape,
Operand<Float> inputMin,
Operand<Float> inputMax)
Factory method to create a class wrapping a new QuantizedReshape operation.
|
static <T,U extends Number> |
QuantizedReshape.create(Scope scope,
Operand<T> tensor,
Operand<U> shape,
Operand<Float> inputMin,
Operand<Float> inputMax)
Factory method to create a class wrapping a new QuantizedReshape operation.
|
static <T,U extends Number> |
QuantizedReshape.create(Scope scope,
Operand<T> tensor,
Operand<U> shape,
Operand<Float> inputMin,
Operand<Float> inputMax)
Factory method to create a class wrapping a new QuantizedReshape operation.
|
static <V,T,U> QuantizedConv2DAndRelu<V> |
QuantizedConv2DAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRelu operation.
|
static <V,T,U> QuantizedConv2DAndRelu<V> |
QuantizedConv2DAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRelu operation.
|
static <V,T,U> QuantizedConv2DAndRelu<V> |
QuantizedConv2DAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRelu operation.
|
static <V,T,U> QuantizedConv2DAndRelu<V> |
QuantizedConv2DAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRelu operation.
|
static <V,T,U> QuantizedConv2DAndRelu<V> |
QuantizedConv2DAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRelu operation.
|
static <V,T,U> QuantizedConv2DAndRelu<V> |
QuantizedConv2DAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRelu operation.
|
static <V,T,U> QuantizedConv2DPerChannel<V> |
QuantizedConv2DPerChannel.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DPerChannel.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DPerChannel operation.
|
static <V,T,U> QuantizedConv2DPerChannel<V> |
QuantizedConv2DPerChannel.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DPerChannel.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DPerChannel operation.
|
static <V,T,U> QuantizedConv2DPerChannel<V> |
QuantizedConv2DPerChannel.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DPerChannel.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DPerChannel operation.
|
static <V,T,U> QuantizedConv2DPerChannel<V> |
QuantizedConv2DPerChannel.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DPerChannel.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DPerChannel operation.
|
static <V,T,U> QuantizedConv2DPerChannel<V> |
QuantizedConv2DPerChannel.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DPerChannel.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DPerChannel operation.
|
static <V,T,U> QuantizedConv2DPerChannel<V> |
QuantizedConv2DPerChannel.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DPerChannel.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DPerChannel operation.
|
static <V,T,U> QuantizedDepthwiseConv2D<V> |
QuantizedDepthwiseConv2D.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2D.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2D operation.
|
static <V,T,U> QuantizedDepthwiseConv2D<V> |
QuantizedDepthwiseConv2D.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2D.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2D operation.
|
static <V,T,U> QuantizedDepthwiseConv2D<V> |
QuantizedDepthwiseConv2D.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2D.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2D operation.
|
static <V,T,U> QuantizedDepthwiseConv2D<V> |
QuantizedDepthwiseConv2D.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2D.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2D operation.
|
static <V,T,U> QuantizedDepthwiseConv2D<V> |
QuantizedDepthwiseConv2D.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2D.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2D operation.
|
static <V,T,U> QuantizedDepthwiseConv2D<V> |
QuantizedDepthwiseConv2D.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2D.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2D operation.
|
static <V,T,U> QuantizedConv2DWithBias<V> |
QuantizedConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBias operation.
|
static <V,T,U> QuantizedConv2DWithBias<V> |
QuantizedConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBias operation.
|
static <V,T,U> QuantizedConv2DWithBias<V> |
QuantizedConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBias operation.
|
static <V,T,U> QuantizedConv2DWithBias<V> |
QuantizedConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBias operation.
|
static <V,T,U> QuantizedConv2DWithBias<V> |
QuantizedConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBias operation.
|
static <V,T,U> QuantizedConv2DWithBias<V> |
QuantizedConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBias operation.
|
static <V,T,U> QuantizedConv2DWithBias<V> |
QuantizedConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBias operation.
|
static <V,T,U> QuantizedConv2DWithBiasAndRelu<V> |
QuantizedConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasAndRelu<V> |
QuantizedConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasAndRelu<V> |
QuantizedConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasAndRelu<V> |
QuantizedConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasAndRelu<V> |
QuantizedConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasAndRelu<V> |
QuantizedConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasAndRelu<V> |
QuantizedConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBias<V> |
QuantizedDepthwiseConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBias operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBias<V> |
QuantizedDepthwiseConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBias operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBias<V> |
QuantizedDepthwiseConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBias operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBias<V> |
QuantizedDepthwiseConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBias operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBias<V> |
QuantizedDepthwiseConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBias operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBias<V> |
QuantizedDepthwiseConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBias operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBias<V> |
QuantizedDepthwiseConv2DWithBias.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBias operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBiasAndRelu<V> |
QuantizedDepthwiseConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBiasAndRelu<V> |
QuantizedDepthwiseConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBiasAndRelu<V> |
QuantizedDepthwiseConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBiasAndRelu<V> |
QuantizedDepthwiseConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBiasAndRelu<V> |
QuantizedDepthwiseConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBiasAndRelu<V> |
QuantizedDepthwiseConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedDepthwiseConv2DWithBiasAndRelu<V> |
QuantizedDepthwiseConv2DWithBiasAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndRelu operation.
|
static <V,T,U> QuantizedMatMulWithBiasAndRelu<V> |
QuantizedMatMulWithBiasAndRelu.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
QuantizedMatMulWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndRelu operation.
|
static <V,T,U> QuantizedMatMulWithBiasAndRelu<V> |
QuantizedMatMulWithBiasAndRelu.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
QuantizedMatMulWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndRelu operation.
|
static <V,T,U> QuantizedMatMulWithBiasAndRelu<V> |
QuantizedMatMulWithBiasAndRelu.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
QuantizedMatMulWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndRelu operation.
|
static <V,T,U> QuantizedMatMulWithBiasAndRelu<V> |
QuantizedMatMulWithBiasAndRelu.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
QuantizedMatMulWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndRelu operation.
|
static <V,T,U> QuantizedMatMulWithBiasAndRelu<V> |
QuantizedMatMulWithBiasAndRelu.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
QuantizedMatMulWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndRelu operation.
|
static <V,T,U> QuantizedMatMulWithBiasAndRelu<V> |
QuantizedMatMulWithBiasAndRelu.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
QuantizedMatMulWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndRelu operation.
|
static <V,T,U> QuantizedMatMulWithBiasAndRelu<V> |
QuantizedMatMulWithBiasAndRelu.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
QuantizedMatMulWithBiasAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndRelu operation.
|
static <V,T,U> QuantizedConv2DAndReluAndRequantize<V> |
QuantizedConv2DAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndReluAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndReluAndRequantize<V> |
QuantizedConv2DAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndReluAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndReluAndRequantize<V> |
QuantizedConv2DAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndReluAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndReluAndRequantize<V> |
QuantizedConv2DAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndReluAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndReluAndRequantize<V> |
QuantizedConv2DAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndReluAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndReluAndRequantize<V> |
QuantizedConv2DAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndReluAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndReluAndRequantize<V> |
QuantizedConv2DAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndReluAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndReluAndRequantize<V> |
QuantizedConv2DAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndReluAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndRequantize<V> |
QuantizedConv2DAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndRequantize<V> |
QuantizedConv2DAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndRequantize<V> |
QuantizedConv2DAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndRequantize<V> |
QuantizedConv2DAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndRequantize<V> |
QuantizedConv2DAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndRequantize<V> |
QuantizedConv2DAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndRequantize<V> |
QuantizedConv2DAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRequantize operation.
|
static <V,T,U> QuantizedConv2DAndRequantize<V> |
QuantizedConv2DAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DAndRequantize operation.
|
static <V,T,U> QuantizedConv2DWithBiasSumAndRelu<V> |
QuantizedConv2DWithBiasSumAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> summand,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasSumAndRelu<V> |
QuantizedConv2DWithBiasSumAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> summand,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasSumAndRelu<V> |
QuantizedConv2DWithBiasSumAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> summand,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasSumAndRelu<V> |
QuantizedConv2DWithBiasSumAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> summand,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasSumAndRelu<V> |
QuantizedConv2DWithBiasSumAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> summand,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasSumAndRelu<V> |
QuantizedConv2DWithBiasSumAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> summand,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasSumAndRelu<V> |
QuantizedConv2DWithBiasSumAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> summand,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndRelu operation.
|
static <V,T,U> QuantizedConv2DWithBiasSumAndRelu<V> |
QuantizedConv2DWithBiasSumAndRelu.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> summand,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndRelu.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndRelu operation.
|
static <T,U extends Number> |
SplitV.create(Scope scope,
Operand<T> value,
Operand<U> sizeSplits,
Operand<Integer> axis,
Long numSplit)
Factory method to create a class wrapping a new SplitV operation.
|
static <T,U extends Number> |
SplitV.create(Scope scope,
Operand<T> value,
Operand<U> sizeSplits,
Operand<Integer> axis,
Long numSplit)
Factory method to create a class wrapping a new SplitV operation.
|
static <T,U extends Number> |
SplitV.create(Scope scope,
Operand<T> value,
Operand<U> sizeSplits,
Operand<Integer> axis,
Long numSplit)
Factory method to create a class wrapping a new SplitV operation.
|
static <T,U extends Number> |
TensorListSplit.create(Scope scope,
Operand<T> tensor,
Operand<U> elementShape,
Operand<Long> lengths)
Factory method to create a class wrapping a new TensorListSplit operation.
|
static <T,U extends Number> |
TensorListSplit.create(Scope scope,
Operand<T> tensor,
Operand<U> elementShape,
Operand<Long> lengths)
Factory method to create a class wrapping a new TensorListSplit operation.
|
static <T,U extends Number> |
TensorListSplit.create(Scope scope,
Operand<T> tensor,
Operand<U> elementShape,
Operand<Long> lengths)
Factory method to create a class wrapping a new TensorListSplit operation.
|
static <T,U extends Number> |
Pad.create(Scope scope,
Operand<T> input,
Operand<U> paddings,
Operand<T> constantValues)
Factory method to create a class wrapping a new Pad operation.
|
static <T,U extends Number> |
Pad.create(Scope scope,
Operand<T> input,
Operand<U> paddings,
Operand<T> constantValues)
Factory method to create a class wrapping a new Pad operation.
|
static <T,U extends Number> |
Pad.create(Scope scope,
Operand<T> input,
Operand<U> paddings,
Operand<T> constantValues)
Factory method to create a class wrapping a new Pad operation.
|
static <T,U extends Number> |
TensorScatterSub.create(Scope scope,
Operand<T> tensor,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new TensorScatterSub operation.
|
static <T,U extends Number> |
TensorScatterSub.create(Scope scope,
Operand<T> tensor,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new TensorScatterSub operation.
|
static <T,U extends Number> |
TensorScatterSub.create(Scope scope,
Operand<T> tensor,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new TensorScatterSub operation.
|
static <T,U extends Number> |
ScatterNdNonAliasingAdd.create(Scope scope,
Operand<T> input,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new ScatterNdNonAliasingAdd operation.
|
static <T,U extends Number> |
ScatterNdNonAliasingAdd.create(Scope scope,
Operand<T> input,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new ScatterNdNonAliasingAdd operation.
|
static <T,U extends Number> |
ScatterNdNonAliasingAdd.create(Scope scope,
Operand<T> input,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new ScatterNdNonAliasingAdd operation.
|
static <T,U extends Number> |
TensorScatterUpdate.create(Scope scope,
Operand<T> tensor,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new TensorScatterUpdate operation.
|
static <T,U extends Number> |
TensorScatterUpdate.create(Scope scope,
Operand<T> tensor,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new TensorScatterUpdate operation.
|
static <T,U extends Number> |
TensorScatterUpdate.create(Scope scope,
Operand<T> tensor,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new TensorScatterUpdate operation.
|
static <T,U extends Number> |
TensorScatterAdd.create(Scope scope,
Operand<T> tensor,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new TensorScatterAdd operation.
|
static <T,U extends Number> |
TensorScatterAdd.create(Scope scope,
Operand<T> tensor,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new TensorScatterAdd operation.
|
static <T,U extends Number> |
TensorScatterAdd.create(Scope scope,
Operand<T> tensor,
Operand<U> indices,
Operand<T> updates)
Factory method to create a class wrapping a new TensorScatterAdd operation.
|
static <U,T extends Number> |
ScatterNd.create(Scope scope,
Operand<T> indices,
Operand<U> updates,
Operand<T> shape)
Factory method to create a class wrapping a new ScatterNd operation.
|
static <U,T extends Number> |
ScatterNd.create(Scope scope,
Operand<T> indices,
Operand<U> updates,
Operand<T> shape)
Factory method to create a class wrapping a new ScatterNd operation.
|
static <U,T extends Number> |
ScatterNd.create(Scope scope,
Operand<T> indices,
Operand<U> updates,
Operand<T> shape)
Factory method to create a class wrapping a new ScatterNd operation.
|
static <T,U extends Number> |
ScatterAdd.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterAdd.Options... options)
Factory method to create a class wrapping a new ScatterAdd operation.
|
static <T,U extends Number> |
ScatterAdd.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterAdd.Options... options)
Factory method to create a class wrapping a new ScatterAdd operation.
|
static <T,U extends Number> |
ScatterAdd.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterAdd.Options... options)
Factory method to create a class wrapping a new ScatterAdd operation.
|
static <T,U extends Number> |
ScatterDiv.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterDiv.Options... options)
Factory method to create a class wrapping a new ScatterDiv operation.
|
static <T,U extends Number> |
ScatterDiv.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterDiv.Options... options)
Factory method to create a class wrapping a new ScatterDiv operation.
|
static <T,U extends Number> |
ScatterDiv.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterDiv.Options... options)
Factory method to create a class wrapping a new ScatterDiv operation.
|
static <T extends Number,U extends Number> |
ScatterMax.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterMax.Options... options)
Factory method to create a class wrapping a new ScatterMax operation.
|
static <T extends Number,U extends Number> |
ScatterMax.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterMax.Options... options)
Factory method to create a class wrapping a new ScatterMax operation.
|
static <T extends Number,U extends Number> |
ScatterMax.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterMax.Options... options)
Factory method to create a class wrapping a new ScatterMax operation.
|
static <T extends Number,U extends Number> |
ScatterMin.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterMin.Options... options)
Factory method to create a class wrapping a new ScatterMin operation.
|
static <T extends Number,U extends Number> |
ScatterMin.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterMin.Options... options)
Factory method to create a class wrapping a new ScatterMin operation.
|
static <T extends Number,U extends Number> |
ScatterMin.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterMin.Options... options)
Factory method to create a class wrapping a new ScatterMin operation.
|
static <T,U extends Number> |
ScatterMul.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterMul.Options... options)
Factory method to create a class wrapping a new ScatterMul operation.
|
static <T,U extends Number> |
ScatterMul.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterMul.Options... options)
Factory method to create a class wrapping a new ScatterMul operation.
|
static <T,U extends Number> |
ScatterMul.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterMul.Options... options)
Factory method to create a class wrapping a new ScatterMul operation.
|
static <T,U extends Number> |
ScatterNdAdd.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterNdAdd.Options... options)
Factory method to create a class wrapping a new ScatterNdAdd operation.
|
static <T,U extends Number> |
ScatterNdAdd.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterNdAdd.Options... options)
Factory method to create a class wrapping a new ScatterNdAdd operation.
|
static <T,U extends Number> |
ScatterNdAdd.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterNdAdd.Options... options)
Factory method to create a class wrapping a new ScatterNdAdd operation.
|
static <T,U extends Number> |
ScatterNdSub.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterNdSub.Options... options)
Factory method to create a class wrapping a new ScatterNdSub operation.
|
static <T,U extends Number> |
ScatterNdSub.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterNdSub.Options... options)
Factory method to create a class wrapping a new ScatterNdSub operation.
|
static <T,U extends Number> |
ScatterNdSub.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterNdSub.Options... options)
Factory method to create a class wrapping a new ScatterNdSub operation.
|
static <T,U extends Number> |
ScatterNdUpdate.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterNdUpdate.Options... options)
Factory method to create a class wrapping a new ScatterNdUpdate operation.
|
static <T,U extends Number> |
ScatterNdUpdate.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterNdUpdate.Options... options)
Factory method to create a class wrapping a new ScatterNdUpdate operation.
|
static <T,U extends Number> |
ScatterNdUpdate.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterNdUpdate.Options... options)
Factory method to create a class wrapping a new ScatterNdUpdate operation.
|
static <T,U extends Number> |
ScatterSub.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterSub.Options... options)
Factory method to create a class wrapping a new ScatterSub operation.
|
static <T,U extends Number> |
ScatterSub.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterSub.Options... options)
Factory method to create a class wrapping a new ScatterSub operation.
|
static <T,U extends Number> |
ScatterSub.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterSub.Options... options)
Factory method to create a class wrapping a new ScatterSub operation.
|
static <T,U extends Number> |
ScatterUpdate.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterUpdate.Options... options)
Factory method to create a class wrapping a new ScatterUpdate operation.
|
static <T,U extends Number> |
ScatterUpdate.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterUpdate.Options... options)
Factory method to create a class wrapping a new ScatterUpdate operation.
|
static <T,U extends Number> |
ScatterUpdate.create(Scope scope,
Operand<T> ref,
Operand<U> indices,
Operand<T> updates,
ScatterUpdate.Options... options)
Factory method to create a class wrapping a new ScatterUpdate operation.
|
static <T,U extends Number> |
Slice.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> size)
Factory method to create a class wrapping a new Slice operation.
|
static <T,U extends Number> |
Slice.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> size)
Factory method to create a class wrapping a new Slice operation.
|
static <T,U extends Number> |
Slice.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> size)
Factory method to create a class wrapping a new Slice operation.
|
static <U,T extends Number,V extends Number> |
RaggedTensorToTensor.create(Scope scope,
Operand<T> shape,
Operand<U> values,
Operand<U> defaultValue,
Iterable<Operand<V>> rowPartitionTensors,
List<String> rowPartitionTypes)
Factory method to create a class wrapping a new RaggedTensorToTensor operation.
|
static <U,T extends Number,V extends Number> |
RaggedTensorToTensor.create(Scope scope,
Operand<T> shape,
Operand<U> values,
Operand<U> defaultValue,
Iterable<Operand<V>> rowPartitionTensors,
List<String> rowPartitionTypes)
Factory method to create a class wrapping a new RaggedTensorToTensor operation.
|
static <U,T extends Number,V extends Number> |
RaggedTensorToTensor.create(Scope scope,
Operand<T> shape,
Operand<U> values,
Operand<U> defaultValue,
Iterable<Operand<V>> rowPartitionTensors,
List<String> rowPartitionTypes)
Factory method to create a class wrapping a new RaggedTensorToTensor operation.
|
static <T,U extends Number> |
StridedSliceAssign.create(Scope scope,
Operand<T> ref,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
Operand<T> value,
StridedSliceAssign.Options... options)
Factory method to create a class wrapping a new StridedSliceAssign operation.
|
static <T,U extends Number> |
StridedSliceAssign.create(Scope scope,
Operand<T> ref,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
Operand<T> value,
StridedSliceAssign.Options... options)
Factory method to create a class wrapping a new StridedSliceAssign operation.
|
static <T,U extends Number> |
StridedSliceAssign.create(Scope scope,
Operand<T> ref,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
Operand<T> value,
StridedSliceAssign.Options... options)
Factory method to create a class wrapping a new StridedSliceAssign operation.
|
static <T,U extends Number> |
StridedSliceAssign.create(Scope scope,
Operand<T> ref,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
Operand<T> value,
StridedSliceAssign.Options... options)
Factory method to create a class wrapping a new StridedSliceAssign operation.
|
static <T,U extends Number> |
StridedSliceAssign.create(Scope scope,
Operand<T> ref,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
Operand<T> value,
StridedSliceAssign.Options... options)
Factory method to create a class wrapping a new StridedSliceAssign operation.
|
static <T,U extends Number> |
TensorStridedSliceUpdate.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
Operand<T> value,
TensorStridedSliceUpdate.Options... options)
Factory method to create a class wrapping a new TensorStridedSliceUpdate operation.
|
static <T,U extends Number> |
TensorStridedSliceUpdate.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
Operand<T> value,
TensorStridedSliceUpdate.Options... options)
Factory method to create a class wrapping a new TensorStridedSliceUpdate operation.
|
static <T,U extends Number> |
TensorStridedSliceUpdate.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
Operand<T> value,
TensorStridedSliceUpdate.Options... options)
Factory method to create a class wrapping a new TensorStridedSliceUpdate operation.
|
static <T,U extends Number> |
TensorStridedSliceUpdate.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
Operand<T> value,
TensorStridedSliceUpdate.Options... options)
Factory method to create a class wrapping a new TensorStridedSliceUpdate operation.
|
static <T,U extends Number> |
TensorStridedSliceUpdate.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
Operand<T> value,
TensorStridedSliceUpdate.Options... options)
Factory method to create a class wrapping a new TensorStridedSliceUpdate operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormV3.create(Scope scope,
Operand<T> x,
Operand<U> scale,
Operand<U> offset,
Operand<U> mean,
Operand<U> variance,
FusedBatchNormV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormV3 operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormV3.create(Scope scope,
Operand<T> x,
Operand<U> scale,
Operand<U> offset,
Operand<U> mean,
Operand<U> variance,
FusedBatchNormV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormV3 operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormV3.create(Scope scope,
Operand<T> x,
Operand<U> scale,
Operand<U> offset,
Operand<U> mean,
Operand<U> variance,
FusedBatchNormV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormV3 operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormV3.create(Scope scope,
Operand<T> x,
Operand<U> scale,
Operand<U> offset,
Operand<U> mean,
Operand<U> variance,
FusedBatchNormV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormV3 operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormV3.create(Scope scope,
Operand<T> x,
Operand<U> scale,
Operand<U> offset,
Operand<U> mean,
Operand<U> variance,
FusedBatchNormV3.Options... options)
Factory method to create a class wrapping a new FusedBatchNormV3 operation.
|
static <T,U extends Number> |
StridedSlice.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
StridedSlice.Options... options)
Factory method to create a class wrapping a new StridedSlice operation.
|
static <T,U extends Number> |
StridedSlice.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
StridedSlice.Options... options)
Factory method to create a class wrapping a new StridedSlice operation.
|
static <T,U extends Number> |
StridedSlice.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
StridedSlice.Options... options)
Factory method to create a class wrapping a new StridedSlice operation.
|
static <T,U extends Number> |
StridedSlice.create(Scope scope,
Operand<T> input,
Operand<U> begin,
Operand<U> end,
Operand<U> strides,
StridedSlice.Options... options)
Factory method to create a class wrapping a new StridedSlice operation.
|
static <T,U extends Number,V extends Number> |
SpaceToBatchNd.create(Scope scope,
Operand<T> input,
Operand<U> blockShape,
Operand<V> paddings)
Factory method to create a class wrapping a new SpaceToBatchNd operation.
|
static <T,U extends Number,V extends Number> |
SpaceToBatchNd.create(Scope scope,
Operand<T> input,
Operand<U> blockShape,
Operand<V> paddings)
Factory method to create a class wrapping a new SpaceToBatchNd operation.
|
static <T,U extends Number,V extends Number> |
SpaceToBatchNd.create(Scope scope,
Operand<T> input,
Operand<U> blockShape,
Operand<V> paddings)
Factory method to create a class wrapping a new SpaceToBatchNd operation.
|
static <T,U extends Number,V extends Number> |
BatchToSpaceNd.create(Scope scope,
Operand<T> input,
Operand<U> blockShape,
Operand<V> crops)
Factory method to create a class wrapping a new BatchToSpaceNd operation.
|
static <T,U extends Number,V extends Number> |
BatchToSpaceNd.create(Scope scope,
Operand<T> input,
Operand<U> blockShape,
Operand<V> crops)
Factory method to create a class wrapping a new BatchToSpaceNd operation.
|
static <T,U extends Number,V extends Number> |
BatchToSpaceNd.create(Scope scope,
Operand<T> input,
Operand<U> blockShape,
Operand<V> crops)
Factory method to create a class wrapping a new BatchToSpaceNd operation.
|
static <T,U extends Number,V extends Number> |
Roll.create(Scope scope,
Operand<T> input,
Operand<U> shift,
Operand<V> axis)
Factory method to create a class wrapping a new Roll operation.
|
static <T,U extends Number,V extends Number> |
Roll.create(Scope scope,
Operand<T> input,
Operand<U> shift,
Operand<V> axis)
Factory method to create a class wrapping a new Roll operation.
|
static <T,U extends Number,V extends Number> |
Roll.create(Scope scope,
Operand<T> input,
Operand<U> shift,
Operand<V> axis)
Factory method to create a class wrapping a new Roll operation.
|
static <T,U extends Number,V extends Number> |
Gather.create(Scope scope,
Operand<T> params,
Operand<U> indices,
Operand<V> axis,
Gather.Options... options)
Factory method to create a class wrapping a new Gather operation.
|
static <T,U extends Number,V extends Number> |
Gather.create(Scope scope,
Operand<T> params,
Operand<U> indices,
Operand<V> axis,
Gather.Options... options)
Factory method to create a class wrapping a new Gather operation.
|
static <T,U extends Number,V extends Number> |
Gather.create(Scope scope,
Operand<T> params,
Operand<U> indices,
Operand<V> axis,
Gather.Options... options)
Factory method to create a class wrapping a new Gather operation.
|
static <W,T,U,V> QuantizedMatMulWithBias<W> |
QuantizedMatMulWithBias.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<W> Toutput,
QuantizedMatMulWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBias operation.
|
static <W,T,U,V> QuantizedMatMulWithBias<W> |
QuantizedMatMulWithBias.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<W> Toutput,
QuantizedMatMulWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBias operation.
|
static <W,T,U,V> QuantizedMatMulWithBias<W> |
QuantizedMatMulWithBias.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<W> Toutput,
QuantizedMatMulWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBias operation.
|
static <W,T,U,V> QuantizedMatMulWithBias<W> |
QuantizedMatMulWithBias.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<W> Toutput,
QuantizedMatMulWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBias operation.
|
static <W,T,U,V> QuantizedMatMulWithBias<W> |
QuantizedMatMulWithBias.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<W> Toutput,
QuantizedMatMulWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBias operation.
|
static <W,T,U,V> QuantizedMatMulWithBias<W> |
QuantizedMatMulWithBias.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<W> Toutput,
QuantizedMatMulWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBias operation.
|
static <W,T,U,V> QuantizedMatMulWithBias<W> |
QuantizedMatMulWithBias.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<W> Toutput,
QuantizedMatMulWithBias.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBias operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndReluAndRequantize<W> |
QuantizedConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndReluAndRequantize<W> |
QuantizedConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndReluAndRequantize<W> |
QuantizedConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndReluAndRequantize<W> |
QuantizedConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndReluAndRequantize<W> |
QuantizedConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndReluAndRequantize<W> |
QuantizedConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndReluAndRequantize<W> |
QuantizedConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndReluAndRequantize<W> |
QuantizedConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndReluAndRequantize<W> |
QuantizedConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndRequantize<W> |
QuantizedConv2DWithBiasAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndRequantize<W> |
QuantizedConv2DWithBiasAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndRequantize<W> |
QuantizedConv2DWithBiasAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndRequantize<W> |
QuantizedConv2DWithBiasAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndRequantize<W> |
QuantizedConv2DWithBiasAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndRequantize<W> |
QuantizedConv2DWithBiasAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndRequantize<W> |
QuantizedConv2DWithBiasAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndRequantize<W> |
QuantizedConv2DWithBiasAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRequantize operation.
|
static <W,T,U,V> QuantizedConv2DWithBiasAndRequantize<W> |
QuantizedConv2DWithBiasAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasAndRequantize operation.
|
static <W,T,U,V> QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize<W> |
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize<W> |
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize<W> |
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize<W> |
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize<W> |
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize<W> |
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize<W> |
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize<W> |
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize<W> |
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> outType,
List<Long> strides,
String padding,
QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedDepthwiseConv2DWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedMatMulWithBiasAndReluAndRequantize<W> |
QuantizedMatMulWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> Toutput,
QuantizedMatMulWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedMatMulWithBiasAndReluAndRequantize<W> |
QuantizedMatMulWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> Toutput,
QuantizedMatMulWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedMatMulWithBiasAndReluAndRequantize<W> |
QuantizedMatMulWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> Toutput,
QuantizedMatMulWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedMatMulWithBiasAndReluAndRequantize<W> |
QuantizedMatMulWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> Toutput,
QuantizedMatMulWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedMatMulWithBiasAndReluAndRequantize<W> |
QuantizedMatMulWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> Toutput,
QuantizedMatMulWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedMatMulWithBiasAndReluAndRequantize<W> |
QuantizedMatMulWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> Toutput,
QuantizedMatMulWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedMatMulWithBiasAndReluAndRequantize<W> |
QuantizedMatMulWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> Toutput,
QuantizedMatMulWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedMatMulWithBiasAndReluAndRequantize<W> |
QuantizedMatMulWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> Toutput,
QuantizedMatMulWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndReluAndRequantize operation.
|
static <W,T,U,V> QuantizedMatMulWithBiasAndReluAndRequantize<W> |
QuantizedMatMulWithBiasAndReluAndRequantize.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<V> bias,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Class<W> Toutput,
QuantizedMatMulWithBiasAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedMatMulWithBiasAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSignedSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSignedSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <X,T,U,V,W> |
QuantizedConv2DWithBiasSumAndReluAndRequantize.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<V> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Operand<Float> minFreezedOutput,
Operand<Float> maxFreezedOutput,
Operand<W> summand,
Operand<Float> minSummand,
Operand<Float> maxSummand,
Class<X> outType,
List<Long> strides,
String padding,
QuantizedConv2DWithBiasSumAndReluAndRequantize.Options... options)
Factory method to create a class wrapping a new QuantizedConv2DWithBiasSumAndReluAndRequantize operation.
|
static <T,U extends Number> |
Prod.create(Scope scope,
Operand<T> input,
Operand<U> axis,
Prod.Options... options)
Factory method to create a class wrapping a new Prod operation.
|
static <T,U extends Number> |
Prod.create(Scope scope,
Operand<T> input,
Operand<U> axis,
Prod.Options... options)
Factory method to create a class wrapping a new Prod operation.
|
static <T,U extends Number> |
ReduceMax.create(Scope scope,
Operand<T> input,
Operand<U> axis,
ReduceMax.Options... options)
Factory method to create a class wrapping a new ReduceMax operation.
|
static <T,U extends Number> |
ReduceMax.create(Scope scope,
Operand<T> input,
Operand<U> axis,
ReduceMax.Options... options)
Factory method to create a class wrapping a new ReduceMax operation.
|
static <T,U extends Number> |
ReduceMin.create(Scope scope,
Operand<T> input,
Operand<U> axis,
ReduceMin.Options... options)
Factory method to create a class wrapping a new ReduceMin operation.
|
static <T,U extends Number> |
ReduceMin.create(Scope scope,
Operand<T> input,
Operand<U> axis,
ReduceMin.Options... options)
Factory method to create a class wrapping a new ReduceMin operation.
|
static <T,U extends Number> |
ReduceProd.create(Scope scope,
Operand<T> input,
Operand<U> axis,
ReduceProd.Options... options)
Factory method to create a class wrapping a new ReduceProd operation.
|
static <T,U extends Number> |
ReduceProd.create(Scope scope,
Operand<T> input,
Operand<U> axis,
ReduceProd.Options... options)
Factory method to create a class wrapping a new ReduceProd operation.
|
static <T,U extends Number> |
ReduceSum.create(Scope scope,
Operand<T> input,
Operand<U> axis,
ReduceSum.Options... options)
Factory method to create a class wrapping a new ReduceSum operation.
|
static <T,U extends Number> |
ReduceSum.create(Scope scope,
Operand<T> input,
Operand<U> axis,
ReduceSum.Options... options)
Factory method to create a class wrapping a new ReduceSum operation.
|
static <T,U extends Number> |
MirrorPadGrad.create(Scope scope,
Operand<T> input,
Operand<U> paddings,
String mode)
Factory method to create a class wrapping a new MirrorPadGrad operation.
|
static <T,U extends Number> |
MirrorPadGrad.create(Scope scope,
Operand<T> input,
Operand<U> paddings,
String mode)
Factory method to create a class wrapping a new MirrorPadGrad operation.
|
static <T,U extends Number> |
MirrorPad.create(Scope scope,
Operand<T> input,
Operand<U> paddings,
String mode)
Factory method to create a class wrapping a new MirrorPad operation.
|
static <T,U extends Number> |
MirrorPad.create(Scope scope,
Operand<T> input,
Operand<U> paddings,
String mode)
Factory method to create a class wrapping a new MirrorPad operation.
|
static <T,U extends Number> |
Sum.create(Scope scope,
Operand<T> input,
Operand<U> axis,
Sum.Options... options)
Factory method to create a class wrapping a new Sum operation.
|
static <T,U extends Number> |
Sum.create(Scope scope,
Operand<T> input,
Operand<U> axis,
Sum.Options... options)
Factory method to create a class wrapping a new Sum operation.
|
static <T> Prelinearize |
Prelinearize.create(Scope scope,
Operand<T> input,
Prelinearize.Options... options)
Factory method to create a class wrapping a new Prelinearize operation.
|
static <T> EnsureShape<T> |
EnsureShape.create(Scope scope,
Operand<T> input,
Shape shape)
Factory method to create a class wrapping a new EnsureShape operation.
|
static <T> PlaceholderWithDefault<T> |
PlaceholderWithDefault.create(Scope scope,
Operand<T> input,
Shape shape)
Factory method to create a class wrapping a new PlaceholderWithDefault operation.
|
static <T extends Number> |
NcclBroadcast.create(Scope scope,
Operand<T> input,
Shape shape)
Factory method to create a class wrapping a new NcclBroadcast operation.
|
static <T> Squeeze<T> |
Squeeze.create(Scope scope,
Operand<T> input,
Squeeze.Options... options)
Factory method to create a class wrapping a new Squeeze operation.
|
static <T> DestroyTemporaryVariable<T> |
DestroyTemporaryVariable.create(Scope scope,
Operand<T> ref,
String varName)
Factory method to create a class wrapping a new DestroyTemporaryVariable operation.
|
static <T> Enter<T> |
Enter.create(Scope scope,
Operand<T> data,
String frameName,
Enter.Options... options)
Factory method to create a class wrapping a new Enter operation.
|
static <T extends Number> |
NcclAllReduce.create(Scope scope,
Operand<T> input,
String reduction,
Long numDevices,
String sharedName)
Factory method to create a class wrapping a new NcclAllReduce operation.
|
static <T> RefEnter<T> |
RefEnter.create(Scope scope,
Operand<T> data,
String frameName,
RefEnter.Options... options)
Factory method to create a class wrapping a new RefEnter operation.
|
static <T,U extends Number> |
Zeros.create(Scope scope,
Operand<U> dims,
Class<T> type)
Creates a zeroed tensor given its type and shape.
|
Modifier and Type | Method and Description |
---|---|
static Gradients |
Gradients.create(Scope scope,
Iterable<? extends Operand<?>> y,
Iterable<? extends Operand<?>> x,
Gradients.Options... options)
Adds gradients computation ops to the graph according to scope.
|
static Gradients |
Gradients.create(Scope scope,
Iterable<? extends Operand<?>> y,
Iterable<? extends Operand<?>> x,
Gradients.Options... options)
Adds gradients computation ops to the graph according to scope.
|
static OutfeedEnqueueTuple |
OutfeedEnqueueTuple.create(Scope scope,
Iterable<Operand<?>> inputs)
Factory method to create a class wrapping a new OutfeedEnqueueTuple operation.
|
static IdentityN |
IdentityN.create(Scope scope,
Iterable<Operand<?>> input)
Factory method to create a class wrapping a new IdentityN operation.
|
static RemoteFusedGraphExecute |
RemoteFusedGraphExecute.create(Scope scope,
Iterable<Operand<?>> inputs,
List<Class<?>> Toutputs,
String serializedRemoteFusedGraphExecuteInfo)
Factory method to create a class wrapping a new RemoteFusedGraphExecute operation.
|
static InfeedEnqueueTuple |
InfeedEnqueueTuple.create(Scope scope,
Iterable<Operand<?>> inputs,
List<Shape> shapes,
InfeedEnqueueTuple.Options... options)
Factory method to create a class wrapping a new InfeedEnqueueTuple operation.
|
static PrelinearizeTuple |
PrelinearizeTuple.create(Scope scope,
Iterable<Operand<?>> inputs,
List<Shape> shapes,
PrelinearizeTuple.Options... options)
Factory method to create a class wrapping a new PrelinearizeTuple operation.
|
static ChooseFastestDataset |
ChooseFastestDataset.create(Scope scope,
Iterable<Operand<?>> inputDatasets,
Long numExperiments,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ChooseFastestDataset operation.
|
static ExperimentalChooseFastestDataset |
ExperimentalChooseFastestDataset.create(Scope scope,
Iterable<Operand<?>> inputDatasets,
Long numExperiments,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalChooseFastestDataset operation.
|
static Batch |
Batch.create(Scope scope,
Iterable<Operand<?>> inTensors,
Long numBatchThreads,
Long maxBatchSize,
Long batchTimeoutMicros,
Long gradTimeoutMicros,
Batch.Options... options)
Factory method to create a class wrapping a new Batch operation.
|
static Stage |
Stage.create(Scope scope,
Iterable<Operand<?>> values,
Stage.Options... options)
Factory method to create a class wrapping a new Stage operation.
|
static BoostedTreesBucketize |
BoostedTreesBucketize.create(Scope scope,
Iterable<Operand<Float>> floatValues,
Iterable<Operand<Float>> bucketBoundaries)
Factory method to create a class wrapping a new BoostedTreesBucketize operation.
|
static BoostedTreesBucketize |
BoostedTreesBucketize.create(Scope scope,
Iterable<Operand<Float>> floatValues,
Iterable<Operand<Float>> bucketBoundaries)
Factory method to create a class wrapping a new BoostedTreesBucketize operation.
|
static SendTPUEmbeddingGradients |
SendTPUEmbeddingGradients.create(Scope scope,
Iterable<Operand<Float>> inputs,
Iterable<Operand<Float>> learningRates,
String config)
Factory method to create a class wrapping a new SendTPUEmbeddingGradients operation.
|
static SendTPUEmbeddingGradients |
SendTPUEmbeddingGradients.create(Scope scope,
Iterable<Operand<Float>> inputs,
Iterable<Operand<Float>> learningRates,
String config)
Factory method to create a class wrapping a new SendTPUEmbeddingGradients operation.
|
static BoostedTreesMakeQuantileSummaries |
BoostedTreesMakeQuantileSummaries.create(Scope scope,
Iterable<Operand<Float>> floatValues,
Operand<Float> exampleWeights,
Operand<Float> epsilon)
Factory method to create a class wrapping a new BoostedTreesMakeQuantileSummaries operation.
|
static <T> DynamicStitch<T> |
DynamicStitch.create(Scope scope,
Iterable<Operand<Integer>> indices,
Iterable<Operand<T>> data)
Factory method to create a class wrapping a new DynamicStitch operation.
|
static <T> DynamicStitch<T> |
DynamicStitch.create(Scope scope,
Iterable<Operand<Integer>> indices,
Iterable<Operand<T>> data)
Factory method to create a class wrapping a new DynamicStitch operation.
|
static <T> ParallelDynamicStitch<T> |
ParallelDynamicStitch.create(Scope scope,
Iterable<Operand<Integer>> indices,
Iterable<Operand<T>> data)
Factory method to create a class wrapping a new ParallelDynamicStitch operation.
|
static <T> ParallelDynamicStitch<T> |
ParallelDynamicStitch.create(Scope scope,
Iterable<Operand<Integer>> indices,
Iterable<Operand<T>> data)
Factory method to create a class wrapping a new ParallelDynamicStitch operation.
|
static EnqueueTPUEmbeddingIntegerBatch |
EnqueueTPUEmbeddingIntegerBatch.create(Scope scope,
Iterable<Operand<Integer>> batch,
Operand<String> modeOverride,
EnqueueTPUEmbeddingIntegerBatch.Options... options)
Factory method to create a class wrapping a new EnqueueTPUEmbeddingIntegerBatch operation.
|
static <T> TPUReplicatedInput<T> |
TPUReplicatedInput.create(Scope scope,
Iterable<Operand<T>> inputs)
Factory method to create a class wrapping a new TPUReplicatedInput operation.
|
static <T> Merge<T> |
Merge.create(Scope scope,
Iterable<Operand<T>> inputs)
Factory method to create a class wrapping a new Merge operation.
|
static <T> ShapeN<Integer> |
ShapeN.create(Scope scope,
Iterable<Operand<T>> input)
Factory method to create a class wrapping a new ShapeN operation using default output types.
|
static <T> RefMerge<T> |
RefMerge.create(Scope scope,
Iterable<Operand<T>> inputs)
Factory method to create a class wrapping a new RefMerge operation.
|
static <U extends Number,T> |
ShapeN.create(Scope scope,
Iterable<Operand<T>> input,
Class<U> outType)
Factory method to create a class wrapping a new ShapeN operation.
|
static <T extends Number,U extends Number,V extends Number> |
EnqueueTPUEmbeddingSparseBatch.create(Scope scope,
Iterable<Operand<T>> sampleIndices,
Iterable<Operand<U>> embeddingIndices,
Iterable<Operand<V>> aggregationWeights,
Operand<String> modeOverride,
EnqueueTPUEmbeddingSparseBatch.Options... options)
Factory method to create a class wrapping a new EnqueueTPUEmbeddingSparseBatch operation.
|
static <T extends Number,U extends Number,V extends Number> |
EnqueueTPUEmbeddingSparseBatch.create(Scope scope,
Iterable<Operand<T>> sampleIndices,
Iterable<Operand<U>> embeddingIndices,
Iterable<Operand<V>> aggregationWeights,
Operand<String> modeOverride,
EnqueueTPUEmbeddingSparseBatch.Options... options)
Factory method to create a class wrapping a new EnqueueTPUEmbeddingSparseBatch operation.
|
static <T extends Number,U extends Number,V extends Number> |
EnqueueTPUEmbeddingSparseBatch.create(Scope scope,
Iterable<Operand<T>> sampleIndices,
Iterable<Operand<U>> embeddingIndices,
Iterable<Operand<V>> aggregationWeights,
Operand<String> modeOverride,
EnqueueTPUEmbeddingSparseBatch.Options... options)
Factory method to create a class wrapping a new EnqueueTPUEmbeddingSparseBatch operation.
|
static <T extends Number,U extends Number,V extends Number> |
EnqueueTPUEmbeddingSparseTensorBatch.create(Scope scope,
Iterable<Operand<T>> sampleIndices,
Iterable<Operand<U>> embeddingIndices,
Iterable<Operand<V>> aggregationWeights,
Operand<String> modeOverride,
List<Long> tableIds,
EnqueueTPUEmbeddingSparseTensorBatch.Options... options)
Factory method to create a class wrapping a new EnqueueTPUEmbeddingSparseTensorBatch operation.
|
static <T extends Number,U extends Number,V extends Number> |
EnqueueTPUEmbeddingSparseTensorBatch.create(Scope scope,
Iterable<Operand<T>> sampleIndices,
Iterable<Operand<U>> embeddingIndices,
Iterable<Operand<V>> aggregationWeights,
Operand<String> modeOverride,
List<Long> tableIds,
EnqueueTPUEmbeddingSparseTensorBatch.Options... options)
Factory method to create a class wrapping a new EnqueueTPUEmbeddingSparseTensorBatch operation.
|
static <T extends Number,U extends Number,V extends Number> |
EnqueueTPUEmbeddingSparseTensorBatch.create(Scope scope,
Iterable<Operand<T>> sampleIndices,
Iterable<Operand<U>> embeddingIndices,
Iterable<Operand<V>> aggregationWeights,
Operand<String> modeOverride,
List<Long> tableIds,
EnqueueTPUEmbeddingSparseTensorBatch.Options... options)
Factory method to create a class wrapping a new EnqueueTPUEmbeddingSparseTensorBatch operation.
|
static <T,U extends Number> |
Concat.create(Scope scope,
Iterable<Operand<T>> values,
Operand<U> axis)
Factory method to create a class wrapping a new Concat operation.
|
static <U,T extends Number> |
RaggedTensorToSparse.create(Scope scope,
Iterable<Operand<T>> rtNestedSplits,
Operand<U> rtDenseValues)
Factory method to create a class wrapping a new RaggedTensorToSparse operation.
|
static <T extends Number,U> |
RaggedTensorToVariant.create(Scope scope,
Iterable<Operand<T>> rtNestedSplits,
Operand<U> rtDenseValues,
Boolean batchedInput)
Factory method to create a class wrapping a new RaggedTensorToVariant operation.
|
static <T extends Number,U,V extends Number> |
RaggedGather.create(Scope scope,
Iterable<Operand<T>> paramsNestedSplits,
Operand<U> paramsDenseValues,
Operand<V> indices,
Long OUTPUTRAGGEDRANK)
Factory method to create a class wrapping a new RaggedGather operation.
|
static <T> ParallelConcat<T> |
ParallelConcat.create(Scope scope,
Iterable<Operand<T>> values,
Shape shape)
Factory method to create a class wrapping a new ParallelConcat operation.
|
static <T> Stack<T> |
Stack.create(Scope scope,
Iterable<Operand<T>> values,
Stack.Options... options)
Factory method to create a class wrapping a new Stack operation.
|
static <T> Einsum<T> |
Einsum.create(Scope scope,
Iterable<Operand<T>> inputs,
String equation)
Factory method to create a class wrapping a new Einsum operation.
|
static <T extends Number> |
NcclReduce.create(Scope scope,
Iterable<Operand<T>> input,
String reduction)
Factory method to create a class wrapping a new NcclReduce operation.
|
static Gradients |
Gradients.create(Scope scope,
Operand<?> y,
Iterable<? extends Operand<?>> x,
Gradients.Options... options)
Adds gradients computation ops to the graph according to scope.
|
static DirectedInterleaveDataset |
DirectedInterleaveDataset.create(Scope scope,
Operand<?> selectorInputDataset,
Iterable<Operand<?>> dataInputDatasets,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new DirectedInterleaveDataset operation.
|
static DeleteMultiDeviceIterator |
DeleteMultiDeviceIterator.create(Scope scope,
Operand<?> multiDeviceIterator,
Iterable<Operand<?>> iterators,
Operand<?> deleter)
Factory method to create a class wrapping a new DeleteMultiDeviceIterator operation.
|
static BoostedTreesQuantileStreamResourceDeserialize |
BoostedTreesQuantileStreamResourceDeserialize.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Iterable<Operand<Float>> bucketBoundaries)
Factory method to create a class wrapping a new BoostedTreesQuantileStreamResourceDeserialize operation.
|
static BoostedTreesQuantileStreamResourceAddSummaries |
BoostedTreesQuantileStreamResourceAddSummaries.create(Scope scope,
Operand<?> quantileStreamResourceHandle,
Iterable<Operand<Float>> summaries)
Factory method to create a class wrapping a new BoostedTreesQuantileStreamResourceAddSummaries operation.
|
static BoostedTreesPredict |
BoostedTreesPredict.create(Scope scope,
Operand<?> treeEnsembleHandle,
Iterable<Operand<Integer>> bucketizedFeatures,
Long logitsDimension)
Factory method to create a class wrapping a new BoostedTreesPredict operation.
|
static BoostedTreesExampleDebugOutputs |
BoostedTreesExampleDebugOutputs.create(Scope scope,
Operand<?> treeEnsembleHandle,
Iterable<Operand<Integer>> bucketizedFeatures,
Long logitsDimension)
Factory method to create a class wrapping a new BoostedTreesExampleDebugOutputs operation.
|
static BoostedTreesUpdateEnsemble |
BoostedTreesUpdateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Long pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsemble operation.
|
static BoostedTreesUpdateEnsemble |
BoostedTreesUpdateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Long pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsemble operation.
|
static BoostedTreesUpdateEnsemble |
BoostedTreesUpdateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Long pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsemble operation.
|
static BoostedTreesUpdateEnsemble |
BoostedTreesUpdateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Long pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsemble operation.
|
static BoostedTreesUpdateEnsemble |
BoostedTreesUpdateEnsemble.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Long pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsemble operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesUpdateEnsembleV2 |
BoostedTreesUpdateEnsembleV2.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> featureIds,
Iterable<Operand<Integer>> dimensionIds,
Iterable<Operand<Integer>> nodeIds,
Iterable<Operand<Float>> gains,
Iterable<Operand<Integer>> thresholds,
Iterable<Operand<Float>> leftNodeContribs,
Iterable<Operand<Float>> rightNodeContribs,
Iterable<Operand<String>> splitTypes,
Operand<Integer> maxDepth,
Operand<Float> learningRate,
Operand<Integer> pruningMode)
Factory method to create a class wrapping a new BoostedTreesUpdateEnsembleV2 operation.
|
static BoostedTreesTrainingPredict |
BoostedTreesTrainingPredict.create(Scope scope,
Operand<?> treeEnsembleHandle,
Operand<Integer> cachedTreeIds,
Operand<Integer> cachedNodeIds,
Iterable<Operand<Integer>> bucketizedFeatures,
Long logitsDimension)
Factory method to create a class wrapping a new BoostedTreesTrainingPredict operation.
|
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 wrapping a new ExperimentalParseExampleDataset operation.
|
static AssertThat |
AssertThat.create(Scope scope,
Operand<Boolean> condition,
Iterable<Operand<?>> data,
AssertThat.Options... options)
Factory method to create a class wrapping a new AssertThat operation.
|
static EncodeProto |
EncodeProto.create(Scope scope,
Operand<Integer> sizes,
Iterable<Operand<?>> values,
List<String> fieldNames,
String messageType,
EncodeProto.Options... options)
Factory method to create a class wrapping a new EncodeProto operation.
|
static BoostedTreesCalculateBestGainsPerFeature |
BoostedTreesCalculateBestGainsPerFeature.create(Scope scope,
Operand<Integer> nodeIdRange,
Iterable<Operand<Float>> statsSummaryList,
Operand<Float> l1,
Operand<Float> l2,
Operand<Float> treeComplexity,
Operand<Float> minNodeWeight,
Long maxSplits)
Factory method to create a class wrapping a new BoostedTreesCalculateBestGainsPerFeature operation.
|
static <T> RefSelect<T> |
RefSelect.create(Scope scope,
Operand<Integer> index,
Iterable<Operand<T>> inputs)
Factory method to create a class wrapping a new RefSelect operation.
|
static <T> QuantizedConcat<T> |
QuantizedConcat.create(Scope scope,
Operand<Integer> concatDim,
Iterable<Operand<T>> values,
Iterable<Operand<Float>> inputMins,
Iterable<Operand<Float>> inputMaxes)
Factory method to create a class wrapping a new QuantizedConcat operation.
|
static <T> QuantizedConcat<T> |
QuantizedConcat.create(Scope scope,
Operand<Integer> concatDim,
Iterable<Operand<T>> values,
Iterable<Operand<Float>> inputMins,
Iterable<Operand<Float>> inputMaxes)
Factory method to create a class wrapping a new QuantizedConcat operation.
|
static <T> QuantizedConcat<T> |
QuantizedConcat.create(Scope scope,
Operand<Integer> concatDim,
Iterable<Operand<T>> values,
Iterable<Operand<Float>> inputMins,
Iterable<Operand<Float>> inputMaxes)
Factory method to create a class wrapping a new QuantizedConcat operation.
|
static BoostedTreesMakeStatsSummary |
BoostedTreesMakeStatsSummary.create(Scope scope,
Operand<Integer> nodeIds,
Operand<Float> gradients,
Operand<Float> hessians,
Iterable<Operand<Integer>> bucketizedFeaturesList,
Long maxSplits,
Long numBuckets)
Factory method to create a class wrapping a new BoostedTreesMakeStatsSummary operation.
|
static <T extends Number> |
CudnnRNNCanonicalToParamsV2.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRNNCanonicalToParamsV2.Options... options)
Factory method to create a class wrapping a new CudnnRNNCanonicalToParamsV2 operation.
|
static <T extends Number> |
CudnnRNNCanonicalToParamsV2.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRNNCanonicalToParamsV2.Options... options)
Factory method to create a class wrapping a new CudnnRNNCanonicalToParamsV2 operation.
|
static MapStage |
MapStage.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
Iterable<Operand<?>> values,
List<Class<?>> dtypes,
MapStage.Options... options)
Factory method to create a class wrapping a new MapStage operation.
|
static OrderedMapStage |
OrderedMapStage.create(Scope scope,
Operand<Long> key,
Operand<Integer> indices,
Iterable<Operand<?>> values,
List<Class<?>> dtypes,
OrderedMapStage.Options... options)
Factory method to create a class wrapping a new OrderedMapStage operation.
|
static CSVDataset |
CSVDataset.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 wrapping a new CSVDataset operation.
|
static <U,T extends Number,V extends Number> |
RaggedTensorToTensor.create(Scope scope,
Operand<T> shape,
Operand<U> values,
Operand<U> defaultValue,
Iterable<Operand<V>> rowPartitionTensors,
List<String> rowPartitionTypes)
Factory method to create a class wrapping a new RaggedTensorToTensor operation.
|
static Gradients.Options |
Gradients.dx(Iterable<? extends Operand<?>> dx) |
Gradients.Options |
Gradients.Options.dx(Iterable<? extends Operand<?>> dx) |
Modifier and Type | Class and Description |
---|---|
class |
AnonymousIterator
A container for an iterator resource.
|
class |
BatchDataset
Creates a dataset that batches `batch_size` elements from `input_dataset`.
|
class |
BytesProducedStatsDataset
Records the bytes size of each element of `input_dataset` in a StatsAggregator.
|
class |
CacheDataset
Creates a dataset that caches elements from `input_dataset`.
|
class |
ConcatenateDataset
Creates a dataset that concatenates `input_dataset` with `another_dataset`.
|
class |
DatasetToGraph
Returns a serialized GraphDef representing `input_dataset`.
|
class |
DenseToSparseBatchDataset
Creates a dataset that batches input elements into a SparseTensor.
|
class |
ExperimentalAssertNextDataset |
class |
ExperimentalCsvDataset |
class |
ExperimentalDirectedInterleaveDataset
A substitute for `InterleaveDataset` on a fixed list of `N` datasets.
|
class |
ExperimentalIgnoreErrorsDataset
Creates a dataset that contains the elements of `input_dataset` ignoring errors.
|
class |
ExperimentalIteratorGetDevice
Returns the name of the device on which `resource` has been placed.
|
class |
ExperimentalLmdbDataset |
class |
ExperimentalNonSerializableDataset |
class |
ExperimentalSleepDataset |
class |
ExperimentalThreadPoolDataset
Creates a dataset that uses a custom thread pool to compute `input_dataset`.
|
class |
ExperimentalThreadPoolHandle
Creates a dataset that uses a custom thread pool to compute `input_dataset`.
|
class |
ExperimentalUniqueDataset
Creates a dataset that contains the unique elements of `input_dataset`.
|
class |
FilterByLastComponentDataset
Creates a dataset containing elements of first component of `input_dataset` having true in the last component.
|
class |
FixedLengthRecordDataset |
class |
Iterator |
class |
IteratorFromStringHandle |
class |
IteratorGetNextAsOptional
Gets the next output from the given iterator as an Optional variant.
|
class |
IteratorToStringHandle
Converts the given `resource_handle` representing an iterator to a string.
|
class |
LatencyStatsDataset
Records the latency of producing `input_dataset` elements in a StatsAggregator.
|
class |
LeakyReluGrad<T extends Number>
Computes rectified linear gradients for a LeakyRelu operation.
|
class |
MatchingFilesDataset |
class |
ModelDataset
Identity transformation that models performance.
|
class |
MultiDeviceIterator
Creates a MultiDeviceIterator resource.
|
class |
MultiDeviceIteratorFromStringHandle
Generates a MultiDeviceIterator resource from its provided string handle.
|
class |
MultiDeviceIteratorInit
Initializes the multi device iterator with the given dataset.
|
class |
MultiDeviceIteratorToStringHandle
Produces a string handle for the given MultiDeviceIterator.
|
class |
OptimizeDataset
Creates a dataset by applying optimizations to `input_dataset`.
|
class |
OptionalFromValue
Constructs an Optional variant from a tuple of tensors.
|
class |
OptionalHasValue
Returns true if and only if the given Optional variant has a value.
|
class |
OptionalNone
Creates an Optional variant with no value.
|
class |
PaddedBatchDataset
Creates a dataset that batches and pads `batch_size` elements from the input.
|
class |
ParseExampleDataset
Transforms `input_dataset` containing `Example` protos as vectors of DT_STRING into a dataset of `Tensor` or `SparseTensor` objects representing the parsed features.
|
class |
PrefetchDataset
Creates a dataset that asynchronously prefetches elements from `input_dataset`.
|
class |
RandomDataset
Creates a Dataset that returns pseudorandom numbers.
|
class |
RangeDataset
Creates a dataset with a range of values.
|
class |
RepeatDataset
Creates a dataset that emits the outputs of `input_dataset` `count` times.
|
class |
SerializeIterator
Converts the given `resource_handle` representing an iterator to a variant tensor.
|
class |
SetStatsAggregatorDataset |
class |
ShuffleAndRepeatDataset
Creates a dataset that shuffles and repeats elements from `input_dataset`
|
class |
ShuffleDataset
Creates a dataset that shuffles elements from `input_dataset` pseudorandomly.
|
class |
SkipDataset
Creates a dataset that skips `count` elements from the `input_dataset`.
|
class |
SparseTensorSliceDataset
Creates a dataset that splits a SparseTensor into elements row-wise.
|
class |
SqlDataset
Creates a dataset that executes a SQL query and emits rows of the result set.
|
class |
StatsAggregatorHandle
Creates a statistics manager resource.
|
class |
TakeDataset
Creates a dataset that contains `count` elements from the `input_dataset`.
|
class |
TensorDataset
Creates a dataset that emits `components` as a tuple of tensors once.
|
class |
TensorSliceDataset
Creates a dataset that emits each dim-0 slice of `components` once.
|
class |
TextLineDataset
Creates a dataset that emits the lines of one or more text files.
|
class |
TfRecordDataset
Creates a dataset that emits the records from one or more TFRecord files.
|
class |
UnbatchDataset
A dataset that splits the elements of its input into multiple elements.
|
class |
WindowDataset
A dataset that creates window datasets from the input dataset.
|
class |
ZipDataset
Creates a dataset that zips together `input_datasets`.
|
Modifier and Type | Method and Description |
---|---|
Iterator<Operand<Object>> |
OptionalGetValue.iterator() |
Iterator<Operand<Object>> |
IteratorGetNextSync.iterator() |
Iterator<Operand<Object>> |
IteratorGetNext.iterator() |
Iterator<Operand<Object>> |
MultiDeviceIteratorGetNextFromShard.iterator() |
Iterator<Operand<Object>> |
DatasetToSingleElement.iterator() |
Modifier and Type | Method and Description |
---|---|
static OptionalHasValue |
OptionalHasValue.create(Scope scope,
Operand<?> optional)
Factory method to create a class wrapping a new OptionalHasValue operation.
|
static SerializeIterator |
SerializeIterator.create(Scope scope,
Operand<?> resourceHandle)
Factory method to create a class wrapping a new SerializeIterator operation.
|
static ExperimentalIteratorGetDevice |
ExperimentalIteratorGetDevice.create(Scope scope,
Operand<?> resource)
Factory method to create a class wrapping a new ExperimentalIteratorGetDevice operation.
|
static IteratorToStringHandle |
IteratorToStringHandle.create(Scope scope,
Operand<?> resourceHandle)
Factory method to create a class wrapping a new IteratorToStringHandle operation.
|
static MultiDeviceIteratorToStringHandle |
MultiDeviceIteratorToStringHandle.create(Scope scope,
Operand<?> multiDeviceIterator)
Factory method to create a class wrapping a new MultiDeviceIteratorToStringHandle operation.
|
static DatasetToGraph |
DatasetToGraph.create(Scope scope,
Operand<?> inputDataset,
DatasetToGraph.Options... options)
Factory method to create a class wrapping a new DatasetToGraph operation.
|
static ExperimentalDirectedInterleaveDataset |
ExperimentalDirectedInterleaveDataset.create(Scope scope,
Operand<?> selectorInputDataset,
Iterable<Operand<?>> dataInputDatasets,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalDirectedInterleaveDataset operation.
|
static ExperimentalUniqueDataset |
ExperimentalUniqueDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalUniqueDataset operation.
|
static FilterByLastComponentDataset |
FilterByLastComponentDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new FilterByLastComponentDataset operation.
|
static OptionalGetValue |
OptionalGetValue.create(Scope scope,
Operand<?> optional,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new OptionalGetValue operation.
|
static ExperimentalNonSerializableDataset |
ExperimentalNonSerializableDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalNonSerializableDataset operation.
|
static IteratorGetNextSync |
IteratorGetNextSync.create(Scope scope,
Operand<?> iterator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new IteratorGetNextSync operation.
|
static UnbatchDataset |
UnbatchDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new UnbatchDataset operation.
|
static ExperimentalIgnoreErrorsDataset |
ExperimentalIgnoreErrorsDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalIgnoreErrorsDataset operation.
|
static IteratorGetNext |
IteratorGetNext.create(Scope scope,
Operand<?> iterator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new IteratorGetNext operation.
|
static DatasetToSingleElement |
DatasetToSingleElement.create(Scope scope,
Operand<?> dataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new DatasetToSingleElement operation.
|
static IteratorGetNextAsOptional |
IteratorGetNextAsOptional.create(Scope scope,
Operand<?> iterator,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new IteratorGetNextAsOptional operation.
|
static ModelDataset |
ModelDataset.create(Scope scope,
Operand<?> inputDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
ModelDataset.Options... options)
Factory method to create a class wrapping a new ModelDataset operation.
|
static DeserializeIterator |
DeserializeIterator.create(Scope scope,
Operand<?> resourceHandle,
Operand<?> serialized)
Factory method to create a class wrapping a new DeserializeIterator operation.
|
static DeserializeIterator |
DeserializeIterator.create(Scope scope,
Operand<?> resourceHandle,
Operand<?> serialized)
Factory method to create a class wrapping a new DeserializeIterator operation.
|
static MakeIterator |
MakeIterator.create(Scope scope,
Operand<?> dataset,
Operand<?> iterator)
Factory method to create a class wrapping a new MakeIterator operation.
|
static MakeIterator |
MakeIterator.create(Scope scope,
Operand<?> dataset,
Operand<?> iterator)
Factory method to create a class wrapping a new MakeIterator operation.
|
static ConcatenateDataset |
ConcatenateDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<?> anotherDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ConcatenateDataset operation.
|
static ConcatenateDataset |
ConcatenateDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<?> anotherDataset,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ConcatenateDataset operation.
|
static ExperimentalThreadPoolDataset |
ExperimentalThreadPoolDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<?> threadPool,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalThreadPoolDataset operation.
|
static ExperimentalThreadPoolDataset |
ExperimentalThreadPoolDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<?> threadPool,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalThreadPoolDataset operation.
|
static MultiDeviceIteratorInit |
MultiDeviceIteratorInit.create(Scope scope,
Operand<?> dataset,
Operand<?> multiDeviceIterator,
Operand<Long> maxBufferSize)
Factory method to create a class wrapping a new MultiDeviceIteratorInit operation.
|
static MultiDeviceIteratorInit |
MultiDeviceIteratorInit.create(Scope scope,
Operand<?> dataset,
Operand<?> multiDeviceIterator,
Operand<Long> maxBufferSize)
Factory method to create a class wrapping a new MultiDeviceIteratorInit operation.
|
static MultiDeviceIteratorInit |
MultiDeviceIteratorInit.create(Scope scope,
Operand<?> dataset,
Operand<?> multiDeviceIterator,
Operand<Long> maxBufferSize)
Factory method to create a class wrapping a new MultiDeviceIteratorInit operation.
|
static SetStatsAggregatorDataset |
SetStatsAggregatorDataset.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 wrapping a new SetStatsAggregatorDataset operation.
|
static SetStatsAggregatorDataset |
SetStatsAggregatorDataset.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 wrapping a new SetStatsAggregatorDataset operation.
|
static SetStatsAggregatorDataset |
SetStatsAggregatorDataset.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 wrapping a new SetStatsAggregatorDataset operation.
|
static SetStatsAggregatorDataset |
SetStatsAggregatorDataset.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 wrapping a new SetStatsAggregatorDataset operation.
|
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 wrapping a new MultiDeviceIteratorGetNextFromShard operation.
|
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 wrapping a new MultiDeviceIteratorGetNextFromShard operation.
|
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 wrapping a new MultiDeviceIteratorGetNextFromShard operation.
|
static ParseExampleDataset |
ParseExampleDataset.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,
ParseExampleDataset.Options... options)
Factory method to create a class wrapping a new ParseExampleDataset operation.
|
static ParseExampleDataset |
ParseExampleDataset.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,
ParseExampleDataset.Options... options)
Factory method to create a class wrapping a new ParseExampleDataset operation.
|
static PaddedBatchDataset |
PaddedBatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Iterable<Operand<Long>> paddedShapes,
Iterable<Operand<?>> paddingValues,
Operand<Boolean> dropRemainder,
List<Shape> outputShapes,
PaddedBatchDataset.Options... options)
Factory method to create a class wrapping a new PaddedBatchDataset operation.
|
static PaddedBatchDataset |
PaddedBatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Iterable<Operand<Long>> paddedShapes,
Iterable<Operand<?>> paddingValues,
Operand<Boolean> dropRemainder,
List<Shape> outputShapes,
PaddedBatchDataset.Options... options)
Factory method to create a class wrapping a new PaddedBatchDataset operation.
|
static PaddedBatchDataset |
PaddedBatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Iterable<Operand<Long>> paddedShapes,
Iterable<Operand<?>> paddingValues,
Operand<Boolean> dropRemainder,
List<Shape> outputShapes,
PaddedBatchDataset.Options... options)
Factory method to create a class wrapping a new PaddedBatchDataset operation.
|
static TakeDataset |
TakeDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new TakeDataset operation.
|
static TakeDataset |
TakeDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new TakeDataset operation.
|
static SkipDataset |
SkipDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new SkipDataset operation.
|
static SkipDataset |
SkipDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new SkipDataset operation.
|
static RepeatDataset |
RepeatDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new RepeatDataset operation.
|
static RepeatDataset |
RepeatDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> count,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new RepeatDataset operation.
|
static ExperimentalSleepDataset |
ExperimentalSleepDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> sleepMicroseconds,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalSleepDataset operation.
|
static ExperimentalSleepDataset |
ExperimentalSleepDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> sleepMicroseconds,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalSleepDataset operation.
|
static PrefetchDataset |
PrefetchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> bufferSize,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
PrefetchDataset.Options... options)
Factory method to create a class wrapping a new PrefetchDataset operation.
|
static PrefetchDataset |
PrefetchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> bufferSize,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
PrefetchDataset.Options... options)
Factory method to create a class wrapping a new PrefetchDataset operation.
|
static BatchDataset |
BatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Operand<Boolean> dropRemainder,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
BatchDataset.Options... options)
Factory method to create a class wrapping a new BatchDataset operation.
|
static BatchDataset |
BatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Operand<Boolean> dropRemainder,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
BatchDataset.Options... options)
Factory method to create a class wrapping a new BatchDataset operation.
|
static BatchDataset |
BatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Operand<Boolean> dropRemainder,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
BatchDataset.Options... options)
Factory method to create a class wrapping a new BatchDataset operation.
|
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 wrapping a new DenseToSparseBatchDataset operation.
|
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 wrapping a new DenseToSparseBatchDataset operation.
|
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 wrapping a new DenseToSparseBatchDataset operation.
|
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 wrapping a new ShuffleDataset operation.
|
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 wrapping a new ShuffleDataset operation.
|
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 wrapping a new ShuffleDataset operation.
|
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 wrapping a new ShuffleDataset operation.
|
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 wrapping a new WindowDataset operation.
|
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 wrapping a new WindowDataset operation.
|
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 wrapping a new WindowDataset operation.
|
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 wrapping a new WindowDataset operation.
|
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 wrapping a new WindowDataset operation.
|
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 wrapping a new ShuffleAndRepeatDataset operation.
|
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 wrapping a new ShuffleAndRepeatDataset operation.
|
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 wrapping a new ShuffleAndRepeatDataset operation.
|
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 wrapping a new ShuffleAndRepeatDataset operation.
|
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 wrapping a new ShuffleAndRepeatDataset operation.
|
static LatencyStatsDataset |
LatencyStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new LatencyStatsDataset operation.
|
static LatencyStatsDataset |
LatencyStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new LatencyStatsDataset operation.
|
static CacheDataset |
CacheDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new CacheDataset operation.
|
static CacheDataset |
CacheDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new CacheDataset operation.
|
static ExperimentalAssertNextDataset |
ExperimentalAssertNextDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> transformations,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalAssertNextDataset operation.
|
static ExperimentalAssertNextDataset |
ExperimentalAssertNextDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> transformations,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalAssertNextDataset operation.
|
static BytesProducedStatsDataset |
BytesProducedStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new BytesProducedStatsDataset operation.
|
static BytesProducedStatsDataset |
BytesProducedStatsDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> tag,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new BytesProducedStatsDataset operation.
|
static OptimizeDataset |
OptimizeDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> optimizations,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
OptimizeDataset.Options... options)
Factory method to create a class wrapping a new OptimizeDataset operation.
|
static OptimizeDataset |
OptimizeDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<String> optimizations,
List<Class<?>> outputTypes,
List<Shape> outputShapes,
OptimizeDataset.Options... options)
Factory method to create a class wrapping a new OptimizeDataset operation.
|
static DatasetToTfRecord |
DatasetToTfRecord.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
Operand<String> compressionType)
Factory method to create a class wrapping a new DatasetToTfRecord operation.
|
static DatasetToTfRecord |
DatasetToTfRecord.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
Operand<String> compressionType)
Factory method to create a class wrapping a new DatasetToTfRecord operation.
|
static DatasetToTfRecord |
DatasetToTfRecord.create(Scope scope,
Operand<?> inputDataset,
Operand<String> filename,
Operand<String> compressionType)
Factory method to create a class wrapping a new DatasetToTfRecord operation.
|
static RandomDataset |
RandomDataset.create(Scope scope,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new RandomDataset operation.
|
static RandomDataset |
RandomDataset.create(Scope scope,
Operand<Long> seed,
Operand<Long> seed2,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new RandomDataset operation.
|
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 wrapping a new RangeDataset operation.
|
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 wrapping a new RangeDataset operation.
|
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 wrapping a new RangeDataset operation.
|
static <T> SparseTensorSliceDataset |
SparseTensorSliceDataset.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> denseShape)
Factory method to create a class wrapping a new SparseTensorSliceDataset operation.
|
static <T> SparseTensorSliceDataset |
SparseTensorSliceDataset.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> denseShape)
Factory method to create a class wrapping a new SparseTensorSliceDataset operation.
|
static <T> SparseTensorSliceDataset |
SparseTensorSliceDataset.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> denseShape)
Factory method to create a class wrapping a new SparseTensorSliceDataset operation.
|
static MatchingFilesDataset |
MatchingFilesDataset.create(Scope scope,
Operand<String> patterns)
Factory method to create a class wrapping a new MatchingFilesDataset operation.
|
static IteratorFromStringHandle |
IteratorFromStringHandle.create(Scope scope,
Operand<String> stringHandle,
List<Class<?>> outputTypes,
IteratorFromStringHandle.Options... options)
Factory method to create a class wrapping a new IteratorFromStringHandle operation.
|
static ExperimentalLmdbDataset |
ExperimentalLmdbDataset.create(Scope scope,
Operand<String> filenames,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalLmdbDataset operation.
|
static MultiDeviceIteratorFromStringHandle |
MultiDeviceIteratorFromStringHandle.create(Scope scope,
Operand<String> stringHandle,
List<Class<?>> outputTypes,
MultiDeviceIteratorFromStringHandle.Options... options)
Factory method to create a class wrapping a new MultiDeviceIteratorFromStringHandle operation.
|
static FixedLengthRecordDataset |
FixedLengthRecordDataset.create(Scope scope,
Operand<String> filenames,
Operand<Long> headerBytes,
Operand<Long> recordBytes,
Operand<Long> footerBytes,
Operand<Long> bufferSize,
Operand<String> compressionType)
Factory method to create a class wrapping a new FixedLengthRecordDataset operation.
|
static FixedLengthRecordDataset |
FixedLengthRecordDataset.create(Scope scope,
Operand<String> filenames,
Operand<Long> headerBytes,
Operand<Long> recordBytes,
Operand<Long> footerBytes,
Operand<Long> bufferSize,
Operand<String> compressionType)
Factory method to create a class wrapping a new FixedLengthRecordDataset operation.
|
static FixedLengthRecordDataset |
FixedLengthRecordDataset.create(Scope scope,
Operand<String> filenames,
Operand<Long> headerBytes,
Operand<Long> recordBytes,
Operand<Long> footerBytes,
Operand<Long> bufferSize,
Operand<String> compressionType)
Factory method to create a class wrapping a new FixedLengthRecordDataset operation.
|
static FixedLengthRecordDataset |
FixedLengthRecordDataset.create(Scope scope,
Operand<String> filenames,
Operand<Long> headerBytes,
Operand<Long> recordBytes,
Operand<Long> footerBytes,
Operand<Long> bufferSize,
Operand<String> compressionType)
Factory method to create a class wrapping a new FixedLengthRecordDataset operation.
|
static FixedLengthRecordDataset |
FixedLengthRecordDataset.create(Scope scope,
Operand<String> filenames,
Operand<Long> headerBytes,
Operand<Long> recordBytes,
Operand<Long> footerBytes,
Operand<Long> bufferSize,
Operand<String> compressionType)
Factory method to create a class wrapping a new FixedLengthRecordDataset operation.
|
static FixedLengthRecordDataset |
FixedLengthRecordDataset.create(Scope scope,
Operand<String> filenames,
Operand<Long> headerBytes,
Operand<Long> recordBytes,
Operand<Long> footerBytes,
Operand<Long> bufferSize,
Operand<String> compressionType)
Factory method to create a class wrapping a new FixedLengthRecordDataset operation.
|
static TextLineDataset |
TextLineDataset.create(Scope scope,
Operand<String> filenames,
Operand<String> compressionType,
Operand<Long> bufferSize)
Factory method to create a class wrapping a new TextLineDataset operation.
|
static TextLineDataset |
TextLineDataset.create(Scope scope,
Operand<String> filenames,
Operand<String> compressionType,
Operand<Long> bufferSize)
Factory method to create a class wrapping a new TextLineDataset operation.
|
static TextLineDataset |
TextLineDataset.create(Scope scope,
Operand<String> filenames,
Operand<String> compressionType,
Operand<Long> bufferSize)
Factory method to create a class wrapping a new TextLineDataset operation.
|
static TfRecordDataset |
TfRecordDataset.create(Scope scope,
Operand<String> filenames,
Operand<String> compressionType,
Operand<Long> bufferSize)
Factory method to create a class wrapping a new TfRecordDataset operation.
|
static TfRecordDataset |
TfRecordDataset.create(Scope scope,
Operand<String> filenames,
Operand<String> compressionType,
Operand<Long> bufferSize)
Factory method to create a class wrapping a new TfRecordDataset operation.
|
static TfRecordDataset |
TfRecordDataset.create(Scope scope,
Operand<String> filenames,
Operand<String> compressionType,
Operand<Long> bufferSize)
Factory method to create a class wrapping a new TfRecordDataset operation.
|
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 wrapping a new ExperimentalCsvDataset operation.
|
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 wrapping a new ExperimentalCsvDataset operation.
|
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 wrapping a new ExperimentalCsvDataset operation.
|
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 wrapping a new ExperimentalCsvDataset operation.
|
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 wrapping a new ExperimentalCsvDataset operation.
|
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 wrapping a new ExperimentalCsvDataset operation.
|
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 wrapping a new ExperimentalCsvDataset operation.
|
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 wrapping a new ExperimentalCsvDataset operation.
|
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 wrapping a new SqlDataset operation.
|
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 wrapping a new SqlDataset operation.
|
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 wrapping a new SqlDataset operation.
|
static <T extends Number> |
LeakyReluGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> features,
LeakyReluGrad.Options... options)
Factory method to create a class wrapping a new LeakyReluGrad operation.
|
static <T extends Number> |
LeakyReluGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> features,
LeakyReluGrad.Options... options)
Factory method to create a class wrapping a new LeakyReluGrad operation.
|
Modifier and Type | Method and Description |
---|---|
static OptionalFromValue |
OptionalFromValue.create(Scope scope,
Iterable<Operand<?>> components)
Factory method to create a class wrapping a new OptionalFromValue operation.
|
static ZipDataset |
ZipDataset.create(Scope scope,
Iterable<Operand<?>> inputDatasets,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ZipDataset operation.
|
static TensorSliceDataset |
TensorSliceDataset.create(Scope scope,
Iterable<Operand<?>> components,
List<Shape> outputShapes)
Factory method to create a class wrapping a new TensorSliceDataset operation.
|
static TensorDataset |
TensorDataset.create(Scope scope,
Iterable<Operand<?>> components,
List<Shape> outputShapes)
Factory method to create a class wrapping a new TensorDataset operation.
|
static ExperimentalDirectedInterleaveDataset |
ExperimentalDirectedInterleaveDataset.create(Scope scope,
Operand<?> selectorInputDataset,
Iterable<Operand<?>> dataInputDatasets,
List<Class<?>> outputTypes,
List<Shape> outputShapes)
Factory method to create a class wrapping a new ExperimentalDirectedInterleaveDataset operation.
|
static ParseExampleDataset |
ParseExampleDataset.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,
ParseExampleDataset.Options... options)
Factory method to create a class wrapping a new ParseExampleDataset operation.
|
static PaddedBatchDataset |
PaddedBatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Iterable<Operand<Long>> paddedShapes,
Iterable<Operand<?>> paddingValues,
Operand<Boolean> dropRemainder,
List<Shape> outputShapes,
PaddedBatchDataset.Options... options)
Factory method to create a class wrapping a new PaddedBatchDataset operation.
|
static PaddedBatchDataset |
PaddedBatchDataset.create(Scope scope,
Operand<?> inputDataset,
Operand<Long> batchSize,
Iterable<Operand<Long>> paddedShapes,
Iterable<Operand<?>> paddingValues,
Operand<Boolean> dropRemainder,
List<Shape> outputShapes,
PaddedBatchDataset.Options... options)
Factory method to create a class wrapping a new PaddedBatchDataset operation.
|
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 wrapping a new ExperimentalCsvDataset operation.
|
Modifier and Type | Class and Description |
---|---|
class |
AsString
Converts each entry in the given tensor to strings.
|
class |
Cast<U>
Cast x of type SrcT to y of DstT.
|
class |
Complex<U>
Converts two real numbers to a complex number.
|
Modifier and Type | Method and Description |
---|---|
static <T> AsString |
AsString.create(Scope scope,
Operand<T> input,
AsString.Options... options)
Factory method to create a class wrapping a new AsString operation.
|
static <U,T> Cast<U> |
Cast.create(Scope scope,
Operand<T> x,
Class<U> DstT,
Cast.Options... options)
Factory method to create a class wrapping a new Cast operation.
|
static <U,T extends Number> |
Complex.create(Scope scope,
Operand<T> real,
Operand<T> imag,
Class<U> Tout)
Factory method to create a class wrapping a new Complex operation.
|
static <U,T extends Number> |
Complex.create(Scope scope,
Operand<T> real,
Operand<T> imag,
Class<U> Tout)
Factory method to create a class wrapping a new Complex operation.
|
Modifier and Type | Class and Description |
---|---|
class |
AdjustContrast<T extends Number>
Adjust the contrast of one or more images.
|
class |
AdjustHue<T extends Number>
Adjust the hue of one or more images.
|
class |
AdjustSaturation<T extends Number>
Adjust the saturation of one or more images.
|
class |
CropAndResize
Extracts crops from the input image tensor and resizes them.
|
class |
CropAndResizeGradBoxes
Computes the gradient of the crop_and_resize op wrt the input boxes tensor.
|
class |
CropAndResizeGradImage<T extends Number>
Computes the gradient of the crop_and_resize op wrt the input image tensor.
|
class |
DecodeAndCropJpeg
Decode and Crop a JPEG-encoded image to a uint8 tensor.
|
class |
DecodeBmp
Decode the first frame of a BMP-encoded image to a uint8 tensor.
|
class |
DecodeGif
Decode the frame(s) of a GIF-encoded image to a uint8 tensor.
|
class |
DecodeJpeg
Decode a JPEG-encoded image to a uint8 tensor.
|
class |
DecodePng<T extends Number>
Decode a PNG-encoded image to a uint8 or uint16 tensor.
|
class |
DrawBoundingBoxes<T extends Number>
Draw bounding boxes on a batch of images.
|
class |
EncodeJpeg
JPEG-encode an image.
|
class |
EncodeJpegVariableQuality
JPEG encode input image with provided compression quality.
|
class |
EncodePng
PNG-encode an image.
|
class |
ExtractGlimpse
Extracts a glimpse from the input tensor.
|
class |
ExtractImagePatches<T extends Number>
Extract `patches` from `images` and put them in the "depth" output dimension.
|
class |
ExtractJpegShape<T extends Number>
Extract the shape information of a JPEG-encoded image.
|
class |
HsvToRgb<T extends Number>
Convert one or more images from HSV to RGB.
|
class |
NonMaxSuppressionWithOverlaps
Greedily selects a subset of bounding boxes in descending order of score,
|
class |
RandomCrop<T extends Number>
Randomly crop `image`.
|
class |
ResizeArea
Resize `images` to `size` using area interpolation.
|
class |
ResizeBicubic
Resize `images` to `size` using bicubic interpolation.
|
class |
ResizeBicubicGrad<T extends Number>
Computes the gradient of bicubic interpolation.
|
class |
ResizeBilinear
Resize `images` to `size` using bilinear interpolation.
|
class |
ResizeBilinearGrad<T extends Number>
Computes the gradient of bilinear interpolation.
|
class |
ResizeNearestNeighbor<T extends Number>
Resize `images` to `size` using nearest neighbor interpolation.
|
class |
ResizeNearestNeighborGrad<T extends Number>
Computes the gradient of nearest neighbor interpolation.
|
class |
RgbToHsv<T extends Number>
Converts one or more images from RGB to HSV.
|
Modifier and Type | Method and Description |
---|---|
static NonMaxSuppressionWithOverlaps |
NonMaxSuppressionWithOverlaps.create(Scope scope,
Operand<Float> overlaps,
Operand<Float> scores,
Operand<Integer> maxOutputSize,
Operand<Float> overlapThreshold,
Operand<Float> scoreThreshold)
Factory method to create a class wrapping a new NonMaxSuppressionWithOverlaps operation.
|
static NonMaxSuppressionWithOverlaps |
NonMaxSuppressionWithOverlaps.create(Scope scope,
Operand<Float> overlaps,
Operand<Float> scores,
Operand<Integer> maxOutputSize,
Operand<Float> overlapThreshold,
Operand<Float> scoreThreshold)
Factory method to create a class wrapping a new NonMaxSuppressionWithOverlaps operation.
|
static NonMaxSuppressionWithOverlaps |
NonMaxSuppressionWithOverlaps.create(Scope scope,
Operand<Float> overlaps,
Operand<Float> scores,
Operand<Integer> maxOutputSize,
Operand<Float> overlapThreshold,
Operand<Float> scoreThreshold)
Factory method to create a class wrapping a new NonMaxSuppressionWithOverlaps operation.
|
static NonMaxSuppressionWithOverlaps |
NonMaxSuppressionWithOverlaps.create(Scope scope,
Operand<Float> overlaps,
Operand<Float> scores,
Operand<Integer> maxOutputSize,
Operand<Float> overlapThreshold,
Operand<Float> scoreThreshold)
Factory method to create a class wrapping a new NonMaxSuppressionWithOverlaps operation.
|
static NonMaxSuppressionWithOverlaps |
NonMaxSuppressionWithOverlaps.create(Scope scope,
Operand<Float> overlaps,
Operand<Float> scores,
Operand<Integer> maxOutputSize,
Operand<Float> overlapThreshold,
Operand<Float> scoreThreshold)
Factory method to create a class wrapping a new NonMaxSuppressionWithOverlaps operation.
|
static <T extends Number> |
CropAndResizeGradImage.create(Scope scope,
Operand<Float> grads,
Operand<Float> boxes,
Operand<Integer> boxInd,
Operand<Integer> imageSize,
Class<T> T,
CropAndResizeGradImage.Options... options)
Factory method to create a class wrapping a new CropAndResizeGradImage operation.
|
static <T extends Number> |
CropAndResizeGradImage.create(Scope scope,
Operand<Float> grads,
Operand<Float> boxes,
Operand<Integer> boxInd,
Operand<Integer> imageSize,
Class<T> T,
CropAndResizeGradImage.Options... options)
Factory method to create a class wrapping a new CropAndResizeGradImage operation.
|
static <T extends Number> |
CropAndResizeGradImage.create(Scope scope,
Operand<Float> grads,
Operand<Float> boxes,
Operand<Integer> boxInd,
Operand<Integer> imageSize,
Class<T> T,
CropAndResizeGradImage.Options... options)
Factory method to create a class wrapping a new CropAndResizeGradImage operation.
|
static <T extends Number> |
CropAndResizeGradImage.create(Scope scope,
Operand<Float> grads,
Operand<Float> boxes,
Operand<Integer> boxInd,
Operand<Integer> imageSize,
Class<T> T,
CropAndResizeGradImage.Options... options)
Factory method to create a class wrapping a new CropAndResizeGradImage operation.
|
static ExtractGlimpse |
ExtractGlimpse.create(Scope scope,
Operand<Float> input,
Operand<Integer> size,
Operand<Float> offsets,
ExtractGlimpse.Options... options)
Factory method to create a class wrapping a new ExtractGlimpse operation.
|
static ExtractGlimpse |
ExtractGlimpse.create(Scope scope,
Operand<Float> input,
Operand<Integer> size,
Operand<Float> offsets,
ExtractGlimpse.Options... options)
Factory method to create a class wrapping a new ExtractGlimpse operation.
|
static ExtractGlimpse |
ExtractGlimpse.create(Scope scope,
Operand<Float> input,
Operand<Integer> size,
Operand<Float> offsets,
ExtractGlimpse.Options... options)
Factory method to create a class wrapping a new ExtractGlimpse operation.
|
static <T extends Number> |
CropAndResizeGradBoxes.create(Scope scope,
Operand<Float> grads,
Operand<T> image,
Operand<Float> boxes,
Operand<Integer> boxInd,
CropAndResizeGradBoxes.Options... options)
Factory method to create a class wrapping a new CropAndResizeGradBoxes operation.
|
static <T extends Number> |
CropAndResizeGradBoxes.create(Scope scope,
Operand<Float> grads,
Operand<T> image,
Operand<Float> boxes,
Operand<Integer> boxInd,
CropAndResizeGradBoxes.Options... options)
Factory method to create a class wrapping a new CropAndResizeGradBoxes operation.
|
static <T extends Number> |
CropAndResizeGradBoxes.create(Scope scope,
Operand<Float> grads,
Operand<T> image,
Operand<Float> boxes,
Operand<Integer> boxInd,
CropAndResizeGradBoxes.Options... options)
Factory method to create a class wrapping a new CropAndResizeGradBoxes operation.
|
static <T extends Number> |
CropAndResizeGradBoxes.create(Scope scope,
Operand<Float> grads,
Operand<T> image,
Operand<Float> boxes,
Operand<Integer> boxInd,
CropAndResizeGradBoxes.Options... options)
Factory method to create a class wrapping a new CropAndResizeGradBoxes operation.
|
static <T extends Number> |
ResizeBicubicGrad.create(Scope scope,
Operand<Float> grads,
Operand<T> originalImage,
ResizeBicubicGrad.Options... options)
Factory method to create a class wrapping a new ResizeBicubicGrad operation.
|
static <T extends Number> |
ResizeBicubicGrad.create(Scope scope,
Operand<Float> grads,
Operand<T> originalImage,
ResizeBicubicGrad.Options... options)
Factory method to create a class wrapping a new ResizeBicubicGrad operation.
|
static <T extends Number> |
ResizeBilinearGrad.create(Scope scope,
Operand<Float> grads,
Operand<T> originalImage,
ResizeBilinearGrad.Options... options)
Factory method to create a class wrapping a new ResizeBilinearGrad operation.
|
static <T extends Number> |
ResizeBilinearGrad.create(Scope scope,
Operand<Float> grads,
Operand<T> originalImage,
ResizeBilinearGrad.Options... options)
Factory method to create a class wrapping a new ResizeBilinearGrad operation.
|
static DecodeGif |
DecodeGif.create(Scope scope,
Operand<String> contents)
Factory method to create a class wrapping a new DecodeGif operation.
|
static ExtractJpegShape<Integer> |
ExtractJpegShape.create(Scope scope,
Operand<String> contents)
Factory method to create a class wrapping a new ExtractJpegShape operation using default output types.
|
static <T extends Number> |
ExtractJpegShape.create(Scope scope,
Operand<String> contents,
Class<T> outputType)
Factory method to create a class wrapping a new ExtractJpegShape operation.
|
static <T extends Number> |
DecodePng.create(Scope scope,
Operand<String> contents,
Class<T> dtype,
DecodePng.Options... options)
Factory method to create a class wrapping a new DecodePng operation.
|
static DecodeBmp |
DecodeBmp.create(Scope scope,
Operand<String> contents,
DecodeBmp.Options... options)
Factory method to create a class wrapping a new DecodeBmp operation.
|
static DecodeJpeg |
DecodeJpeg.create(Scope scope,
Operand<String> contents,
DecodeJpeg.Options... options)
Factory method to create a class wrapping a new DecodeJpeg operation.
|
static DecodePng<UInt8> |
DecodePng.create(Scope scope,
Operand<String> contents,
DecodePng.Options... options)
Factory method to create a class wrapping a new DecodePng operation using default output types.
|
static DecodeAndCropJpeg |
DecodeAndCropJpeg.create(Scope scope,
Operand<String> contents,
Operand<Integer> cropWindow,
DecodeAndCropJpeg.Options... options)
Factory method to create a class wrapping a new DecodeAndCropJpeg operation.
|
static DecodeAndCropJpeg |
DecodeAndCropJpeg.create(Scope scope,
Operand<String> contents,
Operand<Integer> cropWindow,
DecodeAndCropJpeg.Options... options)
Factory method to create a class wrapping a new DecodeAndCropJpeg operation.
|
static <T extends Number> |
RgbToHsv.create(Scope scope,
Operand<T> images)
Factory method to create a class wrapping a new RgbToHsv operation.
|
static <T extends Number> |
HsvToRgb.create(Scope scope,
Operand<T> images)
Factory method to create a class wrapping a new HsvToRgb operation.
|
static <T extends Number> |
EncodePng.create(Scope scope,
Operand<T> image,
EncodePng.Options... options)
Factory method to create a class wrapping a new EncodePng operation.
|
static <T extends Number> |
ExtractImagePatches.create(Scope scope,
Operand<T> images,
List<Long> ksizes,
List<Long> strides,
List<Long> rates,
String padding)
Factory method to create a class wrapping a new ExtractImagePatches operation.
|
static <T extends Number> |
AdjustSaturation.create(Scope scope,
Operand<T> images,
Operand<Float> scale)
Factory method to create a class wrapping a new AdjustSaturation operation.
|
static <T extends Number> |
AdjustSaturation.create(Scope scope,
Operand<T> images,
Operand<Float> scale)
Factory method to create a class wrapping a new AdjustSaturation operation.
|
static <T extends Number> |
AdjustHue.create(Scope scope,
Operand<T> images,
Operand<Float> delta)
Factory method to create a class wrapping a new AdjustHue operation.
|
static <T extends Number> |
AdjustHue.create(Scope scope,
Operand<T> images,
Operand<Float> delta)
Factory method to create a class wrapping a new AdjustHue operation.
|
static <T extends Number> |
DrawBoundingBoxes.create(Scope scope,
Operand<T> images,
Operand<Float> boxes)
Factory method to create a class wrapping a new DrawBoundingBoxes operation.
|
static <T extends Number> |
DrawBoundingBoxes.create(Scope scope,
Operand<T> images,
Operand<Float> boxes)
Factory method to create a class wrapping a new DrawBoundingBoxes operation.
|
static <T extends Number> |
AdjustContrast.create(Scope scope,
Operand<T> images,
Operand<Float> contrastFactor)
Factory method to create a class wrapping a new AdjustContrast operation.
|
static <T extends Number> |
AdjustContrast.create(Scope scope,
Operand<T> images,
Operand<Float> contrastFactor)
Factory method to create a class wrapping a new AdjustContrast operation.
|
static <T extends Number> |
SampleDistortedBoundingBox.create(Scope scope,
Operand<T> imageSize,
Operand<Float> boundingBoxes,
Operand<Float> minObjectCovered,
SampleDistortedBoundingBox.Options... options)
Factory method to create a class wrapping a new SampleDistortedBoundingBox operation.
|
static <T extends Number> |
SampleDistortedBoundingBox.create(Scope scope,
Operand<T> imageSize,
Operand<Float> boundingBoxes,
Operand<Float> minObjectCovered,
SampleDistortedBoundingBox.Options... options)
Factory method to create a class wrapping a new SampleDistortedBoundingBox operation.
|
static <T extends Number> |
SampleDistortedBoundingBox.create(Scope scope,
Operand<T> imageSize,
Operand<Float> boundingBoxes,
Operand<Float> minObjectCovered,
SampleDistortedBoundingBox.Options... options)
Factory method to create a class wrapping a new SampleDistortedBoundingBox operation.
|
static <T extends Number> |
CropAndResize.create(Scope scope,
Operand<T> image,
Operand<Float> boxes,
Operand<Integer> boxInd,
Operand<Integer> cropSize,
CropAndResize.Options... options)
Factory method to create a class wrapping a new CropAndResize operation.
|
static <T extends Number> |
CropAndResize.create(Scope scope,
Operand<T> image,
Operand<Float> boxes,
Operand<Integer> boxInd,
Operand<Integer> cropSize,
CropAndResize.Options... options)
Factory method to create a class wrapping a new CropAndResize operation.
|
static <T extends Number> |
CropAndResize.create(Scope scope,
Operand<T> image,
Operand<Float> boxes,
Operand<Integer> boxInd,
Operand<Integer> cropSize,
CropAndResize.Options... options)
Factory method to create a class wrapping a new CropAndResize operation.
|
static <T extends Number> |
CropAndResize.create(Scope scope,
Operand<T> image,
Operand<Float> boxes,
Operand<Integer> boxInd,
Operand<Integer> cropSize,
CropAndResize.Options... options)
Factory method to create a class wrapping a new CropAndResize operation.
|
static <T> QuantizedResizeBilinear<T> |
QuantizedResizeBilinear.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
Operand<Float> min,
Operand<Float> max,
QuantizedResizeBilinear.Options... options)
Factory method to create a class wrapping a new QuantizedResizeBilinear operation.
|
static <T> QuantizedResizeBilinear<T> |
QuantizedResizeBilinear.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
Operand<Float> min,
Operand<Float> max,
QuantizedResizeBilinear.Options... options)
Factory method to create a class wrapping a new QuantizedResizeBilinear operation.
|
static <T> QuantizedResizeBilinear<T> |
QuantizedResizeBilinear.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
Operand<Float> min,
Operand<Float> max,
QuantizedResizeBilinear.Options... options)
Factory method to create a class wrapping a new QuantizedResizeBilinear operation.
|
static <T> QuantizedResizeBilinear<T> |
QuantizedResizeBilinear.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
Operand<Float> min,
Operand<Float> max,
QuantizedResizeBilinear.Options... options)
Factory method to create a class wrapping a new QuantizedResizeBilinear operation.
|
static <T extends Number> |
ResizeArea.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
ResizeArea.Options... options)
Factory method to create a class wrapping a new ResizeArea operation.
|
static <T extends Number> |
ResizeArea.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
ResizeArea.Options... options)
Factory method to create a class wrapping a new ResizeArea operation.
|
static <T extends Number> |
ResizeBicubic.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
ResizeBicubic.Options... options)
Factory method to create a class wrapping a new ResizeBicubic operation.
|
static <T extends Number> |
ResizeBicubic.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
ResizeBicubic.Options... options)
Factory method to create a class wrapping a new ResizeBicubic operation.
|
static <T extends Number> |
ResizeBilinear.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
ResizeBilinear.Options... options)
Factory method to create a class wrapping a new ResizeBilinear operation.
|
static <T extends Number> |
ResizeBilinear.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
ResizeBilinear.Options... options)
Factory method to create a class wrapping a new ResizeBilinear operation.
|
static <T extends Number> |
ResizeNearestNeighbor.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
ResizeNearestNeighbor.Options... options)
Factory method to create a class wrapping a new ResizeNearestNeighbor operation.
|
static <T extends Number> |
ResizeNearestNeighbor.create(Scope scope,
Operand<T> images,
Operand<Integer> size,
ResizeNearestNeighbor.Options... options)
Factory method to create a class wrapping a new ResizeNearestNeighbor operation.
|
static <T extends Number> |
ResizeNearestNeighborGrad.create(Scope scope,
Operand<T> grads,
Operand<Integer> size,
ResizeNearestNeighborGrad.Options... options)
Factory method to create a class wrapping a new ResizeNearestNeighborGrad operation.
|
static <T extends Number> |
ResizeNearestNeighborGrad.create(Scope scope,
Operand<T> grads,
Operand<Integer> size,
ResizeNearestNeighborGrad.Options... options)
Factory method to create a class wrapping a new ResizeNearestNeighborGrad operation.
|
static <T extends Number> |
RandomCrop.create(Scope scope,
Operand<T> image,
Operand<Long> size,
RandomCrop.Options... options)
Factory method to create a class wrapping a new RandomCrop operation.
|
static <T extends Number> |
RandomCrop.create(Scope scope,
Operand<T> image,
Operand<Long> size,
RandomCrop.Options... options)
Factory method to create a class wrapping a new RandomCrop operation.
|
static <T extends Number,U extends Number> |
NonMaxSuppression.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<U> iouThreshold,
Operand<U> scoreThreshold,
NonMaxSuppression.Options... options)
Factory method to create a class wrapping a new NonMaxSuppression operation.
|
static <T extends Number,U extends Number> |
NonMaxSuppression.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<U> iouThreshold,
Operand<U> scoreThreshold,
NonMaxSuppression.Options... options)
Factory method to create a class wrapping a new NonMaxSuppression operation.
|
static <T extends Number,U extends Number> |
NonMaxSuppression.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<U> iouThreshold,
Operand<U> scoreThreshold,
NonMaxSuppression.Options... options)
Factory method to create a class wrapping a new NonMaxSuppression operation.
|
static <T extends Number,U extends Number> |
NonMaxSuppression.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<U> iouThreshold,
Operand<U> scoreThreshold,
NonMaxSuppression.Options... options)
Factory method to create a class wrapping a new NonMaxSuppression operation.
|
static <T extends Number,U extends Number> |
NonMaxSuppression.create(Scope scope,
Operand<T> boxes,
Operand<T> scores,
Operand<Integer> maxOutputSize,
Operand<U> iouThreshold,
Operand<U> scoreThreshold,
NonMaxSuppression.Options... options)
Factory method to create a class wrapping a new NonMaxSuppression operation.
|
static EncodeJpeg |
EncodeJpeg.create(Scope scope,
Operand<UInt8> image,
EncodeJpeg.Options... options)
Factory method to create a class wrapping a new EncodeJpeg operation.
|
static EncodeJpegVariableQuality |
EncodeJpegVariableQuality.create(Scope scope,
Operand<UInt8> images,
Operand<Integer> quality)
Factory method to create a class wrapping a new EncodeJpegVariableQuality operation.
|
static EncodeJpegVariableQuality |
EncodeJpegVariableQuality.create(Scope scope,
Operand<UInt8> images,
Operand<Integer> quality)
Factory method to create a class wrapping a new EncodeJpegVariableQuality operation.
|
Modifier and Type | Class and Description |
---|---|
class |
BigQueryReader
A Reader that outputs rows from a BigQuery table as tensorflow Examples.
|
class |
DecodeBase64
Decode web-safe base64-encoded strings.
|
class |
DecodeCompressed
Decompress strings.
|
class |
DecodeJsonExample
Convert JSON-encoded Example records to binary protocol buffer strings.
|
class |
DecodeRaw<T>
Reinterpret the bytes of a string as a vector of numbers.
|
class |
EncodeBase64
Encode strings into web-safe base64 format.
|
class |
FifoQueue
A queue that produces elements in first-in first-out order.
|
class |
FixedLengthRecordReader
A Reader that outputs fixed-length records from a file.
|
class |
IdentityReader
A Reader that outputs the queued work as both the key and value.
|
class |
LmdbReader
A Reader that outputs the records from a LMDB file.
|
class |
MatchingFiles
Returns the set of files matching one or more glob patterns.
|
class |
PaddingFifoQueue
A queue that produces elements in first-in first-out order.
|
class |
ParseTensor<T>
Transforms a serialized tensorflow.TensorProto proto into a Tensor.
|
class |
PriorityQueue
A queue that produces elements sorted by the first component value.
|
class |
QueueIsClosed
Returns true if queue is closed.
|
class |
QueueSize
Computes the number of elements in the given queue.
|
class |
RandomShuffleQueue
A queue that randomizes the order of elements.
|
class |
ReaderNumRecordsProduced
Returns the number of records this Reader has produced.
|
class |
ReaderNumWorkUnitsCompleted
Returns the number of work units this Reader has finished processing.
|
class |
ReaderSerializeState
Produce a string tensor that encodes the state of a Reader.
|
class |
ReadFile
Reads and outputs the entire contents of the input filename.
|
class |
SerializeManySparse<U>
Serialize an `N`-minibatch `SparseTensor` into an `[N, 3]` `Tensor` object.
|
class |
SerializeSparse<U>
Serialize a `SparseTensor` into a `[3]` `Tensor` object.
|
class |
SerializeTensor
Transforms a Tensor into a serialized TensorProto proto.
|
class |
ShardedFilename
Generate a sharded filename.
|
class |
ShardedFilespec
Generate a glob pattern matching all sharded file names.
|
class |
TextLineReader
A Reader that outputs the lines of a file delimited by '\n'.
|
class |
TfRecordReader
A Reader that outputs the records from a TensorFlow Records file.
|
class |
WholeFileReader
A Reader that outputs the entire contents of a file as a value.
|
Modifier and Type | Method and Description |
---|---|
Iterator<Operand<Object>> |
QueueDequeueUpTo.iterator() |
Iterator<Operand<Object>> |
QueueDequeueMany.iterator() |
Iterator<Operand<Object>> |
DecodeCsv.iterator() |
Iterator<Operand<Object>> |
QueueDequeue.iterator() |
Modifier and Type | Method and Description |
---|---|
static ReaderNumWorkUnitsCompleted |
ReaderNumWorkUnitsCompleted.create(Scope scope,
Operand<?> readerHandle)
Factory method to create a class wrapping a new ReaderNumWorkUnitsCompleted operation.
|
static ReaderSerializeState |
ReaderSerializeState.create(Scope scope,
Operand<?> readerHandle)
Factory method to create a class wrapping a new ReaderSerializeState operation.
|
static ReaderNumRecordsProduced |
ReaderNumRecordsProduced.create(Scope scope,
Operand<?> readerHandle)
Factory method to create a class wrapping a new ReaderNumRecordsProduced operation.
|
static QueueSize |
QueueSize.create(Scope scope,
Operand<?> handle)
Factory method to create a class wrapping a new QueueSize operation.
|
static QueueIsClosed |
QueueIsClosed.create(Scope scope,
Operand<?> handle)
Factory method to create a class wrapping a new QueueIsClosed operation.
|
static ReaderReset |
ReaderReset.create(Scope scope,
Operand<?> readerHandle)
Factory method to create a class wrapping a new ReaderReset operation.
|
static QueueEnqueue |
QueueEnqueue.create(Scope scope,
Operand<?> handle,
Iterable<Operand<?>> components,
QueueEnqueue.Options... options)
Factory method to create a class wrapping a new QueueEnqueue operation.
|
static QueueEnqueueMany |
QueueEnqueueMany.create(Scope scope,
Operand<?> handle,
Iterable<Operand<?>> components,
QueueEnqueueMany.Options... options)
Factory method to create a class wrapping a new QueueEnqueueMany operation.
|
static QueueDequeue |
QueueDequeue.create(Scope scope,
Operand<?> handle,
List<Class<?>> componentTypes,
QueueDequeue.Options... options)
Factory method to create a class wrapping a new QueueDequeue operation.
|
static ReaderRead |
ReaderRead.create(Scope scope,
Operand<?> readerHandle,
Operand<?> queueHandle)
Factory method to create a class wrapping a new ReaderRead operation.
|
static ReaderRead |
ReaderRead.create(Scope scope,
Operand<?> readerHandle,
Operand<?> queueHandle)
Factory method to create a class wrapping a new ReaderRead operation.
|
static ReaderReadUpTo |
ReaderReadUpTo.create(Scope scope,
Operand<?> readerHandle,
Operand<?> queueHandle,
Operand<Long> numRecords)
Factory method to create a class wrapping a new ReaderReadUpTo operation.
|
static ReaderReadUpTo |
ReaderReadUpTo.create(Scope scope,
Operand<?> readerHandle,
Operand<?> queueHandle,
Operand<Long> numRecords)
Factory method to create a class wrapping a new ReaderReadUpTo operation.
|
static ReaderReadUpTo |
ReaderReadUpTo.create(Scope scope,
Operand<?> readerHandle,
Operand<?> queueHandle,
Operand<Long> numRecords)
Factory method to create a class wrapping a new ReaderReadUpTo operation.
|
static QueueDequeueMany |
QueueDequeueMany.create(Scope scope,
Operand<?> handle,
Operand<Integer> n,
List<Class<?>> componentTypes,
QueueDequeueMany.Options... options)
Factory method to create a class wrapping a new QueueDequeueMany operation.
|
static QueueDequeueMany |
QueueDequeueMany.create(Scope scope,
Operand<?> handle,
Operand<Integer> n,
List<Class<?>> componentTypes,
QueueDequeueMany.Options... options)
Factory method to create a class wrapping a new QueueDequeueMany operation.
|
static QueueDequeueUpTo |
QueueDequeueUpTo.create(Scope scope,
Operand<?> handle,
Operand<Integer> n,
List<Class<?>> componentTypes,
QueueDequeueUpTo.Options... options)
Factory method to create a class wrapping a new QueueDequeueUpTo operation.
|
static QueueDequeueUpTo |
QueueDequeueUpTo.create(Scope scope,
Operand<?> handle,
Operand<Integer> n,
List<Class<?>> componentTypes,
QueueDequeueUpTo.Options... options)
Factory method to create a class wrapping a new QueueDequeueUpTo operation.
|
static ReaderRestoreState |
ReaderRestoreState.create(Scope scope,
Operand<?> readerHandle,
Operand<String> state)
Factory method to create a class wrapping a new ReaderRestoreState operation.
|
static ReaderRestoreState |
ReaderRestoreState.create(Scope scope,
Operand<?> readerHandle,
Operand<String> state)
Factory method to create a class wrapping a new ReaderRestoreState operation.
|
static QueueClose |
QueueClose.create(Scope scope,
Operand<?> handle,
QueueClose.Options... options)
Factory method to create a class wrapping a new QueueClose operation.
|
static <T> SerializeSparse<String> |
SerializeSparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape)
Factory method to create a class wrapping a new SerializeSparse operation using default output types.
|
static <T> SerializeSparse<String> |
SerializeSparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape)
Factory method to create a class wrapping a new SerializeSparse operation using default output types.
|
static <T> SerializeSparse<String> |
SerializeSparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape)
Factory method to create a class wrapping a new SerializeSparse operation using default output types.
|
static <T> SerializeManySparse<String> |
SerializeManySparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape)
Factory method to create a class wrapping a new SerializeManySparse operation using default output types.
|
static <T> SerializeManySparse<String> |
SerializeManySparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape)
Factory method to create a class wrapping a new SerializeManySparse operation using default output types.
|
static <T> SerializeManySparse<String> |
SerializeManySparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape)
Factory method to create a class wrapping a new SerializeManySparse operation using default output types.
|
static <U,T> SerializeSparse<U> |
SerializeSparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
Class<U> outType)
Factory method to create a class wrapping a new SerializeSparse operation.
|
static <U,T> SerializeSparse<U> |
SerializeSparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
Class<U> outType)
Factory method to create a class wrapping a new SerializeSparse operation.
|
static <U,T> SerializeSparse<U> |
SerializeSparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
Class<U> outType)
Factory method to create a class wrapping a new SerializeSparse operation.
|
static <U,T> SerializeManySparse<U> |
SerializeManySparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
Class<U> outType)
Factory method to create a class wrapping a new SerializeManySparse operation.
|
static <U,T> SerializeManySparse<U> |
SerializeManySparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
Class<U> outType)
Factory method to create a class wrapping a new SerializeManySparse operation.
|
static <U,T> SerializeManySparse<U> |
SerializeManySparse.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
Class<U> outType)
Factory method to create a class wrapping a new SerializeManySparse operation.
|
static DecodeJsonExample |
DecodeJsonExample.create(Scope scope,
Operand<String> jsonExamples)
Factory method to create a class wrapping a new DecodeJsonExample operation.
|
static ReadFile |
ReadFile.create(Scope scope,
Operand<String> filename)
Factory method to create a class wrapping a new ReadFile operation.
|
static DecodeBase64 |
DecodeBase64.create(Scope scope,
Operand<String> input)
Factory method to create a class wrapping a new DecodeBase64 operation.
|
static MatchingFiles |
MatchingFiles.create(Scope scope,
Operand<String> pattern)
Factory method to create a class wrapping a new MatchingFiles operation.
|
static <T> DeserializeManySparse<T> |
DeserializeManySparse.create(Scope scope,
Operand<String> serializedSparse,
Class<T> dtype)
Factory method to create a class wrapping a new DeserializeManySparse operation.
|
static <T> ParseTensor<T> |
ParseTensor.create(Scope scope,
Operand<String> serialized,
Class<T> outType)
Factory method to create a class wrapping a new ParseTensor operation.
|
static <T> DecodeRaw<T> |
DecodeRaw.create(Scope scope,
Operand<String> bytes,
Class<T> outType,
DecodeRaw.Options... options)
Factory method to create a class wrapping a new DecodeRaw operation.
|
static DecodeCompressed |
DecodeCompressed.create(Scope scope,
Operand<String> bytes,
DecodeCompressed.Options... options)
Factory method to create a class wrapping a new DecodeCompressed operation.
|
static EncodeBase64 |
EncodeBase64.create(Scope scope,
Operand<String> input,
EncodeBase64.Options... options)
Factory method to create a class wrapping a new EncodeBase64 operation.
|
static DecodeCsv |
DecodeCsv.create(Scope scope,
Operand<String> records,
Iterable<Operand<?>> recordDefaults,
DecodeCsv.Options... options)
Factory method to create a class wrapping a new DecodeCsv operation.
|
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 wrapping a new ParseSingleExample operation.
|
static ShardedFilespec |
ShardedFilespec.create(Scope scope,
Operand<String> basename,
Operand<Integer> numShards)
Factory method to create a class wrapping a new ShardedFilespec operation.
|
static ShardedFilespec |
ShardedFilespec.create(Scope scope,
Operand<String> basename,
Operand<Integer> numShards)
Factory method to create a class wrapping a new ShardedFilespec operation.
|
static ShardedFilename |
ShardedFilename.create(Scope scope,
Operand<String> basename,
Operand<Integer> shard,
Operand<Integer> numShards)
Factory method to create a class wrapping a new ShardedFilename operation.
|
static ShardedFilename |
ShardedFilename.create(Scope scope,
Operand<String> basename,
Operand<Integer> shard,
Operand<Integer> numShards)
Factory method to create a class wrapping a new ShardedFilename operation.
|
static ShardedFilename |
ShardedFilename.create(Scope scope,
Operand<String> basename,
Operand<Integer> shard,
Operand<Integer> numShards)
Factory method to create a class wrapping a new ShardedFilename operation.
|
static WriteFile |
WriteFile.create(Scope scope,
Operand<String> filename,
Operand<String> contents)
Factory method to create a class wrapping a new WriteFile operation.
|
static WriteFile |
WriteFile.create(Scope scope,
Operand<String> filename,
Operand<String> contents)
Factory method to create a class wrapping a new WriteFile operation.
|
static ParseSequenceExample |
ParseSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> debugName,
Iterable<Operand<?>> contextDenseDefaults,
List<String> featureListDenseMissingAssumedEmpty,
List<String> contextSparseKeys,
List<String> contextDenseKeys,
List<String> featureListSparseKeys,
List<String> featureListDenseKeys,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSequenceExample operation.
|
static ParseSequenceExample |
ParseSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> debugName,
Iterable<Operand<?>> contextDenseDefaults,
List<String> featureListDenseMissingAssumedEmpty,
List<String> contextSparseKeys,
List<String> contextDenseKeys,
List<String> featureListSparseKeys,
List<String> featureListDenseKeys,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSequenceExample operation.
|
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 wrapping a new ParseExample operation.
|
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 wrapping a new ParseExample operation.
|
static ParseSingleSequenceExample |
ParseSingleSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSingleSequenceExample operation.
|
static ParseSingleSequenceExample |
ParseSingleSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSingleSequenceExample operation.
|
static ParseSingleSequenceExample |
ParseSingleSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSingleSequenceExample operation.
|
static <T> SerializeTensor |
SerializeTensor.create(Scope scope,
Operand<T> tensor)
Factory method to create a class wrapping a new SerializeTensor operation.
|
Modifier and Type | Method and Description |
---|---|
static QueueEnqueue |
QueueEnqueue.create(Scope scope,
Operand<?> handle,
Iterable<Operand<?>> components,
QueueEnqueue.Options... options)
Factory method to create a class wrapping a new QueueEnqueue operation.
|
static QueueEnqueueMany |
QueueEnqueueMany.create(Scope scope,
Operand<?> handle,
Iterable<Operand<?>> components,
QueueEnqueueMany.Options... options)
Factory method to create a class wrapping a new QueueEnqueueMany operation.
|
static DecodeCsv |
DecodeCsv.create(Scope scope,
Operand<String> records,
Iterable<Operand<?>> recordDefaults,
DecodeCsv.Options... options)
Factory method to create a class wrapping a new DecodeCsv operation.
|
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 wrapping a new ParseSingleExample operation.
|
static ParseSequenceExample |
ParseSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> debugName,
Iterable<Operand<?>> contextDenseDefaults,
List<String> featureListDenseMissingAssumedEmpty,
List<String> contextSparseKeys,
List<String> contextDenseKeys,
List<String> featureListSparseKeys,
List<String> featureListDenseKeys,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSequenceExample operation.
|
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 wrapping a new ParseExample operation.
|
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 wrapping a new ParseExample operation.
|
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 wrapping a new ParseExample operation.
|
static ParseSingleSequenceExample |
ParseSingleSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSingleSequenceExample operation.
|
static ParseSingleSequenceExample |
ParseSingleSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSingleSequenceExample operation.
|
static ParseSingleSequenceExample |
ParseSingleSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSingleSequenceExample operation.
|
static ParseSingleSequenceExample |
ParseSingleSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSingleSequenceExample operation.
|
static ParseSingleSequenceExample |
ParseSingleSequenceExample.create(Scope scope,
Operand<String> serialized,
Operand<String> featureListDenseMissingAssumedEmpty,
Iterable<Operand<String>> contextSparseKeys,
Iterable<Operand<String>> contextDenseKeys,
Iterable<Operand<String>> featureListSparseKeys,
Iterable<Operand<String>> featureListDenseKeys,
Iterable<Operand<?>> contextDenseDefaults,
Operand<String> debugName,
List<Class<?>> contextSparseTypes,
List<Class<?>> featureListDenseTypes,
List<Class<?>> featureListSparseTypes,
ParseSingleSequenceExample.Options... options)
Factory method to create a class wrapping a new ParseSingleSequenceExample operation.
|
Modifier and Type | Class and Description |
---|---|
class |
BandPart<T>
Copy a tensor setting everything outside a central band in each innermost matrix
|
class |
BatchCholesky<T extends Number> |
class |
BatchCholeskyGrad<T extends Number> |
class |
BatchMatMul<T>
Multiplies slices of two tensors in batches.
|
class |
BatchMatrixBandPart<T> |
class |
BatchMatrixDeterminant<T> |
class |
BatchMatrixDiag<T> |
class |
BatchMatrixDiagPart<T> |
class |
BatchMatrixInverse<T extends Number> |
class |
BatchMatrixSetDiag<T> |
class |
BatchMatrixSolve<T extends Number> |
class |
BatchMatrixSolveLs<T extends Number> |
class |
BatchMatrixTriangularSolve<T extends Number> |
class |
Cholesky<T>
Computes the Cholesky decomposition of one or more square matrices.
|
class |
CholeskyGrad<T extends Number>
Computes the reverse mode backpropagated gradient of the Cholesky algorithm.
|
class |
ConjugateTranspose<T>
Shuffle dimensions of x according to a permutation and conjugate the result.
|
class |
Cross<T extends Number>
Compute the pairwise cross product.
|
class |
Det<T>
Computes the determinant of one or more square matrices.
|
class |
Diag<T>
Returns a batched diagonal tensor with a given batched diagonal values.
|
class |
DiagPart<T>
Returns the batched diagonal part of a batched tensor.
|
class |
Inv<T>
Computes the inverse of one or more square invertible matrices or their
|
class |
LoadAndRemapMatrix
Loads a 2-D (matrix) `Tensor` with name `old_tensor_name` from the checkpoint
|
class |
MatMul<T>
Multiply the matrix "a" by the matrix "b".
|
class |
MatrixLogarithm<T>
Computes the matrix logarithm of one or more square matrices:
|
class |
MatrixSolveLs<T>
Solves one or more linear least-squares problems.
|
class |
SetDiag<T>
Returns a batched matrix tensor with new batched diagonal values.
|
class |
Solve<T>
Solves systems of linear equations.
|
class |
Sqrtm<T>
Computes the matrix square root of one or more square matrices:
|
class |
TensorDiag<T>
Returns a diagonal tensor with a given diagonal values.
|
class |
TensorDiagPart<T>
Returns the diagonal part of the tensor.
|
class |
Transpose<T>
Shuffle dimensions of x according to a permutation.
|
class |
TriangularSolve<T>
Solves systems of linear equations with upper or lower triangular matrices by backsubstitution.
|
Modifier and Type | Method and Description |
---|---|
static LoadAndRemapMatrix |
LoadAndRemapMatrix.create(Scope scope,
Operand<String> ckptPath,
Operand<String> oldTensorName,
Operand<Long> rowRemapping,
Operand<Long> colRemapping,
Operand<Float> initializingValues,
Long numRows,
Long numCols,
LoadAndRemapMatrix.Options... options)
Factory method to create a class wrapping a new LoadAndRemapMatrix operation.
|
static LoadAndRemapMatrix |
LoadAndRemapMatrix.create(Scope scope,
Operand<String> ckptPath,
Operand<String> oldTensorName,
Operand<Long> rowRemapping,
Operand<Long> colRemapping,
Operand<Float> initializingValues,
Long numRows,
Long numCols,
LoadAndRemapMatrix.Options... options)
Factory method to create a class wrapping a new LoadAndRemapMatrix operation.
|
static LoadAndRemapMatrix |
LoadAndRemapMatrix.create(Scope scope,
Operand<String> ckptPath,
Operand<String> oldTensorName,
Operand<Long> rowRemapping,
Operand<Long> colRemapping,
Operand<Float> initializingValues,
Long numRows,
Long numCols,
LoadAndRemapMatrix.Options... options)
Factory method to create a class wrapping a new LoadAndRemapMatrix operation.
|
static LoadAndRemapMatrix |
LoadAndRemapMatrix.create(Scope scope,
Operand<String> ckptPath,
Operand<String> oldTensorName,
Operand<Long> rowRemapping,
Operand<Long> colRemapping,
Operand<Float> initializingValues,
Long numRows,
Long numCols,
LoadAndRemapMatrix.Options... options)
Factory method to create a class wrapping a new LoadAndRemapMatrix operation.
|
static LoadAndRemapMatrix |
LoadAndRemapMatrix.create(Scope scope,
Operand<String> ckptPath,
Operand<String> oldTensorName,
Operand<Long> rowRemapping,
Operand<Long> colRemapping,
Operand<Float> initializingValues,
Long numRows,
Long numCols,
LoadAndRemapMatrix.Options... options)
Factory method to create a class wrapping a new LoadAndRemapMatrix operation.
|
static <T> LogMatrixDeterminant<T> |
LogMatrixDeterminant.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new LogMatrixDeterminant operation.
|
static <T> Diag<T> |
Diag.create(Scope scope,
Operand<T> diagonal)
Factory method to create a class wrapping a new Diag operation.
|
static <T> MatrixLogarithm<T> |
MatrixLogarithm.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new MatrixLogarithm operation.
|
static <T> TensorDiagPart<T> |
TensorDiagPart.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new TensorDiagPart operation.
|
static <T> BatchMatrixDeterminant<T> |
BatchMatrixDeterminant.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new BatchMatrixDeterminant operation.
|
static <T> Sqrtm<T> |
Sqrtm.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Sqrtm operation.
|
static <T> DiagPart<T> |
DiagPart.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new DiagPart operation.
|
static <T> Det<T> |
Det.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Det operation.
|
static <T> BatchMatrixDiagPart<T> |
BatchMatrixDiagPart.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new BatchMatrixDiagPart operation.
|
static <T> Cholesky<T> |
Cholesky.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Cholesky operation.
|
static <T> BatchMatrixDiag<T> |
BatchMatrixDiag.create(Scope scope,
Operand<T> diagonal)
Factory method to create a class wrapping a new BatchMatrixDiag operation.
|
static <T> TensorDiag<T> |
TensorDiag.create(Scope scope,
Operand<T> diagonal)
Factory method to create a class wrapping a new TensorDiag operation.
|
static <T extends Number> |
BatchCholesky.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new BatchCholesky operation.
|
static <T extends Number> |
BatchMatrixInverse.create(Scope scope,
Operand<T> input,
BatchMatrixInverse.Options... options)
Factory method to create a class wrapping a new BatchMatrixInverse operation.
|
static <T extends Number> |
BatchSelfAdjointEig.create(Scope scope,
Operand<T> input,
BatchSelfAdjointEig.Options... options)
Factory method to create a class wrapping a new BatchSelfAdjointEig operation.
|
static <T> BatchSvd<T> |
BatchSvd.create(Scope scope,
Operand<T> input,
BatchSvd.Options... options)
Factory method to create a class wrapping a new BatchSvd operation.
|
static <T> Inv<T> |
Inv.create(Scope scope,
Operand<T> input,
Inv.Options... options)
Factory method to create a class wrapping a new Inv operation.
|
static <T> BatchMatrixBandPart<T> |
BatchMatrixBandPart.create(Scope scope,
Operand<T> input,
Operand<Long> numLower,
Operand<Long> numUpper)
Factory method to create a class wrapping a new BatchMatrixBandPart operation.
|
static <T> BatchMatrixBandPart<T> |
BatchMatrixBandPart.create(Scope scope,
Operand<T> input,
Operand<Long> numLower,
Operand<Long> numUpper)
Factory method to create a class wrapping a new BatchMatrixBandPart operation.
|
static <T> BatchMatrixBandPart<T> |
BatchMatrixBandPart.create(Scope scope,
Operand<T> input,
Operand<Long> numLower,
Operand<Long> numUpper)
Factory method to create a class wrapping a new BatchMatrixBandPart operation.
|
static <T> SetDiag<T> |
SetDiag.create(Scope scope,
Operand<T> input,
Operand<T> diagonal)
Factory method to create a class wrapping a new SetDiag operation.
|
static <T> SetDiag<T> |
SetDiag.create(Scope scope,
Operand<T> input,
Operand<T> diagonal)
Factory method to create a class wrapping a new SetDiag operation.
|
static <T> BatchMatrixSetDiag<T> |
BatchMatrixSetDiag.create(Scope scope,
Operand<T> input,
Operand<T> diagonal)
Factory method to create a class wrapping a new BatchMatrixSetDiag operation.
|
static <T> BatchMatrixSetDiag<T> |
BatchMatrixSetDiag.create(Scope scope,
Operand<T> input,
Operand<T> diagonal)
Factory method to create a class wrapping a new BatchMatrixSetDiag operation.
|
static <T extends Number> |
BatchCholeskyGrad.create(Scope scope,
Operand<T> l,
Operand<T> grad)
Factory method to create a class wrapping a new BatchCholeskyGrad operation.
|
static <T extends Number> |
BatchCholeskyGrad.create(Scope scope,
Operand<T> l,
Operand<T> grad)
Factory method to create a class wrapping a new BatchCholeskyGrad operation.
|
static <T extends Number> |
CholeskyGrad.create(Scope scope,
Operand<T> l,
Operand<T> grad)
Factory method to create a class wrapping a new CholeskyGrad operation.
|
static <T extends Number> |
CholeskyGrad.create(Scope scope,
Operand<T> l,
Operand<T> grad)
Factory method to create a class wrapping a new CholeskyGrad operation.
|
static <T extends Number> |
Cross.create(Scope scope,
Operand<T> a,
Operand<T> b)
Factory method to create a class wrapping a new Cross operation.
|
static <T extends Number> |
Cross.create(Scope scope,
Operand<T> a,
Operand<T> b)
Factory method to create a class wrapping a new Cross operation.
|
static <T> BatchMatMul<T> |
BatchMatMul.create(Scope scope,
Operand<T> x,
Operand<T> y,
BatchMatMul.Options... options)
Factory method to create a class wrapping a new BatchMatMul operation.
|
static <T> BatchMatMul<T> |
BatchMatMul.create(Scope scope,
Operand<T> x,
Operand<T> y,
BatchMatMul.Options... options)
Factory method to create a class wrapping a new BatchMatMul operation.
|
static <T extends Number> |
BatchMatrixSolve.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
BatchMatrixSolve.Options... options)
Factory method to create a class wrapping a new BatchMatrixSolve operation.
|
static <T extends Number> |
BatchMatrixSolve.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
BatchMatrixSolve.Options... options)
Factory method to create a class wrapping a new BatchMatrixSolve operation.
|
static <T extends Number> |
BatchMatrixTriangularSolve.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
BatchMatrixTriangularSolve.Options... options)
Factory method to create a class wrapping a new BatchMatrixTriangularSolve operation.
|
static <T extends Number> |
BatchMatrixTriangularSolve.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
BatchMatrixTriangularSolve.Options... options)
Factory method to create a class wrapping a new BatchMatrixTriangularSolve operation.
|
static <T> MatMul<T> |
MatMul.create(Scope scope,
Operand<T> a,
Operand<T> b,
MatMul.Options... options)
Factory method to create a class wrapping a new MatMul operation.
|
static <T> MatMul<T> |
MatMul.create(Scope scope,
Operand<T> a,
Operand<T> b,
MatMul.Options... options)
Factory method to create a class wrapping a new MatMul operation.
|
static <T extends Number> |
BatchMatrixSolveLs.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
Operand<Double> l2Regularizer,
BatchMatrixSolveLs.Options... options)
Factory method to create a class wrapping a new BatchMatrixSolveLs operation.
|
static <T extends Number> |
BatchMatrixSolveLs.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
Operand<Double> l2Regularizer,
BatchMatrixSolveLs.Options... options)
Factory method to create a class wrapping a new BatchMatrixSolveLs operation.
|
static <T extends Number> |
BatchMatrixSolveLs.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
Operand<Double> l2Regularizer,
BatchMatrixSolveLs.Options... options)
Factory method to create a class wrapping a new BatchMatrixSolveLs operation.
|
static <T> MatrixSolveLs<T> |
MatrixSolveLs.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
Operand<Double> l2Regularizer,
MatrixSolveLs.Options... options)
Factory method to create a class wrapping a new MatrixSolveLs operation.
|
static <T> MatrixSolveLs<T> |
MatrixSolveLs.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
Operand<Double> l2Regularizer,
MatrixSolveLs.Options... options)
Factory method to create a class wrapping a new MatrixSolveLs operation.
|
static <T> MatrixSolveLs<T> |
MatrixSolveLs.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
Operand<Double> l2Regularizer,
MatrixSolveLs.Options... options)
Factory method to create a class wrapping a new MatrixSolveLs operation.
|
static <T> Solve<T> |
Solve.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
Solve.Options... options)
Factory method to create a class wrapping a new Solve operation.
|
static <T> Solve<T> |
Solve.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
Solve.Options... options)
Factory method to create a class wrapping a new Solve operation.
|
static <T> TriangularSolve<T> |
TriangularSolve.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
TriangularSolve.Options... options)
Factory method to create a class wrapping a new TriangularSolve operation.
|
static <T> TriangularSolve<T> |
TriangularSolve.create(Scope scope,
Operand<T> matrix,
Operand<T> rhs,
TriangularSolve.Options... options)
Factory method to create a class wrapping a new TriangularSolve operation.
|
static <T,U extends Number> |
Transpose.create(Scope scope,
Operand<T> x,
Operand<U> perm)
Factory method to create a class wrapping a new Transpose operation.
|
static <T,U extends Number> |
Transpose.create(Scope scope,
Operand<T> x,
Operand<U> perm)
Factory method to create a class wrapping a new Transpose operation.
|
static <T,U extends Number> |
ConjugateTranspose.create(Scope scope,
Operand<T> x,
Operand<U> perm)
Factory method to create a class wrapping a new ConjugateTranspose operation.
|
static <T,U extends Number> |
ConjugateTranspose.create(Scope scope,
Operand<T> x,
Operand<U> perm)
Factory method to create a class wrapping a new ConjugateTranspose operation.
|
static <V,T,U,W> QuantizedMatMul<V> |
QuantizedMatMul.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
Class<W> Tactivation,
QuantizedMatMul.Options... options)
Factory method to create a class wrapping a new QuantizedMatMul operation.
|
static <V,T,U,W> QuantizedMatMul<V> |
QuantizedMatMul.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
Class<W> Tactivation,
QuantizedMatMul.Options... options)
Factory method to create a class wrapping a new QuantizedMatMul operation.
|
static <V,T,U,W> QuantizedMatMul<V> |
QuantizedMatMul.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
Class<W> Tactivation,
QuantizedMatMul.Options... options)
Factory method to create a class wrapping a new QuantizedMatMul operation.
|
static <V,T,U,W> QuantizedMatMul<V> |
QuantizedMatMul.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
Class<W> Tactivation,
QuantizedMatMul.Options... options)
Factory method to create a class wrapping a new QuantizedMatMul operation.
|
static <V,T,U,W> QuantizedMatMul<V> |
QuantizedMatMul.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
Class<W> Tactivation,
QuantizedMatMul.Options... options)
Factory method to create a class wrapping a new QuantizedMatMul operation.
|
static <V,T,U,W> QuantizedMatMul<V> |
QuantizedMatMul.create(Scope scope,
Operand<T> a,
Operand<U> b,
Operand<Float> minA,
Operand<Float> maxA,
Operand<Float> minB,
Operand<Float> maxB,
Class<V> Toutput,
Class<W> Tactivation,
QuantizedMatMul.Options... options)
Factory method to create a class wrapping a new QuantizedMatMul operation.
|
static <T,U extends Number> |
BandPart.create(Scope scope,
Operand<T> input,
Operand<U> numLower,
Operand<U> numUpper)
Factory method to create a class wrapping a new BandPart operation.
|
static <T,U extends Number> |
BandPart.create(Scope scope,
Operand<T> input,
Operand<U> numLower,
Operand<U> numUpper)
Factory method to create a class wrapping a new BandPart operation.
|
static <T,U extends Number> |
BandPart.create(Scope scope,
Operand<T> input,
Operand<U> numLower,
Operand<U> numUpper)
Factory method to create a class wrapping a new BandPart operation.
|
static <T> Qr<T> |
Qr.create(Scope scope,
Operand<T> input,
Qr.Options... options)
Factory method to create a class wrapping a new Qr operation.
|
static <T> SelfAdjointEig<T> |
SelfAdjointEig.create(Scope scope,
Operand<T> input,
SelfAdjointEig.Options... options)
Factory method to create a class wrapping a new SelfAdjointEig operation.
|
static <T> Svd<T> |
Svd.create(Scope scope,
Operand<T> input,
Svd.Options... options)
Factory method to create a class wrapping a new Svd operation.
|
Modifier and Type | Class and Description |
---|---|
class |
Abs<T extends Number>
Computes the absolute value of a tensor.
|
class |
AccumulateN<T>
Returns the element-wise sum of a list of tensors.
|
class |
Acos<T>
Computes acos of x element-wise.
|
class |
Acosh<T>
Computes inverse hyperbolic cosine of x element-wise.
|
class |
Add<T>
Returns x + y element-wise.
|
class |
AddN<T>
Add all input tensors element wise.
|
class |
Angle<U extends Number>
Returns the argument of a complex number.
|
class |
ApproximateEqual
Returns the truth value of abs(x-y) < tolerance element-wise.
|
class |
ArgMax<V extends Number>
Returns the index with the largest value across dimensions of a tensor.
|
class |
ArgMin<V extends Number>
Returns the index with the smallest value across dimensions of a tensor.
|
class |
Asin<T>
Computes the trignometric inverse sine of x element-wise.
|
class |
Asinh<T>
Computes inverse hyperbolic sine of x element-wise.
|
class |
Atan<T>
Computes the trignometric inverse tangent of x element-wise.
|
class |
Atan2<T extends Number>
Computes arctangent of `y/x` element-wise, respecting signs of the arguments.
|
class |
Atanh<T>
Computes inverse hyperbolic tangent of x element-wise.
|
class |
BesselI0e<T extends Number>
Computes the Bessel i0e function of `x` element-wise.
|
class |
BesselI1e<T extends Number>
Computes the Bessel i1e function of `x` element-wise.
|
class |
Betainc<T extends Number>
Compute the regularized incomplete beta integral \\(I_x(a, b)\\).
|
class |
Bincount<T extends Number>
Counts the number of occurrences of each value in an integer array.
|
class |
Ceil<T extends Number>
Returns element-wise smallest integer not less than x.
|
class |
CheckNumerics<T extends Number>
Checks a tensor for NaN and Inf values.
|
class |
CompareAndBitpack
Compare values of `input` to `threshold` and pack resulting bits into a `uint8`.
|
class |
ComplexAbs<U extends Number>
Computes the complex absolute value of a tensor.
|
class |
Conj<T>
Returns the complex conjugate of a complex number.
|
class |
Cos<T>
Computes cos of x element-wise.
|
class |
Cosh<T>
Computes hyperbolic cosine of x element-wise.
|
class |
Cumprod<T>
Compute the cumulative product of the tensor `x` along `axis`.
|
class |
Cumsum<T>
Compute the cumulative sum of the tensor `x` along `axis`.
|
class |
Digamma<T extends Number>
Computes Psi, the derivative of Lgamma (the log of the absolute value of
|
class |
Div<T>
Returns x / y element-wise.
|
class |
DivNoNan<T>
Returns 0 if the denominator is zero.
|
class |
Equal
Returns the truth value of (x == y) element-wise.
|
class |
Erf<T extends Number>
Computes the Gauss error function of `x` element-wise.
|
class |
Erfc<T extends Number>
Computes the complementary error function of `x` element-wise.
|
class |
Exp<T>
Computes exponential of x element-wise.
|
class |
Expm1<T>
Computes `exp(x) - 1` element-wise.
|
class |
Fact
Output a fact about factorials.
|
class |
Floor<T extends Number>
Returns element-wise largest integer not greater than x.
|
class |
FloorDiv<T>
Returns x // y element-wise.
|
class |
FloorMod<T extends Number>
Returns element-wise remainder of division.
|
class |
Greater
Returns the truth value of (x > y) element-wise.
|
class |
GreaterEqual
Returns the truth value of (x >= y) element-wise.
|
class |
Igamma<T extends Number>
Compute the lower regularized incomplete Gamma function `P(a, x)`.
|
class |
Igammac<T extends Number>
Compute the upper regularized incomplete Gamma function `Q(a, x)`.
|
class |
IgammaGradA<T extends Number>
Computes the gradient of `igamma(a, x)` wrt `a`.
|
class |
Imag<U extends Number>
Returns the imaginary part of a complex number.
|
class |
InvertPermutation<T extends Number>
Computes the inverse permutation of a tensor.
|
class |
IsFinite
Returns which elements of x are finite.
|
class |
IsInf
Returns which elements of x are Inf.
|
class |
IsNan
Returns which elements of x are NaN.
|
class |
Less
Returns the truth value of (x < y) element-wise.
|
class |
LessEqual
Returns the truth value of (x <= y) element-wise.
|
class |
Lgamma<T extends Number>
Computes the log of the absolute value of `Gamma(x)` element-wise.
|
class |
Log<T>
Computes natural logarithm of x element-wise.
|
class |
Log1p<T>
Computes natural logarithm of (1 + x) element-wise.
|
class |
LogicalAnd
Returns the truth value of x AND y element-wise.
|
class |
LogicalNot
Returns the truth value of NOT x element-wise.
|
class |
LogicalOr
Returns the truth value of x OR y element-wise.
|
class |
Maximum<T extends Number>
Returns the max of x and y (i.e.
|
class |
Mean<T>
Computes the mean of elements across dimensions of a tensor.
|
class |
Minimum<T extends Number>
Returns the min of x and y (i.e.
|
class |
Mod<T extends Number>
Returns element-wise remainder of division.
|
class |
Mul<T>
Returns x * y element-wise.
|
class |
Neg<T>
Computes numerical negative value element-wise.
|
class |
NotEqual
Returns the truth value of (x != y) element-wise.
|
class |
Polygamma<T extends Number>
Compute the polygamma function \\(\psi^{(n)}(x)\\).
|
class |
PopulationCount
Computes element-wise population count (a.k.a.
|
class |
Pow<T>
Computes the power of one value to another.
|
class |
Real<U extends Number>
Returns the real part of a complex number.
|
class |
RealDiv<T>
Returns x / y element-wise for real types.
|
class |
Reciprocal<T>
Computes the reciprocal of x element-wise.
|
class |
ReciprocalGrad<T>
Computes the gradient for the inverse of `x` wrt its input.
|
class |
Rint<T extends Number>
Returns element-wise integer closest to x.
|
class |
Round<T>
Rounds the values of a tensor to the nearest integer, element-wise.
|
class |
Rsqrt<T>
Computes reciprocal of square root of x element-wise.
|
class |
RsqrtGrad<T>
Computes the gradient for the rsqrt of `x` wrt its input.
|
class |
SegmentMax<T extends Number>
Computes the maximum along segments of a tensor.
|
class |
SegmentMean<T>
Computes the mean along segments of a tensor.
|
class |
SegmentMin<T extends Number>
Computes the minimum along segments of a tensor.
|
class |
SegmentProd<T>
Computes the product along segments of a tensor.
|
class |
SegmentSum<T>
Computes the sum along segments of a tensor.
|
class |
Sigmoid<T>
Computes sigmoid of `x` element-wise.
|
class |
SigmoidGrad<T>
Computes the gradient of the sigmoid of `x` wrt its input.
|
class |
Sign<T>
Returns an element-wise indication of the sign of a number.
|
class |
Sin<T>
Computes sine of x element-wise.
|
class |
Sinh<T>
Computes hyperbolic sine of x element-wise.
|
class |
Softplus<T extends Number>
Computes softplus: `log(exp(features) + 1)`.
|
class |
SoftplusGrad<T extends Number>
Computes softplus gradients for a softplus operation.
|
class |
Sqrt<T>
Computes square root of x element-wise.
|
class |
SqrtGrad<T>
Computes the gradient for the sqrt of `x` wrt its input.
|
class |
Square<T>
Computes square of x element-wise.
|
class |
SquaredDifference<T>
Returns (x - y)(x - y) element-wise.
|
class |
Sub<T>
Returns x - y element-wise.
|
class |
Tan<T>
Computes tan of x element-wise.
|
class |
Tanh<T>
Computes hyperbolic tangent of `x` element-wise.
|
class |
TanhGrad<T>
Computes the gradient for the tanh of `x` wrt its input.
|
class |
TruncateDiv<T>
Returns x / y element-wise for integer types.
|
class |
TruncateMod<T extends Number>
Returns element-wise remainder of division.
|
class |
UnsortedSegmentMax<T extends Number>
Computes the maximum along segments of a tensor.
|
class |
UnsortedSegmentMin<T extends Number>
Computes the minimum along segments of a tensor.
|
class |
UnsortedSegmentProd<T>
Computes the product along segments of a tensor.
|
class |
UnsortedSegmentSum<T>
Computes the sum along segments of a tensor.
|
class |
Xdivy<T>
Returns 0 if x == 0, and x / y otherwise, elementwise.
|
class |
Xlogy<T>
Returns 0 if x == 0, and x * log(y) otherwise, elementwise.
|
class |
Zeta<T extends Number>
Compute the Hurwitz zeta function \\(\zeta(x, q)\\).
|
Modifier and Type | Method and Description |
---|---|
static LogicalNot |
LogicalNot.create(Scope scope,
Operand<Boolean> x)
Factory method to create a class wrapping a new LogicalNot operation.
|
static LogicalOr |
LogicalOr.create(Scope scope,
Operand<Boolean> x,
Operand<Boolean> y)
Factory method to create a class wrapping a new LogicalOr operation.
|
static LogicalOr |
LogicalOr.create(Scope scope,
Operand<Boolean> x,
Operand<Boolean> y)
Factory method to create a class wrapping a new LogicalOr operation.
|
static LogicalAnd |
LogicalAnd.create(Scope scope,
Operand<Boolean> x,
Operand<Boolean> y)
Factory method to create a class wrapping a new LogicalAnd operation.
|
static LogicalAnd |
LogicalAnd.create(Scope scope,
Operand<Boolean> x,
Operand<Boolean> y)
Factory method to create a class wrapping a new LogicalAnd operation.
|
static <T extends Number> |
Bincount.create(Scope scope,
Operand<Integer> arr,
Operand<Integer> size,
Operand<T> weights)
Factory method to create a class wrapping a new Bincount operation.
|
static <T extends Number> |
Bincount.create(Scope scope,
Operand<Integer> arr,
Operand<Integer> size,
Operand<T> weights)
Factory method to create a class wrapping a new Bincount operation.
|
static <T extends Number> |
Bincount.create(Scope scope,
Operand<Integer> arr,
Operand<Integer> size,
Operand<T> weights)
Factory method to create a class wrapping a new Bincount operation.
|
static <T> Reciprocal<T> |
Reciprocal.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Reciprocal operation.
|
static <T> Sin<T> |
Sin.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Sin operation.
|
static <T> Atan<T> |
Atan.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Atan operation.
|
static <T> Neg<T> |
Neg.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Neg operation.
|
static <T> Sinh<T> |
Sinh.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Sinh operation.
|
static <T> Rsqrt<T> |
Rsqrt.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Rsqrt operation.
|
static <T> Cosh<T> |
Cosh.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Cosh operation.
|
static <T> Angle<Float> |
Angle.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Angle operation using default output types.
|
static <T> Real<Float> |
Real.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Real operation using default output types.
|
static <T> Asinh<T> |
Asinh.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Asinh operation.
|
static <T> Cos<T> |
Cos.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Cos operation.
|
static <T> Expm1<T> |
Expm1.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Expm1 operation.
|
static <T> Acos<T> |
Acos.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Acos operation.
|
static <T> Asin<T> |
Asin.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Asin operation.
|
static <T> Log1p<T> |
Log1p.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Log1p operation.
|
static <T> Imag<Float> |
Imag.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Imag operation using default output types.
|
static <T> Exp<T> |
Exp.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Exp operation.
|
static <T> Square<T> |
Square.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Square operation.
|
static <T> Atanh<T> |
Atanh.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Atanh operation.
|
static <T> Sqrt<T> |
Sqrt.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Sqrt operation.
|
static <T> ComplexAbs<Float> |
ComplexAbs.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new ComplexAbs operation using default output types.
|
static <T> Round<T> |
Round.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Round operation.
|
static <T> Sign<T> |
Sign.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Sign operation.
|
static <T> Tan<T> |
Tan.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Tan operation.
|
static <T> Log<T> |
Log.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Log operation.
|
static <T> Conj<T> |
Conj.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Conj operation.
|
static <T> Acosh<T> |
Acosh.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Acosh operation.
|
static <T> Sigmoid<T> |
Sigmoid.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Sigmoid operation.
|
static <T> Tanh<T> |
Tanh.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Tanh operation.
|
static <T extends Number> |
Lgamma.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Lgamma operation.
|
static <T extends Number> |
IsInf.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new IsInf operation.
|
static <T extends Number> |
Softplus.create(Scope scope,
Operand<T> features)
Factory method to create a class wrapping a new Softplus operation.
|
static <T extends Number> |
Ceil.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Ceil operation.
|
static <T extends Number> |
IsNan.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new IsNan operation.
|
static <T extends Number> |
Erf.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Erf operation.
|
static <T extends Number> |
Floor.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Floor operation.
|
static <T extends Number> |
Digamma.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Digamma operation.
|
static <T extends Number> |
Erfc.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Erfc operation.
|
static <T extends Number> |
Abs.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Abs operation.
|
static <T extends Number> |
BesselI0e.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new BesselI0e operation.
|
static <T extends Number> |
Rint.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new Rint operation.
|
static <T extends Number> |
BesselI1e.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new BesselI1e operation.
|
static <T extends Number> |
InvertPermutation.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new InvertPermutation operation.
|
static <T extends Number> |
PopulationCount.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new PopulationCount operation.
|
static <T extends Number> |
IsFinite.create(Scope scope,
Operand<T> x)
Factory method to create a class wrapping a new IsFinite operation.
|
static <U extends Number,T> |
Angle.create(Scope scope,
Operand<T> input,
Class<U> Tout)
Factory method to create a class wrapping a new Angle operation.
|
static <U extends Number,T> |
Real.create(Scope scope,
Operand<T> input,
Class<U> Tout)
Factory method to create a class wrapping a new Real operation.
|
static <U extends Number,T> |
Imag.create(Scope scope,
Operand<T> input,
Class<U> Tout)
Factory method to create a class wrapping a new Imag operation.
|
static <U extends Number,T> |
ComplexAbs.create(Scope scope,
Operand<T> x,
Class<U> Tout)
Factory method to create a class wrapping a new ComplexAbs operation.
|
static <T> SigmoidGrad<T> |
SigmoidGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new SigmoidGrad operation.
|
static <T> SigmoidGrad<T> |
SigmoidGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new SigmoidGrad operation.
|
static <T> RsqrtGrad<T> |
RsqrtGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new RsqrtGrad operation.
|
static <T> RsqrtGrad<T> |
RsqrtGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new RsqrtGrad operation.
|
static <T> RealDiv<T> |
RealDiv.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new RealDiv operation.
|
static <T> RealDiv<T> |
RealDiv.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new RealDiv operation.
|
static <T> SquaredDifference<T> |
SquaredDifference.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new SquaredDifference operation.
|
static <T> SquaredDifference<T> |
SquaredDifference.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new SquaredDifference operation.
|
static <T> Xlogy<T> |
Xlogy.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Xlogy operation.
|
static <T> Xlogy<T> |
Xlogy.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Xlogy operation.
|
static <T> TruncateDiv<T> |
TruncateDiv.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new TruncateDiv operation.
|
static <T> TruncateDiv<T> |
TruncateDiv.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new TruncateDiv operation.
|
static <T> Pow<T> |
Pow.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Pow operation.
|
static <T> Pow<T> |
Pow.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Pow operation.
|
static <T> FloorDiv<T> |
FloorDiv.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new FloorDiv operation.
|
static <T> FloorDiv<T> |
FloorDiv.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new FloorDiv operation.
|
static <T> Sub<T> |
Sub.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Sub operation.
|
static <T> Sub<T> |
Sub.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Sub operation.
|
static <T> ReciprocalGrad<T> |
ReciprocalGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new ReciprocalGrad operation.
|
static <T> ReciprocalGrad<T> |
ReciprocalGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new ReciprocalGrad operation.
|
static <T> SqrtGrad<T> |
SqrtGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new SqrtGrad operation.
|
static <T> SqrtGrad<T> |
SqrtGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new SqrtGrad operation.
|
static <T> CompareAndBitpack |
CompareAndBitpack.create(Scope scope,
Operand<T> input,
Operand<T> threshold)
Factory method to create a class wrapping a new CompareAndBitpack operation.
|
static <T> CompareAndBitpack |
CompareAndBitpack.create(Scope scope,
Operand<T> input,
Operand<T> threshold)
Factory method to create a class wrapping a new CompareAndBitpack operation.
|
static <T> TanhGrad<T> |
TanhGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new TanhGrad operation.
|
static <T> TanhGrad<T> |
TanhGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new TanhGrad operation.
|
static <T> Xdivy<T> |
Xdivy.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Xdivy operation.
|
static <T> Xdivy<T> |
Xdivy.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Xdivy operation.
|
static <T> Add<T> |
Add.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Add operation.
|
static <T> Add<T> |
Add.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Add operation.
|
static <T> Mul<T> |
Mul.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Mul operation.
|
static <T> Mul<T> |
Mul.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Mul operation.
|
static <T> DivNoNan<T> |
DivNoNan.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new DivNoNan operation.
|
static <T> DivNoNan<T> |
DivNoNan.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new DivNoNan operation.
|
static <T> Div<T> |
Div.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Div operation.
|
static <T> Div<T> |
Div.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Div operation.
|
static <T extends Number> |
Igamma.create(Scope scope,
Operand<T> a,
Operand<T> x)
Factory method to create a class wrapping a new Igamma operation.
|
static <T extends Number> |
Igamma.create(Scope scope,
Operand<T> a,
Operand<T> x)
Factory method to create a class wrapping a new Igamma operation.
|
static <T extends Number> |
Less.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Less operation.
|
static <T extends Number> |
Less.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Less operation.
|
static <T extends Number> |
Greater.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Greater operation.
|
static <T extends Number> |
Greater.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Greater operation.
|
static <T extends Number> |
SoftplusGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> features)
Factory method to create a class wrapping a new SoftplusGrad operation.
|
static <T extends Number> |
SoftplusGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> features)
Factory method to create a class wrapping a new SoftplusGrad operation.
|
static <T extends Number> |
Zeta.create(Scope scope,
Operand<T> x,
Operand<T> q)
Factory method to create a class wrapping a new Zeta operation.
|
static <T extends Number> |
Zeta.create(Scope scope,
Operand<T> x,
Operand<T> q)
Factory method to create a class wrapping a new Zeta operation.
|
static <T extends Number> |
Igammac.create(Scope scope,
Operand<T> a,
Operand<T> x)
Factory method to create a class wrapping a new Igammac operation.
|
static <T extends Number> |
Igammac.create(Scope scope,
Operand<T> a,
Operand<T> x)
Factory method to create a class wrapping a new Igammac operation.
|
static <T extends Number> |
Minimum.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Minimum operation.
|
static <T extends Number> |
Minimum.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Minimum operation.
|
static <T extends Number> |
IgammaGradA.create(Scope scope,
Operand<T> a,
Operand<T> x)
Factory method to create a class wrapping a new IgammaGradA operation.
|
static <T extends Number> |
IgammaGradA.create(Scope scope,
Operand<T> a,
Operand<T> x)
Factory method to create a class wrapping a new IgammaGradA operation.
|
static <T extends Number> |
GreaterEqual.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new GreaterEqual operation.
|
static <T extends Number> |
GreaterEqual.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new GreaterEqual operation.
|
static <T extends Number> |
FloorMod.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new FloorMod operation.
|
static <T extends Number> |
FloorMod.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new FloorMod operation.
|
static <T extends Number> |
Atan2.create(Scope scope,
Operand<T> y,
Operand<T> x)
Factory method to create a class wrapping a new Atan2 operation.
|
static <T extends Number> |
Atan2.create(Scope scope,
Operand<T> y,
Operand<T> x)
Factory method to create a class wrapping a new Atan2 operation.
|
static <T extends Number> |
Maximum.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Maximum operation.
|
static <T extends Number> |
Maximum.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Maximum operation.
|
static <T extends Number> |
Polygamma.create(Scope scope,
Operand<T> a,
Operand<T> x)
Factory method to create a class wrapping a new Polygamma operation.
|
static <T extends Number> |
Polygamma.create(Scope scope,
Operand<T> a,
Operand<T> x)
Factory method to create a class wrapping a new Polygamma operation.
|
static <T extends Number> |
LessEqual.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new LessEqual operation.
|
static <T extends Number> |
LessEqual.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new LessEqual operation.
|
static <T extends Number> |
TruncateMod.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new TruncateMod operation.
|
static <T extends Number> |
TruncateMod.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new TruncateMod operation.
|
static <T extends Number> |
Mod.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Mod operation.
|
static <T extends Number> |
Mod.create(Scope scope,
Operand<T> x,
Operand<T> y)
Factory method to create a class wrapping a new Mod operation.
|
static <T> ApproximateEqual |
ApproximateEqual.create(Scope scope,
Operand<T> x,
Operand<T> y,
ApproximateEqual.Options... options)
Factory method to create a class wrapping a new ApproximateEqual operation.
|
static <T> ApproximateEqual |
ApproximateEqual.create(Scope scope,
Operand<T> x,
Operand<T> y,
ApproximateEqual.Options... options)
Factory method to create a class wrapping a new ApproximateEqual operation.
|
static <T> Equal |
Equal.create(Scope scope,
Operand<T> x,
Operand<T> y,
Equal.Options... options)
Factory method to create a class wrapping a new Equal operation.
|
static <T> Equal |
Equal.create(Scope scope,
Operand<T> x,
Operand<T> y,
Equal.Options... options)
Factory method to create a class wrapping a new Equal operation.
|
static <T> NotEqual |
NotEqual.create(Scope scope,
Operand<T> x,
Operand<T> y,
NotEqual.Options... options)
Factory method to create a class wrapping a new NotEqual operation.
|
static <T> NotEqual |
NotEqual.create(Scope scope,
Operand<T> x,
Operand<T> y,
NotEqual.Options... options)
Factory method to create a class wrapping a new NotEqual operation.
|
static <T extends Number> |
Betainc.create(Scope scope,
Operand<T> a,
Operand<T> b,
Operand<T> x)
Factory method to create a class wrapping a new Betainc operation.
|
static <T extends Number> |
Betainc.create(Scope scope,
Operand<T> a,
Operand<T> b,
Operand<T> x)
Factory method to create a class wrapping a new Betainc operation.
|
static <T extends Number> |
Betainc.create(Scope scope,
Operand<T> a,
Operand<T> b,
Operand<T> x)
Factory method to create a class wrapping a new Betainc operation.
|
static <T extends Number,U extends Number> |
SegmentMin.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds)
Factory method to create a class wrapping a new SegmentMin operation.
|
static <T extends Number,U extends Number> |
SegmentMin.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds)
Factory method to create a class wrapping a new SegmentMin operation.
|
static <T extends Number,U extends Number> |
SegmentMax.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds)
Factory method to create a class wrapping a new SegmentMax operation.
|
static <T extends Number,U extends Number> |
SegmentMax.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds)
Factory method to create a class wrapping a new SegmentMax operation.
|
static <T,U extends Number> |
SegmentMean.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds)
Factory method to create a class wrapping a new SegmentMean operation.
|
static <T,U extends Number> |
SegmentMean.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds)
Factory method to create a class wrapping a new SegmentMean operation.
|
static <T,U extends Number> |
SegmentProd.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds)
Factory method to create a class wrapping a new SegmentProd operation.
|
static <T,U extends Number> |
SegmentProd.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds)
Factory method to create a class wrapping a new SegmentProd operation.
|
static <T,U extends Number> |
ArgMin.create(Scope scope,
Operand<T> input,
Operand<U> dimension)
Factory method to create a class wrapping a new ArgMin operation using default output types.
|
static <T,U extends Number> |
ArgMin.create(Scope scope,
Operand<T> input,
Operand<U> dimension)
Factory method to create a class wrapping a new ArgMin operation using default output types.
|
static <T,U extends Number> |
SegmentSum.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds)
Factory method to create a class wrapping a new SegmentSum operation.
|
static <T,U extends Number> |
SegmentSum.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds)
Factory method to create a class wrapping a new SegmentSum operation.
|
static <T,U extends Number> |
ArgMax.create(Scope scope,
Operand<T> input,
Operand<U> dimension)
Factory method to create a class wrapping a new ArgMax operation using default output types.
|
static <T,U extends Number> |
ArgMax.create(Scope scope,
Operand<T> input,
Operand<U> dimension)
Factory method to create a class wrapping a new ArgMax operation using default output types.
|
static <V extends Number,T,U extends Number> |
ArgMin.create(Scope scope,
Operand<T> input,
Operand<U> dimension,
Class<V> outputType)
Factory method to create a class wrapping a new ArgMin operation.
|
static <V extends Number,T,U extends Number> |
ArgMin.create(Scope scope,
Operand<T> input,
Operand<U> dimension,
Class<V> outputType)
Factory method to create a class wrapping a new ArgMin operation.
|
static <V extends Number,T,U extends Number> |
ArgMax.create(Scope scope,
Operand<T> input,
Operand<U> dimension,
Class<V> outputType)
Factory method to create a class wrapping a new ArgMax operation.
|
static <V extends Number,T,U extends Number> |
ArgMax.create(Scope scope,
Operand<T> input,
Operand<U> dimension,
Class<V> outputType)
Factory method to create a class wrapping a new ArgMax operation.
|
static <T,U extends Number> |
Cumprod.create(Scope scope,
Operand<T> x,
Operand<U> axis,
Cumprod.Options... options)
Factory method to create a class wrapping a new Cumprod operation.
|
static <T,U extends Number> |
Cumprod.create(Scope scope,
Operand<T> x,
Operand<U> axis,
Cumprod.Options... options)
Factory method to create a class wrapping a new Cumprod operation.
|
static <T,U extends Number> |
Cumsum.create(Scope scope,
Operand<T> x,
Operand<U> axis,
Cumsum.Options... options)
Factory method to create a class wrapping a new Cumsum operation.
|
static <T,U extends Number> |
Cumsum.create(Scope scope,
Operand<T> x,
Operand<U> axis,
Cumsum.Options... options)
Factory method to create a class wrapping a new Cumsum operation.
|
static <T,U extends Number> |
Mean.create(Scope scope,
Operand<T> input,
Operand<U> axis,
Mean.Options... options)
Factory method to create a class wrapping a new Mean operation.
|
static <T,U extends Number> |
Mean.create(Scope scope,
Operand<T> input,
Operand<U> axis,
Mean.Options... options)
Factory method to create a class wrapping a new Mean operation.
|
static <V,T,U> QuantizedMul<V> |
QuantizedMul.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedMul operation.
|
static <V,T,U> QuantizedMul<V> |
QuantizedMul.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedMul operation.
|
static <V,T,U> QuantizedMul<V> |
QuantizedMul.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedMul operation.
|
static <V,T,U> QuantizedMul<V> |
QuantizedMul.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedMul operation.
|
static <V,T,U> QuantizedMul<V> |
QuantizedMul.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedMul operation.
|
static <V,T,U> QuantizedMul<V> |
QuantizedMul.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedMul operation.
|
static <V,T,U> QuantizedAdd<V> |
QuantizedAdd.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedAdd operation.
|
static <V,T,U> QuantizedAdd<V> |
QuantizedAdd.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedAdd operation.
|
static <V,T,U> QuantizedAdd<V> |
QuantizedAdd.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedAdd operation.
|
static <V,T,U> QuantizedAdd<V> |
QuantizedAdd.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedAdd operation.
|
static <V,T,U> QuantizedAdd<V> |
QuantizedAdd.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedAdd operation.
|
static <V,T,U> QuantizedAdd<V> |
QuantizedAdd.create(Scope scope,
Operand<T> x,
Operand<U> y,
Operand<Float> minX,
Operand<Float> maxX,
Operand<Float> minY,
Operand<Float> maxY,
Class<V> Toutput)
Factory method to create a class wrapping a new QuantizedAdd operation.
|
static <T extends Number,U extends Number,V extends Number> |
UnsortedSegmentMin.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentMin operation.
|
static <T extends Number,U extends Number,V extends Number> |
UnsortedSegmentMin.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentMin operation.
|
static <T extends Number,U extends Number,V extends Number> |
UnsortedSegmentMin.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentMin operation.
|
static <T extends Number,U extends Number,V extends Number> |
UnsortedSegmentMax.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentMax operation.
|
static <T extends Number,U extends Number,V extends Number> |
UnsortedSegmentMax.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentMax operation.
|
static <T extends Number,U extends Number,V extends Number> |
UnsortedSegmentMax.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentMax operation.
|
static <T,U extends Number,V extends Number> |
UnsortedSegmentSum.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentSum operation.
|
static <T,U extends Number,V extends Number> |
UnsortedSegmentSum.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentSum operation.
|
static <T,U extends Number,V extends Number> |
UnsortedSegmentSum.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentSum operation.
|
static <T,U extends Number,V extends Number> |
UnsortedSegmentProd.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentProd operation.
|
static <T,U extends Number,V extends Number> |
UnsortedSegmentProd.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentProd operation.
|
static <T,U extends Number,V extends Number> |
UnsortedSegmentProd.create(Scope scope,
Operand<T> data,
Operand<U> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new UnsortedSegmentProd operation.
|
static <T extends Number> |
CheckNumerics.create(Scope scope,
Operand<T> tensor,
String message)
Factory method to create a class wrapping a new CheckNumerics operation.
|
Modifier and Type | Method and Description |
---|---|
static <T> AddN<T> |
AddN.create(Scope scope,
Iterable<Operand<T>> inputs)
Factory method to create a class wrapping a new AddN operation.
|
static <T> AccumulateN<T> |
AccumulateN.create(Scope scope,
Iterable<Operand<T>> inputs,
Shape shape)
Factory method to create a class wrapping a new AccumulateN operation.
|
Modifier and Type | Class and Description |
---|---|
class |
AvgPool<T extends Number>
Performs average pooling on the input.
|
class |
AvgPool3d<T extends Number>
Performs 3D average pooling on the input.
|
class |
AvgPool3dGrad<T extends Number>
Computes gradients of average pooling function.
|
class |
AvgPoolGrad<T extends Number>
Computes gradients of the average pooling function.
|
class |
BatchNormWithGlobalNormalization<T>
Batch normalization.
|
class |
BiasAdd<T>
Adds `bias` to `value`.
|
class |
BiasAddGrad<T>
The backward operation for "BiasAdd" on the "bias" tensor.
|
class |
Conv2d<T extends Number>
Computes a 2-D convolution given 4-D `input` and `filter` tensors.
|
class |
Conv2dBackpropFilter<T extends Number>
Computes the gradients of convolution with respect to the filter.
|
class |
Conv2dBackpropInput<T extends Number>
Computes the gradients of convolution with respect to the input.
|
class |
Conv3d<T extends Number>
Computes a 3-D convolution given 5-D `input` and `filter` tensors.
|
class |
Conv3dBackpropFilter<T extends Number>
Computes the gradients of 3-D convolution with respect to the filter.
|
class |
Conv3dBackpropInput<U extends Number>
Computes the gradients of 3-D convolution with respect to the input.
|
class |
CudnnRnnCanonicalToParams<T extends Number>
Converts CudnnRNN params from canonical form to usable form.
|
class |
CudnnRnnParamsSize<U extends Number>
Computes size of weights that can be used by a Cudnn RNN model.
|
class |
DataFormatDimMap<T extends Number>
Returns the dimension index in the destination data format given the one in
|
class |
DataFormatVecPermute<T extends Number>
Returns the permuted vector/tensor in the destination data format given the
|
class |
DepthToSpace<T>
DepthToSpace for tensors of type T.
|
class |
DepthwiseConv2dNative<T extends Number>
Computes a 2-D depthwise convolution given 4-D `input` and `filter` tensors.
|
class |
DepthwiseConv2dNativeBackpropFilter<T extends Number>
Computes the gradients of depthwise convolution with respect to the filter.
|
class |
DepthwiseConv2dNativeBackpropInput<T extends Number>
Computes the gradients of depthwise convolution with respect to the input.
|
class |
Dilation2d<T extends Number>
Computes the grayscale dilation of 4-D `input` and 3-D `filter` tensors.
|
class |
Dilation2dBackpropFilter<T extends Number>
Computes the gradient of morphological 2-D dilation with respect to the filter.
|
class |
Dilation2dBackpropInput<T extends Number>
Computes the gradient of morphological 2-D dilation with respect to the input.
|
class |
Elu<T extends Number>
Computes exponential linear: `exp(features) - 1` if < 0, `features` otherwise.
|
class |
EluGrad<T extends Number>
Computes gradients for the exponential linear (Elu) operation.
|
class |
FractionalAvgPoolGrad<T extends Number>
Computes gradient of the FractionalAvgPool function.
|
class |
FractionalMaxPoolGrad<T extends Number>
Computes gradient of the FractionalMaxPool function.
|
class |
FusedPadConv2d<T extends Number>
Performs a padding as a preprocess during a convolution.
|
class |
FusedResizeAndPadConv2d<T extends Number>
Performs a resize and padding as a preprocess during a convolution.
|
class |
InTopK
Says whether the targets are in the top `K` predictions.
|
class |
InvGrad<T>
Computes the gradient for the inverse of `x` wrt its input.
|
class |
L2Loss<T extends Number>
L2 Loss.
|
class |
LeakyRelu<T extends Number>
Computes rectified linear: `max(features, features * alpha)`.
|
class |
LocalResponseNormalization<T extends Number>
Local Response Normalization.
|
class |
LocalResponseNormalizationGrad<T extends Number>
Gradients for Local Response Normalization.
|
class |
LogSoftmax<T extends Number>
Computes log softmax activations.
|
class |
MaxPool<T>
Performs max pooling on the input.
|
class |
MaxPool3d<T extends Number>
Performs 3D max pooling on the input.
|
class |
MaxPool3dGrad<U extends Number>
Computes gradients of max pooling function.
|
class |
MaxPool3dGradGrad<T extends Number>
Computes second-order gradients of the maxpooling function.
|
class |
MaxPoolGrad<T extends Number>
Computes gradients of the maxpooling function.
|
class |
MaxPoolGradGrad<T extends Number>
Computes second-order gradients of the maxpooling function.
|
class |
MaxPoolGradGradWithArgmax<T extends Number>
Computes second-order gradients of the maxpooling function.
|
class |
MaxPoolGradWithArgmax<T extends Number>
Computes gradients of the maxpooling function.
|
class |
NthElement<T extends Number>
Finds values of the `n`-th order statistic for the last dimension.
|
class |
Relu<T>
Computes rectified linear: `max(features, 0)`.
|
class |
Relu6<T extends Number>
Computes rectified linear 6: `min(max(features, 0), 6)`.
|
class |
Relu6Grad<T extends Number>
Computes rectified linear 6 gradients for a Relu6 operation.
|
class |
ReluGrad<T extends Number>
Computes rectified linear gradients for a Relu operation.
|
class |
Selu<T extends Number>
Computes scaled exponential linear: `scale * alpha * (exp(features) - 1)`
|
class |
SeluGrad<T extends Number>
Computes gradients for the scaled exponential linear (Selu) operation.
|
class |
Softmax<T extends Number>
Computes softmax activations.
|
class |
Softsign<T extends Number>
Computes softsign: `features / (abs(features) + 1)`.
|
class |
SoftsignGrad<T extends Number>
Computes softsign gradients for a softsign operation.
|
class |
SpaceToBatch<T>
SpaceToBatch for 4-D tensors of type T.
|
class |
SpaceToDepth<T>
SpaceToDepth for tensors of type T.
|
Modifier and Type | Method and Description |
---|---|
static <T extends Number> |
InTopK.create(Scope scope,
Operand<Float> predictions,
Operand<T> targets,
Operand<T> k)
Factory method to create a class wrapping a new InTopK operation.
|
static <T extends Number> |
InTopK.create(Scope scope,
Operand<Float> predictions,
Operand<T> targets,
Operand<T> k)
Factory method to create a class wrapping a new InTopK operation.
|
static <T extends Number> |
InTopK.create(Scope scope,
Operand<Float> predictions,
Operand<T> targets,
Operand<T> k)
Factory method to create a class wrapping a new InTopK operation.
|
static <U extends Number,T extends Number> |
CudnnRnnParamsSize.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Class<T> T,
Class<U> S,
CudnnRnnParamsSize.Options... options)
Factory method to create a class wrapping a new CudnnRnnParamsSize operation.
|
static <U extends Number,T extends Number> |
CudnnRnnParamsSize.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Class<T> T,
Class<U> S,
CudnnRnnParamsSize.Options... options)
Factory method to create a class wrapping a new CudnnRnnParamsSize operation.
|
static <U extends Number,T extends Number> |
CudnnRnnParamsSize.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Class<T> T,
Class<U> S,
CudnnRnnParamsSize.Options... options)
Factory method to create a class wrapping a new CudnnRnnParamsSize operation.
|
static <T extends Number> |
CudnnRnnCanonicalToParams.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRnnCanonicalToParams.Options... options)
Factory method to create a class wrapping a new CudnnRnnCanonicalToParams operation.
|
static <T extends Number> |
CudnnRnnCanonicalToParams.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRnnCanonicalToParams.Options... options)
Factory method to create a class wrapping a new CudnnRnnCanonicalToParams operation.
|
static <T extends Number> |
CudnnRnnCanonicalToParams.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRnnCanonicalToParams.Options... options)
Factory method to create a class wrapping a new CudnnRnnCanonicalToParams operation.
|
static <T extends Number> |
CudnnRnnParamsToCanonical.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Operand<T> params,
Long numParams,
CudnnRnnParamsToCanonical.Options... options)
Factory method to create a class wrapping a new CudnnRnnParamsToCanonical operation.
|
static <T extends Number> |
CudnnRnnParamsToCanonical.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Operand<T> params,
Long numParams,
CudnnRnnParamsToCanonical.Options... options)
Factory method to create a class wrapping a new CudnnRnnParamsToCanonical operation.
|
static <T extends Number> |
CudnnRnnParamsToCanonical.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Operand<T> params,
Long numParams,
CudnnRnnParamsToCanonical.Options... options)
Factory method to create a class wrapping a new CudnnRnnParamsToCanonical operation.
|
static <T extends Number> |
CudnnRnnParamsToCanonical.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Operand<T> params,
Long numParams,
CudnnRnnParamsToCanonical.Options... options)
Factory method to create a class wrapping a new CudnnRnnParamsToCanonical operation.
|
static <T extends Number> |
AvgPool3dGrad.create(Scope scope,
Operand<Integer> origInputShape,
Operand<T> grad,
List<Long> ksize,
List<Long> strides,
String padding,
AvgPool3dGrad.Options... options)
Factory method to create a class wrapping a new AvgPool3dGrad operation.
|
static <T extends Number> |
AvgPool3dGrad.create(Scope scope,
Operand<Integer> origInputShape,
Operand<T> grad,
List<Long> ksize,
List<Long> strides,
String padding,
AvgPool3dGrad.Options... options)
Factory method to create a class wrapping a new AvgPool3dGrad operation.
|
static <T extends Number> |
AvgPoolGrad.create(Scope scope,
Operand<Integer> origInputShape,
Operand<T> grad,
List<Long> ksize,
List<Long> strides,
String padding,
AvgPoolGrad.Options... options)
Factory method to create a class wrapping a new AvgPoolGrad operation.
|
static <T extends Number> |
AvgPoolGrad.create(Scope scope,
Operand<Integer> origInputShape,
Operand<T> grad,
List<Long> ksize,
List<Long> strides,
String padding,
AvgPoolGrad.Options... options)
Factory method to create a class wrapping a new AvgPoolGrad operation.
|
static <T extends Number> |
Conv2dBackpropInput.create(Scope scope,
Operand<Integer> inputSizes,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
String padding,
Conv2dBackpropInput.Options... options)
Factory method to create a class wrapping a new Conv2dBackpropInput operation.
|
static <T extends Number> |
Conv2dBackpropInput.create(Scope scope,
Operand<Integer> inputSizes,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
String padding,
Conv2dBackpropInput.Options... options)
Factory method to create a class wrapping a new Conv2dBackpropInput operation.
|
static <T extends Number> |
Conv2dBackpropInput.create(Scope scope,
Operand<Integer> inputSizes,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
String padding,
Conv2dBackpropInput.Options... options)
Factory method to create a class wrapping a new Conv2dBackpropInput operation.
|
static <T extends Number> |
DepthwiseConv2dNativeBackpropInput.create(Scope scope,
Operand<Integer> inputSizes,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
String padding,
DepthwiseConv2dNativeBackpropInput.Options... options)
Factory method to create a class wrapping a new DepthwiseConv2dNativeBackpropInput operation.
|
static <T extends Number> |
DepthwiseConv2dNativeBackpropInput.create(Scope scope,
Operand<Integer> inputSizes,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
String padding,
DepthwiseConv2dNativeBackpropInput.Options... options)
Factory method to create a class wrapping a new DepthwiseConv2dNativeBackpropInput operation.
|
static <T extends Number> |
DepthwiseConv2dNativeBackpropInput.create(Scope scope,
Operand<Integer> inputSizes,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
String padding,
DepthwiseConv2dNativeBackpropInput.Options... options)
Factory method to create a class wrapping a new DepthwiseConv2dNativeBackpropInput operation.
|
static FixedUnigramCandidateSampler |
FixedUnigramCandidateSampler.create(Scope scope,
Operand<Long> trueClasses,
Long numTrue,
Long numSampled,
Boolean unique,
Long rangeMax,
FixedUnigramCandidateSampler.Options... options)
Factory method to create a class wrapping a new FixedUnigramCandidateSampler operation.
|
static LearnedUnigramCandidateSampler |
LearnedUnigramCandidateSampler.create(Scope scope,
Operand<Long> trueClasses,
Long numTrue,
Long numSampled,
Boolean unique,
Long rangeMax,
LearnedUnigramCandidateSampler.Options... options)
Factory method to create a class wrapping a new LearnedUnigramCandidateSampler operation.
|
static ComputeAccidentalHits |
ComputeAccidentalHits.create(Scope scope,
Operand<Long> trueClasses,
Operand<Long> sampledCandidates,
Long numTrue,
ComputeAccidentalHits.Options... options)
Factory method to create a class wrapping a new ComputeAccidentalHits operation.
|
static ComputeAccidentalHits |
ComputeAccidentalHits.create(Scope scope,
Operand<Long> trueClasses,
Operand<Long> sampledCandidates,
Long numTrue,
ComputeAccidentalHits.Options... options)
Factory method to create a class wrapping a new ComputeAccidentalHits operation.
|
static <T extends Number> |
FractionalAvgPoolGrad.create(Scope scope,
Operand<Long> origInputTensorShape,
Operand<T> outBackprop,
Operand<Long> rowPoolingSequence,
Operand<Long> colPoolingSequence,
FractionalAvgPoolGrad.Options... options)
Factory method to create a class wrapping a new FractionalAvgPoolGrad operation.
|
static <T extends Number> |
FractionalAvgPoolGrad.create(Scope scope,
Operand<Long> origInputTensorShape,
Operand<T> outBackprop,
Operand<Long> rowPoolingSequence,
Operand<Long> colPoolingSequence,
FractionalAvgPoolGrad.Options... options)
Factory method to create a class wrapping a new FractionalAvgPoolGrad operation.
|
static <T extends Number> |
FractionalAvgPoolGrad.create(Scope scope,
Operand<Long> origInputTensorShape,
Operand<T> outBackprop,
Operand<Long> rowPoolingSequence,
Operand<Long> colPoolingSequence,
FractionalAvgPoolGrad.Options... options)
Factory method to create a class wrapping a new FractionalAvgPoolGrad operation.
|
static <T extends Number> |
FractionalAvgPoolGrad.create(Scope scope,
Operand<Long> origInputTensorShape,
Operand<T> outBackprop,
Operand<Long> rowPoolingSequence,
Operand<Long> colPoolingSequence,
FractionalAvgPoolGrad.Options... options)
Factory method to create a class wrapping a new FractionalAvgPoolGrad operation.
|
static <T> Relu<T> |
Relu.create(Scope scope,
Operand<T> features)
Factory method to create a class wrapping a new Relu operation.
|
static <T extends Number> |
LogSoftmax.create(Scope scope,
Operand<T> logits)
Factory method to create a class wrapping a new LogSoftmax operation.
|
static <T extends Number> |
Softmax.create(Scope scope,
Operand<T> logits)
Factory method to create a class wrapping a new Softmax operation.
|
static <T extends Number> |
L2Loss.create(Scope scope,
Operand<T> t)
Factory method to create a class wrapping a new L2Loss operation.
|
static <T extends Number> |
Softsign.create(Scope scope,
Operand<T> features)
Factory method to create a class wrapping a new Softsign operation.
|
static <T extends Number> |
Elu.create(Scope scope,
Operand<T> features)
Factory method to create a class wrapping a new Elu operation.
|
static <T extends Number> |
Selu.create(Scope scope,
Operand<T> features)
Factory method to create a class wrapping a new Selu operation.
|
static <T extends Number> |
Relu6.create(Scope scope,
Operand<T> features)
Factory method to create a class wrapping a new Relu6 operation.
|
static <T> BiasAddGrad<T> |
BiasAddGrad.create(Scope scope,
Operand<T> outBackprop,
BiasAddGrad.Options... options)
Factory method to create a class wrapping a new BiasAddGrad operation.
|
static <T extends Number> |
DataFormatDimMap.create(Scope scope,
Operand<T> x,
DataFormatDimMap.Options... options)
Factory method to create a class wrapping a new DataFormatDimMap operation.
|
static <T extends Number> |
DataFormatVecPermute.create(Scope scope,
Operand<T> x,
DataFormatVecPermute.Options... options)
Factory method to create a class wrapping a new DataFormatVecPermute operation.
|
static <T extends Number> |
LeakyRelu.create(Scope scope,
Operand<T> features,
LeakyRelu.Options... options)
Factory method to create a class wrapping a new LeakyRelu operation.
|
static <T extends Number> |
FractionalAvgPool.create(Scope scope,
Operand<T> value,
List<Float> poolingRatio,
FractionalAvgPool.Options... options)
Factory method to create a class wrapping a new FractionalAvgPool operation.
|
static <T extends Number> |
FractionalMaxPool.create(Scope scope,
Operand<T> value,
List<Float> poolingRatio,
FractionalMaxPool.Options... options)
Factory method to create a class wrapping a new FractionalMaxPool operation.
|
static <T extends Number,U extends Number> |
MaxPoolWithArgmax.create(Scope scope,
Operand<T> input,
List<Long> ksize,
List<Long> strides,
Class<U> Targmax,
String padding,
MaxPoolWithArgmax.Options... options)
Factory method to create a class wrapping a new MaxPoolWithArgmax operation.
|
static <T extends Number> |
AvgPool.create(Scope scope,
Operand<T> value,
List<Long> ksize,
List<Long> strides,
String padding,
AvgPool.Options... options)
Factory method to create a class wrapping a new AvgPool operation.
|
static <T extends Number> |
AvgPool3d.create(Scope scope,
Operand<T> input,
List<Long> ksize,
List<Long> strides,
String padding,
AvgPool3d.Options... options)
Factory method to create a class wrapping a new AvgPool3d operation.
|
static <T extends Number> |
MaxPool3d.create(Scope scope,
Operand<T> input,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPool3d.Options... options)
Factory method to create a class wrapping a new MaxPool3d operation.
|
static <T extends Number> |
MaxPoolWithArgmax.create(Scope scope,
Operand<T> input,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPoolWithArgmax.Options... options)
Factory method to create a class wrapping a new MaxPoolWithArgmax operation using default output types.
|
static <T extends Number> |
LocalResponseNormalization.create(Scope scope,
Operand<T> input,
LocalResponseNormalization.Options... options)
Factory method to create a class wrapping a new LocalResponseNormalization operation.
|
static <T> DepthToSpace<T> |
DepthToSpace.create(Scope scope,
Operand<T> input,
Long blockSize,
DepthToSpace.Options... options)
Factory method to create a class wrapping a new DepthToSpace operation.
|
static <T> SpaceToDepth<T> |
SpaceToDepth.create(Scope scope,
Operand<T> input,
Long blockSize,
SpaceToDepth.Options... options)
Factory method to create a class wrapping a new SpaceToDepth operation.
|
static <U,T> QuantizedRelu<U> |
QuantizedRelu.create(Scope scope,
Operand<T> features,
Operand<Float> minFeatures,
Operand<Float> maxFeatures,
Class<U> outType)
Factory method to create a class wrapping a new QuantizedRelu operation.
|
static <U,T> QuantizedRelu<U> |
QuantizedRelu.create(Scope scope,
Operand<T> features,
Operand<Float> minFeatures,
Operand<Float> maxFeatures,
Class<U> outType)
Factory method to create a class wrapping a new QuantizedRelu operation.
|
static <U,T> QuantizedRelu<U> |
QuantizedRelu.create(Scope scope,
Operand<T> features,
Operand<Float> minFeatures,
Operand<Float> maxFeatures,
Class<U> outType)
Factory method to create a class wrapping a new QuantizedRelu operation.
|
static <U,T> QuantizedRelu6<U> |
QuantizedRelu6.create(Scope scope,
Operand<T> features,
Operand<Float> minFeatures,
Operand<Float> maxFeatures,
Class<U> outType)
Factory method to create a class wrapping a new QuantizedRelu6 operation.
|
static <U,T> QuantizedRelu6<U> |
QuantizedRelu6.create(Scope scope,
Operand<T> features,
Operand<Float> minFeatures,
Operand<Float> maxFeatures,
Class<U> outType)
Factory method to create a class wrapping a new QuantizedRelu6 operation.
|
static <U,T> QuantizedRelu6<U> |
QuantizedRelu6.create(Scope scope,
Operand<T> features,
Operand<Float> minFeatures,
Operand<Float> maxFeatures,
Class<U> outType)
Factory method to create a class wrapping a new QuantizedRelu6 operation.
|
static <T> QuantizedMaxPool<T> |
QuantizedMaxPool.create(Scope scope,
Operand<T> input,
Operand<Float> minInput,
Operand<Float> maxInput,
List<Long> ksize,
List<Long> strides,
String padding)
Factory method to create a class wrapping a new QuantizedMaxPool operation.
|
static <T> QuantizedMaxPool<T> |
QuantizedMaxPool.create(Scope scope,
Operand<T> input,
Operand<Float> minInput,
Operand<Float> maxInput,
List<Long> ksize,
List<Long> strides,
String padding)
Factory method to create a class wrapping a new QuantizedMaxPool operation.
|
static <T> QuantizedMaxPool<T> |
QuantizedMaxPool.create(Scope scope,
Operand<T> input,
Operand<Float> minInput,
Operand<Float> maxInput,
List<Long> ksize,
List<Long> strides,
String padding)
Factory method to create a class wrapping a new QuantizedMaxPool operation.
|
static <T> QuantizedAvgPool<T> |
QuantizedAvgPool.create(Scope scope,
Operand<T> input,
Operand<Float> minInput,
Operand<Float> maxInput,
List<Long> ksize,
List<Long> strides,
String padding)
Factory method to create a class wrapping a new QuantizedAvgPool operation.
|
static <T> QuantizedAvgPool<T> |
QuantizedAvgPool.create(Scope scope,
Operand<T> input,
Operand<Float> minInput,
Operand<Float> maxInput,
List<Long> ksize,
List<Long> strides,
String padding)
Factory method to create a class wrapping a new QuantizedAvgPool operation.
|
static <T> QuantizedAvgPool<T> |
QuantizedAvgPool.create(Scope scope,
Operand<T> input,
Operand<Float> minInput,
Operand<Float> maxInput,
List<Long> ksize,
List<Long> strides,
String padding)
Factory method to create a class wrapping a new QuantizedAvgPool operation.
|
static <U,T> QuantizedReluX<U> |
QuantizedReluX.create(Scope scope,
Operand<T> features,
Operand<Float> maxValue,
Operand<Float> minFeatures,
Operand<Float> maxFeatures,
Class<U> outType)
Factory method to create a class wrapping a new QuantizedReluX operation.
|
static <U,T> QuantizedReluX<U> |
QuantizedReluX.create(Scope scope,
Operand<T> features,
Operand<Float> maxValue,
Operand<Float> minFeatures,
Operand<Float> maxFeatures,
Class<U> outType)
Factory method to create a class wrapping a new QuantizedReluX operation.
|
static <U,T> QuantizedReluX<U> |
QuantizedReluX.create(Scope scope,
Operand<T> features,
Operand<Float> maxValue,
Operand<Float> minFeatures,
Operand<Float> maxFeatures,
Class<U> outType)
Factory method to create a class wrapping a new QuantizedReluX operation.
|
static <U,T> QuantizedReluX<U> |
QuantizedReluX.create(Scope scope,
Operand<T> features,
Operand<Float> maxValue,
Operand<Float> minFeatures,
Operand<Float> maxFeatures,
Class<U> outType)
Factory method to create a class wrapping a new QuantizedReluX operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <U,T> QuantizedBatchNormWithGlobalNormalization<U> |
QuantizedBatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<Float> tMin,
Operand<Float> tMax,
Operand<T> m,
Operand<Float> mMin,
Operand<Float> mMax,
Operand<T> v,
Operand<Float> vMin,
Operand<Float> vMax,
Operand<T> beta,
Operand<Float> betaMin,
Operand<Float> betaMax,
Operand<T> gamma,
Operand<Float> gammaMin,
Operand<Float> gammaMax,
Class<U> outType,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new QuantizedBatchNormWithGlobalNormalization operation.
|
static <T> QuantizedInstanceNorm<T> |
QuantizedInstanceNorm.create(Scope scope,
Operand<T> x,
Operand<Float> xMin,
Operand<Float> xMax,
QuantizedInstanceNorm.Options... options)
Factory method to create a class wrapping a new QuantizedInstanceNorm operation.
|
static <T> QuantizedInstanceNorm<T> |
QuantizedInstanceNorm.create(Scope scope,
Operand<T> x,
Operand<Float> xMin,
Operand<Float> xMax,
QuantizedInstanceNorm.Options... options)
Factory method to create a class wrapping a new QuantizedInstanceNorm operation.
|
static <T> QuantizedInstanceNorm<T> |
QuantizedInstanceNorm.create(Scope scope,
Operand<T> x,
Operand<Float> xMin,
Operand<Float> xMax,
QuantizedInstanceNorm.Options... options)
Factory method to create a class wrapping a new QuantizedInstanceNorm operation.
|
static <T extends Number> |
CtcGreedyDecoder.create(Scope scope,
Operand<T> inputs,
Operand<Integer> sequenceLength,
CtcGreedyDecoder.Options... options)
Factory method to create a class wrapping a new CtcGreedyDecoder operation.
|
static <T extends Number> |
CtcGreedyDecoder.create(Scope scope,
Operand<T> inputs,
Operand<Integer> sequenceLength,
CtcGreedyDecoder.Options... options)
Factory method to create a class wrapping a new CtcGreedyDecoder operation.
|
static <T extends Number> |
CtcBeamSearchDecoder.create(Scope scope,
Operand<T> inputs,
Operand<Integer> sequenceLength,
Long beamWidth,
Long topPaths,
CtcBeamSearchDecoder.Options... options)
Factory method to create a class wrapping a new CtcBeamSearchDecoder operation.
|
static <T extends Number> |
CtcBeamSearchDecoder.create(Scope scope,
Operand<T> inputs,
Operand<Integer> sequenceLength,
Long beamWidth,
Long topPaths,
CtcBeamSearchDecoder.Options... options)
Factory method to create a class wrapping a new CtcBeamSearchDecoder operation.
|
static <T extends Number> |
NthElement.create(Scope scope,
Operand<T> input,
Operand<Integer> n,
NthElement.Options... options)
Factory method to create a class wrapping a new NthElement operation.
|
static <T extends Number> |
NthElement.create(Scope scope,
Operand<T> input,
Operand<Integer> n,
NthElement.Options... options)
Factory method to create a class wrapping a new NthElement operation.
|
static <T extends Number> |
FusedResizeAndPadConv2d.create(Scope scope,
Operand<T> input,
Operand<Integer> size,
Operand<Integer> paddings,
Operand<T> filter,
String mode,
List<Long> strides,
String padding,
FusedResizeAndPadConv2d.Options... options)
Factory method to create a class wrapping a new FusedResizeAndPadConv2d operation.
|
static <T extends Number> |
FusedResizeAndPadConv2d.create(Scope scope,
Operand<T> input,
Operand<Integer> size,
Operand<Integer> paddings,
Operand<T> filter,
String mode,
List<Long> strides,
String padding,
FusedResizeAndPadConv2d.Options... options)
Factory method to create a class wrapping a new FusedResizeAndPadConv2d operation.
|
static <T extends Number> |
FusedResizeAndPadConv2d.create(Scope scope,
Operand<T> input,
Operand<Integer> size,
Operand<Integer> paddings,
Operand<T> filter,
String mode,
List<Long> strides,
String padding,
FusedResizeAndPadConv2d.Options... options)
Factory method to create a class wrapping a new FusedResizeAndPadConv2d operation.
|
static <T extends Number> |
FusedResizeAndPadConv2d.create(Scope scope,
Operand<T> input,
Operand<Integer> size,
Operand<Integer> paddings,
Operand<T> filter,
String mode,
List<Long> strides,
String padding,
FusedResizeAndPadConv2d.Options... options)
Factory method to create a class wrapping a new FusedResizeAndPadConv2d operation.
|
static <T> MaxPool<T> |
MaxPool.create(Scope scope,
Operand<T> input,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPool.Options... options)
Factory method to create a class wrapping a new MaxPool operation.
|
static <T> MaxPool<T> |
MaxPool.create(Scope scope,
Operand<T> input,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPool.Options... options)
Factory method to create a class wrapping a new MaxPool operation.
|
static <T> MaxPool<T> |
MaxPool.create(Scope scope,
Operand<T> input,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPool.Options... options)
Factory method to create a class wrapping a new MaxPool operation.
|
static <T extends Number> |
Conv2dBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<Integer> filterSizes,
Operand<T> outBackprop,
List<Long> strides,
String padding,
Conv2dBackpropFilter.Options... options)
Factory method to create a class wrapping a new Conv2dBackpropFilter operation.
|
static <T extends Number> |
Conv2dBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<Integer> filterSizes,
Operand<T> outBackprop,
List<Long> strides,
String padding,
Conv2dBackpropFilter.Options... options)
Factory method to create a class wrapping a new Conv2dBackpropFilter operation.
|
static <T extends Number> |
Conv2dBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<Integer> filterSizes,
Operand<T> outBackprop,
List<Long> strides,
String padding,
Conv2dBackpropFilter.Options... options)
Factory method to create a class wrapping a new Conv2dBackpropFilter operation.
|
static <T extends Number> |
Conv3dBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<Integer> filterSizes,
Operand<T> outBackprop,
List<Long> strides,
String padding,
Conv3dBackpropFilter.Options... options)
Factory method to create a class wrapping a new Conv3dBackpropFilter operation.
|
static <T extends Number> |
Conv3dBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<Integer> filterSizes,
Operand<T> outBackprop,
List<Long> strides,
String padding,
Conv3dBackpropFilter.Options... options)
Factory method to create a class wrapping a new Conv3dBackpropFilter operation.
|
static <T extends Number> |
Conv3dBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<Integer> filterSizes,
Operand<T> outBackprop,
List<Long> strides,
String padding,
Conv3dBackpropFilter.Options... options)
Factory method to create a class wrapping a new Conv3dBackpropFilter operation.
|
static <T extends Number> |
DepthwiseConv2dNativeBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<Integer> filterSizes,
Operand<T> outBackprop,
List<Long> strides,
String padding,
DepthwiseConv2dNativeBackpropFilter.Options... options)
Factory method to create a class wrapping a new DepthwiseConv2dNativeBackpropFilter operation.
|
static <T extends Number> |
DepthwiseConv2dNativeBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<Integer> filterSizes,
Operand<T> outBackprop,
List<Long> strides,
String padding,
DepthwiseConv2dNativeBackpropFilter.Options... options)
Factory method to create a class wrapping a new DepthwiseConv2dNativeBackpropFilter operation.
|
static <T extends Number> |
DepthwiseConv2dNativeBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<Integer> filterSizes,
Operand<T> outBackprop,
List<Long> strides,
String padding,
DepthwiseConv2dNativeBackpropFilter.Options... options)
Factory method to create a class wrapping a new DepthwiseConv2dNativeBackpropFilter operation.
|
static <T extends Number> |
FusedPadConv2d.create(Scope scope,
Operand<T> input,
Operand<Integer> paddings,
Operand<T> filter,
String mode,
List<Long> strides,
String padding)
Factory method to create a class wrapping a new FusedPadConv2d operation.
|
static <T extends Number> |
FusedPadConv2d.create(Scope scope,
Operand<T> input,
Operand<Integer> paddings,
Operand<T> filter,
String mode,
List<Long> strides,
String padding)
Factory method to create a class wrapping a new FusedPadConv2d operation.
|
static <T extends Number> |
FusedPadConv2d.create(Scope scope,
Operand<T> input,
Operand<Integer> paddings,
Operand<T> filter,
String mode,
List<Long> strides,
String padding)
Factory method to create a class wrapping a new FusedPadConv2d operation.
|
static <T extends Number> |
TopK.create(Scope scope,
Operand<T> input,
Operand<Integer> k,
TopK.Options... options)
Factory method to create a class wrapping a new TopK operation.
|
static <T extends Number> |
TopK.create(Scope scope,
Operand<T> input,
Operand<Integer> k,
TopK.Options... options)
Factory method to create a class wrapping a new TopK operation.
|
static <T extends Number> |
CtcLoss.create(Scope scope,
Operand<T> inputs,
Operand<Long> labelsIndices,
Operand<Integer> labelsValues,
Operand<Integer> sequenceLength,
CtcLoss.Options... options)
Factory method to create a class wrapping a new CtcLoss operation.
|
static <T extends Number> |
CtcLoss.create(Scope scope,
Operand<T> inputs,
Operand<Long> labelsIndices,
Operand<Integer> labelsValues,
Operand<Integer> sequenceLength,
CtcLoss.Options... options)
Factory method to create a class wrapping a new CtcLoss operation.
|
static <T extends Number> |
CtcLoss.create(Scope scope,
Operand<T> inputs,
Operand<Long> labelsIndices,
Operand<Integer> labelsValues,
Operand<Integer> sequenceLength,
CtcLoss.Options... options)
Factory method to create a class wrapping a new CtcLoss operation.
|
static <T extends Number> |
CtcLoss.create(Scope scope,
Operand<T> inputs,
Operand<Long> labelsIndices,
Operand<Integer> labelsValues,
Operand<Integer> sequenceLength,
CtcLoss.Options... options)
Factory method to create a class wrapping a new CtcLoss operation.
|
static <T> InvGrad<T> |
InvGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new InvGrad operation.
|
static <T> InvGrad<T> |
InvGrad.create(Scope scope,
Operand<T> y,
Operand<T> dy)
Factory method to create a class wrapping a new InvGrad operation.
|
static <T extends Number> |
Relu6Grad.create(Scope scope,
Operand<T> gradients,
Operand<T> features)
Factory method to create a class wrapping a new Relu6Grad operation.
|
static <T extends Number> |
Relu6Grad.create(Scope scope,
Operand<T> gradients,
Operand<T> features)
Factory method to create a class wrapping a new Relu6Grad operation.
|
static <T extends Number> |
SoftmaxCrossEntropyWithLogits.create(Scope scope,
Operand<T> features,
Operand<T> labels)
Factory method to create a class wrapping a new SoftmaxCrossEntropyWithLogits operation.
|
static <T extends Number> |
SoftmaxCrossEntropyWithLogits.create(Scope scope,
Operand<T> features,
Operand<T> labels)
Factory method to create a class wrapping a new SoftmaxCrossEntropyWithLogits operation.
|
static <T extends Number> |
SoftsignGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> features)
Factory method to create a class wrapping a new SoftsignGrad operation.
|
static <T extends Number> |
SoftsignGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> features)
Factory method to create a class wrapping a new SoftsignGrad operation.
|
static <T extends Number> |
EluGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> outputs)
Factory method to create a class wrapping a new EluGrad operation.
|
static <T extends Number> |
EluGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> outputs)
Factory method to create a class wrapping a new EluGrad operation.
|
static <T extends Number> |
SeluGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> outputs)
Factory method to create a class wrapping a new SeluGrad operation.
|
static <T extends Number> |
SeluGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> outputs)
Factory method to create a class wrapping a new SeluGrad operation.
|
static <T extends Number> |
ReluGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> features)
Factory method to create a class wrapping a new ReluGrad operation.
|
static <T extends Number> |
ReluGrad.create(Scope scope,
Operand<T> gradients,
Operand<T> features)
Factory method to create a class wrapping a new ReluGrad operation.
|
static <T> BiasAdd<T> |
BiasAdd.create(Scope scope,
Operand<T> value,
Operand<T> bias,
BiasAdd.Options... options)
Factory method to create a class wrapping a new BiasAdd operation.
|
static <T> BiasAdd<T> |
BiasAdd.create(Scope scope,
Operand<T> value,
Operand<T> bias,
BiasAdd.Options... options)
Factory method to create a class wrapping a new BiasAdd operation.
|
static <T extends Number> |
Dilation2d.create(Scope scope,
Operand<T> input,
Operand<T> filter,
List<Long> strides,
List<Long> rates,
String padding)
Factory method to create a class wrapping a new Dilation2d operation.
|
static <T extends Number> |
Dilation2d.create(Scope scope,
Operand<T> input,
Operand<T> filter,
List<Long> strides,
List<Long> rates,
String padding)
Factory method to create a class wrapping a new Dilation2d operation.
|
static <T extends Number> |
Conv2d.create(Scope scope,
Operand<T> input,
Operand<T> filter,
List<Long> strides,
String padding,
Conv2d.Options... options)
Factory method to create a class wrapping a new Conv2d operation.
|
static <T extends Number> |
Conv2d.create(Scope scope,
Operand<T> input,
Operand<T> filter,
List<Long> strides,
String padding,
Conv2d.Options... options)
Factory method to create a class wrapping a new Conv2d operation.
|
static <T extends Number> |
Conv3d.create(Scope scope,
Operand<T> input,
Operand<T> filter,
List<Long> strides,
String padding,
Conv3d.Options... options)
Factory method to create a class wrapping a new Conv3d operation.
|
static <T extends Number> |
Conv3d.create(Scope scope,
Operand<T> input,
Operand<T> filter,
List<Long> strides,
String padding,
Conv3d.Options... options)
Factory method to create a class wrapping a new Conv3d operation.
|
static <T extends Number> |
DepthwiseConv2dNative.create(Scope scope,
Operand<T> input,
Operand<T> filter,
List<Long> strides,
String padding,
DepthwiseConv2dNative.Options... options)
Factory method to create a class wrapping a new DepthwiseConv2dNative operation.
|
static <T extends Number> |
DepthwiseConv2dNative.create(Scope scope,
Operand<T> input,
Operand<T> filter,
List<Long> strides,
String padding,
DepthwiseConv2dNative.Options... options)
Factory method to create a class wrapping a new DepthwiseConv2dNative operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGrad.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
FusedBatchNormGrad.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGrad operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGrad.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
FusedBatchNormGrad.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGrad operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGrad.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
FusedBatchNormGrad.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGrad operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGrad.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
FusedBatchNormGrad.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGrad operation.
|
static <T extends Number,U extends Number> |
FusedBatchNormGrad.create(Scope scope,
Operand<T> yBackprop,
Operand<T> x,
Operand<Float> scale,
Operand<U> reserveSpace1,
Operand<U> reserveSpace2,
FusedBatchNormGrad.Options... options)
Factory method to create a class wrapping a new FusedBatchNormGrad operation.
|
static <T extends Number> |
Dilation2dBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
List<Long> rates,
String padding)
Factory method to create a class wrapping a new Dilation2dBackpropFilter operation.
|
static <T extends Number> |
Dilation2dBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
List<Long> rates,
String padding)
Factory method to create a class wrapping a new Dilation2dBackpropFilter operation.
|
static <T extends Number> |
Dilation2dBackpropFilter.create(Scope scope,
Operand<T> input,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
List<Long> rates,
String padding)
Factory method to create a class wrapping a new Dilation2dBackpropFilter operation.
|
static <T extends Number> |
Dilation2dBackpropInput.create(Scope scope,
Operand<T> input,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
List<Long> rates,
String padding)
Factory method to create a class wrapping a new Dilation2dBackpropInput operation.
|
static <T extends Number> |
Dilation2dBackpropInput.create(Scope scope,
Operand<T> input,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
List<Long> rates,
String padding)
Factory method to create a class wrapping a new Dilation2dBackpropInput operation.
|
static <T extends Number> |
Dilation2dBackpropInput.create(Scope scope,
Operand<T> input,
Operand<T> filter,
Operand<T> outBackprop,
List<Long> strides,
List<Long> rates,
String padding)
Factory method to create a class wrapping a new Dilation2dBackpropInput operation.
|
static <T extends Number> |
MaxPool3dGradGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPool3dGradGrad.Options... options)
Factory method to create a class wrapping a new MaxPool3dGradGrad operation.
|
static <T extends Number> |
MaxPool3dGradGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPool3dGradGrad.Options... options)
Factory method to create a class wrapping a new MaxPool3dGradGrad operation.
|
static <T extends Number> |
MaxPool3dGradGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPool3dGradGrad.Options... options)
Factory method to create a class wrapping a new MaxPool3dGradGrad operation.
|
static <T extends Number> |
LocalResponseNormalizationGrad.create(Scope scope,
Operand<T> inputGrads,
Operand<T> inputImage,
Operand<T> outputImage,
LocalResponseNormalizationGrad.Options... options)
Factory method to create a class wrapping a new LocalResponseNormalizationGrad operation.
|
static <T extends Number> |
LocalResponseNormalizationGrad.create(Scope scope,
Operand<T> inputGrads,
Operand<T> inputImage,
Operand<T> outputImage,
LocalResponseNormalizationGrad.Options... options)
Factory method to create a class wrapping a new LocalResponseNormalizationGrad operation.
|
static <T extends Number> |
LocalResponseNormalizationGrad.create(Scope scope,
Operand<T> inputGrads,
Operand<T> inputImage,
Operand<T> outputImage,
LocalResponseNormalizationGrad.Options... options)
Factory method to create a class wrapping a new LocalResponseNormalizationGrad operation.
|
static <T extends Number> |
MaxPoolGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPoolGrad.Options... options)
Factory method to create a class wrapping a new MaxPoolGrad operation.
|
static <T extends Number> |
MaxPoolGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPoolGrad.Options... options)
Factory method to create a class wrapping a new MaxPoolGrad operation.
|
static <T extends Number> |
MaxPoolGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPoolGrad.Options... options)
Factory method to create a class wrapping a new MaxPoolGrad operation.
|
static <T extends Number> |
MaxPoolGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPoolGrad.Options... options)
Factory method to create a class wrapping a new MaxPoolGrad operation.
|
static <T extends Number> |
MaxPoolGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPoolGrad.Options... options)
Factory method to create a class wrapping a new MaxPoolGrad operation.
|
static <T extends Number> |
MaxPoolGradGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPoolGradGrad.Options... options)
Factory method to create a class wrapping a new MaxPoolGradGrad operation.
|
static <T extends Number> |
MaxPoolGradGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPoolGradGrad.Options... options)
Factory method to create a class wrapping a new MaxPoolGradGrad operation.
|
static <T extends Number> |
MaxPoolGradGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPoolGradGrad.Options... options)
Factory method to create a class wrapping a new MaxPoolGradGrad operation.
|
static <T extends Number> |
MaxPoolGradGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPoolGradGrad.Options... options)
Factory method to create a class wrapping a new MaxPoolGradGrad operation.
|
static <T extends Number> |
MaxPoolGradGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> grad,
Operand<Integer> ksize,
Operand<Integer> strides,
String padding,
MaxPoolGradGrad.Options... options)
Factory method to create a class wrapping a new MaxPoolGradGrad operation.
|
static <T extends Number> |
FractionalMaxPoolGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> outBackprop,
Operand<Long> rowPoolingSequence,
Operand<Long> colPoolingSequence,
FractionalMaxPoolGrad.Options... options)
Factory method to create a class wrapping a new FractionalMaxPoolGrad operation.
|
static <T extends Number> |
FractionalMaxPoolGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> outBackprop,
Operand<Long> rowPoolingSequence,
Operand<Long> colPoolingSequence,
FractionalMaxPoolGrad.Options... options)
Factory method to create a class wrapping a new FractionalMaxPoolGrad operation.
|
static <T extends Number> |
FractionalMaxPoolGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> outBackprop,
Operand<Long> rowPoolingSequence,
Operand<Long> colPoolingSequence,
FractionalMaxPoolGrad.Options... options)
Factory method to create a class wrapping a new FractionalMaxPoolGrad operation.
|
static <T extends Number> |
FractionalMaxPoolGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> outBackprop,
Operand<Long> rowPoolingSequence,
Operand<Long> colPoolingSequence,
FractionalMaxPoolGrad.Options... options)
Factory method to create a class wrapping a new FractionalMaxPoolGrad operation.
|
static <T extends Number> |
FractionalMaxPoolGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<T> outBackprop,
Operand<Long> rowPoolingSequence,
Operand<Long> colPoolingSequence,
FractionalMaxPoolGrad.Options... options)
Factory method to create a class wrapping a new FractionalMaxPoolGrad operation.
|
static <T extends Number> |
CudnnRnn.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
CudnnRnn.Options... options)
Factory method to create a class wrapping a new CudnnRnn operation.
|
static <T extends Number> |
CudnnRnn.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
CudnnRnn.Options... options)
Factory method to create a class wrapping a new CudnnRnn operation.
|
static <T extends Number> |
CudnnRnn.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
CudnnRnn.Options... options)
Factory method to create a class wrapping a new CudnnRnn operation.
|
static <T extends Number> |
CudnnRnn.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
CudnnRnn.Options... options)
Factory method to create a class wrapping a new CudnnRnn operation.
|
static <T> BatchNormWithGlobalNormalizationGrad<T> |
BatchNormWithGlobalNormalizationGrad.create(Scope scope,
Operand<T> t,
Operand<T> m,
Operand<T> v,
Operand<T> gamma,
Operand<T> backprop,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new BatchNormWithGlobalNormalizationGrad operation.
|
static <T> BatchNormWithGlobalNormalizationGrad<T> |
BatchNormWithGlobalNormalizationGrad.create(Scope scope,
Operand<T> t,
Operand<T> m,
Operand<T> v,
Operand<T> gamma,
Operand<T> backprop,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new BatchNormWithGlobalNormalizationGrad operation.
|
static <T> BatchNormWithGlobalNormalizationGrad<T> |
BatchNormWithGlobalNormalizationGrad.create(Scope scope,
Operand<T> t,
Operand<T> m,
Operand<T> v,
Operand<T> gamma,
Operand<T> backprop,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new BatchNormWithGlobalNormalizationGrad operation.
|
static <T> BatchNormWithGlobalNormalizationGrad<T> |
BatchNormWithGlobalNormalizationGrad.create(Scope scope,
Operand<T> t,
Operand<T> m,
Operand<T> v,
Operand<T> gamma,
Operand<T> backprop,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new BatchNormWithGlobalNormalizationGrad operation.
|
static <T> BatchNormWithGlobalNormalizationGrad<T> |
BatchNormWithGlobalNormalizationGrad.create(Scope scope,
Operand<T> t,
Operand<T> m,
Operand<T> v,
Operand<T> gamma,
Operand<T> backprop,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new BatchNormWithGlobalNormalizationGrad operation.
|
static <T> BatchNormWithGlobalNormalization<T> |
BatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<T> m,
Operand<T> v,
Operand<T> beta,
Operand<T> gamma,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new BatchNormWithGlobalNormalization operation.
|
static <T> BatchNormWithGlobalNormalization<T> |
BatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<T> m,
Operand<T> v,
Operand<T> beta,
Operand<T> gamma,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new BatchNormWithGlobalNormalization operation.
|
static <T> BatchNormWithGlobalNormalization<T> |
BatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<T> m,
Operand<T> v,
Operand<T> beta,
Operand<T> gamma,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new BatchNormWithGlobalNormalization operation.
|
static <T> BatchNormWithGlobalNormalization<T> |
BatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<T> m,
Operand<T> v,
Operand<T> beta,
Operand<T> gamma,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new BatchNormWithGlobalNormalization operation.
|
static <T> BatchNormWithGlobalNormalization<T> |
BatchNormWithGlobalNormalization.create(Scope scope,
Operand<T> t,
Operand<T> m,
Operand<T> v,
Operand<T> beta,
Operand<T> gamma,
Float varianceEpsilon,
Boolean scaleAfterNormalization)
Factory method to create a class wrapping a new BatchNormWithGlobalNormalization operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <T extends Number> |
CudnnRnnBackprop.create(Scope scope,
Operand<T> input,
Operand<T> inputH,
Operand<T> inputC,
Operand<T> params,
Operand<T> output,
Operand<T> outputH,
Operand<T> outputC,
Operand<T> outputBackprop,
Operand<T> outputHBackprop,
Operand<T> outputCBackprop,
Operand<T> reserveSpace,
Operand<?> hostReserved,
CudnnRnnBackprop.Options... options)
Factory method to create a class wrapping a new CudnnRnnBackprop operation.
|
static <U extends Number,T extends Number> |
MaxPool3dGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<U> grad,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPool3dGrad.Options... options)
Factory method to create a class wrapping a new MaxPool3dGrad operation.
|
static <U extends Number,T extends Number> |
MaxPool3dGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<U> grad,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPool3dGrad.Options... options)
Factory method to create a class wrapping a new MaxPool3dGrad operation.
|
static <U extends Number,T extends Number> |
MaxPool3dGrad.create(Scope scope,
Operand<T> origInput,
Operand<T> origOutput,
Operand<U> grad,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPool3dGrad.Options... options)
Factory method to create a class wrapping a new MaxPool3dGrad operation.
|
static <T extends Number,U extends Number> |
MaxPoolGradGradWithArgmax.create(Scope scope,
Operand<T> input,
Operand<T> grad,
Operand<U> argmax,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPoolGradGradWithArgmax.Options... options)
Factory method to create a class wrapping a new MaxPoolGradGradWithArgmax operation.
|
static <T extends Number,U extends Number> |
MaxPoolGradGradWithArgmax.create(Scope scope,
Operand<T> input,
Operand<T> grad,
Operand<U> argmax,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPoolGradGradWithArgmax.Options... options)
Factory method to create a class wrapping a new MaxPoolGradGradWithArgmax operation.
|
static <T extends Number,U extends Number> |
MaxPoolGradGradWithArgmax.create(Scope scope,
Operand<T> input,
Operand<T> grad,
Operand<U> argmax,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPoolGradGradWithArgmax.Options... options)
Factory method to create a class wrapping a new MaxPoolGradGradWithArgmax operation.
|
static <T extends Number,U extends Number> |
MaxPoolGradWithArgmax.create(Scope scope,
Operand<T> input,
Operand<T> grad,
Operand<U> argmax,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPoolGradWithArgmax.Options... options)
Factory method to create a class wrapping a new MaxPoolGradWithArgmax operation.
|
static <T extends Number,U extends Number> |
MaxPoolGradWithArgmax.create(Scope scope,
Operand<T> input,
Operand<T> grad,
Operand<U> argmax,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPoolGradWithArgmax.Options... options)
Factory method to create a class wrapping a new MaxPoolGradWithArgmax operation.
|
static <T extends Number,U extends Number> |
MaxPoolGradWithArgmax.create(Scope scope,
Operand<T> input,
Operand<T> grad,
Operand<U> argmax,
List<Long> ksize,
List<Long> strides,
String padding,
MaxPoolGradWithArgmax.Options... options)
Factory method to create a class wrapping a new MaxPoolGradWithArgmax operation.
|
static <T extends Number,U extends Number> |
SparseSoftmaxCrossEntropyWithLogits.create(Scope scope,
Operand<T> features,
Operand<U> labels)
Factory method to create a class wrapping a new SparseSoftmaxCrossEntropyWithLogits operation.
|
static <T extends Number,U extends Number> |
SparseSoftmaxCrossEntropyWithLogits.create(Scope scope,
Operand<T> features,
Operand<U> labels)
Factory method to create a class wrapping a new SparseSoftmaxCrossEntropyWithLogits operation.
|
static <T,U extends Number> |
SpaceToBatch.create(Scope scope,
Operand<T> input,
Operand<U> paddings,
Long blockSize)
Factory method to create a class wrapping a new SpaceToBatch operation.
|
static <T,U extends Number> |
SpaceToBatch.create(Scope scope,
Operand<T> input,
Operand<U> paddings,
Long blockSize)
Factory method to create a class wrapping a new SpaceToBatch operation.
|
static <V,T,U> QuantizedBiasAdd<V> |
QuantizedBiasAdd.create(Scope scope,
Operand<T> input,
Operand<U> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minBias,
Operand<Float> maxBias,
Class<V> outType)
Factory method to create a class wrapping a new QuantizedBiasAdd operation.
|
static <V,T,U> QuantizedBiasAdd<V> |
QuantizedBiasAdd.create(Scope scope,
Operand<T> input,
Operand<U> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minBias,
Operand<Float> maxBias,
Class<V> outType)
Factory method to create a class wrapping a new QuantizedBiasAdd operation.
|
static <V,T,U> QuantizedBiasAdd<V> |
QuantizedBiasAdd.create(Scope scope,
Operand<T> input,
Operand<U> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minBias,
Operand<Float> maxBias,
Class<V> outType)
Factory method to create a class wrapping a new QuantizedBiasAdd operation.
|
static <V,T,U> QuantizedBiasAdd<V> |
QuantizedBiasAdd.create(Scope scope,
Operand<T> input,
Operand<U> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minBias,
Operand<Float> maxBias,
Class<V> outType)
Factory method to create a class wrapping a new QuantizedBiasAdd operation.
|
static <V,T,U> QuantizedBiasAdd<V> |
QuantizedBiasAdd.create(Scope scope,
Operand<T> input,
Operand<U> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minBias,
Operand<Float> maxBias,
Class<V> outType)
Factory method to create a class wrapping a new QuantizedBiasAdd operation.
|
static <V,T,U> QuantizedBiasAdd<V> |
QuantizedBiasAdd.create(Scope scope,
Operand<T> input,
Operand<U> bias,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minBias,
Operand<Float> maxBias,
Class<V> outType)
Factory method to create a class wrapping a new QuantizedBiasAdd operation.
|
static <V,T,U> QuantizedConv2d<V> |
QuantizedConv2d.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2d.Options... options)
Factory method to create a class wrapping a new QuantizedConv2d operation.
|
static <V,T,U> QuantizedConv2d<V> |
QuantizedConv2d.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2d.Options... options)
Factory method to create a class wrapping a new QuantizedConv2d operation.
|
static <V,T,U> QuantizedConv2d<V> |
QuantizedConv2d.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2d.Options... options)
Factory method to create a class wrapping a new QuantizedConv2d operation.
|
static <V,T,U> QuantizedConv2d<V> |
QuantizedConv2d.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2d.Options... options)
Factory method to create a class wrapping a new QuantizedConv2d operation.
|
static <V,T,U> QuantizedConv2d<V> |
QuantizedConv2d.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2d.Options... options)
Factory method to create a class wrapping a new QuantizedConv2d operation.
|
static <V,T,U> QuantizedConv2d<V> |
QuantizedConv2d.create(Scope scope,
Operand<T> input,
Operand<U> filter,
Operand<Float> minInput,
Operand<Float> maxInput,
Operand<Float> minFilter,
Operand<Float> maxFilter,
Class<V> outType,
List<Long> strides,
String padding,
QuantizedConv2d.Options... options)
Factory method to create a class wrapping a new QuantizedConv2d operation.
|
static <U extends Number,T extends Number> |
Conv3dBackpropInput.create(Scope scope,
Operand<T> inputSizes,
Operand<U> filter,
Operand<U> outBackprop,
List<Long> strides,
String padding,
Conv3dBackpropInput.Options... options)
Factory method to create a class wrapping a new Conv3dBackpropInput operation.
|
static <U extends Number,T extends Number> |
Conv3dBackpropInput.create(Scope scope,
Operand<T> inputSizes,
Operand<U> filter,
Operand<U> outBackprop,
List<Long> strides,
String padding,
Conv3dBackpropInput.Options... options)
Factory method to create a class wrapping a new Conv3dBackpropInput operation.
|
static <U extends Number,T extends Number> |
Conv3dBackpropInput.create(Scope scope,
Operand<T> inputSizes,
Operand<U> filter,
Operand<U> outBackprop,
List<Long> strides,
String padding,
Conv3dBackpropInput.Options... options)
Factory method to create a class wrapping a new Conv3dBackpropInput operation.
|
static <T extends Number,U extends Number> |
FusedBatchNorm.create(Scope scope,
Operand<T> x,
Operand<U> scale,
Operand<U> offset,
Operand<U> mean,
Operand<U> variance,
FusedBatchNorm.Options... options)
Factory method to create a class wrapping a new FusedBatchNorm operation.
|
static <T extends Number,U extends Number> |
FusedBatchNorm.create(Scope scope,
Operand<T> x,
Operand<U> scale,
Operand<U> offset,
Operand<U> mean,
Operand<U> variance,
FusedBatchNorm.Options... options)
Factory method to create a class wrapping a new FusedBatchNorm operation.
|
static <T extends Number,U extends Number> |
FusedBatchNorm.create(Scope scope,
Operand<T> x,
Operand<U> scale,
Operand<U> offset,
Operand<U> mean,
Operand<U> variance,
FusedBatchNorm.Options... options)
Factory method to create a class wrapping a new FusedBatchNorm operation.
|
static <T extends Number,U extends Number> |
FusedBatchNorm.create(Scope scope,
Operand<T> x,
Operand<U> scale,
Operand<U> offset,
Operand<U> mean,
Operand<U> variance,
FusedBatchNorm.Options... options)
Factory method to create a class wrapping a new FusedBatchNorm operation.
|
static <T extends Number,U extends Number> |
FusedBatchNorm.create(Scope scope,
Operand<T> x,
Operand<U> scale,
Operand<U> offset,
Operand<U> mean,
Operand<U> variance,
FusedBatchNorm.Options... options)
Factory method to create a class wrapping a new FusedBatchNorm operation.
|
Modifier and Type | Method and Description |
---|---|
static <T extends Number> |
CudnnRnnCanonicalToParams.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRnnCanonicalToParams.Options... options)
Factory method to create a class wrapping a new CudnnRnnCanonicalToParams operation.
|
static <T extends Number> |
CudnnRnnCanonicalToParams.create(Scope scope,
Operand<Integer> numLayers,
Operand<Integer> numUnits,
Operand<Integer> inputSize,
Iterable<Operand<T>> weights,
Iterable<Operand<T>> biases,
CudnnRnnCanonicalToParams.Options... options)
Factory method to create a class wrapping a new CudnnRnnCanonicalToParams operation.
|
Modifier and Type | Class and Description |
---|---|
class |
Dequantize
Dequantize the 'input' tensor into a float Tensor.
|
class |
FakeQuantWithMinMaxArgs
Fake-quantize the 'inputs' tensor, type float to 'outputs' tensor of same type.
|
class |
FakeQuantWithMinMaxArgsGradient
Compute gradients for a FakeQuantWithMinMaxArgs operation.
|
class |
FakeQuantWithMinMaxVars
Fake-quantize the 'inputs' tensor of type float via global float scalars `min`
|
class |
FakeQuantWithMinMaxVarsPerChannel
Fake-quantize the 'inputs' tensor of type float and one of the shapes: `[d]`,
|
class |
QuantizeAndDequantize<T extends Number>
Quantizes then dequantizes a tensor.
|
Modifier and Type | Method and Description |
---|---|
static FakeQuantWithMinMaxArgs |
FakeQuantWithMinMaxArgs.create(Scope scope,
Operand<Float> inputs,
FakeQuantWithMinMaxArgs.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxArgs operation.
|
static FakeQuantWithMinMaxArgsGradient |
FakeQuantWithMinMaxArgsGradient.create(Scope scope,
Operand<Float> gradients,
Operand<Float> inputs,
FakeQuantWithMinMaxArgsGradient.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxArgsGradient operation.
|
static FakeQuantWithMinMaxArgsGradient |
FakeQuantWithMinMaxArgsGradient.create(Scope scope,
Operand<Float> gradients,
Operand<Float> inputs,
FakeQuantWithMinMaxArgsGradient.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxArgsGradient operation.
|
static <T> Quantize<T> |
Quantize.create(Scope scope,
Operand<Float> input,
Operand<Float> minRange,
Operand<Float> maxRange,
Class<T> T,
Quantize.Options... options)
Factory method to create a class wrapping a new Quantize operation.
|
static <T> Quantize<T> |
Quantize.create(Scope scope,
Operand<Float> input,
Operand<Float> minRange,
Operand<Float> maxRange,
Class<T> T,
Quantize.Options... options)
Factory method to create a class wrapping a new Quantize operation.
|
static <T> Quantize<T> |
Quantize.create(Scope scope,
Operand<Float> input,
Operand<Float> minRange,
Operand<Float> maxRange,
Class<T> T,
Quantize.Options... options)
Factory method to create a class wrapping a new Quantize operation.
|
static FakeQuantWithMinMaxVars |
FakeQuantWithMinMaxVars.create(Scope scope,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVars.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVars operation.
|
static FakeQuantWithMinMaxVars |
FakeQuantWithMinMaxVars.create(Scope scope,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVars.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVars operation.
|
static FakeQuantWithMinMaxVars |
FakeQuantWithMinMaxVars.create(Scope scope,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVars.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVars operation.
|
static FakeQuantWithMinMaxVarsPerChannel |
FakeQuantWithMinMaxVarsPerChannel.create(Scope scope,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsPerChannel.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsPerChannel operation.
|
static FakeQuantWithMinMaxVarsPerChannel |
FakeQuantWithMinMaxVarsPerChannel.create(Scope scope,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsPerChannel.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsPerChannel operation.
|
static FakeQuantWithMinMaxVarsPerChannel |
FakeQuantWithMinMaxVarsPerChannel.create(Scope scope,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsPerChannel.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsPerChannel operation.
|
static FakeQuantWithMinMaxVarsGradient |
FakeQuantWithMinMaxVarsGradient.create(Scope scope,
Operand<Float> gradients,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsGradient.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsGradient operation.
|
static FakeQuantWithMinMaxVarsGradient |
FakeQuantWithMinMaxVarsGradient.create(Scope scope,
Operand<Float> gradients,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsGradient.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsGradient operation.
|
static FakeQuantWithMinMaxVarsGradient |
FakeQuantWithMinMaxVarsGradient.create(Scope scope,
Operand<Float> gradients,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsGradient.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsGradient operation.
|
static FakeQuantWithMinMaxVarsGradient |
FakeQuantWithMinMaxVarsGradient.create(Scope scope,
Operand<Float> gradients,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsGradient.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsGradient operation.
|
static FakeQuantWithMinMaxVarsPerChannelGradient |
FakeQuantWithMinMaxVarsPerChannelGradient.create(Scope scope,
Operand<Float> gradients,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsPerChannelGradient.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsPerChannelGradient operation.
|
static FakeQuantWithMinMaxVarsPerChannelGradient |
FakeQuantWithMinMaxVarsPerChannelGradient.create(Scope scope,
Operand<Float> gradients,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsPerChannelGradient.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsPerChannelGradient operation.
|
static FakeQuantWithMinMaxVarsPerChannelGradient |
FakeQuantWithMinMaxVarsPerChannelGradient.create(Scope scope,
Operand<Float> gradients,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsPerChannelGradient.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsPerChannelGradient operation.
|
static FakeQuantWithMinMaxVarsPerChannelGradient |
FakeQuantWithMinMaxVarsPerChannelGradient.create(Scope scope,
Operand<Float> gradients,
Operand<Float> inputs,
Operand<Float> min,
Operand<Float> max,
FakeQuantWithMinMaxVarsPerChannelGradient.Options... options)
Factory method to create a class wrapping a new FakeQuantWithMinMaxVarsPerChannelGradient operation.
|
static <T> RequantizationRange |
RequantizationRange.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax)
Factory method to create a class wrapping a new RequantizationRange operation.
|
static <T> RequantizationRange |
RequantizationRange.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax)
Factory method to create a class wrapping a new RequantizationRange operation.
|
static <T> RequantizationRange |
RequantizationRange.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax)
Factory method to create a class wrapping a new RequantizationRange operation.
|
static <U,T> QuantizeDownAndShrinkRange<U> |
QuantizeDownAndShrinkRange.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Class<U> outType)
Factory method to create a class wrapping a new QuantizeDownAndShrinkRange operation.
|
static <U,T> QuantizeDownAndShrinkRange<U> |
QuantizeDownAndShrinkRange.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Class<U> outType)
Factory method to create a class wrapping a new QuantizeDownAndShrinkRange operation.
|
static <U,T> QuantizeDownAndShrinkRange<U> |
QuantizeDownAndShrinkRange.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Class<U> outType)
Factory method to create a class wrapping a new QuantizeDownAndShrinkRange operation.
|
static <T> Dequantize |
Dequantize.create(Scope scope,
Operand<T> input,
Operand<Float> minRange,
Operand<Float> maxRange,
Dequantize.Options... options)
Factory method to create a class wrapping a new Dequantize operation.
|
static <T> Dequantize |
Dequantize.create(Scope scope,
Operand<T> input,
Operand<Float> minRange,
Operand<Float> maxRange,
Dequantize.Options... options)
Factory method to create a class wrapping a new Dequantize operation.
|
static <T> Dequantize |
Dequantize.create(Scope scope,
Operand<T> input,
Operand<Float> minRange,
Operand<Float> maxRange,
Dequantize.Options... options)
Factory method to create a class wrapping a new Dequantize operation.
|
static <U,T> Requantize<U> |
Requantize.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Operand<Float> requestedOutputMin,
Operand<Float> requestedOutputMax,
Class<U> outType)
Factory method to create a class wrapping a new Requantize operation.
|
static <U,T> Requantize<U> |
Requantize.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Operand<Float> requestedOutputMin,
Operand<Float> requestedOutputMax,
Class<U> outType)
Factory method to create a class wrapping a new Requantize operation.
|
static <U,T> Requantize<U> |
Requantize.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Operand<Float> requestedOutputMin,
Operand<Float> requestedOutputMax,
Class<U> outType)
Factory method to create a class wrapping a new Requantize operation.
|
static <U,T> Requantize<U> |
Requantize.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Operand<Float> requestedOutputMin,
Operand<Float> requestedOutputMax,
Class<U> outType)
Factory method to create a class wrapping a new Requantize operation.
|
static <U,T> Requantize<U> |
Requantize.create(Scope scope,
Operand<T> input,
Operand<Float> inputMin,
Operand<Float> inputMax,
Operand<Float> requestedOutputMin,
Operand<Float> requestedOutputMax,
Class<U> outType)
Factory method to create a class wrapping a new Requantize operation.
|
static <T extends Number> |
QuantizeAndDequantize.create(Scope scope,
Operand<T> input,
Operand<T> inputMin,
Operand<T> inputMax,
Operand<Integer> numBits,
QuantizeAndDequantize.Options... options)
Factory method to create a class wrapping a new QuantizeAndDequantize operation.
|
static <T extends Number> |
QuantizeAndDequantize.create(Scope scope,
Operand<T> input,
Operand<T> inputMin,
Operand<T> inputMax,
Operand<Integer> numBits,
QuantizeAndDequantize.Options... options)
Factory method to create a class wrapping a new QuantizeAndDequantize operation.
|
static <T extends Number> |
QuantizeAndDequantize.create(Scope scope,
Operand<T> input,
Operand<T> inputMin,
Operand<T> inputMax,
Operand<Integer> numBits,
QuantizeAndDequantize.Options... options)
Factory method to create a class wrapping a new QuantizeAndDequantize operation.
|
static <T extends Number> |
QuantizeAndDequantize.create(Scope scope,
Operand<T> input,
Operand<T> inputMin,
Operand<T> inputMax,
Operand<Integer> numBits,
QuantizeAndDequantize.Options... options)
Factory method to create a class wrapping a new QuantizeAndDequantize operation.
|
Modifier and Type | Class and Description |
---|---|
class |
Multinomial<U extends Number>
Draws samples from a multinomial distribution.
|
class |
ParameterizedTruncatedNormal<U extends Number>
Outputs random values from a normal distribution.
|
class |
RandomGamma<U extends Number>
Outputs random values from the Gamma distribution(s) described by alpha.
|
class |
RandomGammaGrad<T extends Number>
Computes the derivative of a Gamma random sample w.r.t.
|
class |
RandomPoisson<V extends Number>
Outputs random values from the Poisson distribution(s) described by rate.
|
class |
RandomShuffle<T>
Randomly shuffles a tensor along its first dimension.
|
class |
RandomStandardNormal<U extends Number>
Outputs random values from a normal distribution.
|
class |
RandomUniform<U extends Number>
Outputs random values from a uniform distribution.
|
class |
RandomUniformInt<U extends Number>
Outputs random integers from a uniform distribution.
|
class |
RecordInput
Emits randomized records.
|
class |
StatelessMultinomial<V extends Number>
Draws samples from a multinomial distribution.
|
class |
StatelessRandomNormal<V extends Number>
Outputs deterministic pseudorandom values from a normal distribution.
|
class |
StatelessRandomUniform<V extends Number>
Outputs deterministic pseudorandom random values from a uniform distribution.
|
class |
StatelessRandomUniformInt<V extends Number>
Outputs deterministic pseudorandom random integers from a uniform distribution.
|
class |
StatelessTruncatedNormal<V extends Number>
Outputs deterministic pseudorandom values from a truncated normal distribution.
|
class |
TruncatedNormal<U extends Number>
Outputs random values from a truncated normal distribution.
|
Modifier and Type | Method and Description |
---|---|
static AllCandidateSampler |
AllCandidateSampler.create(Scope scope,
Operand<Long> trueClasses,
Long numTrue,
Long numSampled,
Boolean unique,
AllCandidateSampler.Options... options)
Factory method to create a class wrapping a new AllCandidateSampler operation.
|
static LogUniformCandidateSampler |
LogUniformCandidateSampler.create(Scope scope,
Operand<Long> trueClasses,
Long numTrue,
Long numSampled,
Boolean unique,
Long rangeMax,
LogUniformCandidateSampler.Options... options)
Factory method to create a class wrapping a new LogUniformCandidateSampler operation.
|
static UniformCandidateSampler |
UniformCandidateSampler.create(Scope scope,
Operand<Long> trueClasses,
Long numTrue,
Long numSampled,
Boolean unique,
Long rangeMax,
UniformCandidateSampler.Options... options)
Factory method to create a class wrapping a new UniformCandidateSampler operation.
|
static <U extends Number,T extends Number> |
RandomStandardNormal.create(Scope scope,
Operand<T> shape,
Class<U> dtype,
RandomStandardNormal.Options... options)
Factory method to create a class wrapping a new RandomStandardNormal operation.
|
static <U extends Number,T extends Number> |
RandomUniform.create(Scope scope,
Operand<T> shape,
Class<U> dtype,
RandomUniform.Options... options)
Factory method to create a class wrapping a new RandomUniform operation.
|
static <U extends Number,T extends Number> |
TruncatedNormal.create(Scope scope,
Operand<T> shape,
Class<U> dtype,
TruncatedNormal.Options... options)
Factory method to create a class wrapping a new TruncatedNormal operation.
|
static <U extends Number,T extends Number> |
Multinomial.create(Scope scope,
Operand<T> logits,
Operand<Integer> numSamples,
Class<U> outputDtype,
Multinomial.Options... options)
Factory method to create a class wrapping a new Multinomial operation.
|
static <U extends Number,T extends Number> |
Multinomial.create(Scope scope,
Operand<T> logits,
Operand<Integer> numSamples,
Class<U> outputDtype,
Multinomial.Options... options)
Factory method to create a class wrapping a new Multinomial operation.
|
static <T extends Number> |
Multinomial.create(Scope scope,
Operand<T> logits,
Operand<Integer> numSamples,
Multinomial.Options... options)
Factory method to create a class wrapping a new Multinomial operation using default output types.
|
static <T extends Number> |
Multinomial.create(Scope scope,
Operand<T> logits,
Operand<Integer> numSamples,
Multinomial.Options... options)
Factory method to create a class wrapping a new Multinomial operation using default output types.
|
static <T extends Number,U extends Number> |
StatelessMultinomial.create(Scope scope,
Operand<T> logits,
Operand<Integer> numSamples,
Operand<U> seed)
Factory method to create a class wrapping a new StatelessMultinomial operation using default output types.
|
static <T extends Number,U extends Number> |
StatelessMultinomial.create(Scope scope,
Operand<T> logits,
Operand<Integer> numSamples,
Operand<U> seed)
Factory method to create a class wrapping a new StatelessMultinomial operation using default output types.
|
static <T extends Number,U extends Number> |
StatelessMultinomial.create(Scope scope,
Operand<T> logits,
Operand<Integer> numSamples,
Operand<U> seed)
Factory method to create a class wrapping a new StatelessMultinomial operation using default output types.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessMultinomial.create(Scope scope,
Operand<T> logits,
Operand<Integer> numSamples,
Operand<U> seed,
Class<V> outputDtype)
Factory method to create a class wrapping a new StatelessMultinomial operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessMultinomial.create(Scope scope,
Operand<T> logits,
Operand<Integer> numSamples,
Operand<U> seed,
Class<V> outputDtype)
Factory method to create a class wrapping a new StatelessMultinomial operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessMultinomial.create(Scope scope,
Operand<T> logits,
Operand<Integer> numSamples,
Operand<U> seed,
Class<V> outputDtype)
Factory method to create a class wrapping a new StatelessMultinomial operation.
|
static <T extends Number> |
RandomGammaGrad.create(Scope scope,
Operand<T> alpha,
Operand<T> sample)
Factory method to create a class wrapping a new RandomGammaGrad operation.
|
static <T extends Number> |
RandomGammaGrad.create(Scope scope,
Operand<T> alpha,
Operand<T> sample)
Factory method to create a class wrapping a new RandomGammaGrad operation.
|
static <T extends Number,U extends Number> |
StatelessTruncatedNormal.create(Scope scope,
Operand<T> shape,
Operand<U> seed)
Factory method to create a class wrapping a new StatelessTruncatedNormal operation using default output types.
|
static <T extends Number,U extends Number> |
StatelessTruncatedNormal.create(Scope scope,
Operand<T> shape,
Operand<U> seed)
Factory method to create a class wrapping a new StatelessTruncatedNormal operation using default output types.
|
static <T extends Number,U extends Number> |
StatelessRandomUniform.create(Scope scope,
Operand<T> shape,
Operand<U> seed)
Factory method to create a class wrapping a new StatelessRandomUniform operation using default output types.
|
static <T extends Number,U extends Number> |
StatelessRandomUniform.create(Scope scope,
Operand<T> shape,
Operand<U> seed)
Factory method to create a class wrapping a new StatelessRandomUniform operation using default output types.
|
static <T extends Number,U extends Number> |
StatelessRandomNormal.create(Scope scope,
Operand<T> shape,
Operand<U> seed)
Factory method to create a class wrapping a new StatelessRandomNormal operation using default output types.
|
static <T extends Number,U extends Number> |
StatelessRandomNormal.create(Scope scope,
Operand<T> shape,
Operand<U> seed)
Factory method to create a class wrapping a new StatelessRandomNormal operation using default output types.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessTruncatedNormal.create(Scope scope,
Operand<T> shape,
Operand<U> seed,
Class<V> dtype)
Factory method to create a class wrapping a new StatelessTruncatedNormal operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessTruncatedNormal.create(Scope scope,
Operand<T> shape,
Operand<U> seed,
Class<V> dtype)
Factory method to create a class wrapping a new StatelessTruncatedNormal operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessRandomUniform.create(Scope scope,
Operand<T> shape,
Operand<U> seed,
Class<V> dtype)
Factory method to create a class wrapping a new StatelessRandomUniform operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessRandomUniform.create(Scope scope,
Operand<T> shape,
Operand<U> seed,
Class<V> dtype)
Factory method to create a class wrapping a new StatelessRandomUniform operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessRandomNormal.create(Scope scope,
Operand<T> shape,
Operand<U> seed,
Class<V> dtype)
Factory method to create a class wrapping a new StatelessRandomNormal operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessRandomNormal.create(Scope scope,
Operand<T> shape,
Operand<U> seed,
Class<V> dtype)
Factory method to create a class wrapping a new StatelessRandomNormal operation.
|
static <V extends Number,T extends Number,U extends Number> |
RandomPoisson.create(Scope scope,
Operand<T> shape,
Operand<U> rate,
Class<V> dtype,
RandomPoisson.Options... options)
Factory method to create a class wrapping a new RandomPoisson operation.
|
static <V extends Number,T extends Number,U extends Number> |
RandomPoisson.create(Scope scope,
Operand<T> shape,
Operand<U> rate,
Class<V> dtype,
RandomPoisson.Options... options)
Factory method to create a class wrapping a new RandomPoisson operation.
|
static <U extends Number,T extends Number> |
ParameterizedTruncatedNormal.create(Scope scope,
Operand<T> shape,
Operand<U> means,
Operand<U> stdevs,
Operand<U> minvals,
Operand<U> maxvals,
ParameterizedTruncatedNormal.Options... options)
Factory method to create a class wrapping a new ParameterizedTruncatedNormal operation.
|
static <U extends Number,T extends Number> |
ParameterizedTruncatedNormal.create(Scope scope,
Operand<T> shape,
Operand<U> means,
Operand<U> stdevs,
Operand<U> minvals,
Operand<U> maxvals,
ParameterizedTruncatedNormal.Options... options)
Factory method to create a class wrapping a new ParameterizedTruncatedNormal operation.
|
static <U extends Number,T extends Number> |
ParameterizedTruncatedNormal.create(Scope scope,
Operand<T> shape,
Operand<U> means,
Operand<U> stdevs,
Operand<U> minvals,
Operand<U> maxvals,
ParameterizedTruncatedNormal.Options... options)
Factory method to create a class wrapping a new ParameterizedTruncatedNormal operation.
|
static <U extends Number,T extends Number> |
ParameterizedTruncatedNormal.create(Scope scope,
Operand<T> shape,
Operand<U> means,
Operand<U> stdevs,
Operand<U> minvals,
Operand<U> maxvals,
ParameterizedTruncatedNormal.Options... options)
Factory method to create a class wrapping a new ParameterizedTruncatedNormal operation.
|
static <U extends Number,T extends Number> |
ParameterizedTruncatedNormal.create(Scope scope,
Operand<T> shape,
Operand<U> means,
Operand<U> stdevs,
Operand<U> minvals,
Operand<U> maxvals,
ParameterizedTruncatedNormal.Options... options)
Factory method to create a class wrapping a new ParameterizedTruncatedNormal operation.
|
static <U extends Number,T extends Number> |
RandomUniformInt.create(Scope scope,
Operand<T> shape,
Operand<U> minval,
Operand<U> maxval,
RandomUniformInt.Options... options)
Factory method to create a class wrapping a new RandomUniformInt operation.
|
static <U extends Number,T extends Number> |
RandomUniformInt.create(Scope scope,
Operand<T> shape,
Operand<U> minval,
Operand<U> maxval,
RandomUniformInt.Options... options)
Factory method to create a class wrapping a new RandomUniformInt operation.
|
static <U extends Number,T extends Number> |
RandomUniformInt.create(Scope scope,
Operand<T> shape,
Operand<U> minval,
Operand<U> maxval,
RandomUniformInt.Options... options)
Factory method to create a class wrapping a new RandomUniformInt operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessRandomUniformInt.create(Scope scope,
Operand<T> shape,
Operand<U> seed,
Operand<V> minval,
Operand<V> maxval)
Factory method to create a class wrapping a new StatelessRandomUniformInt operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessRandomUniformInt.create(Scope scope,
Operand<T> shape,
Operand<U> seed,
Operand<V> minval,
Operand<V> maxval)
Factory method to create a class wrapping a new StatelessRandomUniformInt operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessRandomUniformInt.create(Scope scope,
Operand<T> shape,
Operand<U> seed,
Operand<V> minval,
Operand<V> maxval)
Factory method to create a class wrapping a new StatelessRandomUniformInt operation.
|
static <V extends Number,T extends Number,U extends Number> |
StatelessRandomUniformInt.create(Scope scope,
Operand<T> shape,
Operand<U> seed,
Operand<V> minval,
Operand<V> maxval)
Factory method to create a class wrapping a new StatelessRandomUniformInt operation.
|
static <U extends Number,T extends Number> |
RandomGamma.create(Scope scope,
Operand<T> shape,
Operand<U> alpha,
RandomGamma.Options... options)
Factory method to create a class wrapping a new RandomGamma operation.
|
static <U extends Number,T extends Number> |
RandomGamma.create(Scope scope,
Operand<T> shape,
Operand<U> alpha,
RandomGamma.Options... options)
Factory method to create a class wrapping a new RandomGamma operation.
|
static <T extends Number,U extends Number> |
RandomPoisson.create(Scope scope,
Operand<T> shape,
Operand<U> rate,
RandomPoisson.Options... options)
Factory method to create a class wrapping a new RandomPoisson operation using default output types.
|
static <T extends Number,U extends Number> |
RandomPoisson.create(Scope scope,
Operand<T> shape,
Operand<U> rate,
RandomPoisson.Options... options)
Factory method to create a class wrapping a new RandomPoisson operation using default output types.
|
static <T> RandomShuffle<T> |
RandomShuffle.create(Scope scope,
Operand<T> value,
RandomShuffle.Options... options)
Factory method to create a class wrapping a new RandomShuffle operation.
|
Modifier and Type | Class and Description |
---|---|
class |
BatchFft |
class |
BatchFft2d |
class |
BatchFft3d |
class |
BatchIfft |
class |
BatchIfft2d |
class |
BatchIfft3d |
class |
Fft<T>
Fast Fourier transform.
|
class |
Fft2d<T>
2D fast Fourier transform.
|
class |
Fft3d<T>
3D fast Fourier transform.
|
class |
Ifft<T>
Inverse fast Fourier transform.
|
class |
Ifft2d<T>
Inverse 2D fast Fourier transform.
|
class |
Ifft3d<T>
Inverse 3D fast Fourier transform.
|
class |
Irfft
Inverse real-valued fast Fourier transform.
|
class |
Irfft2d
Inverse 2D real-valued fast Fourier transform.
|
class |
Irfft3d
Inverse 3D real-valued fast Fourier transform.
|
class |
Rfft
Real-valued fast Fourier transform.
|
class |
Rfft2d
2D real-valued fast Fourier transform.
|
class |
Rfft3d
3D real-valued fast Fourier transform.
|
Modifier and Type | Method and Description |
---|---|
static BatchIfft2d |
BatchIfft2d.create(Scope scope,
Operand<?> input)
Factory method to create a class wrapping a new BatchIfft2d operation.
|
static BatchIfft |
BatchIfft.create(Scope scope,
Operand<?> input)
Factory method to create a class wrapping a new BatchIfft operation.
|
static BatchIfft3d |
BatchIfft3d.create(Scope scope,
Operand<?> input)
Factory method to create a class wrapping a new BatchIfft3d operation.
|
static BatchFft3d |
BatchFft3d.create(Scope scope,
Operand<?> input)
Factory method to create a class wrapping a new BatchFft3d operation.
|
static BatchFft2d |
BatchFft2d.create(Scope scope,
Operand<?> input)
Factory method to create a class wrapping a new BatchFft2d operation.
|
static BatchFft |
BatchFft.create(Scope scope,
Operand<?> input)
Factory method to create a class wrapping a new BatchFft operation.
|
static Irfft3d |
Irfft3d.create(Scope scope,
Operand<?> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Irfft3d operation.
|
static Irfft3d |
Irfft3d.create(Scope scope,
Operand<?> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Irfft3d operation.
|
static Irfft |
Irfft.create(Scope scope,
Operand<?> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Irfft operation.
|
static Irfft |
Irfft.create(Scope scope,
Operand<?> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Irfft operation.
|
static Irfft2d |
Irfft2d.create(Scope scope,
Operand<?> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Irfft2d operation.
|
static Irfft2d |
Irfft2d.create(Scope scope,
Operand<?> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Irfft2d operation.
|
static Rfft2d |
Rfft2d.create(Scope scope,
Operand<Float> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Rfft2d operation.
|
static Rfft2d |
Rfft2d.create(Scope scope,
Operand<Float> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Rfft2d operation.
|
static Rfft |
Rfft.create(Scope scope,
Operand<Float> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Rfft operation.
|
static Rfft |
Rfft.create(Scope scope,
Operand<Float> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Rfft operation.
|
static Rfft3d |
Rfft3d.create(Scope scope,
Operand<Float> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Rfft3d operation.
|
static Rfft3d |
Rfft3d.create(Scope scope,
Operand<Float> input,
Operand<Integer> fftLength)
Factory method to create a class wrapping a new Rfft3d operation.
|
static <T> Fft2d<T> |
Fft2d.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Fft2d operation.
|
static <T> Ifft2d<T> |
Ifft2d.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Ifft2d operation.
|
static <T> Ifft3d<T> |
Ifft3d.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Ifft3d operation.
|
static <T> Ifft<T> |
Ifft.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Ifft operation.
|
static <T> Fft3d<T> |
Fft3d.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Fft3d operation.
|
static <T> Fft<T> |
Fft.create(Scope scope,
Operand<T> input)
Factory method to create a class wrapping a new Fft operation.
|
Modifier and Type | Class and Description |
---|---|
class |
AddManySparseToTensorsMap
Add an `N`-minibatch `SparseTensor` to a `SparseTensorsMap`, return `N` handles.
|
class |
AddSparseToTensorsMap
Add a `SparseTensor` to a `SparseTensorsMap` return its handle.
|
class |
SparseConditionalAccumulator
A conditional accumulator for aggregating sparse gradients.
|
class |
SparseDenseCwiseAdd<T>
Adds up a SparseTensor and a dense Tensor, using these special rules:
|
class |
SparseDenseCwiseDiv<T>
Component-wise divides a SparseTensor by a dense Tensor.
|
class |
SparseDenseCwiseMul<T>
Component-wise multiplies a SparseTensor by a dense Tensor.
|
class |
SparseMatMul
Multiply matrix "a" by matrix "b".
|
class |
SparseReduceMax<T extends Number>
Computes the max of elements across dimensions of a SparseTensor.
|
class |
SparseReduceSum<T>
Computes the sum of elements across dimensions of a SparseTensor.
|
class |
SparseSegmentMean<T extends Number>
Computes the mean along sparse segments of a tensor.
|
class |
SparseSegmentMeanGrad<T extends Number>
Computes gradients for SparseSegmentMean.
|
class |
SparseSegmentMeanWithNumSegments<T extends Number>
Computes the mean along sparse segments of a tensor.
|
class |
SparseSegmentSqrtN<T extends Number>
Computes the sum along sparse segments of a tensor divided by the sqrt of N.
|
class |
SparseSegmentSqrtNGrad<T extends Number>
Computes gradients for SparseSegmentSqrtN.
|
class |
SparseSegmentSqrtNWithNumSegments<T extends Number>
Computes the sum along sparse segments of a tensor divided by the sqrt of N.
|
class |
SparseSegmentSum<T extends Number>
Computes the sum along sparse segments of a tensor.
|
class |
SparseSegmentSumWithNumSegments<T extends Number>
Computes the sum along sparse segments of a tensor.
|
class |
SparseSliceGrad<T>
The gradient operator for the SparseSlice op.
|
class |
SparseSoftmax<T extends Number>
Applies softmax to a batched N-D `SparseTensor`.
|
class |
SparseTensorDenseAdd<U>
Adds up a `SparseTensor` and a dense `Tensor`, producing a dense `Tensor`.
|
class |
SparseTensorDenseMatMul<U>
Multiply SparseTensor (of rank 2) "A" by dense matrix "B".
|
class |
SparseToDense<U>
Converts a sparse representation into a dense tensor.
|
Modifier and Type | Method and Description |
---|---|
static <T> TakeManySparseFromTensorsMap<T> |
TakeManySparseFromTensorsMap.create(Scope scope,
Operand<Long> sparseHandles,
Class<T> dtype,
TakeManySparseFromTensorsMap.Options... options)
Factory method to create a class wrapping a new TakeManySparseFromTensorsMap operation.
|
static SparseReshape |
SparseReshape.create(Scope scope,
Operand<Long> inputIndices,
Operand<Long> inputShape,
Operand<Long> newShape)
Factory method to create a class wrapping a new SparseReshape operation.
|
static SparseReshape |
SparseReshape.create(Scope scope,
Operand<Long> inputIndices,
Operand<Long> inputShape,
Operand<Long> newShape)
Factory method to create a class wrapping a new SparseReshape operation.
|
static SparseReshape |
SparseReshape.create(Scope scope,
Operand<Long> inputIndices,
Operand<Long> inputShape,
Operand<Long> newShape)
Factory method to create a class wrapping a new SparseReshape operation.
|
static <T> SparseSplit<T> |
SparseSplit.create(Scope scope,
Operand<Long> splitDim,
Operand<Long> indices,
Operand<T> values,
Operand<Long> shape,
Long numSplit)
Factory method to create a class wrapping a new SparseSplit operation.
|
static <T> SparseSplit<T> |
SparseSplit.create(Scope scope,
Operand<Long> splitDim,
Operand<Long> indices,
Operand<T> values,
Operand<Long> shape,
Long numSplit)
Factory method to create a class wrapping a new SparseSplit operation.
|
static <T> SparseSplit<T> |
SparseSplit.create(Scope scope,
Operand<Long> splitDim,
Operand<Long> indices,
Operand<T> values,
Operand<Long> shape,
Long numSplit)
Factory method to create a class wrapping a new SparseSplit operation.
|
static <T> SparseSplit<T> |
SparseSplit.create(Scope scope,
Operand<Long> splitDim,
Operand<Long> indices,
Operand<T> values,
Operand<Long> shape,
Long numSplit)
Factory method to create a class wrapping a new SparseSplit operation.
|
static <T> SparseFillEmptyRowsGrad<T> |
SparseFillEmptyRowsGrad.create(Scope scope,
Operand<Long> reverseIndexMap,
Operand<T> gradValues)
Factory method to create a class wrapping a new SparseFillEmptyRowsGrad operation.
|
static <T> SparseFillEmptyRowsGrad<T> |
SparseFillEmptyRowsGrad.create(Scope scope,
Operand<Long> reverseIndexMap,
Operand<T> gradValues)
Factory method to create a class wrapping a new SparseFillEmptyRowsGrad operation.
|
static <T> SparseReorder<T> |
SparseReorder.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape)
Factory method to create a class wrapping a new SparseReorder operation.
|
static <T> SparseReorder<T> |
SparseReorder.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape)
Factory method to create a class wrapping a new SparseReorder operation.
|
static <T> SparseReorder<T> |
SparseReorder.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape)
Factory method to create a class wrapping a new SparseReorder operation.
|
static <T extends Number> |
SparseSoftmax.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape)
Factory method to create a class wrapping a new SparseSoftmax operation.
|
static <T extends Number> |
SparseSoftmax.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape)
Factory method to create a class wrapping a new SparseSoftmax operation.
|
static <T extends Number> |
SparseSoftmax.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape)
Factory method to create a class wrapping a new SparseSoftmax operation.
|
static <T> AddManySparseToTensorsMap |
AddManySparseToTensorsMap.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
AddManySparseToTensorsMap.Options... options)
Factory method to create a class wrapping a new AddManySparseToTensorsMap operation.
|
static <T> AddManySparseToTensorsMap |
AddManySparseToTensorsMap.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
AddManySparseToTensorsMap.Options... options)
Factory method to create a class wrapping a new AddManySparseToTensorsMap operation.
|
static <T> AddManySparseToTensorsMap |
AddManySparseToTensorsMap.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
AddManySparseToTensorsMap.Options... options)
Factory method to create a class wrapping a new AddManySparseToTensorsMap operation.
|
static <T> AddSparseToTensorsMap |
AddSparseToTensorsMap.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
AddSparseToTensorsMap.Options... options)
Factory method to create a class wrapping a new AddSparseToTensorsMap operation.
|
static <T> AddSparseToTensorsMap |
AddSparseToTensorsMap.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
AddSparseToTensorsMap.Options... options)
Factory method to create a class wrapping a new AddSparseToTensorsMap operation.
|
static <T> AddSparseToTensorsMap |
AddSparseToTensorsMap.create(Scope scope,
Operand<Long> sparseIndices,
Operand<T> sparseValues,
Operand<Long> sparseShape,
AddSparseToTensorsMap.Options... options)
Factory method to create a class wrapping a new AddSparseToTensorsMap operation.
|
static <T extends Number> |
SparseReduceMax.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceMax.Options... options)
Factory method to create a class wrapping a new SparseReduceMax operation.
|
static <T extends Number> |
SparseReduceMax.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceMax.Options... options)
Factory method to create a class wrapping a new SparseReduceMax operation.
|
static <T extends Number> |
SparseReduceMax.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceMax.Options... options)
Factory method to create a class wrapping a new SparseReduceMax operation.
|
static <T extends Number> |
SparseReduceMax.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceMax.Options... options)
Factory method to create a class wrapping a new SparseReduceMax operation.
|
static <T extends Number> |
SparseReduceMaxSparse.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceMaxSparse.Options... options)
Factory method to create a class wrapping a new SparseReduceMaxSparse operation.
|
static <T extends Number> |
SparseReduceMaxSparse.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceMaxSparse.Options... options)
Factory method to create a class wrapping a new SparseReduceMaxSparse operation.
|
static <T extends Number> |
SparseReduceMaxSparse.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceMaxSparse.Options... options)
Factory method to create a class wrapping a new SparseReduceMaxSparse operation.
|
static <T extends Number> |
SparseReduceMaxSparse.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceMaxSparse.Options... options)
Factory method to create a class wrapping a new SparseReduceMaxSparse operation.
|
static <T> SparseReduceSum<T> |
SparseReduceSum.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceSum.Options... options)
Factory method to create a class wrapping a new SparseReduceSum operation.
|
static <T> SparseReduceSum<T> |
SparseReduceSum.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceSum.Options... options)
Factory method to create a class wrapping a new SparseReduceSum operation.
|
static <T> SparseReduceSum<T> |
SparseReduceSum.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceSum.Options... options)
Factory method to create a class wrapping a new SparseReduceSum operation.
|
static <T> SparseReduceSum<T> |
SparseReduceSum.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceSum.Options... options)
Factory method to create a class wrapping a new SparseReduceSum operation.
|
static <T> SparseReduceSumSparse<T> |
SparseReduceSumSparse.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceSumSparse.Options... options)
Factory method to create a class wrapping a new SparseReduceSumSparse operation.
|
static <T> SparseReduceSumSparse<T> |
SparseReduceSumSparse.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceSumSparse.Options... options)
Factory method to create a class wrapping a new SparseReduceSumSparse operation.
|
static <T> SparseReduceSumSparse<T> |
SparseReduceSumSparse.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceSumSparse.Options... options)
Factory method to create a class wrapping a new SparseReduceSumSparse operation.
|
static <T> SparseReduceSumSparse<T> |
SparseReduceSumSparse.create(Scope scope,
Operand<Long> inputIndices,
Operand<T> inputValues,
Operand<Long> inputShape,
Operand<Integer> reductionAxes,
SparseReduceSumSparse.Options... options)
Factory method to create a class wrapping a new SparseReduceSumSparse operation.
|
static <T> SparseSlice<T> |
SparseSlice.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> shape,
Operand<Long> start,
Operand<Long> size)
Factory method to create a class wrapping a new SparseSlice operation.
|
static <T> SparseSlice<T> |
SparseSlice.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> shape,
Operand<Long> start,
Operand<Long> size)
Factory method to create a class wrapping a new SparseSlice operation.
|
static <T> SparseSlice<T> |
SparseSlice.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> shape,
Operand<Long> start,
Operand<Long> size)
Factory method to create a class wrapping a new SparseSlice operation.
|
static <T> SparseSlice<T> |
SparseSlice.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> shape,
Operand<Long> start,
Operand<Long> size)
Factory method to create a class wrapping a new SparseSlice operation.
|
static <T> SparseSlice<T> |
SparseSlice.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> shape,
Operand<Long> start,
Operand<Long> size)
Factory method to create a class wrapping a new SparseSlice operation.
|
static <T> SparseSparseMinimum<T> |
SparseSparseMinimum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMinimum operation.
|
static <T> SparseSparseMinimum<T> |
SparseSparseMinimum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMinimum operation.
|
static <T> SparseSparseMinimum<T> |
SparseSparseMinimum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMinimum operation.
|
static <T> SparseSparseMinimum<T> |
SparseSparseMinimum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMinimum operation.
|
static <T> SparseSparseMinimum<T> |
SparseSparseMinimum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMinimum operation.
|
static <T> SparseSparseMinimum<T> |
SparseSparseMinimum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMinimum operation.
|
static <T extends Number> |
SparseSparseMaximum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMaximum operation.
|
static <T extends Number> |
SparseSparseMaximum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMaximum operation.
|
static <T extends Number> |
SparseSparseMaximum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMaximum operation.
|
static <T extends Number> |
SparseSparseMaximum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMaximum operation.
|
static <T extends Number> |
SparseSparseMaximum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMaximum operation.
|
static <T extends Number> |
SparseSparseMaximum.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape)
Factory method to create a class wrapping a new SparseSparseMaximum operation.
|
static <T,U extends Number> |
SparseAdd.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape,
Operand<U> thresh)
Factory method to create a class wrapping a new SparseAdd operation.
|
static <T,U extends Number> |
SparseAdd.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape,
Operand<U> thresh)
Factory method to create a class wrapping a new SparseAdd operation.
|
static <T,U extends Number> |
SparseAdd.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape,
Operand<U> thresh)
Factory method to create a class wrapping a new SparseAdd operation.
|
static <T,U extends Number> |
SparseAdd.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape,
Operand<U> thresh)
Factory method to create a class wrapping a new SparseAdd operation.
|
static <T,U extends Number> |
SparseAdd.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape,
Operand<U> thresh)
Factory method to create a class wrapping a new SparseAdd operation.
|
static <T,U extends Number> |
SparseAdd.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape,
Operand<U> thresh)
Factory method to create a class wrapping a new SparseAdd operation.
|
static <T,U extends Number> |
SparseAdd.create(Scope scope,
Operand<Long> aIndices,
Operand<T> aValues,
Operand<Long> aShape,
Operand<Long> bIndices,
Operand<T> bValues,
Operand<Long> bShape,
Operand<U> thresh)
Factory method to create a class wrapping a new SparseAdd operation.
|
static <T> SparseToSparseSetOperation<T> |
SparseToSparseSetOperation.create(Scope scope,
Operand<Long> set1Indices,
Operand<T> set1Values,
Operand<Long> set1Shape,
Operand<Long> set2Indices,
Operand<T> set2Values,
Operand<Long> set2Shape,
String setOperation,
SparseToSparseSetOperation.Options... options)
Factory method to create a class wrapping a new SparseToSparseSetOperation operation.
|
static <T> SparseToSparseSetOperation<T> |
SparseToSparseSetOperation.create(Scope scope,
Operand<Long> set1Indices,
Operand<T> set1Values,
Operand<Long> set1Shape,
Operand<Long> set2Indices,
Operand<T> set2Values,
Operand<Long> set2Shape,
String setOperation,
SparseToSparseSetOperation.Options... options)
Factory method to create a class wrapping a new SparseToSparseSetOperation operation.
|
static <T> SparseToSparseSetOperation<T> |
SparseToSparseSetOperation.create(Scope scope,
Operand<Long> set1Indices,
Operand<T> set1Values,
Operand<Long> set1Shape,
Operand<Long> set2Indices,
Operand<T> set2Values,
Operand<Long> set2Shape,
String setOperation,
SparseToSparseSetOperation.Options... options)
Factory method to create a class wrapping a new SparseToSparseSetOperation operation.
|
static <T> SparseToSparseSetOperation<T> |
SparseToSparseSetOperation.create(Scope scope,
Operand<Long> set1Indices,
Operand<T> set1Values,
Operand<Long> set1Shape,
Operand<Long> set2Indices,
Operand<T> set2Values,
Operand<Long> set2Shape,
String setOperation,
SparseToSparseSetOperation.Options... options)
Factory method to create a class wrapping a new SparseToSparseSetOperation operation.
|
static <T> SparseToSparseSetOperation<T> |
SparseToSparseSetOperation.create(Scope scope,
Operand<Long> set1Indices,
Operand<T> set1Values,
Operand<Long> set1Shape,
Operand<Long> set2Indices,
Operand<T> set2Values,
Operand<Long> set2Shape,
String setOperation,
SparseToSparseSetOperation.Options... options)
Factory method to create a class wrapping a new SparseToSparseSetOperation operation.
|
static <T> SparseToSparseSetOperation<T> |
SparseToSparseSetOperation.create(Scope scope,
Operand<Long> set1Indices,
Operand<T> set1Values,
Operand<Long> set1Shape,
Operand<Long> set2Indices,
Operand<T> set2Values,
Operand<Long> set2Shape,
String setOperation,
SparseToSparseSetOperation.Options... options)
Factory method to create a class wrapping a new SparseToSparseSetOperation operation.
|
static <T> SparseDenseCwiseDiv<T> |
SparseDenseCwiseDiv.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseDiv operation.
|
static <T> SparseDenseCwiseDiv<T> |
SparseDenseCwiseDiv.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseDiv operation.
|
static <T> SparseDenseCwiseDiv<T> |
SparseDenseCwiseDiv.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseDiv operation.
|
static <T> SparseDenseCwiseDiv<T> |
SparseDenseCwiseDiv.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseDiv operation.
|
static <T> SparseDenseCwiseMul<T> |
SparseDenseCwiseMul.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseMul operation.
|
static <T> SparseDenseCwiseMul<T> |
SparseDenseCwiseMul.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseMul operation.
|
static <T> SparseDenseCwiseMul<T> |
SparseDenseCwiseMul.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseMul operation.
|
static <T> SparseDenseCwiseMul<T> |
SparseDenseCwiseMul.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseMul operation.
|
static <T> SparseFillEmptyRows<T> |
SparseFillEmptyRows.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> denseShape,
Operand<T> defaultValue)
Factory method to create a class wrapping a new SparseFillEmptyRows operation.
|
static <T> SparseFillEmptyRows<T> |
SparseFillEmptyRows.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> denseShape,
Operand<T> defaultValue)
Factory method to create a class wrapping a new SparseFillEmptyRows operation.
|
static <T> SparseFillEmptyRows<T> |
SparseFillEmptyRows.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> denseShape,
Operand<T> defaultValue)
Factory method to create a class wrapping a new SparseFillEmptyRows operation.
|
static <T> SparseFillEmptyRows<T> |
SparseFillEmptyRows.create(Scope scope,
Operand<Long> indices,
Operand<T> values,
Operand<Long> denseShape,
Operand<T> defaultValue)
Factory method to create a class wrapping a new SparseFillEmptyRows operation.
|
static <T> SparseDenseCwiseAdd<T> |
SparseDenseCwiseAdd.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseAdd operation.
|
static <T> SparseDenseCwiseAdd<T> |
SparseDenseCwiseAdd.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseAdd operation.
|
static <T> SparseDenseCwiseAdd<T> |
SparseDenseCwiseAdd.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseAdd operation.
|
static <T> SparseDenseCwiseAdd<T> |
SparseDenseCwiseAdd.create(Scope scope,
Operand<Long> spIndices,
Operand<T> spValues,
Operand<Long> spShape,
Operand<T> dense)
Factory method to create a class wrapping a new SparseDenseCwiseAdd operation.
|
static <T> SparseAccumulatorTakeGradient<T> |
SparseAccumulatorTakeGradient.create(Scope scope,
Operand<String> handle,
Operand<Integer> numRequired,
Class<T> dtype)
Factory method to create a class wrapping a new SparseAccumulatorTakeGradient operation.
|
static <T> SparseAccumulatorTakeGradient<T> |
SparseAccumulatorTakeGradient.create(Scope scope,
Operand<String> handle,
Operand<Integer> numRequired,
Class<T> dtype)
Factory method to create a class wrapping a new SparseAccumulatorTakeGradient operation.
|
static <T> SparseAccumulatorApplyGradient |
SparseAccumulatorApplyGradient.create(Scope scope,
Operand<String> handle,
Operand<Long> localStep,
Operand<Long> gradientIndices,
Operand<T> gradientValues,
Operand<Long> gradientShape,
Boolean hasKnownShape)
Factory method to create a class wrapping a new SparseAccumulatorApplyGradient operation.
|
static <T> SparseAccumulatorApplyGradient |
SparseAccumulatorApplyGradient.create(Scope scope,
Operand<String> handle,
Operand<Long> localStep,
Operand<Long> gradientIndices,
Operand<T> gradientValues,
Operand<Long> gradientShape,
Boolean hasKnownShape)
Factory method to create a class wrapping a new SparseAccumulatorApplyGradient operation.
|
static <T> SparseAccumulatorApplyGradient |
SparseAccumulatorApplyGradient.create(Scope scope,
Operand<String> handle,
Operand<Long> localStep,
Operand<Long> gradientIndices,
Operand<T> gradientValues,
Operand<Long> gradientShape,
Boolean hasKnownShape)
Factory method to create a class wrapping a new SparseAccumulatorApplyGradient operation.
|
static <T> SparseAccumulatorApplyGradient |
SparseAccumulatorApplyGradient.create(Scope scope,
Operand<String> handle,
Operand<Long> localStep,
Operand<Long> gradientIndices,
Operand<T> gradientValues,
Operand<Long> gradientShape,
Boolean hasKnownShape)
Factory method to create a class wrapping a new SparseAccumulatorApplyGradient operation.
|
static <T> SparseAccumulatorApplyGradient |
SparseAccumulatorApplyGradient.create(Scope scope,
Operand<String> handle,
Operand<Long> localStep,
Operand<Long> gradientIndices,
Operand<T> gradientValues,
Operand<Long> gradientShape,
Boolean hasKnownShape)
Factory method to create a class wrapping a new SparseAccumulatorApplyGradient operation.
|
static <U,T> DeserializeSparse<U> |
DeserializeSparse.create(Scope scope,
Operand<T> serializedSparse,
Class<U> dtype)
Factory method to create a class wrapping a new DeserializeSparse operation.
|
static <T> SparseAddGrad<T> |
SparseAddGrad.create(Scope scope,
Operand<T> backpropValGrad,
Operand<Long> aIndices,
Operand<Long> bIndices,
Operand<Long> sumIndices)
Factory method to create a class wrapping a new SparseAddGrad operation.
|
static <T> SparseAddGrad<T> |
SparseAddGrad.create(Scope scope,
Operand<T> backpropValGrad,
Operand<Long> aIndices,
Operand<Long> bIndices,
Operand<Long> sumIndices)
Factory method to create a class wrapping a new SparseAddGrad operation.
|
static <T> SparseAddGrad<T> |
SparseAddGrad.create(Scope scope,
Operand<T> backpropValGrad,
Operand<Long> aIndices,
Operand<Long> bIndices,
Operand<Long> sumIndices)
Factory method to create a class wrapping a new SparseAddGrad operation.
|
static <T> SparseAddGrad<T> |
SparseAddGrad.create(Scope scope,
Operand<T> backpropValGrad,
Operand<Long> aIndices,
Operand<Long> bIndices,
Operand<Long> sumIndices)
Factory method to create a class wrapping a new SparseAddGrad operation.
|
static <T> SparseSliceGrad<T> |
SparseSliceGrad.create(Scope scope,
Operand<T> backpropValGrad,
Operand<Long> inputIndices,
Operand<Long> inputStart,
Operand<Long> outputIndices)
Factory method to create a class wrapping a new SparseSliceGrad operation.
|
static <T> SparseSliceGrad<T> |
SparseSliceGrad.create(Scope scope,
Operand<T> backpropValGrad,
Operand<Long> inputIndices,
Operand<Long> inputStart,
Operand<Long> outputIndices)
Factory method to create a class wrapping a new SparseSliceGrad operation.
|
static <T> SparseSliceGrad<T> |
SparseSliceGrad.create(Scope scope,
Operand<T> backpropValGrad,
Operand<Long> inputIndices,
Operand<Long> inputStart,
Operand<Long> outputIndices)
Factory method to create a class wrapping a new SparseSliceGrad operation.
|
static <T> SparseSliceGrad<T> |
SparseSliceGrad.create(Scope scope,
Operand<T> backpropValGrad,
Operand<Long> inputIndices,
Operand<Long> inputStart,
Operand<Long> outputIndices)
Factory method to create a class wrapping a new SparseSliceGrad operation.
|
static <T> DenseToSparseSetOperation<T> |
DenseToSparseSetOperation.create(Scope scope,
Operand<T> set1,
Operand<Long> set2Indices,
Operand<T> set2Values,
Operand<Long> set2Shape,
String setOperation,
DenseToSparseSetOperation.Options... options)
Factory method to create a class wrapping a new DenseToSparseSetOperation operation.
|
static <T> DenseToSparseSetOperation<T> |
DenseToSparseSetOperation.create(Scope scope,
Operand<T> set1,
Operand<Long> set2Indices,
Operand<T> set2Values,
Operand<Long> set2Shape,
String setOperation,
DenseToSparseSetOperation.Options... options)
Factory method to create a class wrapping a new DenseToSparseSetOperation operation.
|
static <T> DenseToSparseSetOperation<T> |
DenseToSparseSetOperation.create(Scope scope,
Operand<T> set1,
Operand<Long> set2Indices,
Operand<T> set2Values,
Operand<Long> set2Shape,
String setOperation,
DenseToSparseSetOperation.Options... options)
Factory method to create a class wrapping a new DenseToSparseSetOperation operation.
|
static <T> DenseToSparseSetOperation<T> |
DenseToSparseSetOperation.create(Scope scope,
Operand<T> set1,
Operand<Long> set2Indices,
Operand<T> set2Values,
Operand<Long> set2Shape,
String setOperation,
DenseToSparseSetOperation.Options... options)
Factory method to create a class wrapping a new DenseToSparseSetOperation operation.
|
static <U,T extends Number> |
SparseToDense.create(Scope scope,
Operand<T> sparseIndices,
Operand<T> outputShape,
Operand<U> sparseValues,
Operand<U> defaultValue,
SparseToDense.Options... options)
Factory method to create a class wrapping a new SparseToDense operation.
|
static <U,T extends Number> |
SparseToDense.create(Scope scope,
Operand<T> sparseIndices,
Operand<T> outputShape,
Operand<U> sparseValues,
Operand<U> defaultValue,
SparseToDense.Options... options)
Factory method to create a class wrapping a new SparseToDense operation.
|
static <U,T extends Number> |
SparseToDense.create(Scope scope,
Operand<T> sparseIndices,
Operand<T> outputShape,
Operand<U> sparseValues,
Operand<U> defaultValue,
SparseToDense.Options... options)
Factory method to create a class wrapping a new SparseToDense operation.
|
static <U,T extends Number> |
SparseToDense.create(Scope scope,
Operand<T> sparseIndices,
Operand<T> outputShape,
Operand<U> sparseValues,
Operand<U> defaultValue,
SparseToDense.Options... options)
Factory method to create a class wrapping a new SparseToDense operation.
|
static <T> DenseToDenseSetOperation<T> |
DenseToDenseSetOperation.create(Scope scope,
Operand<T> set1,
Operand<T> set2,
String setOperation,
DenseToDenseSetOperation.Options... options)
Factory method to create a class wrapping a new DenseToDenseSetOperation operation.
|
static <T> DenseToDenseSetOperation<T> |
DenseToDenseSetOperation.create(Scope scope,
Operand<T> set1,
Operand<T> set2,
String setOperation,
DenseToDenseSetOperation.Options... options)
Factory method to create a class wrapping a new DenseToDenseSetOperation operation.
|
static <T extends Number,U extends Number> |
SparseSegmentMean.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds)
Factory method to create a class wrapping a new SparseSegmentMean operation.
|
static <T extends Number,U extends Number> |
SparseSegmentMean.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds)
Factory method to create a class wrapping a new SparseSegmentMean operation.
|
static <T extends Number,U extends Number> |
SparseSegmentMean.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds)
Factory method to create a class wrapping a new SparseSegmentMean operation.
|
static <T extends Number,U extends Number> |
SparseSegmentSqrtN.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds)
Factory method to create a class wrapping a new SparseSegmentSqrtN operation.
|
static <T extends Number,U extends Number> |
SparseSegmentSqrtN.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds)
Factory method to create a class wrapping a new SparseSegmentSqrtN operation.
|
static <T extends Number,U extends Number> |
SparseSegmentSqrtN.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds)
Factory method to create a class wrapping a new SparseSegmentSqrtN operation.
|
static <T extends Number,U extends Number> |
SparseSegmentSum.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds)
Factory method to create a class wrapping a new SparseSegmentSum operation.
|
static <T extends Number,U extends Number> |
SparseSegmentSum.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds)
Factory method to create a class wrapping a new SparseSegmentSum operation.
|
static <T extends Number,U extends Number> |
SparseSegmentSum.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds)
Factory method to create a class wrapping a new SparseSegmentSum operation.
|
static <T extends Number,U extends Number> |
SparseSegmentMeanGrad.create(Scope scope,
Operand<T> grad,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<Integer> outputDim0)
Factory method to create a class wrapping a new SparseSegmentMeanGrad operation.
|
static <T extends Number,U extends Number> |
SparseSegmentMeanGrad.create(Scope scope,
Operand<T> grad,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<Integer> outputDim0)
Factory method to create a class wrapping a new SparseSegmentMeanGrad operation.
|
static <T extends Number,U extends Number> |
SparseSegmentMeanGrad.create(Scope scope,
Operand<T> grad,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<Integer> outputDim0)
Factory method to create a class wrapping a new SparseSegmentMeanGrad operation.
|
static <T extends Number,U extends Number> |
SparseSegmentMeanGrad.create(Scope scope,
Operand<T> grad,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<Integer> outputDim0)
Factory method to create a class wrapping a new SparseSegmentMeanGrad operation.
|
static <T extends Number,U extends Number> |
SparseSegmentSqrtNGrad.create(Scope scope,
Operand<T> grad,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<Integer> outputDim0)
Factory method to create a class wrapping a new SparseSegmentSqrtNGrad operation.
|
static <T extends Number,U extends Number> |
SparseSegmentSqrtNGrad.create(Scope scope,
Operand<T> grad,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<Integer> outputDim0)
Factory method to create a class wrapping a new SparseSegmentSqrtNGrad operation.
|
static <T extends Number,U extends Number> |
SparseSegmentSqrtNGrad.create(Scope scope,
Operand<T> grad,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<Integer> outputDim0)
Factory method to create a class wrapping a new SparseSegmentSqrtNGrad operation.
|
static <T extends Number,U extends Number> |
SparseSegmentSqrtNGrad.create(Scope scope,
Operand<T> grad,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<Integer> outputDim0)
Factory method to create a class wrapping a new SparseSegmentSqrtNGrad operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentSqrtNWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentSqrtNWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentSqrtNWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentSqrtNWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentSqrtNWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentSqrtNWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentSqrtNWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentSqrtNWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentSumWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentSumWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentSumWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentSumWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentSumWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentSumWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentSumWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentSumWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentMeanWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentMeanWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentMeanWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentMeanWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentMeanWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentMeanWithNumSegments operation.
|
static <T extends Number,U extends Number,V extends Number> |
SparseSegmentMeanWithNumSegments.create(Scope scope,
Operand<T> data,
Operand<U> indices,
Operand<Integer> segmentIds,
Operand<V> numSegments)
Factory method to create a class wrapping a new SparseSegmentMeanWithNumSegments operation.
|
static <U,T extends Number> |
SparseTensorDenseMatMul.create(Scope scope,
Operand<T> aIndices,
Operand<U> aValues,
Operand<Long> aShape,
Operand<U> b,
SparseTensorDenseMatMul.Options... options)
Factory method to create a class wrapping a new SparseTensorDenseMatMul operation.
|
static <U,T extends Number> |
SparseTensorDenseMatMul.create(Scope scope,
Operand<T> aIndices,
Operand<U> aValues,
Operand<Long> aShape,
Operand<U> b,
SparseTensorDenseMatMul.Options... options)
Factory method to create a class wrapping a new SparseTensorDenseMatMul operation.
|
static <U,T extends Number> |
SparseTensorDenseMatMul.create(Scope scope,
Operand<T> aIndices,
Operand<U> aValues,
Operand<Long> aShape,
Operand<U> b,
SparseTensorDenseMatMul.Options... options)
Factory method to create a class wrapping a new SparseTensorDenseMatMul operation.
|
static <U,T extends Number> |
SparseTensorDenseMatMul.create(Scope scope,
Operand<T> aIndices,
Operand<U> aValues,
Operand<Long> aShape,
Operand<U> b,
SparseTensorDenseMatMul.Options... options)
Factory method to create a class wrapping a new SparseTensorDenseMatMul operation.
|
static <U,T extends Number> |
SparseTensorDenseAdd.create(Scope scope,
Operand<T> aIndices,
Operand<U> aValues,
Operand<T> aShape,
Operand<U> b)
Factory method to create a class wrapping a new SparseTensorDenseAdd operation.
|
static <U,T extends Number> |
SparseTensorDenseAdd.create(Scope scope,
Operand<T> aIndices,
Operand<U> aValues,
Operand<T> aShape,
Operand<U> b)
Factory method to create a class wrapping a new SparseTensorDenseAdd operation.
|
static <U,T extends Number> |
SparseTensorDenseAdd.create(Scope scope,
Operand<T> aIndices,
Operand<U> aValues,
Operand<T> aShape,
Operand<U> b)
Factory method to create a class wrapping a new SparseTensorDenseAdd operation.
|
static <U,T extends Number> |
SparseTensorDenseAdd.create(Scope scope,
Operand<T> aIndices,
Operand<U> aValues,
Operand<T> aShape,
Operand<U> b)
Factory method to create a class wrapping a new SparseTensorDenseAdd operation.
|
static <T extends Number,U extends Number> |
SparseMatMul.create(Scope scope,
Operand<T> a,
Operand<U> b,
SparseMatMul.Options... options)
Factory method to create a class wrapping a new SparseMatMul operation.
|
static <T extends Number,U extends Number> |
SparseMatMul.create(Scope scope,
Operand<T> a,
Operand<U> b,
SparseMatMul.Options... options)
Factory method to create a class wrapping a new SparseMatMul operation.
|
Modifier and Type | Method and Description |
---|---|
static <T,U> SparseCross<T> |
SparseCross.create(Scope scope,
Iterable<Operand<Long>> indices,
Iterable<Operand<?>> values,
Iterable<Operand<Long>> shapes,
Iterable<Operand<?>> denseInputs,
Boolean hashedOutput,
Long numBuckets,
Long hashKey,
Class<T> outType,
Class<U> internalType)
Factory method to create a class wrapping a new SparseCross operation.
|
static <T,U> SparseCross<T> |
SparseCross.create(Scope scope,
Iterable<Operand<Long>> indices,
Iterable<Operand<?>> values,
Iterable<Operand<Long>> shapes,
Iterable<Operand<?>> denseInputs,
Boolean hashedOutput,
Long numBuckets,
Long hashKey,
Class<T> outType,
Class<U> internalType)
Factory method to create a class wrapping a new SparseCross operation.
|
static <T,U> SparseCross<T> |
SparseCross.create(Scope scope,
Iterable<Operand<Long>> indices,
Iterable<Operand<?>> values,
Iterable<Operand<Long>> shapes,
Iterable<Operand<?>> denseInputs,
Boolean hashedOutput,
Long numBuckets,
Long hashKey,
Class<T> outType,
Class<U> internalType)
Factory method to create a class wrapping a new SparseCross operation.
|
static <T,U> SparseCross<T> |
SparseCross.create(Scope scope,
Iterable<Operand<Long>> indices,
Iterable<Operand<?>> values,
Iterable<Operand<Long>> shapes,
Iterable<Operand<?>> denseInputs,
Boolean hashedOutput,
Long numBuckets,
Long hashKey,
Class<T> outType,
Class<U> internalType)
Factory method to create a class wrapping a new SparseCross operation.
|
static <T> SparseConcat<T> |
SparseConcat.create(Scope scope,
Iterable<Operand<Long>> indices,
Iterable<Operand<T>> values,
Iterable<Operand<Long>> shapes,
Long concatDim)
Factory method to create a class wrapping a new SparseConcat operation.
|
static <T> SparseConcat<T> |
SparseConcat.create(Scope scope,
Iterable<Operand<Long>> indices,
Iterable<Operand<T>> values,
Iterable<Operand<Long>> shapes,
Long concatDim)
Factory method to create a class wrapping a new SparseConcat operation.
|
static <T> SparseConcat<T> |
SparseConcat.create(Scope scope,
Iterable<Operand<Long>> indices,
Iterable<Operand<T>> values,
Iterable<Operand<Long>> shapes,
Long concatDim)
Factory method to create a class wrapping a new SparseConcat operation.
|
Modifier and Type | Class and Description |
---|---|
class |
Join
Joins the strings in the given list of string tensors into one tensor;
|
class |
ReduceJoin
Joins a string Tensor across the given dimensions.
|
class |
RegexFullMatch
Check if the input matches the regex pattern.
|
class |
RegexReplace
Replaces matches of the `pattern` regular expression in `input` with the
replacement string provided in `rewrite`.
|
class |
StaticRegexFullMatch
Check if the input matches the regex pattern.
|
class |
StaticRegexReplace
Replaces the match of pattern in input with rewrite.
|
class |
StringFormat
Formats a string template using a list of tensors.
|
class |
StringLength
String lengths of `input`.
|
class |
Strip
Strip leading and trailing whitespaces from the Tensor.
|
class |
Substr
Return substrings from `Tensor` of strings.
|
class |
ToHashBucket
Converts each string in the input Tensor to its hash mod by a number of buckets.
|
class |
ToHashBucketFast
Converts each string in the input Tensor to its hash mod by a number of buckets.
|
class |
ToHashBucketStrong
Converts each string in the input Tensor to its hash mod by a number of buckets.
|
class |
ToNumber<T extends Number>
Converts each string in the input Tensor to the specified numeric type.
|
class |
UnicodeScript
Determine the script codes of a given tensor of Unicode integer code points.
|
class |
UnicodeTranscode
Transcode the input text from a source encoding to a destination encoding.
|
Modifier and Type | Method and Description |
---|---|
static UnicodeScript |
UnicodeScript.create(Scope scope,
Operand<Integer> input)
Factory method to create a class wrapping a new UnicodeScript operation.
|
static Strip |
Strip.create(Scope scope,
Operand<String> input)
Factory method to create a class wrapping a new Strip operation.
|
static ToNumber<Float> |
ToNumber.create(Scope scope,
Operand<String> stringTensor)
Factory method to create a class wrapping a new ToNumber operation using default output types.
|
static <T extends Number> |
ToNumber.create(Scope scope,
Operand<String> stringTensor,
Class<T> outType)
Factory method to create a class wrapping a new ToNumber operation.
|
static ToHashBucketFast |
ToHashBucketFast.create(Scope scope,
Operand<String> input,
Long numBuckets)
Factory method to create a class wrapping a new ToHashBucketFast operation.
|
static ToHashBucket |
ToHashBucket.create(Scope scope,
Operand<String> stringTensor,
Long numBuckets)
Factory method to create a class wrapping a new ToHashBucket operation.
|
static ToHashBucketStrong |
ToHashBucketStrong.create(Scope scope,
Operand<String> input,
Long numBuckets,
List<Long> key)
Factory method to create a class wrapping a new ToHashBucketStrong operation.
|
static ReduceJoin |
ReduceJoin.create(Scope scope,
Operand<String> inputs,
Operand<Integer> reductionIndices,
ReduceJoin.Options... options)
Factory method to create a class wrapping a new ReduceJoin operation.
|
static ReduceJoin |
ReduceJoin.create(Scope scope,
Operand<String> inputs,
Operand<Integer> reductionIndices,
ReduceJoin.Options... options)
Factory method to create a class wrapping a new ReduceJoin operation.
|
static RegexFullMatch |
RegexFullMatch.create(Scope scope,
Operand<String> input,
Operand<String> pattern)
Factory method to create a class wrapping a new RegexFullMatch operation.
|
static RegexFullMatch |
RegexFullMatch.create(Scope scope,
Operand<String> input,
Operand<String> pattern)
Factory method to create a class wrapping a new RegexFullMatch operation.
|
static RegexReplace |
RegexReplace.create(Scope scope,
Operand<String> input,
Operand<String> pattern,
Operand<String> rewrite,
RegexReplace.Options... options)
Factory method to create a class wrapping a new RegexReplace operation.
|
static RegexReplace |
RegexReplace.create(Scope scope,
Operand<String> input,
Operand<String> pattern,
Operand<String> rewrite,
RegexReplace.Options... options)
Factory method to create a class wrapping a new RegexReplace operation.
|
static RegexReplace |
RegexReplace.create(Scope scope,
Operand<String> input,
Operand<String> pattern,
Operand<String> rewrite,
RegexReplace.Options... options)
Factory method to create a class wrapping a new RegexReplace operation.
|
static StringSplit |
StringSplit.create(Scope scope,
Operand<String> input,
Operand<String> sep,
StringSplit.Options... options)
Factory method to create a class wrapping a new StringSplit operation.
|
static StringSplit |
StringSplit.create(Scope scope,
Operand<String> input,
Operand<String> sep,
StringSplit.Options... options)
Factory method to create a class wrapping a new StringSplit operation.
|
static <T extends Number> |
Substr.create(Scope scope,
Operand<String> input,
Operand<T> pos,
Operand<T> len,
Substr.Options... options)
Factory method to create a class wrapping a new Substr operation.
|
static <T extends Number> |
Substr.create(Scope scope,
Operand<String> input,
Operand<T> pos,
Operand<T> len,
Substr.Options... options)
Factory method to create a class wrapping a new Substr operation.
|
static <T extends Number> |
Substr.create(Scope scope,
Operand<String> input,
Operand<T> pos,
Operand<T> len,
Substr.Options... options)
Factory method to create a class wrapping a new Substr operation.
|
static StaticRegexFullMatch |
StaticRegexFullMatch.create(Scope scope,
Operand<String> input,
String pattern)
Factory method to create a class wrapping a new StaticRegexFullMatch operation.
|
static <T extends Number> |
UnicodeDecodeWithOffsets.create(Scope scope,
Operand<String> input,
String inputEncoding,
Class<T> Tsplits,
UnicodeDecodeWithOffsets.Options... options)
Factory method to create a class wrapping a new UnicodeDecodeWithOffsets operation.
|
static StringLength |
StringLength.create(Scope scope,
Operand<String> input,
StringLength.Options... options)
Factory method to create a class wrapping a new StringLength operation.
|
static StaticRegexReplace |
StaticRegexReplace.create(Scope scope,
Operand<String> input,
String pattern,
String rewrite,
StaticRegexReplace.Options... options)
Factory method to create a class wrapping a new StaticRegexReplace operation.
|
static UnicodeTranscode |
UnicodeTranscode.create(Scope scope,
Operand<String> input,
String inputEncoding,
String outputEncoding,
UnicodeTranscode.Options... options)
Factory method to create a class wrapping a new UnicodeTranscode operation.
|
static UnicodeDecodeWithOffsets<Long> |
UnicodeDecodeWithOffsets.create(Scope scope,
Operand<String> input,
String inputEncoding,
UnicodeDecodeWithOffsets.Options... options)
Factory method to create a class wrapping a new UnicodeDecodeWithOffsets operation using default output types.
|
Modifier and Type | Method and Description |
---|---|
static StringFormat |
StringFormat.create(Scope scope,
Iterable<Operand<?>> inputs,
StringFormat.Options... options)
Factory method to create a class wrapping a new StringFormat operation.
|
static Join |
Join.create(Scope scope,
Iterable<Operand<String>> inputs,
Join.Options... options)
Factory method to create a class wrapping a new Join operation.
|
Modifier and Type | Class and Description |
---|---|
class |
AudioSummary
Outputs a `Summary` protocol buffer with audio.
|
class |
HistogramSummary
Outputs a `Summary` protocol buffer with a histogram.
|
class |
ImageSummary
Outputs a `Summary` protocol buffer with images.
|
class |
MergeSummary
Merges summaries.
|
class |
ScalarSummary
Outputs a `Summary` protocol buffer with scalar values.
|
class |
StatsAggregatorSummary
Produces a summary of any statistics recorded by the given statistics manager.
|
class |
SummaryWriter |
class |
TensorSummary
Outputs a `Summary` protocol buffer with a tensor and per-plugin data.
|
Modifier and Type | Method and Description |
---|---|
static StatsAggregatorSummary |
StatsAggregatorSummary.create(Scope scope,
Operand<?> iterator)
Factory method to create a class wrapping a new StatsAggregatorSummary operation.
|
static CloseSummaryWriter |
CloseSummaryWriter.create(Scope scope,
Operand<?> writer)
Factory method to create a class wrapping a new CloseSummaryWriter operation.
|
static FlushSummaryWriter |
FlushSummaryWriter.create(Scope scope,
Operand<?> writer)
Factory method to create a class wrapping a new FlushSummaryWriter operation.
|
static WriteGraphSummary |
WriteGraphSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tensor)
Factory method to create a class wrapping a new WriteGraphSummary operation.
|
static WriteGraphSummary |
WriteGraphSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tensor)
Factory method to create a class wrapping a new WriteGraphSummary operation.
|
static WriteGraphSummary |
WriteGraphSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tensor)
Factory method to create a class wrapping a new WriteGraphSummary operation.
|
static WriteAudioSummary |
WriteAudioSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<Float> tensor,
Operand<Float> sampleRate,
WriteAudioSummary.Options... options)
Factory method to create a class wrapping a new WriteAudioSummary operation.
|
static WriteAudioSummary |
WriteAudioSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<Float> tensor,
Operand<Float> sampleRate,
WriteAudioSummary.Options... options)
Factory method to create a class wrapping a new WriteAudioSummary operation.
|
static WriteAudioSummary |
WriteAudioSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<Float> tensor,
Operand<Float> sampleRate,
WriteAudioSummary.Options... options)
Factory method to create a class wrapping a new WriteAudioSummary operation.
|
static WriteAudioSummary |
WriteAudioSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<Float> tensor,
Operand<Float> sampleRate,
WriteAudioSummary.Options... options)
Factory method to create a class wrapping a new WriteAudioSummary operation.
|
static WriteAudioSummary |
WriteAudioSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<Float> tensor,
Operand<Float> sampleRate,
WriteAudioSummary.Options... options)
Factory method to create a class wrapping a new WriteAudioSummary operation.
|
static <T extends Number> |
WriteScalarSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> value)
Factory method to create a class wrapping a new WriteScalarSummary operation.
|
static <T extends Number> |
WriteScalarSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> value)
Factory method to create a class wrapping a new WriteScalarSummary operation.
|
static <T extends Number> |
WriteScalarSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> value)
Factory method to create a class wrapping a new WriteScalarSummary operation.
|
static <T extends Number> |
WriteScalarSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> value)
Factory method to create a class wrapping a new WriteScalarSummary operation.
|
static <T extends Number> |
WriteHistogramSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> values)
Factory method to create a class wrapping a new WriteHistogramSummary operation.
|
static <T extends Number> |
WriteHistogramSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> values)
Factory method to create a class wrapping a new WriteHistogramSummary operation.
|
static <T extends Number> |
WriteHistogramSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> values)
Factory method to create a class wrapping a new WriteHistogramSummary operation.
|
static <T extends Number> |
WriteHistogramSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> values)
Factory method to create a class wrapping a new WriteHistogramSummary operation.
|
static <T extends Number> |
WriteImageSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> tensor,
Operand<UInt8> badColor,
WriteImageSummary.Options... options)
Factory method to create a class wrapping a new WriteImageSummary operation.
|
static <T extends Number> |
WriteImageSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> tensor,
Operand<UInt8> badColor,
WriteImageSummary.Options... options)
Factory method to create a class wrapping a new WriteImageSummary operation.
|
static <T extends Number> |
WriteImageSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> tensor,
Operand<UInt8> badColor,
WriteImageSummary.Options... options)
Factory method to create a class wrapping a new WriteImageSummary operation.
|
static <T extends Number> |
WriteImageSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> tensor,
Operand<UInt8> badColor,
WriteImageSummary.Options... options)
Factory method to create a class wrapping a new WriteImageSummary operation.
|
static <T extends Number> |
WriteImageSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<String> tag,
Operand<T> tensor,
Operand<UInt8> badColor,
WriteImageSummary.Options... options)
Factory method to create a class wrapping a new WriteImageSummary operation.
|
static <T> WriteSummary |
WriteSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<T> tensor,
Operand<String> tag,
Operand<String> summaryMetadata)
Factory method to create a class wrapping a new WriteSummary operation.
|
static <T> WriteSummary |
WriteSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<T> tensor,
Operand<String> tag,
Operand<String> summaryMetadata)
Factory method to create a class wrapping a new WriteSummary operation.
|
static <T> WriteSummary |
WriteSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<T> tensor,
Operand<String> tag,
Operand<String> summaryMetadata)
Factory method to create a class wrapping a new WriteSummary operation.
|
static <T> WriteSummary |
WriteSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<T> tensor,
Operand<String> tag,
Operand<String> summaryMetadata)
Factory method to create a class wrapping a new WriteSummary operation.
|
static <T> WriteSummary |
WriteSummary.create(Scope scope,
Operand<?> writer,
Operand<Long> step,
Operand<T> tensor,
Operand<String> tag,
Operand<String> summaryMetadata)
Factory method to create a class wrapping a new WriteSummary operation.
|
static ImportEvent |
ImportEvent.create(Scope scope,
Operand<?> writer,
Operand<String> event)
Factory method to create a class wrapping a new ImportEvent operation.
|
static ImportEvent |
ImportEvent.create(Scope scope,
Operand<?> writer,
Operand<String> event)
Factory method to create a class wrapping a new ImportEvent operation.
|
static CreateSummaryFileWriter |
CreateSummaryFileWriter.create(Scope scope,
Operand<?> writer,
Operand<String> logdir,
Operand<Integer> maxQueue,
Operand<Integer> flushMillis,
Operand<String> filenameSuffix)
Factory method to create a class wrapping a new CreateSummaryFileWriter operation.
|
static CreateSummaryFileWriter |
CreateSummaryFileWriter.create(Scope scope,
Operand<?> writer,
Operand<String> logdir,
Operand<Integer> maxQueue,
Operand<Integer> flushMillis,
Operand<String> filenameSuffix)
Factory method to create a class wrapping a new CreateSummaryFileWriter operation.
|
static CreateSummaryFileWriter |
CreateSummaryFileWriter.create(Scope scope,
Operand<?> writer,
Operand<String> logdir,
Operand<Integer> maxQueue,
Operand<Integer> flushMillis,
Operand<String> filenameSuffix)
Factory method to create a class wrapping a new CreateSummaryFileWriter operation.
|
static CreateSummaryFileWriter |
CreateSummaryFileWriter.create(Scope scope,
Operand<?> writer,
Operand<String> logdir,
Operand<Integer> maxQueue,
Operand<Integer> flushMillis,
Operand<String> filenameSuffix)
Factory method to create a class wrapping a new CreateSummaryFileWriter operation.
|
static CreateSummaryFileWriter |
CreateSummaryFileWriter.create(Scope scope,
Operand<?> writer,
Operand<String> logdir,
Operand<Integer> maxQueue,
Operand<Integer> flushMillis,
Operand<String> filenameSuffix)
Factory method to create a class wrapping a new CreateSummaryFileWriter operation.
|
static CreateSummaryDbWriter |
CreateSummaryDbWriter.create(Scope scope,
Operand<?> writer,
Operand<String> dbUri,
Operand<String> experimentName,
Operand<String> runName,
Operand<String> userName)
Factory method to create a class wrapping a new CreateSummaryDbWriter operation.
|
static CreateSummaryDbWriter |
CreateSummaryDbWriter.create(Scope scope,
Operand<?> writer,
Operand<String> dbUri,
Operand<String> experimentName,
Operand<String> runName,
Operand<String> userName)
Factory method to create a class wrapping a new CreateSummaryDbWriter operation.
|
static CreateSummaryDbWriter |
CreateSummaryDbWriter.create(Scope scope,
Operand<?> writer,
Operand<String> dbUri,
Operand<String> experimentName,
Operand<String> runName,
Operand<String> userName)
Factory method to create a class wrapping a new CreateSummaryDbWriter operation.
|
static CreateSummaryDbWriter |
CreateSummaryDbWriter.create(Scope scope,
Operand<?> writer,
Operand<String> dbUri,
Operand<String> experimentName,
Operand<String> runName,
Operand<String> userName)
Factory method to create a class wrapping a new CreateSummaryDbWriter operation.
|
static CreateSummaryDbWriter |
CreateSummaryDbWriter.create(Scope scope,
Operand<?> writer,
Operand<String> dbUri,
Operand<String> experimentName,
Operand<String> runName,
Operand<String> userName)
Factory method to create a class wrapping a new CreateSummaryDbWriter operation.
|
static AudioSummary |
AudioSummary.create(Scope scope,
Operand<String> tag,
Operand<Float> tensor,
Operand<Float> sampleRate,
AudioSummary.Options... options)
Factory method to create a class wrapping a new AudioSummary operation.
|
static AudioSummary |
AudioSummary.create(Scope scope,
Operand<String> tag,
Operand<Float> tensor,
Operand<Float> sampleRate,
AudioSummary.Options... options)
Factory method to create a class wrapping a new AudioSummary operation.
|
static AudioSummary |
AudioSummary.create(Scope scope,
Operand<String> tag,
Operand<Float> tensor,
Operand<Float> sampleRate,
AudioSummary.Options... options)
Factory method to create a class wrapping a new AudioSummary operation.
|
static <T extends Number> |
HistogramSummary.create(Scope scope,
Operand<String> tag,
Operand<T> values)
Factory method to create a class wrapping a new HistogramSummary operation.
|
static <T extends Number> |
HistogramSummary.create(Scope scope,
Operand<String> tag,
Operand<T> values)
Factory method to create a class wrapping a new HistogramSummary operation.
|
static <T extends Number> |
ScalarSummary.create(Scope scope,
Operand<String> tags,
Operand<T> values)
Factory method to create a class wrapping a new ScalarSummary operation.
|
static <T extends Number> |
ScalarSummary.create(Scope scope,
Operand<String> tags,
Operand<T> values)
Factory method to create a class wrapping a new ScalarSummary operation.
|
static <T extends Number> |
ImageSummary.create(Scope scope,
Operand<String> tag,
Operand<T> tensor,
ImageSummary.Options... options)
Factory method to create a class wrapping a new ImageSummary operation.
|
static <T extends Number> |
ImageSummary.create(Scope scope,
Operand<String> tag,
Operand<T> tensor,
ImageSummary.Options... options)
Factory method to create a class wrapping a new ImageSummary operation.
|
static <T> TensorSummary |
TensorSummary.create(Scope scope,
Operand<String> tag,
Operand<T> tensor,
Operand<String> serializedSummaryMetadata)
Factory method to create a class wrapping a new TensorSummary operation.
|
static <T> TensorSummary |
TensorSummary.create(Scope scope,
Operand<String> tag,
Operand<T> tensor,
Operand<String> serializedSummaryMetadata)
Factory method to create a class wrapping a new TensorSummary operation.
|
static <T> TensorSummary |
TensorSummary.create(Scope scope,
Operand<String> tag,
Operand<T> tensor,
Operand<String> serializedSummaryMetadata)
Factory method to create a class wrapping a new TensorSummary operation.
|
Modifier and Type | Method and Description |
---|---|
static MergeSummary |
MergeSummary.create(Scope scope,
Iterable<Operand<String>> inputs)
Factory method to create a class wrapping a new MergeSummary operation.
|
Modifier and Type | Class and Description |
---|---|
class |
AccumulatorNumAccumulated
Returns the number of gradients aggregated in the given accumulators.
|
class |
AccumulatorTakeGradient<T>
Extracts the average gradient in the given ConditionalAccumulator.
|
class |
ApplyAdadelta<T>
Update '*var' according to the adadelta scheme.
|
class |
ApplyAdagrad<T>
Update '*var' according to the adagrad scheme.
|
class |
ApplyAdagradDa<T>
Update '*var' according to the proximal adagrad scheme.
|
class |
ApplyAdam<T>
Update '*var' according to the Adam algorithm.
|
class |
ApplyAdaMax<T>
Update '*var' according to the AdaMax algorithm.
|
class |
ApplyAddSign<T>
Update '*var' according to the AddSign update.
|
class |
ApplyCenteredRmsProp<T>
Update '*var' according to the centered RMSProp algorithm.
|
class |
ApplyFtrl<T>
Update '*var' according to the Ftrl-proximal scheme.
|
class |
ApplyGradientDescent<T>
Update '*var' by subtracting 'alpha' * 'delta' from it.
|
class |
ApplyMomentum<T>
Update '*var' according to the momentum scheme.
|
class |
ApplyPowerSign<T>
Update '*var' according to the AddSign update.
|
class |
ApplyProximalAdagrad<T>
Update '*var' and '*accum' according to FOBOS with Adagrad learning rate.
|
class |
ApplyProximalGradientDescent<T>
Update '*var' as FOBOS algorithm with fixed learning rate.
|
class |
ApplyRmsProp<T>
Update '*var' according to the RMSProp algorithm.
|
class |
ConditionalAccumulator
A conditional accumulator for aggregating gradients.
|
class |
PreventGradient<T>
An identity op that triggers an error if a gradient is requested.
|
class |
RestoreSlice<T>
Restores a tensor from checkpoint files.
|
class |
SdcaFprint
Computes fingerprints of the input strings.
|
class |
SparseApplyAdadelta<T>
var: Should be from a Variable().
|
class |
SparseApplyAdagrad<T>
Update relevant entries in '*var' and '*accum' according to the adagrad scheme.
|
class |
SparseApplyAdagradDa<T>
Update entries in '*var' and '*accum' according to the proximal adagrad scheme.
|
class |
SparseApplyCenteredRmsProp<T>
Update '*var' according to the centered RMSProp algorithm.
|
class |
SparseApplyFtrl<T>
Update relevant entries in '*var' according to the Ftrl-proximal scheme.
|
class |
SparseApplyMomentum<T>
Update relevant entries in '*var' and '*accum' according to the momentum scheme.
|
class |
SparseApplyProximalAdagrad<T>
Sparse update entries in '*var' and '*accum' according to FOBOS algorithm.
|
class |
SparseApplyProximalGradientDescent<T>
Sparse update '*var' as FOBOS algorithm with fixed learning rate.
|
class |
SparseApplyRmsProp<T>
Update '*var' according to the RMSProp algorithm.
|
class |
TileGrad<T>
Returns the gradient of `Tile`.
|
Modifier and Type | Method and Description |
---|---|
Iterator<Operand<Object>> |
Restore.iterator() |
Modifier and Type | Method and Description |
---|---|
static SdcaOptimizer |
SdcaOptimizer.create(Scope scope,
Iterable<Operand<Long>> sparseExampleIndices,
Iterable<Operand<Long>> sparseFeatureIndices,
Iterable<Operand<Float>> sparseFeatureValues,
Iterable<Operand<Float>> denseFeatures,
Operand<Float> exampleWeights,
Operand<Float> exampleLabels,
Iterable<Operand<Long>> sparseIndices,
Iterable<Operand<Float>> sparseWeights,
Iterable<Operand<Float>> denseWeights,
Operand<Float> exampleStateData,
String lossType,
Float l1,
Float l2,
Long numLossPartitions,
Long numInnerIterations,
SdcaOptimizer.Options... options)
Factory method to create a class wrapping a new SdcaOptimizer operation.
|
static SdcaOptimizer |
SdcaOptimizer.create(Scope scope,
Iterable<Operand<Long>> sparseExampleIndices,
Iterable<Operand<Long>> sparseFeatureIndices,
Iterable<Operand<Float>> sparseFeatureValues,
Iterable<Operand<Float>> denseFeatures,
Operand<Float> exampleWeights,
Operand<Float> exampleLabels,
Iterable<Operand<Long>> sparseIndices,
Iterable<Operand<Float>> sparseWeights,
Iterable<Operand<Float>> denseWeights,
Operand<Float> exampleStateData,
String lossType,
Float l1,
Float l2,
Long numLossPartitions,
Long numInnerIterations,
SdcaOptimizer.Options... options)
Factory method to create a class wrapping a new SdcaOptimizer operation.
|
static SdcaOptimizer |
SdcaOptimizer.create(Scope scope,
Iterable<Operand<Long>> sparseExampleIndices,
Iterable<Operand<Long>> sparseFeatureIndices,
Iterable<Operand<Float>> sparseFeatureValues,
Iterable<Operand<Float>> denseFeatures,
Operand<Float> exampleWeights,
Operand<Float> exampleLabels,
Iterable<Operand<Long>> sparseIndices,
Iterable<Operand<Float>> sparseWeights,
Iterable<Operand<Float>> denseWeights,
Operand<Float> exampleStateData,
String lossType,
Float l1,
Float l2,
Long numLossPartitions,
Long numInnerIterations,
SdcaOptimizer.Options... options)
Factory method to create a class wrapping a new SdcaOptimizer operation.
|
static <T,U extends Number> |
ResourceSparseApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyCenteredRmsProp operation.
|
static <T> ResourceApplyCenteredRmsProp |
ResourceApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyCenteredRmsProp operation.
|
static <T> ResourceApplyCenteredRmsProp |
ResourceApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyCenteredRmsProp operation.
|
static <T> ResourceApplyCenteredRmsProp |
ResourceApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyCenteredRmsProp operation.
|
static <T> ResourceApplyCenteredRmsProp |
ResourceApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyCenteredRmsProp operation.
|
static <T> ResourceApplyCenteredRmsProp |
ResourceApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyCenteredRmsProp operation.
|
static <T> ResourceApplyCenteredRmsProp |
ResourceApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyCenteredRmsProp operation.
|
static <T> ResourceApplyCenteredRmsProp |
ResourceApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyCenteredRmsProp operation.
|
static <T> ResourceApplyCenteredRmsProp |
ResourceApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyCenteredRmsProp operation.
|
static <T> ResourceApplyCenteredRmsProp |
ResourceApplyCenteredRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> mg,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyCenteredRmsProp operation.
|
static <T> ResourceApplyAdagradDa |
ResourceApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradDa operation.
|
static <T> ResourceApplyAdagradDa |
ResourceApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradDa operation.
|
static <T> ResourceApplyAdagradDa |
ResourceApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradDa operation.
|
static <T> ResourceApplyAdagradDa |
ResourceApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradDa operation.
|
static <T> ResourceApplyAdagradDa |
ResourceApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradDa operation.
|
static <T> ResourceApplyAdagradDa |
ResourceApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradDa operation.
|
static <T> ResourceApplyAdagradDa |
ResourceApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradDa operation.
|
static <T> ResourceApplyAdagradDa |
ResourceApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagradDa operation.
|
static <T> ResourceApplyAdam |
ResourceApplyAdam.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdam.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdam operation.
|
static <T> ResourceApplyAdam |
ResourceApplyAdam.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdam.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdam operation.
|
static <T> ResourceApplyAdam |
ResourceApplyAdam.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdam.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdam operation.
|
static <T> ResourceApplyAdam |
ResourceApplyAdam.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdam.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdam operation.
|
static <T> ResourceApplyAdam |
ResourceApplyAdam.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdam.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdam operation.
|
static <T> ResourceApplyAdam |
ResourceApplyAdam.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdam.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdam operation.
|
static <T> ResourceApplyAdam |
ResourceApplyAdam.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdam.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdam operation.
|
static <T> ResourceApplyAdam |
ResourceApplyAdam.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdam.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdam operation.
|
static <T> ResourceApplyAdam |
ResourceApplyAdam.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdam.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdam operation.
|
static <T> ResourceApplyAdam |
ResourceApplyAdam.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdam.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdam operation.
|
static <T> ResourceApplyAdaMax |
ResourceApplyAdaMax.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdaMax operation.
|
static <T> ResourceApplyAdaMax |
ResourceApplyAdaMax.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdaMax operation.
|
static <T> ResourceApplyAdaMax |
ResourceApplyAdaMax.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdaMax operation.
|
static <T> ResourceApplyAdaMax |
ResourceApplyAdaMax.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdaMax operation.
|
static <T> ResourceApplyAdaMax |
ResourceApplyAdaMax.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdaMax operation.
|
static <T> ResourceApplyAdaMax |
ResourceApplyAdaMax.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdaMax operation.
|
static <T> ResourceApplyAdaMax |
ResourceApplyAdaMax.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdaMax operation.
|
static <T> ResourceApplyAdaMax |
ResourceApplyAdaMax.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdaMax operation.
|
static <T> ResourceApplyAdaMax |
ResourceApplyAdaMax.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<?> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdaMax operation.
|
static <T> ResourceApplyFtrl |
ResourceApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceApplyFtrl operation.
|
static <T> ResourceApplyFtrl |
ResourceApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceApplyFtrl operation.
|
static <T> ResourceApplyFtrl |
ResourceApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceApplyFtrl operation.
|
static <T> ResourceApplyFtrl |
ResourceApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceApplyFtrl operation.
|
static <T> ResourceApplyFtrl |
ResourceApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceApplyFtrl operation.
|
static <T> ResourceApplyFtrl |
ResourceApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceApplyFtrl operation.
|
static <T> ResourceApplyFtrl |
ResourceApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceApplyFtrl operation.
|
static <T> ResourceApplyFtrl |
ResourceApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceApplyFtrl operation.
|
static <T> ResourceApplyFtrl |
ResourceApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceApplyFtrl operation.
|
static <T,U extends Number> |
ResourceSparseApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyRmsProp operation.
|
static <T> ResourceApplyRmsProp |
ResourceApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyRmsProp operation.
|
static <T> ResourceApplyRmsProp |
ResourceApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyRmsProp operation.
|
static <T> ResourceApplyRmsProp |
ResourceApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyRmsProp operation.
|
static <T> ResourceApplyRmsProp |
ResourceApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyRmsProp operation.
|
static <T> ResourceApplyRmsProp |
ResourceApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyRmsProp operation.
|
static <T> ResourceApplyRmsProp |
ResourceApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyRmsProp operation.
|
static <T> ResourceApplyRmsProp |
ResourceApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyRmsProp operation.
|
static <T> ResourceApplyRmsProp |
ResourceApplyRmsProp.create(Scope scope,
Operand<?> var,
Operand<?> ms,
Operand<?> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ResourceApplyRmsProp operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdadelta operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdadelta operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdadelta operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdadelta operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdadelta operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdadelta operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdadelta operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdadelta operation.
|
static <T> ResourceApplyAdadelta |
ResourceApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdadelta operation.
|
static <T> ResourceApplyAdadelta |
ResourceApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdadelta operation.
|
static <T> ResourceApplyAdadelta |
ResourceApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdadelta operation.
|
static <T> ResourceApplyAdadelta |
ResourceApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdadelta operation.
|
static <T> ResourceApplyAdadelta |
ResourceApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdadelta operation.
|
static <T> ResourceApplyAdadelta |
ResourceApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdadelta operation.
|
static <T> ResourceApplyAdadelta |
ResourceApplyAdadelta.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ResourceApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdadelta operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceSparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradDa operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceSparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradDa operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceSparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradDa operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceSparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradDa operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceSparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradDa operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceSparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradDa operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceSparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradDa operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceSparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradDa operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagradDa.create(Scope scope,
Operand<?> var,
Operand<?> gradientAccumulator,
Operand<?> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ResourceSparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagradDa operation.
|
static <T,U extends Number> |
ResourceSparseApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceSparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyFtrl operation.
|
static <T,U extends Number> |
ResourceSparseApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceSparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyFtrl operation.
|
static <T,U extends Number> |
ResourceSparseApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceSparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyFtrl operation.
|
static <T,U extends Number> |
ResourceSparseApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceSparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyFtrl operation.
|
static <T,U extends Number> |
ResourceSparseApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceSparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyFtrl operation.
|
static <T,U extends Number> |
ResourceSparseApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceSparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyFtrl operation.
|
static <T,U extends Number> |
ResourceSparseApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceSparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyFtrl operation.
|
static <T,U extends Number> |
ResourceSparseApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceSparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyFtrl operation.
|
static <T,U extends Number> |
ResourceSparseApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceSparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyFtrl operation.
|
static <T,U extends Number> |
ResourceSparseApplyFtrl.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<?> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ResourceSparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyFtrl operation.
|
static <T> ResourceApplyAddSign |
ResourceApplyAddSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyAddSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyAddSign operation.
|
static <T> ResourceApplyAddSign |
ResourceApplyAddSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyAddSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyAddSign operation.
|
static <T> ResourceApplyAddSign |
ResourceApplyAddSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyAddSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyAddSign operation.
|
static <T> ResourceApplyAddSign |
ResourceApplyAddSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyAddSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyAddSign operation.
|
static <T> ResourceApplyAddSign |
ResourceApplyAddSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyAddSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyAddSign operation.
|
static <T> ResourceApplyAddSign |
ResourceApplyAddSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyAddSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyAddSign operation.
|
static <T> ResourceApplyAddSign |
ResourceApplyAddSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyAddSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyAddSign operation.
|
static <T> ResourceApplyPowerSign |
ResourceApplyPowerSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyPowerSign operation.
|
static <T> ResourceApplyPowerSign |
ResourceApplyPowerSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyPowerSign operation.
|
static <T> ResourceApplyPowerSign |
ResourceApplyPowerSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyPowerSign operation.
|
static <T> ResourceApplyPowerSign |
ResourceApplyPowerSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyPowerSign operation.
|
static <T> ResourceApplyPowerSign |
ResourceApplyPowerSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyPowerSign operation.
|
static <T> ResourceApplyPowerSign |
ResourceApplyPowerSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyPowerSign operation.
|
static <T> ResourceApplyPowerSign |
ResourceApplyPowerSign.create(Scope scope,
Operand<?> var,
Operand<?> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ResourceApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ResourceApplyPowerSign operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalAdagrad operation.
|
static <T> ResourceApplyProximalAdagrad |
ResourceApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ResourceApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalAdagrad operation.
|
static <T> ResourceApplyProximalAdagrad |
ResourceApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ResourceApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalAdagrad operation.
|
static <T> ResourceApplyProximalAdagrad |
ResourceApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ResourceApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalAdagrad operation.
|
static <T> ResourceApplyProximalAdagrad |
ResourceApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ResourceApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalAdagrad operation.
|
static <T> ResourceApplyProximalAdagrad |
ResourceApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ResourceApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalAdagrad operation.
|
static <T> ResourceApplyProximalAdagrad |
ResourceApplyProximalAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ResourceApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalAdagrad operation.
|
static <T> ResourceApplyMomentum |
ResourceApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ResourceApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceApplyMomentum operation.
|
static <T> ResourceApplyMomentum |
ResourceApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ResourceApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceApplyMomentum operation.
|
static <T> ResourceApplyMomentum |
ResourceApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ResourceApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceApplyMomentum operation.
|
static <T> ResourceApplyMomentum |
ResourceApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ResourceApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceApplyMomentum operation.
|
static <T> ResourceApplyMomentum |
ResourceApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ResourceApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceApplyMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyMomentum.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
ResourceSparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyMomentum operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyAdagrad operation.
|
static <T> ResourceApplyAdagrad |
ResourceApplyAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
ResourceApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagrad operation.
|
static <T> ResourceApplyAdagrad |
ResourceApplyAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
ResourceApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagrad operation.
|
static <T> ResourceApplyAdagrad |
ResourceApplyAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
ResourceApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagrad operation.
|
static <T> ResourceApplyAdagrad |
ResourceApplyAdagrad.create(Scope scope,
Operand<?> var,
Operand<?> accum,
Operand<T> lr,
Operand<T> grad,
ResourceApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ResourceApplyAdagrad operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
ResourceSparseApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
ResourceSparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceSparseApplyProximalGradientDescent operation.
|
static <T> ResourceApplyProximalGradientDescent |
ResourceApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> delta,
ResourceApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalGradientDescent operation.
|
static <T> ResourceApplyProximalGradientDescent |
ResourceApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> delta,
ResourceApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalGradientDescent operation.
|
static <T> ResourceApplyProximalGradientDescent |
ResourceApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> delta,
ResourceApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalGradientDescent operation.
|
static <T> ResourceApplyProximalGradientDescent |
ResourceApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> delta,
ResourceApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalGradientDescent operation.
|
static <T> ResourceApplyProximalGradientDescent |
ResourceApplyProximalGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> delta,
ResourceApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceApplyProximalGradientDescent operation.
|
static <T> ResourceApplyGradientDescent |
ResourceApplyGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> delta,
ResourceApplyGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceApplyGradientDescent operation.
|
static <T> ResourceApplyGradientDescent |
ResourceApplyGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> delta,
ResourceApplyGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceApplyGradientDescent operation.
|
static <T> ResourceApplyGradientDescent |
ResourceApplyGradientDescent.create(Scope scope,
Operand<?> var,
Operand<T> alpha,
Operand<T> delta,
ResourceApplyGradientDescent.Options... options)
Factory method to create a class wrapping a new ResourceApplyGradientDescent operation.
|
static NegTrain |
NegTrain.create(Scope scope,
Operand<Float> wIn,
Operand<Float> wOut,
Operand<Integer> examples,
Operand<Integer> labels,
Operand<Float> lr,
List<Long> vocabCount,
Long numNegativeSamples)
Factory method to create a class wrapping a new NegTrain operation.
|
static NegTrain |
NegTrain.create(Scope scope,
Operand<Float> wIn,
Operand<Float> wOut,
Operand<Integer> examples,
Operand<Integer> labels,
Operand<Float> lr,
List<Long> vocabCount,
Long numNegativeSamples)
Factory method to create a class wrapping a new NegTrain operation.
|
static NegTrain |
NegTrain.create(Scope scope,
Operand<Float> wIn,
Operand<Float> wOut,
Operand<Integer> examples,
Operand<Integer> labels,
Operand<Float> lr,
List<Long> vocabCount,
Long numNegativeSamples)
Factory method to create a class wrapping a new NegTrain operation.
|
static NegTrain |
NegTrain.create(Scope scope,
Operand<Float> wIn,
Operand<Float> wOut,
Operand<Integer> examples,
Operand<Integer> labels,
Operand<Float> lr,
List<Long> vocabCount,
Long numNegativeSamples)
Factory method to create a class wrapping a new NegTrain operation.
|
static NegTrain |
NegTrain.create(Scope scope,
Operand<Float> wIn,
Operand<Float> wOut,
Operand<Integer> examples,
Operand<Integer> labels,
Operand<Float> lr,
List<Long> vocabCount,
Long numNegativeSamples)
Factory method to create a class wrapping a new NegTrain operation.
|
static AccumulatorNumAccumulated |
AccumulatorNumAccumulated.create(Scope scope,
Operand<String> handle)
Factory method to create a class wrapping a new AccumulatorNumAccumulated operation.
|
static SdcaFprint |
SdcaFprint.create(Scope scope,
Operand<String> input)
Factory method to create a class wrapping a new SdcaFprint operation.
|
static <T> AccumulatorTakeGradient<T> |
AccumulatorTakeGradient.create(Scope scope,
Operand<String> handle,
Operand<Integer> numRequired,
Class<T> dtype)
Factory method to create a class wrapping a new AccumulatorTakeGradient operation.
|
static <T> AccumulatorTakeGradient<T> |
AccumulatorTakeGradient.create(Scope scope,
Operand<String> handle,
Operand<Integer> numRequired,
Class<T> dtype)
Factory method to create a class wrapping a new AccumulatorTakeGradient operation.
|
static AccumulatorSetGlobalStep |
AccumulatorSetGlobalStep.create(Scope scope,
Operand<String> handle,
Operand<Long> newGlobalStep)
Factory method to create a class wrapping a new AccumulatorSetGlobalStep operation.
|
static AccumulatorSetGlobalStep |
AccumulatorSetGlobalStep.create(Scope scope,
Operand<String> handle,
Operand<Long> newGlobalStep)
Factory method to create a class wrapping a new AccumulatorSetGlobalStep operation.
|
static <T> AccumulatorApplyGradient |
AccumulatorApplyGradient.create(Scope scope,
Operand<String> handle,
Operand<Long> localStep,
Operand<T> gradient)
Factory method to create a class wrapping a new AccumulatorApplyGradient operation.
|
static <T> AccumulatorApplyGradient |
AccumulatorApplyGradient.create(Scope scope,
Operand<String> handle,
Operand<Long> localStep,
Operand<T> gradient)
Factory method to create a class wrapping a new AccumulatorApplyGradient operation.
|
static <T> AccumulatorApplyGradient |
AccumulatorApplyGradient.create(Scope scope,
Operand<String> handle,
Operand<Long> localStep,
Operand<T> gradient)
Factory method to create a class wrapping a new AccumulatorApplyGradient operation.
|
static GenerateVocabRemapping |
GenerateVocabRemapping.create(Scope scope,
Operand<String> newVocabFile,
Operand<String> oldVocabFile,
Long newVocabOffset,
Long numNewVocab,
GenerateVocabRemapping.Options... options)
Factory method to create a class wrapping a new GenerateVocabRemapping operation.
|
static GenerateVocabRemapping |
GenerateVocabRemapping.create(Scope scope,
Operand<String> newVocabFile,
Operand<String> oldVocabFile,
Long newVocabOffset,
Long numNewVocab,
GenerateVocabRemapping.Options... options)
Factory method to create a class wrapping a new GenerateVocabRemapping operation.
|
static MergeV2Checkpoints |
MergeV2Checkpoints.create(Scope scope,
Operand<String> checkpointPrefixes,
Operand<String> destinationPrefix,
MergeV2Checkpoints.Options... options)
Factory method to create a class wrapping a new MergeV2Checkpoints operation.
|
static MergeV2Checkpoints |
MergeV2Checkpoints.create(Scope scope,
Operand<String> checkpointPrefixes,
Operand<String> destinationPrefix,
MergeV2Checkpoints.Options... options)
Factory method to create a class wrapping a new MergeV2Checkpoints operation.
|
static <T> RestoreSlice<T> |
RestoreSlice.create(Scope scope,
Operand<String> filePattern,
Operand<String> tensorName,
Operand<String> shapeAndSlice,
Class<T> dt,
RestoreSlice.Options... options)
Factory method to create a class wrapping a new RestoreSlice operation.
|
static <T> RestoreSlice<T> |
RestoreSlice.create(Scope scope,
Operand<String> filePattern,
Operand<String> tensorName,
Operand<String> shapeAndSlice,
Class<T> dt,
RestoreSlice.Options... options)
Factory method to create a class wrapping a new RestoreSlice operation.
|
static <T> RestoreSlice<T> |
RestoreSlice.create(Scope scope,
Operand<String> filePattern,
Operand<String> tensorName,
Operand<String> shapeAndSlice,
Class<T> dt,
RestoreSlice.Options... options)
Factory method to create a class wrapping a new RestoreSlice operation.
|
static Save |
Save.create(Scope scope,
Operand<String> prefix,
Operand<String> tensorNames,
Operand<String> shapeAndSlices,
Iterable<Operand<?>> tensors)
Factory method to create a class wrapping a new Save operation.
|
static Save |
Save.create(Scope scope,
Operand<String> prefix,
Operand<String> tensorNames,
Operand<String> shapeAndSlices,
Iterable<Operand<?>> tensors)
Factory method to create a class wrapping a new Save operation.
|
static Save |
Save.create(Scope scope,
Operand<String> prefix,
Operand<String> tensorNames,
Operand<String> shapeAndSlices,
Iterable<Operand<?>> tensors)
Factory method to create a class wrapping a new Save operation.
|
static SaveSlices |
SaveSlices.create(Scope scope,
Operand<String> filename,
Operand<String> tensorNames,
Operand<String> shapesAndSlices,
Iterable<Operand<?>> data)
Factory method to create a class wrapping a new SaveSlices operation.
|
static SaveSlices |
SaveSlices.create(Scope scope,
Operand<String> filename,
Operand<String> tensorNames,
Operand<String> shapesAndSlices,
Iterable<Operand<?>> data)
Factory method to create a class wrapping a new SaveSlices operation.
|
static SaveSlices |
SaveSlices.create(Scope scope,
Operand<String> filename,
Operand<String> tensorNames,
Operand<String> shapesAndSlices,
Iterable<Operand<?>> data)
Factory method to create a class wrapping a new SaveSlices operation.
|
static Restore |
Restore.create(Scope scope,
Operand<String> prefix,
Operand<String> tensorNames,
Operand<String> shapeAndSlices,
List<Class<?>> dtypes)
Factory method to create a class wrapping a new Restore operation.
|
static Restore |
Restore.create(Scope scope,
Operand<String> prefix,
Operand<String> tensorNames,
Operand<String> shapeAndSlices,
List<Class<?>> dtypes)
Factory method to create a class wrapping a new Restore operation.
|
static Restore |
Restore.create(Scope scope,
Operand<String> prefix,
Operand<String> tensorNames,
Operand<String> shapeAndSlices,
List<Class<?>> dtypes)
Factory method to create a class wrapping a new Restore operation.
|
static <T> TileGrad<T> |
TileGrad.create(Scope scope,
Operand<T> input,
Operand<Integer> multiples)
Factory method to create a class wrapping a new TileGrad operation.
|
static <T> TileGrad<T> |
TileGrad.create(Scope scope,
Operand<T> input,
Operand<Integer> multiples)
Factory method to create a class wrapping a new TileGrad operation.
|
static <T> ApplyGradientDescent<T> |
ApplyGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> delta,
ApplyGradientDescent.Options... options)
Factory method to create a class wrapping a new ApplyGradientDescent operation.
|
static <T> ApplyGradientDescent<T> |
ApplyGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> delta,
ApplyGradientDescent.Options... options)
Factory method to create a class wrapping a new ApplyGradientDescent operation.
|
static <T> ApplyGradientDescent<T> |
ApplyGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> delta,
ApplyGradientDescent.Options... options)
Factory method to create a class wrapping a new ApplyGradientDescent operation.
|
static <T> ApplyAdagrad<T> |
ApplyAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
ApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ApplyAdagrad operation.
|
static <T> ApplyAdagrad<T> |
ApplyAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
ApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ApplyAdagrad operation.
|
static <T> ApplyAdagrad<T> |
ApplyAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
ApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ApplyAdagrad operation.
|
static <T> ApplyAdagrad<T> |
ApplyAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
ApplyAdagrad.Options... options)
Factory method to create a class wrapping a new ApplyAdagrad operation.
|
static <T> ApplyMomentum<T> |
ApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ApplyMomentum.Options... options)
Factory method to create a class wrapping a new ApplyMomentum operation.
|
static <T> ApplyMomentum<T> |
ApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ApplyMomentum.Options... options)
Factory method to create a class wrapping a new ApplyMomentum operation.
|
static <T> ApplyMomentum<T> |
ApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ApplyMomentum.Options... options)
Factory method to create a class wrapping a new ApplyMomentum operation.
|
static <T> ApplyMomentum<T> |
ApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ApplyMomentum.Options... options)
Factory method to create a class wrapping a new ApplyMomentum operation.
|
static <T> ApplyMomentum<T> |
ApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<T> momentum,
ApplyMomentum.Options... options)
Factory method to create a class wrapping a new ApplyMomentum operation.
|
static <T> ApplyProximalGradientDescent<T> |
ApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> delta,
ApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ApplyProximalGradientDescent operation.
|
static <T> ApplyProximalGradientDescent<T> |
ApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> delta,
ApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ApplyProximalGradientDescent operation.
|
static <T> ApplyProximalGradientDescent<T> |
ApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> delta,
ApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ApplyProximalGradientDescent operation.
|
static <T> ApplyProximalGradientDescent<T> |
ApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> delta,
ApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ApplyProximalGradientDescent operation.
|
static <T> ApplyProximalGradientDescent<T> |
ApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> delta,
ApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new ApplyProximalGradientDescent operation.
|
static <T> ApplyProximalAdagrad<T> |
ApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ApplyProximalAdagrad operation.
|
static <T> ApplyProximalAdagrad<T> |
ApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ApplyProximalAdagrad operation.
|
static <T> ApplyProximalAdagrad<T> |
ApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ApplyProximalAdagrad operation.
|
static <T> ApplyProximalAdagrad<T> |
ApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ApplyProximalAdagrad operation.
|
static <T> ApplyProximalAdagrad<T> |
ApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ApplyProximalAdagrad operation.
|
static <T> ApplyProximalAdagrad<T> |
ApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
ApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new ApplyProximalAdagrad operation.
|
static <T> ApplyAdadelta<T> |
ApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ApplyAdadelta operation.
|
static <T> ApplyAdadelta<T> |
ApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ApplyAdadelta operation.
|
static <T> ApplyAdadelta<T> |
ApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ApplyAdadelta operation.
|
static <T> ApplyAdadelta<T> |
ApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ApplyAdadelta operation.
|
static <T> ApplyAdadelta<T> |
ApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ApplyAdadelta operation.
|
static <T> ApplyAdadelta<T> |
ApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ApplyAdadelta operation.
|
static <T> ApplyAdadelta<T> |
ApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdadelta.Options... options)
Factory method to create a class wrapping a new ApplyAdadelta operation.
|
static <T> ApplyAddSign<T> |
ApplyAddSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyAddSign.Options... options)
Factory method to create a class wrapping a new ApplyAddSign operation.
|
static <T> ApplyAddSign<T> |
ApplyAddSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyAddSign.Options... options)
Factory method to create a class wrapping a new ApplyAddSign operation.
|
static <T> ApplyAddSign<T> |
ApplyAddSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyAddSign.Options... options)
Factory method to create a class wrapping a new ApplyAddSign operation.
|
static <T> ApplyAddSign<T> |
ApplyAddSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyAddSign.Options... options)
Factory method to create a class wrapping a new ApplyAddSign operation.
|
static <T> ApplyAddSign<T> |
ApplyAddSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyAddSign.Options... options)
Factory method to create a class wrapping a new ApplyAddSign operation.
|
static <T> ApplyAddSign<T> |
ApplyAddSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyAddSign.Options... options)
Factory method to create a class wrapping a new ApplyAddSign operation.
|
static <T> ApplyAddSign<T> |
ApplyAddSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> alpha,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyAddSign.Options... options)
Factory method to create a class wrapping a new ApplyAddSign operation.
|
static <T> ApplyPowerSign<T> |
ApplyPowerSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ApplyPowerSign operation.
|
static <T> ApplyPowerSign<T> |
ApplyPowerSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ApplyPowerSign operation.
|
static <T> ApplyPowerSign<T> |
ApplyPowerSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ApplyPowerSign operation.
|
static <T> ApplyPowerSign<T> |
ApplyPowerSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ApplyPowerSign operation.
|
static <T> ApplyPowerSign<T> |
ApplyPowerSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ApplyPowerSign operation.
|
static <T> ApplyPowerSign<T> |
ApplyPowerSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ApplyPowerSign operation.
|
static <T> ApplyPowerSign<T> |
ApplyPowerSign.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> lr,
Operand<T> logbase,
Operand<T> signDecay,
Operand<T> beta,
Operand<T> grad,
ApplyPowerSign.Options... options)
Factory method to create a class wrapping a new ApplyPowerSign operation.
|
static <T> ApplyAdagradDa<T> |
ApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ApplyAdagradDa operation.
|
static <T> ApplyAdagradDa<T> |
ApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ApplyAdagradDa operation.
|
static <T> ApplyAdagradDa<T> |
ApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ApplyAdagradDa operation.
|
static <T> ApplyAdagradDa<T> |
ApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ApplyAdagradDa operation.
|
static <T> ApplyAdagradDa<T> |
ApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ApplyAdagradDa operation.
|
static <T> ApplyAdagradDa<T> |
ApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ApplyAdagradDa operation.
|
static <T> ApplyAdagradDa<T> |
ApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ApplyAdagradDa operation.
|
static <T> ApplyAdagradDa<T> |
ApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
ApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new ApplyAdagradDa operation.
|
static <T> ApplyRmsProp<T> |
ApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyRmsProp operation.
|
static <T> ApplyRmsProp<T> |
ApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyRmsProp operation.
|
static <T> ApplyRmsProp<T> |
ApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyRmsProp operation.
|
static <T> ApplyRmsProp<T> |
ApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyRmsProp operation.
|
static <T> ApplyRmsProp<T> |
ApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyRmsProp operation.
|
static <T> ApplyRmsProp<T> |
ApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyRmsProp operation.
|
static <T> ApplyRmsProp<T> |
ApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyRmsProp operation.
|
static <T> ApplyRmsProp<T> |
ApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyRmsProp operation.
|
static <T> ApplyAdaMax<T> |
ApplyAdaMax.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ApplyAdaMax operation.
|
static <T> ApplyAdaMax<T> |
ApplyAdaMax.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ApplyAdaMax operation.
|
static <T> ApplyAdaMax<T> |
ApplyAdaMax.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ApplyAdaMax operation.
|
static <T> ApplyAdaMax<T> |
ApplyAdaMax.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ApplyAdaMax operation.
|
static <T> ApplyAdaMax<T> |
ApplyAdaMax.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ApplyAdaMax operation.
|
static <T> ApplyAdaMax<T> |
ApplyAdaMax.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ApplyAdaMax operation.
|
static <T> ApplyAdaMax<T> |
ApplyAdaMax.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ApplyAdaMax operation.
|
static <T> ApplyAdaMax<T> |
ApplyAdaMax.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ApplyAdaMax operation.
|
static <T> ApplyAdaMax<T> |
ApplyAdaMax.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdaMax.Options... options)
Factory method to create a class wrapping a new ApplyAdaMax operation.
|
static <T> ApplyCenteredRmsProp<T> |
ApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyCenteredRmsProp operation.
|
static <T> ApplyCenteredRmsProp<T> |
ApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyCenteredRmsProp operation.
|
static <T> ApplyCenteredRmsProp<T> |
ApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyCenteredRmsProp operation.
|
static <T> ApplyCenteredRmsProp<T> |
ApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyCenteredRmsProp operation.
|
static <T> ApplyCenteredRmsProp<T> |
ApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyCenteredRmsProp operation.
|
static <T> ApplyCenteredRmsProp<T> |
ApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyCenteredRmsProp operation.
|
static <T> ApplyCenteredRmsProp<T> |
ApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyCenteredRmsProp operation.
|
static <T> ApplyCenteredRmsProp<T> |
ApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyCenteredRmsProp operation.
|
static <T> ApplyCenteredRmsProp<T> |
ApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
ApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new ApplyCenteredRmsProp operation.
|
static <T> ApplyFtrl<T> |
ApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ApplyFtrl.Options... options)
Factory method to create a class wrapping a new ApplyFtrl operation.
|
static <T> ApplyFtrl<T> |
ApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ApplyFtrl.Options... options)
Factory method to create a class wrapping a new ApplyFtrl operation.
|
static <T> ApplyFtrl<T> |
ApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ApplyFtrl.Options... options)
Factory method to create a class wrapping a new ApplyFtrl operation.
|
static <T> ApplyFtrl<T> |
ApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ApplyFtrl.Options... options)
Factory method to create a class wrapping a new ApplyFtrl operation.
|
static <T> ApplyFtrl<T> |
ApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ApplyFtrl.Options... options)
Factory method to create a class wrapping a new ApplyFtrl operation.
|
static <T> ApplyFtrl<T> |
ApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ApplyFtrl.Options... options)
Factory method to create a class wrapping a new ApplyFtrl operation.
|
static <T> ApplyFtrl<T> |
ApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ApplyFtrl.Options... options)
Factory method to create a class wrapping a new ApplyFtrl operation.
|
static <T> ApplyFtrl<T> |
ApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ApplyFtrl.Options... options)
Factory method to create a class wrapping a new ApplyFtrl operation.
|
static <T> ApplyFtrl<T> |
ApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
ApplyFtrl.Options... options)
Factory method to create a class wrapping a new ApplyFtrl operation.
|
static <T> ApplyAdam<T> |
ApplyAdam.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdam.Options... options)
Factory method to create a class wrapping a new ApplyAdam operation.
|
static <T> ApplyAdam<T> |
ApplyAdam.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdam.Options... options)
Factory method to create a class wrapping a new ApplyAdam operation.
|
static <T> ApplyAdam<T> |
ApplyAdam.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdam.Options... options)
Factory method to create a class wrapping a new ApplyAdam operation.
|
static <T> ApplyAdam<T> |
ApplyAdam.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdam.Options... options)
Factory method to create a class wrapping a new ApplyAdam operation.
|
static <T> ApplyAdam<T> |
ApplyAdam.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdam.Options... options)
Factory method to create a class wrapping a new ApplyAdam operation.
|
static <T> ApplyAdam<T> |
ApplyAdam.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdam.Options... options)
Factory method to create a class wrapping a new ApplyAdam operation.
|
static <T> ApplyAdam<T> |
ApplyAdam.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdam.Options... options)
Factory method to create a class wrapping a new ApplyAdam operation.
|
static <T> ApplyAdam<T> |
ApplyAdam.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdam.Options... options)
Factory method to create a class wrapping a new ApplyAdam operation.
|
static <T> ApplyAdam<T> |
ApplyAdam.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdam.Options... options)
Factory method to create a class wrapping a new ApplyAdam operation.
|
static <T> ApplyAdam<T> |
ApplyAdam.create(Scope scope,
Operand<T> var,
Operand<T> m,
Operand<T> v,
Operand<T> beta1Power,
Operand<T> beta2Power,
Operand<T> lr,
Operand<T> beta1,
Operand<T> beta2,
Operand<T> epsilon,
Operand<T> grad,
ApplyAdam.Options... options)
Factory method to create a class wrapping a new ApplyAdam operation.
|
static <T,U extends Number> |
SparseApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
SparseApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
SparseApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
SparseApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
SparseApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
SparseApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
SparseApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
SparseApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
SparseApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
SparseApplyCenteredRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> mg,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyCenteredRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyCenteredRmsProp operation.
|
static <T,U extends Number> |
SparseApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyRmsProp operation.
|
static <T,U extends Number> |
SparseApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyRmsProp operation.
|
static <T,U extends Number> |
SparseApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyRmsProp operation.
|
static <T,U extends Number> |
SparseApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyRmsProp operation.
|
static <T,U extends Number> |
SparseApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyRmsProp operation.
|
static <T,U extends Number> |
SparseApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyRmsProp operation.
|
static <T,U extends Number> |
SparseApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyRmsProp operation.
|
static <T,U extends Number> |
SparseApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyRmsProp operation.
|
static <T,U extends Number> |
SparseApplyRmsProp.create(Scope scope,
Operand<T> var,
Operand<T> ms,
Operand<T> mom,
Operand<T> lr,
Operand<T> rho,
Operand<T> momentum,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyRmsProp.Options... options)
Factory method to create a class wrapping a new SparseApplyRmsProp operation.
|
static <T,U extends Number> |
SparseApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new SparseApplyAdadelta operation.
|
static <T,U extends Number> |
SparseApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new SparseApplyAdadelta operation.
|
static <T,U extends Number> |
SparseApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new SparseApplyAdadelta operation.
|
static <T,U extends Number> |
SparseApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new SparseApplyAdadelta operation.
|
static <T,U extends Number> |
SparseApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new SparseApplyAdadelta operation.
|
static <T,U extends Number> |
SparseApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new SparseApplyAdadelta operation.
|
static <T,U extends Number> |
SparseApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new SparseApplyAdadelta operation.
|
static <T,U extends Number> |
SparseApplyAdadelta.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> accumUpdate,
Operand<T> lr,
Operand<T> rho,
Operand<T> epsilon,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdadelta.Options... options)
Factory method to create a class wrapping a new SparseApplyAdadelta operation.
|
static <T,U extends Number> |
SparseApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
SparseApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
SparseApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
SparseApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
SparseApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
SparseApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
SparseApplyProximalAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalAdagrad operation.
|
static <T,U extends Number> |
SparseApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
SparseApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
SparseApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
SparseApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
SparseApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
SparseApplyProximalGradientDescent.create(Scope scope,
Operand<T> var,
Operand<T> alpha,
Operand<T> l1,
Operand<T> l2,
Operand<T> grad,
Operand<U> indices,
SparseApplyProximalGradientDescent.Options... options)
Factory method to create a class wrapping a new SparseApplyProximalGradientDescent operation.
|
static <T,U extends Number> |
SparseApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
SparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradDa operation.
|
static <T,U extends Number> |
SparseApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
SparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradDa operation.
|
static <T,U extends Number> |
SparseApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
SparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradDa operation.
|
static <T,U extends Number> |
SparseApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
SparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradDa operation.
|
static <T,U extends Number> |
SparseApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
SparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradDa operation.
|
static <T,U extends Number> |
SparseApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
SparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradDa operation.
|
static <T,U extends Number> |
SparseApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
SparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradDa operation.
|
static <T,U extends Number> |
SparseApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
SparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradDa operation.
|
static <T,U extends Number> |
SparseApplyAdagradDa.create(Scope scope,
Operand<T> var,
Operand<T> gradientAccumulator,
Operand<T> gradientSquaredAccumulator,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<Long> globalStep,
SparseApplyAdagradDa.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagradDa operation.
|
static <T,U extends Number> |
SparseApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
SparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new SparseApplyFtrl operation.
|
static <T,U extends Number> |
SparseApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
SparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new SparseApplyFtrl operation.
|
static <T,U extends Number> |
SparseApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
SparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new SparseApplyFtrl operation.
|
static <T,U extends Number> |
SparseApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
SparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new SparseApplyFtrl operation.
|
static <T,U extends Number> |
SparseApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
SparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new SparseApplyFtrl operation.
|
static <T,U extends Number> |
SparseApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
SparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new SparseApplyFtrl operation.
|
static <T,U extends Number> |
SparseApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
SparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new SparseApplyFtrl operation.
|
static <T,U extends Number> |
SparseApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
SparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new SparseApplyFtrl operation.
|
static <T,U extends Number> |
SparseApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
SparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new SparseApplyFtrl operation.
|
static <T,U extends Number> |
SparseApplyFtrl.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> linear,
Operand<T> grad,
Operand<U> indices,
Operand<T> lr,
Operand<T> l1,
Operand<T> l2,
Operand<T> l2Shrinkage,
Operand<T> lrPower,
SparseApplyFtrl.Options... options)
Factory method to create a class wrapping a new SparseApplyFtrl operation.
|
static <T,U extends Number> |
SparseApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
SparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new SparseApplyMomentum operation.
|
static <T,U extends Number> |
SparseApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
SparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new SparseApplyMomentum operation.
|
static <T,U extends Number> |
SparseApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
SparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new SparseApplyMomentum operation.
|
static <T,U extends Number> |
SparseApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
SparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new SparseApplyMomentum operation.
|
static <T,U extends Number> |
SparseApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
SparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new SparseApplyMomentum operation.
|
static <T,U extends Number> |
SparseApplyMomentum.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
Operand<T> momentum,
SparseApplyMomentum.Options... options)
Factory method to create a class wrapping a new SparseApplyMomentum operation.
|
static <T,U extends Number> |
SparseApplyAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagrad operation.
|
static <T,U extends Number> |
SparseApplyAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagrad operation.
|
static <T,U extends Number> |
SparseApplyAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagrad operation.
|
static <T,U extends Number> |
SparseApplyAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagrad operation.
|
static <T,U extends Number> |
SparseApplyAdagrad.create(Scope scope,
Operand<T> var,
Operand<T> accum,
Operand<T> lr,
Operand<T> grad,
Operand<U> indices,
SparseApplyAdagrad.Options... options)
Factory method to create a class wrapping a new SparseApplyAdagrad operation.
|
static <T> PreventGradient<T> |
PreventGradient.create(Scope scope,
Operand<T> input,
PreventGradient.Options... options)
Factory method to create a class wrapping a new PreventGradient operation.
|
Modifier and Type | Method and Description |
---|---|
static SdcaShrinkL1 |
SdcaShrinkL1.create(Scope scope,
Iterable<Operand<Float>> weights,
Float l1,
Float l2)
Factory method to create a class wrapping a new SdcaShrinkL1 operation.
|
static SdcaOptimizer |
SdcaOptimizer.create(Scope scope,
Iterable<Operand<Long>> sparseExampleIndices,
Iterable<Operand<Long>> sparseFeatureIndices,
Iterable<Operand<Float>> sparseFeatureValues,
Iterable<Operand<Float>> denseFeatures,
Operand<Float> exampleWeights,
Operand<Float> exampleLabels,
Iterable<Operand<Long>> sparseIndices,
Iterable<Operand<Float>> sparseWeights,
Iterable<Operand<Float>> denseWeights,
Operand<Float> exampleStateData,
String lossType,
Float l1,
Float l2,
Long numLossPartitions,
Long numInnerIterations,
SdcaOptimizer.Options... options)
Factory method to create a class wrapping a new SdcaOptimizer operation.
|
static SdcaOptimizer |
SdcaOptimizer.create(Scope scope,
Iterable<Operand<Long>> sparseExampleIndices,
Iterable<Operand<Long>> sparseFeatureIndices,
Iterable<Operand<Float>> sparseFeatureValues,
Iterable<Operand<Float>> denseFeatures,
Operand<Float> exampleWeights,
Operand<Float> exampleLabels,
Iterable<Operand<Long>> sparseIndices,
Iterable<Operand<Float>> sparseWeights,
Iterable<Operand<Float>> denseWeights,
Operand<Float> exampleStateData,
String lossType,
Float l1,
Float l2,
Long numLossPartitions,
Long numInnerIterations,
SdcaOptimizer.Options... options)
Factory method to create a class wrapping a new SdcaOptimizer operation.
|
static SdcaOptimizer |
SdcaOptimizer.create(Scope scope,
Iterable<Operand<Long>> sparseExampleIndices,
Iterable<Operand<Long>> sparseFeatureIndices,
Iterable<Operand<Float>> sparseFeatureValues,
Iterable<Operand<Float>> denseFeatures,
Operand<Float> exampleWeights,
Operand<Float> exampleLabels,
Iterable<Operand<Long>> sparseIndices,
Iterable<Operand<Float>> sparseWeights,
Iterable<Operand<Float>> denseWeights,
Operand<Float> exampleStateData,
String lossType,
Float l1,
Float l2,
Long numLossPartitions,
Long numInnerIterations,
SdcaOptimizer.Options... options)
Factory method to create a class wrapping a new SdcaOptimizer operation.
|
static SdcaOptimizer |
SdcaOptimizer.create(Scope scope,
Iterable<Operand<Long>> sparseExampleIndices,
Iterable<Operand<Long>> sparseFeatureIndices,
Iterable<Operand<Float>> sparseFeatureValues,
Iterable<Operand<Float>> denseFeatures,
Operand<Float> exampleWeights,
Operand<Float> exampleLabels,
Iterable<Operand<Long>> sparseIndices,
Iterable<Operand<Float>> sparseWeights,
Iterable<Operand<Float>> denseWeights,
Operand<Float> exampleStateData,
String lossType,
Float l1,
Float l2,
Long numLossPartitions,
Long numInnerIterations,
SdcaOptimizer.Options... options)
Factory method to create a class wrapping a new SdcaOptimizer operation.
|
static SdcaOptimizer |
SdcaOptimizer.create(Scope scope,
Iterable<Operand<Long>> sparseExampleIndices,
Iterable<Operand<Long>> sparseFeatureIndices,
Iterable<Operand<Float>> sparseFeatureValues,
Iterable<Operand<Float>> denseFeatures,
Operand<Float> exampleWeights,
Operand<Float> exampleLabels,
Iterable<Operand<Long>> sparseIndices,
Iterable<Operand<Float>> sparseWeights,
Iterable<Operand<Float>> denseWeights,
Operand<Float> exampleStateData,
String lossType,
Float l1,
Float l2,
Long numLossPartitions,
Long numInnerIterations,
SdcaOptimizer.Options... options)
Factory method to create a class wrapping a new SdcaOptimizer operation.
|
static SdcaOptimizer |
SdcaOptimizer.create(Scope scope,
Iterable<Operand<Long>> sparseExampleIndices,
Iterable<Operand<Long>> sparseFeatureIndices,
Iterable<Operand<Float>> sparseFeatureValues,
Iterable<Operand<Float>> denseFeatures,
Operand<Float> exampleWeights,
Operand<Float> exampleLabels,
Iterable<Operand<Long>> sparseIndices,
Iterable<Operand<Float>> sparseWeights,
Iterable<Operand<Float>> denseWeights,
Operand<Float> exampleStateData,
String lossType,
Float l1,
Float l2,
Long numLossPartitions,
Long numInnerIterations,
SdcaOptimizer.Options... options)
Factory method to create a class wrapping a new SdcaOptimizer operation.
|
static SdcaOptimizer |
SdcaOptimizer.create(Scope scope,
Iterable<Operand<Long>> sparseExampleIndices,
Iterable<Operand<Long>> sparseFeatureIndices,
Iterable<Operand<Float>> sparseFeatureValues,
Iterable<Operand<Float>> denseFeatures,
Operand<Float> exampleWeights,
Operand<Float> exampleLabels,
Iterable<Operand<Long>> sparseIndices,
Iterable<Operand<Float>> sparseWeights,
Iterable<Operand<Float>> denseWeights,
Operand<Float> exampleStateData,
String lossType,
Float l1,
Float l2,
Long numLossPartitions,
Long numInnerIterations,
SdcaOptimizer.Options... options)
Factory method to create a class wrapping a new SdcaOptimizer operation.
|
static Save |
Save.create(Scope scope,
Operand<String> prefix,
Operand<String> tensorNames,
Operand<String> shapeAndSlices,
Iterable<Operand<?>> tensors)
Factory method to create a class wrapping a new Save operation.
|
static SaveSlices |
SaveSlices.create(Scope scope,
Operand<String> filename,
Operand<String> tensorNames,
Operand<String> shapesAndSlices,
Iterable<Operand<?>> data)
Factory method to create a class wrapping a new SaveSlices operation.
|
Copyright © 2015–2019. All rights reserved.