- pad(String, int) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
Return a String of length a minimum of totalChars characters by
padding the input String str with spaces.
- pad(Object, int) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
Pads the toString value of the given Object.
- padding(int) - Method in class org.deeplearning4j.nn.conf.layers.Convolution1DLayer.Builder
-
- padding - Variable in class org.deeplearning4j.nn.conf.layers.ConvolutionLayer.BaseConvBuilder
-
- padding(int...) - Method in class org.deeplearning4j.nn.conf.layers.ConvolutionLayer.Builder
-
- padding - Variable in class org.deeplearning4j.nn.conf.layers.ConvolutionLayer
-
- padding(int) - Method in class org.deeplearning4j.nn.conf.layers.Subsampling1DLayer.Builder
-
Padding
- padding - Variable in class org.deeplearning4j.nn.conf.layers.SubsamplingLayer.BaseSubsamplingBuilder
-
- padding(int...) - Method in class org.deeplearning4j.nn.conf.layers.SubsamplingLayer.Builder
-
Padding
- padding - Variable in class org.deeplearning4j.nn.conf.layers.SubsamplingLayer
-
- padLeft(String, int) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
Pads the given String to the left with spaces to ensure that it's
at least totalChars long.
- padLeft(Object, int) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
- padLeft(int, int) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
- padLeft(double, int) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
- padOrTrim(String, int) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
Pad or trim so as to produce a string of exactly a certain length.
- padOrTrim(Object, int) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
Pad or trim the toString value of the given Object.
- paginate(String, BucketKeyListener) - Method in class org.deeplearning4j.aws.s3.reader.S3Downloader
-
Paginates through a bucket's keys invoking the listener
at each key
- Pair<F,S> - Class in org.deeplearning4j.berkeley
-
A generic-typed pair of objects.
- Pair(F, S) - Constructor for class org.deeplearning4j.berkeley.Pair
-
- Pair.DefaultLexicographicPairComparator<F extends java.lang.Comparable<F>,S extends java.lang.Comparable<S>> - Class in org.deeplearning4j.berkeley
-
- Pair.FirstComparator<S extends java.lang.Comparable<? super S>,T> - Class in org.deeplearning4j.berkeley
-
- Pair.LexicographicPairComparator<F,S> - Class in org.deeplearning4j.berkeley
-
- Pair.ReverseFirstComparator<S extends java.lang.Comparable<? super S>,T> - Class in org.deeplearning4j.berkeley
-
- Pair.ReverseSecondComparator<S,T extends java.lang.Comparable<? super T>> - Class in org.deeplearning4j.berkeley
-
- Pair.SecondComparator<S,T extends java.lang.Comparable<? super T>> - Class in org.deeplearning4j.berkeley
-
- PairDataSetToMultiDataSetFn<K> - Class in org.deeplearning4j.spark.impl.graph.dataset
-
Simple conversion function to convert from a JavaPairRDD<K,DataSet>
to a JavaPairRDD<K,MultiDataSet>
- PairDataSetToMultiDataSetFn() - Constructor for class org.deeplearning4j.spark.impl.graph.dataset.PairDataSetToMultiDataSetFn
-
- PairToArrayPair<K> - Class in org.deeplearning4j.spark.impl.graph.scoring
-
Simple conversion function for SparkComputationGraph
- PairToArrayPair() - Constructor for class org.deeplearning4j.spark.impl.graph.scoring.PairToArrayPair
-
- ParagraphVectors - Class in org.deeplearning4j.models.paragraphvectors
-
Basic ParagraphVectors (aka Doc2Vec) implementation for DL4j, as wrapper over SequenceVectors
- ParagraphVectors() - Constructor for class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
-
- ParagraphVectors.BlindInferenceCallable - Class in org.deeplearning4j.models.paragraphvectors
-
- ParagraphVectors.Builder - Class in org.deeplearning4j.models.paragraphvectors
-
- ParagraphVectors.InferenceCallable - Class in org.deeplearning4j.models.paragraphvectors
-
- ParagraphVectorsTest - Class in org.deeplearning4j.models.paragraphvectors
-
Created by agibsonccc on 12/3/14.
- ParagraphVectorsTest() - Constructor for class org.deeplearning4j.models.paragraphvectors.ParagraphVectorsTest
-
- parallelCounter() - Static method in class org.deeplearning4j.text.movingwindow.Util
-
Returns a thread safe counter
- parallelCounterMap() - Static method in class org.deeplearning4j.berkeley.CounterMap
-
Returns a thread safe counter map
- parallelCounterMap() - Static method in class org.deeplearning4j.text.movingwindow.Util
-
Returns a thread safe counter map
- parallelTasks(List<Runnable>, ExecutorService) - Static method in class org.deeplearning4j.util.MultiThreadUtils
-
- ParallelTransformerIterator - Class in org.deeplearning4j.models.sequencevectors.transformers.impl.iterables
-
TransformerIterator implementation that's does transformation/tokenization/normalization/whatever in parallel threads.
- ParallelTransformerIterator(LabelAwareIterator, SentenceTransformer) - Constructor for class org.deeplearning4j.models.sequencevectors.transformers.impl.iterables.ParallelTransformerIterator
-
- ParallelTransformerIterator(LabelAwareIterator, SentenceTransformer, boolean) - Constructor for class org.deeplearning4j.models.sequencevectors.transformers.impl.iterables.ParallelTransformerIterator
-
- ParallelTransformerIteratorTest - Class in org.deeplearning4j.models.sequencevectors.transformers.impl.iterables
-
- ParallelTransformerIteratorTest() - Constructor for class org.deeplearning4j.models.sequencevectors.transformers.impl.iterables.ParallelTransformerIteratorTest
-
- ParallelWrapper - Class in org.deeplearning4j.parallelism
-
This is simple data-parallel wrapper
suitable for multi-cpu/multi-gpu environments.
- ParallelWrapper(Model, int, int) - Constructor for class org.deeplearning4j.parallelism.ParallelWrapper
-
- parallelWrapper(ParallelWrapper) - Method in class org.deeplearning4j.parallelism.parameterserver.ParameterServerTrainer.ParameterServerTrainerBuilder
-
- parallelWrapper - Variable in class org.deeplearning4j.parallelism.trainer.DefaultTrainer
-
- ParallelWrapper.Builder<T extends Model> - Class in org.deeplearning4j.parallelism
-
- ParallelWrapperMain - Class in org.deeplearning4j.parallelism.main
-
Parallelwrapper main class.
- ParallelWrapperMain() - Constructor for class org.deeplearning4j.parallelism.main.ParallelWrapperMain
-
- ParallelWrapperMainTest - Class in org.deeplearning4j.parallelism.main
-
Created by agibsonccc on 12/29/16.
- ParallelWrapperMainTest() - Constructor for class org.deeplearning4j.parallelism.main.ParallelWrapperMainTest
-
- ParallelWrapperTest - Class in org.deeplearning4j.parallelism
-
Created by agibsonccc on 11/12/16.
- ParallelWrapperTest() - Constructor for class org.deeplearning4j.parallelism.ParallelWrapperTest
-
- PARAM_NAME_BETA - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasBatchNormalization
-
- PARAM_NAME_GAMMA - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasBatchNormalization
-
- PARAM_NAME_RUNNING_MEAN - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasBatchNormalization
-
- PARAM_NAME_RUNNING_STD - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasBatchNormalization
-
- ParamAndGradientIterationListener - Class in org.deeplearning4j.optimize.listeners
-
An iteration listener that provides details on parameters and gradients at each iteration during traning.
- ParamAndGradientIterationListener() - Constructor for class org.deeplearning4j.optimize.listeners.ParamAndGradientIterationListener
-
Default constructor for output to console only every iteration, tab delimited
- ParamAndGradientIterationListener(int, boolean, boolean, boolean, boolean, boolean, boolean, boolean, File, String) - Constructor for class org.deeplearning4j.optimize.listeners.ParamAndGradientIterationListener
-
Full constructor with all options.
- PARAMETER_AVERAGING_MASTER_AGGREGATE_TIMES_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats
-
- PARAMETER_AVERAGING_MASTER_BROADCAST_CREATE_TIMES_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats
-
- PARAMETER_AVERAGING_MASTER_COUNT_RDD_TIMES_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats
-
- PARAMETER_AVERAGING_MASTER_EXPORT_RDD_TIMES_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats
-
- PARAMETER_AVERAGING_MASTER_FIT_TIMES_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats
-
- PARAMETER_AVERAGING_MASTER_MAP_PARTITIONS_TIMES_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats
-
- PARAMETER_AVERAGING_MASTER_PROCESS_PARAMS_UPDATER_TIMES_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats
-
- PARAMETER_AVERAGING_MASTER_REPARTITION_TIMES_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats
-
- PARAMETER_AVERAGING_MASTER_SPLIT_TIMES_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats
-
- PARAMETER_AVERAGING_WORKER_BROADCAST_GET_VALUE_TIME_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingWorkerStats
-
- PARAMETER_AVERAGING_WORKER_FIT_TIMES_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingWorkerStats
-
- PARAMETER_AVERAGING_WORKER_INIT_TIME_MS - Static variable in class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingWorkerStats
-
- ParameterAveragingAggregationTuple - Class in org.deeplearning4j.spark.impl.paramavg.aggregator
-
Simple helper tuple used to execute parameter averaging
- ParameterAveragingAggregationTuple() - Constructor for class org.deeplearning4j.spark.impl.paramavg.aggregator.ParameterAveragingAggregationTuple
-
- ParameterAveragingElementAddFunction - Class in org.deeplearning4j.spark.impl.paramavg.aggregator
-
Add function for parameter averaging
- ParameterAveragingElementAddFunction() - Constructor for class org.deeplearning4j.spark.impl.paramavg.aggregator.ParameterAveragingElementAddFunction
-
- ParameterAveragingElementCombineFunction - Class in org.deeplearning4j.spark.impl.paramavg.aggregator
-
Function used in ParameterAveraging TrainingMaster, for doing parameter averaging, and handling updaters
- ParameterAveragingElementCombineFunction() - Constructor for class org.deeplearning4j.spark.impl.paramavg.aggregator.ParameterAveragingElementCombineFunction
-
- ParameterAveragingTrainingMaster - Class in org.deeplearning4j.spark.impl.paramavg
-
ParameterAveragingTrainingMaster: A
TrainingMaster
implementation for training networks on Spark.
- ParameterAveragingTrainingMaster(boolean, Integer, int, int, int, int) - Constructor for class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingMaster
-
- ParameterAveragingTrainingMaster(boolean, Integer, int, int, int, int, Repartition, RepartitionStrategy, boolean) - Constructor for class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingMaster
-
- ParameterAveragingTrainingMaster(boolean, Integer, int, int, int, int, Repartition, RepartitionStrategy, StorageLevel, boolean) - Constructor for class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingMaster
-
- ParameterAveragingTrainingMaster.Builder - Class in org.deeplearning4j.spark.impl.paramavg
-
- ParameterAveragingTrainingMasterStats - Class in org.deeplearning4j.spark.impl.paramavg.stats
-
- ParameterAveragingTrainingMasterStats(SparkTrainingStats, List<EventStats>, List<EventStats>, List<EventStats>, List<EventStats>, List<EventStats>, List<EventStats>, List<EventStats>, List<EventStats>, List<EventStats>) - Constructor for class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats
-
- ParameterAveragingTrainingMasterStats.ParameterAveragingTrainingMasterStatsHelper - Class in org.deeplearning4j.spark.impl.paramavg.stats
-
- ParameterAveragingTrainingMasterStatsHelper() - Constructor for class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingMasterStats.ParameterAveragingTrainingMasterStatsHelper
-
- ParameterAveragingTrainingResult - Class in org.deeplearning4j.spark.impl.paramavg
-
- ParameterAveragingTrainingResult(INDArray, INDArray, double, Collection<StorageMetaData>, Collection<Persistable>, Collection<Persistable>) - Constructor for class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingResult
-
- ParameterAveragingTrainingResult(INDArray, INDArray, double, SparkTrainingStats, Collection<StorageMetaData>, Collection<Persistable>, Collection<Persistable>) - Constructor for class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingResult
-
- ParameterAveragingTrainingWorker - Class in org.deeplearning4j.spark.impl.paramavg
-
ParameterAveragingTrainingWorker
implements standard parameter
averaging every m iterations.
- ParameterAveragingTrainingWorker(Broadcast<NetBroadcastTuple>, boolean, WorkerConfiguration, Collection<TrainingHook>, Collection<IterationListener>, StatsStorageRouterProvider) - Constructor for class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingWorker
-
- ParameterAveragingTrainingWorkerStats - Class in org.deeplearning4j.spark.impl.paramavg.stats
-
- ParameterAveragingTrainingWorkerStats(List<EventStats>, List<EventStats>, List<EventStats>) - Constructor for class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingWorkerStats
-
- ParameterAveragingTrainingWorkerStats.ParameterAveragingTrainingWorkerStatsHelper - Class in org.deeplearning4j.spark.impl.paramavg.stats
-
- ParameterAveragingTrainingWorkerStatsHelper() - Constructor for class org.deeplearning4j.spark.impl.paramavg.stats.ParameterAveragingTrainingWorkerStats.ParameterAveragingTrainingWorkerStatsHelper
-
- ParameterServerParallelWrapperTest - Class in org.deeplearning4j.parallelism.parameterserver
-
Created by agibsonccc on 12/17/16.
- ParameterServerParallelWrapperTest() - Constructor for class org.deeplearning4j.parallelism.parameterserver.ParameterServerParallelWrapperTest
-
- ParameterServerSubscriber - Class in org.deeplearning4j.spark.parameterserver
-
Created by agibsonccc on 9/27/16.
- ParameterServerSubscriber() - Constructor for class org.deeplearning4j.spark.parameterserver.ParameterServerSubscriber
-
- ParameterServerTrainer - Class in org.deeplearning4j.parallelism.parameterserver
-
Using an ParameterServerClient
we maintain updates for training a neural net.
- ParameterServerTrainer() - Constructor for class org.deeplearning4j.parallelism.parameterserver.ParameterServerTrainer
-
- ParameterServerTrainer.ParameterServerTrainerBuilder - Class in org.deeplearning4j.parallelism.parameterserver
-
- ParameterServerTrainerBuilder() - Constructor for class org.deeplearning4j.parallelism.parameterserver.ParameterServerTrainer.ParameterServerTrainerBuilder
-
- ParameterServerTrainerContext - Class in org.deeplearning4j.parallelism.parameterserver
-
- ParameterServerTrainerContext() - Constructor for class org.deeplearning4j.parallelism.parameterserver.ParameterServerTrainerContext
-
- ParameterServerTrainingHook - Class in org.deeplearning4j.spark.parameterserver
-
Training hook for the
parameter server
- ParameterServerTrainingHook() - Constructor for class org.deeplearning4j.spark.parameterserver.ParameterServerTrainingHook
-
- ParamHelper() - Constructor for class org.deeplearning4j.spark.ml.impl.AutoEncoderNetworkTest.ParamHelper
-
- ParamHelper() - Constructor for class org.deeplearning4j.spark.ml.impl.SparkDl4jNetworkTest.ParamHelper
-
- ParamInitializer - Interface in org.deeplearning4j.nn.api
-
Param initializer for a layer
- paramName() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.ParamNamesDecoder
-
- paramName(String) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.ParamNamesEncoder
-
- paramNameCharacterEncoding() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.ParamNamesDecoder
-
- paramNameCharacterEncoding() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.ParamNamesEncoder
-
- paramNameHeaderLength() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.ParamNamesDecoder
-
- paramNameHeaderLength() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.ParamNamesEncoder
-
- paramNameId() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.ParamNamesDecoder
-
- paramNameId() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.ParamNamesEncoder
-
- paramNameLength() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.ParamNamesDecoder
-
- paramNameMetaAttribute(MetaAttribute) - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.ParamNamesDecoder
-
- paramNameMetaAttribute(MetaAttribute) - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.ParamNamesEncoder
-
- paramNames() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder
-
- paramNamesCount(int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- ParamNamesDecoder() - Constructor for class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.ParamNamesDecoder
-
- paramNamesDecoderId() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder
-
- ParamNamesEncoder() - Constructor for class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.ParamNamesEncoder
-
- paramNamesId() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- params() - Method in interface org.deeplearning4j.nn.api.Model
-
Parameters of the model (if any)
- params(boolean) - Method in class org.deeplearning4j.nn.graph.ComputationGraph
-
Get the parameters for the ComputationGraph
- params() - Method in class org.deeplearning4j.nn.graph.ComputationGraph
-
- params() - Method in class org.deeplearning4j.nn.layers.ActivationLayer
-
- params - Variable in class org.deeplearning4j.nn.layers.BaseLayer
-
- params() - Method in class org.deeplearning4j.nn.layers.BaseLayer
-
Returns the parameters of the neural network as a flattened row vector
- params() - Method in class org.deeplearning4j.nn.layers.BasePretrainNetwork
-
- params() - Method in class org.deeplearning4j.nn.layers.convolution.ConvolutionLayer
-
- params() - Method in class org.deeplearning4j.nn.layers.convolution.subsampling.SubsamplingLayer
-
- params() - Method in class org.deeplearning4j.nn.layers.DropoutLayer
-
- params() - Method in class org.deeplearning4j.nn.layers.FrozenLayer
-
- params() - Method in class org.deeplearning4j.nn.layers.LossLayer
-
- params() - Method in class org.deeplearning4j.nn.layers.normalization.LocalResponseNormalization
-
- params - Variable in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
-
- params() - Method in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
-
- params(boolean) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
Returns a 1 x m vector where the vector is composed of
a flattened vector of all of the weights for the
various neuralNets(w,hbias NOT VBIAS) and output layer
- params() - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
Returns a 1 x m vector where the vector is composed of
a flattened vector of all of the weights for the
various neuralNets(w,hbias NOT VBIAS) and output layer
- params() - Method in class org.deeplearning4j.plot.BarnesHutTsne
-
- params - Variable in class org.deeplearning4j.spark.impl.common.score.BaseVaeScoreWithKeyFunctionAdapter
-
- PARAMS_KEY - Static variable in class org.deeplearning4j.optimize.solvers.BaseOptimizer
-
- paramServer - Variable in class org.deeplearning4j.spark.models.sequencevectors.functions.PartitionTrainingFunction
-
- paramServer - Variable in class org.deeplearning4j.spark.models.sequencevectors.functions.TrainingFunction
-
- paramServerConfiguration - Variable in class org.deeplearning4j.spark.models.sequencevectors.SparkSequenceVectors
-
- paramServerConfigurationBroadcast - Variable in class org.deeplearning4j.spark.models.sequencevectors.functions.PartitionTrainingFunction
-
- paramServerConfigurationBroadcast - Variable in class org.deeplearning4j.spark.models.sequencevectors.functions.TrainingFunction
-
- paramsFlattened - Variable in class org.deeplearning4j.nn.layers.BaseLayer
-
- paramsFlattened - Variable in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
-
- paramTable() - Method in interface org.deeplearning4j.nn.api.Model
-
The param table
- paramTable(boolean) - Method in interface org.deeplearning4j.nn.api.Model
-
Table of parameters by key, for backprop
For many models (dense layers, etc) - all parameters are backprop parameters
- paramTable() - Method in class org.deeplearning4j.nn.graph.ComputationGraph
-
- paramTable(boolean) - Method in class org.deeplearning4j.nn.graph.ComputationGraph
-
- paramTable() - Method in class org.deeplearning4j.nn.layers.BaseLayer
-
- paramTable(boolean) - Method in class org.deeplearning4j.nn.layers.BaseLayer
-
- paramTable - Variable in class org.deeplearning4j.nn.layers.BaseLayerTest
-
- paramTable(boolean) - Method in class org.deeplearning4j.nn.layers.BasePretrainNetwork
-
- paramTable() - Method in class org.deeplearning4j.nn.layers.FrozenLayer
-
- paramTable(boolean) - Method in class org.deeplearning4j.nn.layers.FrozenLayer
-
- paramTable() - Method in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
-
- paramTable(boolean) - Method in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
-
- paramTable() - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
- paramTable(boolean) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
- paramTable() - Method in class org.deeplearning4j.plot.BarnesHutTsne
-
- paramTable(boolean) - Method in class org.deeplearning4j.plot.BarnesHutTsne
-
- parent(int) - Method in class org.deeplearning4j.berkeley.PriorityQueue
-
- parent(Tree) - Method in class org.deeplearning4j.nn.layers.feedforward.autoencoder.recursive.Tree
-
Returns the parent of the passed in tree via traversal
- parent() - Method in class org.deeplearning4j.nn.layers.feedforward.autoencoder.recursive.Tree
-
- parentNode - Variable in class org.deeplearning4j.spark.models.sequencevectors.utils.NetworkOrganizer.VirtualNode
-
- parse(String) - Method in class com.atilika.kuromoji.compile.TokenInfoDictionaryCompilerBase
-
- parse(String) - Method in class com.atilika.kuromoji.ipadic.compile.TokenInfoDictionaryCompiler
-
- parse(String) - Method in class com.atilika.kuromoji.util.UnknownDictionaryEntryParser
-
- parse(String, Class<E>) - Static method in class org.deeplearning4j.util.EnumUtil
-
- parseCommandLineArguments(String[]) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
A simpler form of command line argument parsing.
- ParseException - Exception in org.deeplearning4j.graph.exception
-
Unchecked exception signifying that an error occurred during parsing of text
- ParseException() - Constructor for exception org.deeplearning4j.graph.exception.ParseException
-
- ParseException(String) - Constructor for exception org.deeplearning4j.graph.exception.ParseException
-
- ParseException(String, Exception) - Constructor for exception org.deeplearning4j.graph.exception.ParseException
-
- ParseException - Exception in org.deeplearning4j.models.sequencevectors.graph.exception
-
Unchecked exception signifying that an error occurred during parsing of text
- ParseException() - Constructor for exception org.deeplearning4j.models.sequencevectors.graph.exception.ParseException
-
- ParseException(String) - Constructor for exception org.deeplearning4j.models.sequencevectors.graph.exception.ParseException
-
- ParseException(String, Exception) - Constructor for exception org.deeplearning4j.models.sequencevectors.graph.exception.ParseException
-
- parseJsonString(String) - Static method in class org.deeplearning4j.nn.modelimport.keras.KerasModel
-
Convenience function for parsing JSON strings.
- parseLine(String) - Static method in class com.atilika.kuromoji.util.DictionaryEntryLineParser
-
Parse CSV line
- parseTime(long) - Method in class org.deeplearning4j.ui.flow.FlowIterationListener
-
Deprecated.
- parseTime(long) - Method in class org.deeplearning4j.ui.flow.RemoteFlowIterationListener
-
- parseYamlString(String) - Static method in class org.deeplearning4j.nn.modelimport.keras.KerasModel
-
Convenience function for parsing JSON strings.
- PART_OF_SPEECH_FEATURE - Static variable in class com.atilika.kuromoji.ipadic.compile.DictionaryEntry
-
- PART_OF_SPEECH_LEVEL_1 - Static variable in class com.atilika.kuromoji.ipadic.compile.DictionaryEntry
-
- PART_OF_SPEECH_LEVEL_2 - Static variable in class com.atilika.kuromoji.ipadic.compile.DictionaryEntry
-
- PART_OF_SPEECH_LEVEL_3 - Static variable in class com.atilika.kuromoji.ipadic.compile.DictionaryEntry
-
- PART_OF_SPEECH_LEVEL_4 - Static variable in class com.atilika.kuromoji.ipadic.compile.DictionaryEntry
-
- PartitionCountEventStats - Class in org.deeplearning4j.spark.stats
-
Event stats implementation with partition count
- PartitionCountEventStats(long, long, int) - Constructor for class org.deeplearning4j.spark.stats.PartitionCountEventStats
-
- PartitionCountEventStats(String, String, long, long, long, int) - Constructor for class org.deeplearning4j.spark.stats.PartitionCountEventStats
-
- PartitionTrainingFunction<T extends SequenceElement> - Class in org.deeplearning4j.spark.models.sequencevectors.functions
-
- PartitionTrainingFunction(Broadcast<VocabCache<ShallowSequenceElement>>, Broadcast<VectorsConfiguration>, Broadcast<VoidConfiguration>) - Constructor for class org.deeplearning4j.spark.models.sequencevectors.functions.PartitionTrainingFunction
-
- partitionVariable(List<Double>, int) - Static method in class org.deeplearning4j.util.MathUtils
-
This will partition the given whole variable data applyTransformToDestination in to the specified chunk number.
- partOfSpeechFeature - Variable in class com.atilika.kuromoji.TokenizerBase.Builder
-
- path - Variable in class org.deeplearning4j.spark.models.sequencevectors.export.impl.HdfsModelExporter
-
- path - Variable in class org.deeplearning4j.text.sentenceiterator.UimaSentenceIterator
-
- PathSparkDataSetIterator - Class in org.deeplearning4j.spark.iterator
-
A DataSetIterator that loads serialized DataSet objects (saved with DataSet.save(OutputStream)
) from
a String that represents the path (for example, on HDFS)
- PathSparkDataSetIterator(Iterator<String>) - Constructor for class org.deeplearning4j.spark.iterator.PathSparkDataSetIterator
-
- PathSparkDataSetIterator(Collection<String>) - Constructor for class org.deeplearning4j.spark.iterator.PathSparkDataSetIterator
-
- PathSparkMultiDataSetIterator - Class in org.deeplearning4j.spark.iterator
-
A DataSetIterator that loads serialized DataSet objects (saved with MultiDataSet.save(OutputStream)
) from
a String that represents the path (for example, on HDFS)
- PathSparkMultiDataSetIterator(Iterator<String>) - Constructor for class org.deeplearning4j.spark.iterator.PathSparkMultiDataSetIterator
-
- PathSparkMultiDataSetIterator(Collection<String>) - Constructor for class org.deeplearning4j.spark.iterator.PathSparkMultiDataSetIterator
-
- PathToDataSetFunction - Class in org.deeplearning4j.spark.data
-
Simple function used to load DataSets (serialized with DataSet.save()) from a given Path (as a String)
to a DataSet object - i.e., RDD<String>
to RDD<DataSet>
- PathToDataSetFunction() - Constructor for class org.deeplearning4j.spark.data.PathToDataSetFunction
-
- PathToMultiDataSetFunction - Class in org.deeplearning4j.spark.data
-
Simple function used to load MultiDataSets (serialized with MultiDataSet.save()) from a given Path (as a String)
to a MultiDataSet object - i.e., RDD<String>
to RDD<MultiDataSet>
- PathToMultiDataSetFunction() - Constructor for class org.deeplearning4j.spark.data.PathToMultiDataSetFunction
-
- PathUpdate - Class in org.deeplearning4j.ui.activation
-
- PathUpdate() - Constructor for class org.deeplearning4j.ui.activation.PathUpdate
-
- PathUpdate - Class in org.deeplearning4j.ui.renders
-
- PathUpdate() - Constructor for class org.deeplearning4j.ui.renders.PathUpdate
-
- PatriciaNode(String, V, int) - Constructor for class com.atilika.kuromoji.trie.PatriciaTrie.PatriciaNode
-
Constructs a new node
- PatriciaTrie<V> - Class in com.atilika.kuromoji.trie
-
Convenient and compact structure for storing key-value pairs and quickly
looking them up, including doing prefix searches
- PatriciaTrie() - Constructor for class com.atilika.kuromoji.trie.PatriciaTrie
-
Constructs and empty trie
- PatriciaTrie.KeyMapper<K> - Interface in com.atilika.kuromoji.trie
-
Generic interface to map a key to bits
- PatriciaTrie.PatriciaNode<V> - Class in com.atilika.kuromoji.trie
-
Nodes used in a
PatriciaTrie
containing a String key and associated value data
- PatriciaTrie.StringKeyMapper - Class in com.atilika.kuromoji.trie
-
- PatriciaTrieFormatter<V> - Class in com.atilika.kuromoji.trie
-
Utility class to format a
PatriciaTrie
to dot format for debugging, inspection, etc.
- PatriciaTrieFormatter() - Constructor for class com.atilika.kuromoji.trie.PatriciaTrieFormatter
-
Constructor
- PatriciaTrieTest - Class in com.atilika.kuromoji.trie
-
- PatriciaTrieTest() - Constructor for class com.atilika.kuromoji.trie.PatriciaTrieTest
-
- pattern0 - Static variable in class org.deeplearning4j.spark.models.sequencevectors.export.ExportContainer
-
- pattern1 - Static variable in class org.deeplearning4j.spark.models.sequencevectors.export.ExportContainer
-
- peek() - Method in class org.deeplearning4j.berkeley.PriorityQueue
-
- peek() - Method in interface org.deeplearning4j.berkeley.PriorityQueueInterface
-
Returns the highest-priority element in the queue, but does not pop it.
- peek() - Method in class org.deeplearning4j.parallelism.MagicQueue
-
- peek() - Method in class org.deeplearning4j.util.DiskBasedQueue
-
- peersConfiguration - Variable in class org.deeplearning4j.spark.models.sequencevectors.SparkSequenceVectors.Builder
-
- penalties - Variable in class com.atilika.kuromoji.TokenizerBase.Builder
-
- pennPOSToWordnetPOS(String) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
Computes the WordNet 2.0 POS tag corresponding to the PTB POS tag s.
- performance() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder
-
- performance() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateFieldsPresentDecoder
-
- performance(boolean) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateFieldsPresentEncoder
-
- performanceCount(int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- PerformanceDecoder() - Constructor for class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerformanceDecoder
-
- performanceDecoderId() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder
-
- PerformanceEncoder() - Constructor for class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerformanceEncoder
-
- performanceId() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- PerformanceListener - Class in org.deeplearning4j.optimize.listeners
-
Simple IterationListener that tracks time spend on training per iteration.
- PerformanceListener(int) - Constructor for class org.deeplearning4j.optimize.listeners.PerformanceListener
-
- PerformanceListener(int, boolean) - Constructor for class org.deeplearning4j.optimize.listeners.PerformanceListener
-
- PerformanceListener.Builder - Class in org.deeplearning4j.optimize.listeners
-
- PerformanceTests - Class in org.deeplearning4j.text.tokenization.tokenizer
-
- PerformanceTests() - Constructor for class org.deeplearning4j.text.tokenization.tokenizer.PerformanceTests
-
- permutation(double, double) - Static method in class org.deeplearning4j.util.MathUtils
-
This returns the permutation of n choose r.
- perParameterStats() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder
-
- perParameterStatsCount(int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- PerParameterStatsDecoder() - Constructor for class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder
-
- perParameterStatsDecoderId() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder
-
- PerParameterStatsEncoder() - Constructor for class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerParameterStatsEncoder
-
- perParameterStatsId() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- perplexity(double) - Method in class org.deeplearning4j.plot.BarnesHutTsne.Builder
-
- perplexity - Variable in class org.deeplearning4j.plot.BarnesHutTsne
-
- perplexity - Variable in class org.deeplearning4j.plot.Tsne.Builder
-
- perplexity(double) - Method in class org.deeplearning4j.plot.Tsne.Builder
-
- perplexity - Variable in class org.deeplearning4j.plot.Tsne
-
- Persistable - Interface in org.deeplearning4j.api.storage
-
Created by Alex on 07/10/2016.
- Pipeline - Interface in org.deeplearning4j
-
A pipeline consists of a
set of input,output, and datavec uris.
- PlayUIServer - Class in org.deeplearning4j.ui.play
-
A UI server based on the Play framework
- PlayUIServer() - Constructor for class org.deeplearning4j.ui.play.PlayUIServer
-
- PlayUIServer(int) - Constructor for class org.deeplearning4j.ui.play.PlayUIServer
-
- plot(INDArray, int, List<String>, String) - Method in class org.deeplearning4j.plot.BarnesHutTsne
-
- plot(INDArray, int, List<String>, String) - Method in class org.deeplearning4j.plot.Tsne
-
- plotVocab(BarnesHutTsne, int, File) - Method in class org.deeplearning4j.models.embeddings.inmemory.InMemoryLookupTable
-
- plotVocab(int, File) - Method in class org.deeplearning4j.models.embeddings.inmemory.InMemoryLookupTable
-
Render the words via tsne
- plotVocab(int, UiConnectionInfo) - Method in class org.deeplearning4j.models.embeddings.inmemory.InMemoryLookupTable
-
Render the words via tsne
- plotVocab(BarnesHutTsne, int, UiConnectionInfo) - Method in class org.deeplearning4j.models.embeddings.inmemory.InMemoryLookupTable
-
Render the words via TSNE
- plotVocab(BarnesHutTsne, int, UiConnectionInfo) - Method in interface org.deeplearning4j.models.embeddings.WeightLookupTable
-
Render the words via TSNE
- plotVocab(BarnesHutTsne, int, File) - Method in interface org.deeplearning4j.models.embeddings.WeightLookupTable
-
Render the words via TSNE
- plotVocab(int, UiConnectionInfo) - Method in interface org.deeplearning4j.models.embeddings.WeightLookupTable
-
Render the words via tsne
- plotVocab(int, File) - Method in interface org.deeplearning4j.models.embeddings.WeightLookupTable
-
Render the words via tsne
- pnorm(int) - Method in class org.deeplearning4j.nn.conf.layers.GlobalPoolingLayer.Builder
-
P-norm constant.
- pnorm - Variable in class org.deeplearning4j.nn.conf.layers.SubsamplingLayer.BaseSubsamplingBuilder
-
- pnorm(int) - Method in class org.deeplearning4j.nn.conf.layers.SubsamplingLayer.BaseSubsamplingBuilder
-
- pnorm - Variable in class org.deeplearning4j.nn.conf.layers.SubsamplingLayer
-
- Point - Class in org.deeplearning4j.clustering.cluster
-
- Point() - Constructor for class org.deeplearning4j.clustering.cluster.Point
-
- Point(INDArray) - Constructor for class org.deeplearning4j.clustering.cluster.Point
-
- Point(String, INDArray) - Constructor for class org.deeplearning4j.clustering.cluster.Point
-
- Point(String, String, double[]) - Constructor for class org.deeplearning4j.clustering.cluster.Point
-
- Point(String, String, INDArray) - Constructor for class org.deeplearning4j.clustering.cluster.Point
-
- point(INDArray) - Static method in class org.deeplearning4j.clustering.kdtree.HyperRect
-
- PointClassification - Class in org.deeplearning4j.clustering.cluster
-
- PointClassification() - Constructor for class org.deeplearning4j.clustering.cluster.PointClassification
-
- PointClassification(Cluster, double, boolean) - Constructor for class org.deeplearning4j.clustering.cluster.PointClassification
-
- pointOf(Collection<Writable>) - Static method in class org.deeplearning4j.spark.util.MLLibUtil
-
Returns a labeled point of the writables
where the final item is the point and the rest of the items are
features
- points - Variable in class org.deeplearning4j.models.sequencevectors.sequence.SequenceElement
-
- pointSize - Variable in class org.deeplearning4j.ui.components.chart.style.StyleChart.Builder
-
- pointSize(double) - Method in class org.deeplearning4j.ui.components.chart.style.StyleChart.Builder
-
Point size, for scatter plot etc
- pointSize - Variable in class org.deeplearning4j.ui.components.chart.style.StyleChart
-
- poll(long, TimeUnit) - Method in class org.deeplearning4j.parallelism.MagicQueue
-
This method is supposed to be called from managed thread, attached to specific device.
- poll() - Method in class org.deeplearning4j.parallelism.MagicQueue
-
This method is supposed to be called from managed thread, attached to specific device.
- poll() - Method in class org.deeplearning4j.util.DiskBasedQueue
-
- POOLING_TYPE - Static variable in class org.deeplearning4j.nn.modelimport.keras.KerasLayerTest
-
- poolingDimensions(int...) - Method in class org.deeplearning4j.nn.conf.layers.GlobalPoolingLayer.Builder
-
Pooling dimensions.
- poolingType(PoolingType) - Method in class org.deeplearning4j.nn.conf.layers.GlobalPoolingLayer.Builder
-
- PoolingType - Enum in org.deeplearning4j.nn.conf.layers
-
Created by Alex on 17/01/2017.
- poolingType - Variable in class org.deeplearning4j.nn.conf.layers.SubsamplingLayer.BaseSubsamplingBuilder
-
- poolingType(SubsamplingLayer.PoolingType) - Method in class org.deeplearning4j.nn.conf.layers.SubsamplingLayer.BaseSubsamplingBuilder
-
- poolingType - Variable in class org.deeplearning4j.nn.conf.layers.SubsamplingLayer
-
- PopularityMode - Enum in org.deeplearning4j.models.sequencevectors.graph.enums
-
This enum is used in PopularityWalker, and it defines which nodes will be considered for next hop.
- popularityMode - Variable in class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.PopularityWalker.Builder
-
- popularityMode - Variable in class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.PopularityWalker
-
- PopularityWalker<T extends SequenceElement> - Class in org.deeplearning4j.models.sequencevectors.graph.walkers.impl
-
This is vertex popularity-based walker for SequenceVectors-based DeepWalk implementation.
- PopularityWalker() - Constructor for class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.PopularityWalker
-
- PopularityWalker.Builder<T extends SequenceElement> - Class in org.deeplearning4j.models.sequencevectors.graph.walkers.impl
-
- PopularityWalkerTest - Class in org.deeplearning4j.models.sequencevectors.graph.walkers.impl
-
- PopularityWalkerTest() - Constructor for class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.PopularityWalkerTest
-
- PortableDataStreamDataSetIterator - Class in org.deeplearning4j.spark.iterator
-
A DataSetIterator that loads serialized DataSet objects (saved with DataSet.save(OutputStream)
) from
a PortableDataStream
, usually obtained from SparkContext.binaryFiles()
- PortableDataStreamDataSetIterator(Iterator<PortableDataStream>) - Constructor for class org.deeplearning4j.spark.iterator.PortableDataStreamDataSetIterator
-
- PortableDataStreamDataSetIterator(Collection<PortableDataStream>) - Constructor for class org.deeplearning4j.spark.iterator.PortableDataStreamDataSetIterator
-
- PortableDataStreamMultiDataSetIterator - Class in org.deeplearning4j.spark.iterator
-
A DataSetIterator that loads serialized MultiDataSet objects (saved with MultiDataSet.save(OutputStream)
) from
a PortableDataStream
, usually obtained from SparkContext.binaryFiles()
- PortableDataStreamMultiDataSetIterator(Iterator<PortableDataStream>) - Constructor for class org.deeplearning4j.spark.iterator.PortableDataStreamMultiDataSetIterator
-
- PortableDataStreamMultiDataSetIterator(Collection<PortableDataStream>) - Constructor for class org.deeplearning4j.spark.iterator.PortableDataStreamMultiDataSetIterator
-
- pos(List<String>) - Method in class com.atilika.kuromoji.dict.GenericDictionaryEntry.Builder
-
- POS_MAP_FILENAME - Static variable in class com.atilika.kuromoji.dict.TokenInfoDictionary
-
- posInfo - Variable in class com.atilika.kuromoji.buffer.BufferEntry
-
- posInfo - Variable in class com.atilika.kuromoji.compile.TokenInfoDictionaryCompilerBase
-
- posInfos - Variable in class com.atilika.kuromoji.buffer.BufferEntry
-
- position - Variable in class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.RandomWalker
-
- position - Variable in class org.deeplearning4j.text.documentiterator.FileLabelAwareIterator
-
- position - Variable in class org.deeplearning4j.text.documentiterator.FilenamesLabelAwareIterator
-
- positive() - Method in class org.deeplearning4j.eval.Evaluation
-
Returns all of the positive guesses:
true positive + false negative
- PoStagger - Class in org.deeplearning4j.text.annotator
-
- PoStagger() - Constructor for class org.deeplearning4j.text.annotator.PoStagger
-
Initializes a new instance.
- postApply(Layer, INDArray, String, int) - Method in class org.deeplearning4j.nn.updater.LayerUpdater
-
Apply the regularization
- postFirstStep(INDArray) - Method in class org.deeplearning4j.optimize.solvers.BaseOptimizer
-
- postProcessAnnotations(Span[], AnnotationFS[]) - Method in class org.deeplearning4j.text.tokenization.tokenizer.ConcurrentTokenizer
-
- postReport(WebTarget, Entity) - Method in class org.deeplearning4j.ui.WebReporter
-
This method immediately sends UI report to specified target using POST request
- postStep(INDArray) - Method in interface org.deeplearning4j.optimize.api.ConvexOptimizer
-
After the step has been made, do an action
- postStep(INDArray) - Method in class org.deeplearning4j.optimize.solvers.BaseOptimizer
-
Post step to update searchDirection with new gradient and parameter information
- postStep(INDArray) - Method in class org.deeplearning4j.optimize.solvers.ConjugateGradient
-
- postStep(INDArray) - Method in class org.deeplearning4j.optimize.solvers.LBFGS
-
- postStep(INDArray) - Method in class org.deeplearning4j.optimize.solvers.LineGradientDescent
-
- postStep(INDArray) - Method in class org.deeplearning4j.optimize.solvers.StochasticGradientDescent
-
- postUpdate(DataSet, Model) - Method in interface org.deeplearning4j.spark.api.TrainingHook
-
A hook method for post update
- postUpdate(MultiDataSet, Model) - Method in interface org.deeplearning4j.spark.api.TrainingHook
-
A hook method for post update
- postUpdate(DataSet, Model) - Method in class org.deeplearning4j.spark.parameterserver.ParameterServerTrainingHook
-
A hook method for post update
- postUpdate(MultiDataSet, Model) - Method in class org.deeplearning4j.spark.parameterserver.ParameterServerTrainingHook
-
A hook method for post update
- PosUimaTokenizer - Class in org.deeplearning4j.text.tokenization.tokenizer
-
Filter by part of speech tag.
- PosUimaTokenizer(String, AnalysisEngine, Collection<String>) - Constructor for class org.deeplearning4j.text.tokenization.tokenizer.PosUimaTokenizer
-
- PosUimaTokenizer(String, AnalysisEngine, Collection<String>, boolean) - Constructor for class org.deeplearning4j.text.tokenization.tokenizer.PosUimaTokenizer
-
- PosUimaTokenizerFactory - Class in org.deeplearning4j.text.tokenization.tokenizerfactory
-
Creates a tokenizer that filters by
part of speech tags
- PosUimaTokenizerFactory(Collection<String>, boolean) - Constructor for class org.deeplearning4j.text.tokenization.tokenizerfactory.PosUimaTokenizerFactory
-
- PosUimaTokenizerFactory(Collection<String>) - Constructor for class org.deeplearning4j.text.tokenization.tokenizerfactory.PosUimaTokenizerFactory
-
- PosUimaTokenizerFactory(AnalysisEngine, Collection<String>) - Constructor for class org.deeplearning4j.text.tokenization.tokenizerfactory.PosUimaTokenizerFactory
-
- PosUimaTokenizerFactoryTest - Class in org.deeplearning4j.text.tokenization.tokenizerfactory
-
- PosUimaTokenizerFactoryTest() - Constructor for class org.deeplearning4j.text.tokenization.tokenizerfactory.PosUimaTokenizerFactoryTest
-
- posValues - Variable in class com.atilika.kuromoji.dict.TokenInfoDictionary
-
- preApply(Layer, Gradient, int) - Method in class org.deeplearning4j.nn.updater.LayerUpdater
-
Apply gradient normalization: scale based on L2, clipping etc.
- preciseWeightInit - Variable in class org.deeplearning4j.models.sequencevectors.SequenceVectors.Builder
-
- precision(Integer) - Method in class org.deeplearning4j.eval.Evaluation
-
Returns the precision for a given label
- precision(Integer, double) - Method in class org.deeplearning4j.eval.Evaluation
-
Returns the precision for a given label
- precision() - Method in class org.deeplearning4j.eval.Evaluation
-
Precision based on guesses so far
Takes into account all known classes and outputs average precision across all of them
- precision(int) - Method in class org.deeplearning4j.eval.EvaluationBinary
-
Get the precision (tp / (tp + fp)) for the specified output
- PrecisionRecallPoint() - Constructor for class org.deeplearning4j.eval.ROC.PrecisionRecallPoint
-
- PrecisionRecallPoint() - Constructor for class org.deeplearning4j.eval.ROCBinary.PrecisionRecallPoint
-
- predict(String) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
-
Deprecated.
- predict(LabelledDocument) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
-
Deprecated.
- predict(List<VocabWord>) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
-
Deprecated.
- predict(INDArray) - Method in interface org.deeplearning4j.nn.api.Classifier
-
Takes in a list of examples
For each row, returns a label
- predict(DataSet) - Method in interface org.deeplearning4j.nn.api.Classifier
-
Takes in a DataSet of examples
For each row, returns a label
- predict(INDArray) - Method in class org.deeplearning4j.nn.layers.BaseOutputLayer
-
Returns the predictions for each example in the dataset
- predict(DataSet) - Method in class org.deeplearning4j.nn.layers.BaseOutputLayer
-
Return predicted label names
- predict(INDArray) - Method in class org.deeplearning4j.nn.layers.LossLayer
-
Returns the predictions for each example in the dataset
- predict(DataSet) - Method in class org.deeplearning4j.nn.layers.LossLayer
-
Return predicted label names
- predict(INDArray) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
Returns the predictions for each example in the dataset
- predict(DataSet) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
Return predicted label names
- predict(Matrix) - Method in class org.deeplearning4j.spark.impl.layer.SparkDl4jLayer
-
Predict the given feature matrix
- predict(Vector) - Method in class org.deeplearning4j.spark.impl.layer.SparkDl4jLayer
-
Predict the given vector
- predict(Matrix) - Method in class org.deeplearning4j.spark.impl.multilayer.SparkDl4jMultiLayer
-
Predict the given feature matrix
- predict(Vector) - Method in class org.deeplearning4j.spark.impl.multilayer.SparkDl4jMultiLayer
-
Predict the given vector
- Prediction - Class in org.deeplearning4j.eval.meta
-
Prediction: a prediction for classification, used with the
Evaluation
class.
- Prediction() - Constructor for class org.deeplearning4j.eval.meta.Prediction
-
- prediction() - Method in class org.deeplearning4j.nn.layers.feedforward.autoencoder.recursive.Tree
-
- predictSeveral(LabelledDocument, int) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
-
Deprecated.
- predictSeveral(String, int) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
-
Deprecated.
- predictSeveral(List<VocabWord>, int) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
-
Deprecated.
- prefetchBuffer(int) - Method in class org.deeplearning4j.parallelism.ParallelWrapper.Builder
-
Size of prefetch buffer that will be used for background data prefetching.
- PrefetchingSentenceIterator - Class in org.deeplearning4j.text.sentenceiterator
-
Deprecated.
- PrefetchingSentenceIterator.Builder - Class in org.deeplearning4j.text.sentenceiterator
-
Deprecated.
- PrefetchingSentenceIteratorTest - Class in org.deeplearning4j.text.sentenceiterator
-
- PrefetchingSentenceIteratorTest() - Constructor for class org.deeplearning4j.text.sentenceiterator.PrefetchingSentenceIteratorTest
-
- prefetchNumBatches - Variable in class org.deeplearning4j.spark.api.WorkerConfiguration
-
- prefetchSize - Variable in class org.deeplearning4j.parallelism.ParallelWrapper.Builder
-
- prefetchSize - Variable in class org.deeplearning4j.parallelism.ParallelWrapper
-
- preloadedDataSet - Variable in class org.deeplearning4j.spark.iterator.BaseDataSetIterator
-
- preOutput(INDArray) - Method in interface org.deeplearning4j.nn.api.Layer
-
Raw activations
- preOutput(INDArray, Layer.TrainingMode) - Method in interface org.deeplearning4j.nn.api.Layer
-
Raw activations
- preOutput(INDArray, boolean) - Method in interface org.deeplearning4j.nn.api.Layer
-
Raw activations
- preOutput(INDArray, Layer.TrainingMode) - Method in class org.deeplearning4j.nn.layers.BaseLayer
-
- preOutput(INDArray, boolean) - Method in class org.deeplearning4j.nn.layers.BaseLayer
-
- preOutput(boolean) - Method in class org.deeplearning4j.nn.layers.BaseLayer
-
- preOutput(INDArray) - Method in class org.deeplearning4j.nn.layers.BaseLayer
-
Classify input
- preOutput(boolean) - Method in class org.deeplearning4j.nn.layers.convolution.Convolution1DLayer
-
- preOutput(INDArray, INDArray, INDArray, int[], int[], int[], ConvolutionLayer.AlgoMode, ConvolutionMode) - Method in interface org.deeplearning4j.nn.layers.convolution.ConvolutionHelper
-
- preOutput(boolean) - Method in class org.deeplearning4j.nn.layers.convolution.ConvolutionLayer
-
- preOutput(INDArray, INDArray, INDArray, int[], int[], int[], ConvolutionLayer.AlgoMode, ConvolutionMode) - Method in class org.deeplearning4j.nn.layers.convolution.CudnnConvolutionHelper
-
- preOutput(boolean) - Method in class org.deeplearning4j.nn.layers.DropoutLayer
-
- preOutput(boolean) - Method in class org.deeplearning4j.nn.layers.feedforward.embedding.EmbeddingLayer
-
- preOutput(INDArray, boolean) - Method in class org.deeplearning4j.nn.layers.feedforward.rbm.RBM
-
- preOutput(INDArray) - Method in class org.deeplearning4j.nn.layers.FrozenLayer
-
- preOutput(INDArray, Layer.TrainingMode) - Method in class org.deeplearning4j.nn.layers.FrozenLayer
-
- preOutput(INDArray, boolean) - Method in class org.deeplearning4j.nn.layers.FrozenLayer
-
- preOutput(INDArray) - Method in class org.deeplearning4j.nn.layers.normalization.BatchNormalization
-
- preOutput(INDArray, Layer.TrainingMode) - Method in class org.deeplearning4j.nn.layers.normalization.BatchNormalization
-
- preOutput(INDArray, boolean) - Method in class org.deeplearning4j.nn.layers.normalization.BatchNormalization
-
- preOutput(INDArray, boolean, int[], INDArray, INDArray, INDArray, INDArray, double, double) - Method in interface org.deeplearning4j.nn.layers.normalization.BatchNormalizationHelper
-
- preOutput(INDArray, boolean, int[], INDArray, INDArray, INDArray, INDArray, double, double) - Method in class org.deeplearning4j.nn.layers.normalization.CudnnBatchNormalizationHelper
-
- preOutput(INDArray) - Method in class org.deeplearning4j.nn.layers.recurrent.GravesBidirectionalLSTM
-
- preOutput(INDArray, boolean) - Method in class org.deeplearning4j.nn.layers.recurrent.GravesBidirectionalLSTM
-
- preOutput(INDArray) - Method in class org.deeplearning4j.nn.layers.recurrent.GravesLSTM
-
- preOutput(INDArray, boolean) - Method in class org.deeplearning4j.nn.layers.recurrent.GravesLSTM
-
- preOutput(INDArray, boolean) - Method in class org.deeplearning4j.nn.layers.recurrent.RnnOutputLayer
-
- preOutput(INDArray) - Method in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
-
- preOutput(INDArray, Layer.TrainingMode) - Method in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
-
- preOutput(INDArray, boolean) - Method in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
-
- preOutput(boolean) - Method in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
-
- preOutput(INDArray) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
- preOutput(INDArray, Layer.TrainingMode) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
- preOutput(INDArray, boolean) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
- preOutput2d(boolean) - Method in class org.deeplearning4j.nn.layers.BaseOutputLayer
-
- preOutput2d(boolean) - Method in class org.deeplearning4j.nn.layers.recurrent.RnnOutputLayer
-
- preOutput4d(boolean) - Method in class org.deeplearning4j.nn.layers.convolution.Convolution1DLayer
-
- preOutput4d(boolean) - Method in class org.deeplearning4j.nn.layers.convolution.ConvolutionLayer
-
preOutput4d: Used so that ConvolutionLayer subclasses (such as Convolution1DLayer) can maintain their standard
non-4d preOutput method, while overriding this to return 4d activations (for use in backprop) without modifying
the public API
- prependToEach(String, int) - Method in class org.deeplearning4j.util.StringGrid
-
- preProcess(DataSet) - Method in class org.deeplearning4j.datasets.iterator.CombinedPreProcessor
-
Pre process a dataset sequentially
- preProcess(DataSet) - Method in class org.deeplearning4j.datasets.iterator.DummyPreProcessor
-
Pre process a dataset
- preProcess(INDArray, int) - Method in interface org.deeplearning4j.nn.conf.InputPreProcessor
-
Pre preProcess input/activations for a multi layer network
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.BinomialSamplingPreProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.CnnToFeedForwardPreProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.CnnToRnnPreProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.ComposableInputPreProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.custom.MyCustomPreprocessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.FeedForwardToCnnPreProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.FeedForwardToRnnPreProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.RnnToCnnPreProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.RnnToFeedForwardPreProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.UnitVarianceProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.ZeroMeanAndUnitVariancePreProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.conf.preprocessor.ZeroMeanPrePreProcessor
-
- preProcess(INDArray, int) - Method in class org.deeplearning4j.nn.modelimport.keras.preprocessors.TensorFlowCnnToFeedForwardPreProcessor
-
- preProcess(String) - Method in interface org.deeplearning4j.text.sentenceiterator.SentencePreProcessor
-
Pre process a sentence
- preProcess(String) - Method in class org.deeplearning4j.text.tokenization.tokenizer.preprocessor.CommonPreprocessor
-
- preProcess(String) - Method in class org.deeplearning4j.text.tokenization.tokenizer.preprocessor.CustomStemmingPreprocessor
-
- preProcess(String) - Method in class org.deeplearning4j.text.tokenization.tokenizer.preprocessor.EmbeddedStemmingPreprocessor
-
- preProcess(String) - Method in class org.deeplearning4j.text.tokenization.tokenizer.preprocessor.EndingPreProcessor
-
- preProcess(String) - Method in class org.deeplearning4j.text.tokenization.tokenizer.preprocessor.LowCasePreProcessor
-
Pre process a token
- preProcess(String) - Method in class org.deeplearning4j.text.tokenization.tokenizer.preprocessor.StemmingPreprocessor
-
- preProcess(String) - Method in interface org.deeplearning4j.text.tokenization.tokenizer.TokenPreProcess
-
Pre process a token
- preProcessLine() - Method in interface org.deeplearning4j.optimize.api.ConvexOptimizer
-
Pre preProcess a line before an iteration
- preProcessLine() - Method in class org.deeplearning4j.optimize.solvers.BaseOptimizer
-
Pre preProcess to setup initial searchDirection approximation
- preProcessLine() - Method in class org.deeplearning4j.optimize.solvers.ConjugateGradient
-
- preProcessLine() - Method in class org.deeplearning4j.optimize.solvers.LBFGS
-
- preProcessLine() - Method in class org.deeplearning4j.optimize.solvers.LineGradientDescent
-
- preProcessLine() - Method in class org.deeplearning4j.optimize.solvers.StochasticGradientDescent
-
- preProcessor - Variable in class org.deeplearning4j.datasets.datavec.RecordReaderDataSetIterator
-
- preProcessor - Variable in class org.deeplearning4j.datasets.iterator.BaseDatasetIterator
-
- preProcessor - Variable in class org.deeplearning4j.datasets.iterator.MultipleEpochsIterator
-
- preprocessor - Variable in class org.deeplearning4j.spark.iterator.BaseDataSetIterator
-
- preProcessor - Variable in class org.deeplearning4j.text.sentenceiterator.BaseSentenceIterator
-
- PreprocessorVertex - Class in org.deeplearning4j.nn.conf.graph
-
PreprocessorVertex is a simple adaptor class that allows a
InputPreProcessor
to be used in a ComputationGraph
GraphVertex, without it being associated with a layer.
- PreprocessorVertex(InputPreProcessor) - Constructor for class org.deeplearning4j.nn.conf.graph.PreprocessorVertex
-
- PreprocessorVertex - Class in org.deeplearning4j.nn.graph.vertex.impl
-
PreprocessorVertex is a simple adaptor class that allows a
InputPreProcessor
to be used in a ComputationGraph
GraphVertex, without it being associated with a layer.
- PreprocessorVertex(ComputationGraph, String, int, InputPreProcessor) - Constructor for class org.deeplearning4j.nn.graph.vertex.impl.PreprocessorVertex
-
- PreprocessorVertex(ComputationGraph, String, int, VertexIndices[], VertexIndices[], InputPreProcessor) - Constructor for class org.deeplearning4j.nn.graph.vertex.impl.PreprocessorVertex
-
- presetTables() - Method in class org.deeplearning4j.models.node2vec.Node2Vec.Builder
-
Deprecated.
- presetTables() - Method in class org.deeplearning4j.models.sequencevectors.SequenceVectors.Builder
-
This method creates new WeightLookupTable and VocabCache if there were none set
- pretrain(SequenceIterator<T>) - Method in interface org.deeplearning4j.models.embeddings.learning.ElementsLearningAlgorithm
-
- pretrain(SequenceIterator<T>) - Method in class org.deeplearning4j.models.embeddings.learning.impl.elements.CBOW
-
CBOW doesn't involve any pretraining
- pretrain(SequenceIterator<T>) - Method in class org.deeplearning4j.models.embeddings.learning.impl.elements.GloVe
-
pretrain is used to build CoOccurrence matrix for GloVe algorithm
- pretrain(SequenceIterator<T>) - Method in class org.deeplearning4j.models.embeddings.learning.impl.elements.SkipGram
-
SkipGram doesn't involves any pretraining
- pretrain(SequenceIterator<T>) - Method in class org.deeplearning4j.models.embeddings.learning.impl.sequence.DBOW
-
DBOW doesn't involves any pretraining
- pretrain(SequenceIterator<T>) - Method in class org.deeplearning4j.models.embeddings.learning.impl.sequence.DM
-
- pretrain(SequenceIterator<T>) - Method in interface org.deeplearning4j.models.embeddings.learning.SequenceLearningAlgorithm
-
- pretrain - Variable in class org.deeplearning4j.nn.conf.ComputationGraphConfiguration.GraphBuilder
-
- pretrain(boolean) - Method in class org.deeplearning4j.nn.conf.ComputationGraphConfiguration.GraphBuilder
-
Whether to do layerwise pre training or not
- pretrain - Variable in class org.deeplearning4j.nn.conf.ComputationGraphConfiguration
-
- pretrain - Variable in class org.deeplearning4j.nn.conf.MultiLayerConfiguration.Builder
-
- pretrain(boolean) - Method in class org.deeplearning4j.nn.conf.MultiLayerConfiguration.Builder
-
Whether to do pre train or not
- pretrain - Variable in class org.deeplearning4j.nn.conf.MultiLayerConfiguration
-
- pretrain - Variable in class org.deeplearning4j.nn.conf.NeuralNetConfiguration.Builder
-
- pretrain(boolean) - Method in class org.deeplearning4j.nn.conf.NeuralNetConfiguration.ListBuilder
-
- pretrain - Variable in class org.deeplearning4j.nn.conf.NeuralNetConfiguration
-
- pretrain(DataSetIterator) - Method in class org.deeplearning4j.nn.graph.ComputationGraph
-
Pretrain network with a single input and single output.
- pretrain(MultiDataSetIterator) - Method in class org.deeplearning4j.nn.graph.ComputationGraph
-
Pretrain network with multiple inputs and/or outputs
- pretrain(DataSetIterator) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
Perform layerwise pretraining on all pre-trainable layers in the network (VAEs, RBMs, Autoencoders, etc)
Note that pretraining will be performed on one layer after the other, resetting the DataSetIterator between iterations.
For multiple epochs per layer, appropriately wrap the iterator (for example, a MultipleEpochsIterator) or train
each layer manually using
MultiLayerNetwork.pretrainLayer(int, DataSetIterator)
- pretrain(INDArray) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
- pretrain - Variable in class org.deeplearning4j.nn.transferlearning.FineTuneConfiguration
-
- pretrain(SequenceIterator<ShallowSequenceElement>) - Method in class org.deeplearning4j.spark.models.sequencevectors.learning.elements.BaseSparkLearningAlgorithm
-
- pretrain(SequenceIterator<ShallowSequenceElement>) - Method in class org.deeplearning4j.spark.models.sequencevectors.learning.sequence.BaseSparkSequenceLearningAlgorithm
-
- preTrainIterations - Variable in class org.deeplearning4j.nn.conf.layers.BasePretrainNetwork.Builder
-
- preTrainIterations(int) - Method in class org.deeplearning4j.nn.conf.layers.BasePretrainNetwork.Builder
-
- pretrainLayer(String, DataSetIterator) - Method in class org.deeplearning4j.nn.graph.ComputationGraph
-
Pretrain a specified layer with the given DataSetIterator
- pretrainLayer(String, MultiDataSetIterator) - Method in class org.deeplearning4j.nn.graph.ComputationGraph
-
Pretrain a specified layer with the given MultiDataSetIterator
- pretrainLayer(int, DataSetIterator) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
Perform layerwise unsupervised training on a single pre-trainable layer in the network (VAEs, RBMs, Autoencoders, etc)
If the specified layer index (0 to numLayers - 1) is not a pretrainable layer, this is a no-op.
- pretrainLayer(int, INDArray) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
Perform layerwise unsupervised training on a single pre-trainable layer in the network (VAEs, RBMs, Autoencoders, etc)
If the specified layer index (0 to numLayers - 1) is not a pretrainable layer, this is a no-op.
- PretrainParamInitializer - Class in org.deeplearning4j.nn.params
-
Pretrain weight initializer.
- PretrainParamInitializer() - Constructor for class org.deeplearning4j.nn.params.PretrainParamInitializer
-
- preUpdate(DataSet, Model) - Method in interface org.deeplearning4j.spark.api.TrainingHook
-
A hook method for pre update.
- preUpdate(MultiDataSet, Model) - Method in interface org.deeplearning4j.spark.api.TrainingHook
-
A hook method for pre update.
- preUpdate(DataSet, Model) - Method in class org.deeplearning4j.spark.parameterserver.ParameterServerTrainingHook
-
A hook method for pre update.
- preUpdate(MultiDataSet, Model) - Method in class org.deeplearning4j.spark.parameterserver.ParameterServerTrainingHook
-
A hook method for pre update.
- prev() - Method in class org.deeplearning4j.datasets.mnist.MnistDbFile
-
Move to the previous entry.
- prevImage() - Method in class org.deeplearning4j.datasets.mnist.MnistImageFile
-
Move the cursor to the previous image.
- previous() - Method in class org.deeplearning4j.models.glove.count.RoundCount
-
- PRINT_INDENT - Static variable in interface org.deeplearning4j.spark.api.stats.SparkTrainingStats
-
- PRINT_RESULTS - Static variable in class org.deeplearning4j.gradientcheck.GradientCheckTestsComputationGraph
-
- printConfiguration() - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
-
Prints the configuration
- PrintDataSet - Class in org.deeplearning4j.streaming.pipeline.spark
-
Created by agibsonccc on 6/11/16.
- PrintDataSet() - Constructor for class org.deeplearning4j.streaming.pipeline.spark.PrintDataSet
-
- printFeatures(String[][]) - Method in class com.atilika.kuromoji.compile.UnknownDictionaryCompiler
-
- println(String) - Static method in class com.atilika.kuromoji.compile.ProgressLog
-
- printOutProjectedMemoryUse(long, int, int) - Static method in class org.deeplearning4j.models.embeddings.loader.WordVectorSerializer
-
- printStringOneCharPerLine(String) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
- printSummary() - Method in class org.deeplearning4j.nn.graph.TestComputationGraphNetwork
-
- printThreadInfo(PrintWriter, String) - Static method in class org.deeplearning4j.util.ReflectionUtils
-
Print all of the thread's information and stack traces.
- printToFile(File, String, boolean) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
Prints to a file.
- printToFile(File, String) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
Prints to a file.
- printToFile(String, String, boolean) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
Prints to a file.
- printToFile(String, String) - Static method in class org.deeplearning4j.berkeley.StringUtils
-
Prints to a file.
- PriorityQueue<E> - Class in org.deeplearning4j.berkeley
-
A priority queue based on a binary heap.
- PriorityQueue() - Constructor for class org.deeplearning4j.berkeley.PriorityQueue
-
- PriorityQueue(int) - Constructor for class org.deeplearning4j.berkeley.PriorityQueue
-
- PriorityQueueInterface<E> - Interface in org.deeplearning4j.berkeley
-
- probRound(double, Random) - Static method in class org.deeplearning4j.util.MathUtils
-
Rounds a double to the next nearest integer value in a probabilistic
fashion (e.g.
- probToLogOdds(double) - Static method in class org.deeplearning4j.util.MathUtils
-
Returns the log-odds for a given probability.
- process(CAS) - Method in class org.deeplearning4j.text.annotator.PoStagger
-
Performs pos-tagging on the given tcas object.
- process(JCas) - Method in class org.deeplearning4j.text.annotator.SentenceAnnotator
-
- process(JCas) - Method in class org.deeplearning4j.text.annotator.StemmerAnnotator
-
- process(CAS) - Method in class org.deeplearning4j.text.tokenization.tokenizer.ConcurrentTokenizer
-
- process(String) - Method in class org.deeplearning4j.text.uima.UimaResource
-
Use the given analysis engine and process the given text
You must release the return cas yourself
- processEvent(ListenerEvent, SequenceVectors<T>, long) - Method in interface org.deeplearning4j.models.sequencevectors.interfaces.VectorsListener
-
This method is called at each epoch end
- processEvent(ListenerEvent, SequenceVectors<T>, long) - Method in class org.deeplearning4j.models.sequencevectors.listeners.ScoreListener
-
Deprecated.
- processEvent(ListenerEvent, SequenceVectors<T>, long) - Method in class org.deeplearning4j.models.sequencevectors.listeners.SerializingListener
-
This method is called at each epoch end
- processEvent(ListenerEvent, SequenceVectors<T>, long) - Method in class org.deeplearning4j.models.sequencevectors.listeners.SimilarityListener
-
- processing - Variable in class org.deeplearning4j.models.sequencevectors.transformers.impl.iterables.ParallelTransformerIterator
-
- processLine(String) - Method in interface org.deeplearning4j.graph.data.EdgeLineProcessor
-
Process a line of text into an edge.
- processLine(String) - Method in class org.deeplearning4j.graph.data.impl.DelimitedEdgeLineProcessor
-
- processLine(String) - Method in class org.deeplearning4j.graph.data.impl.WeightedEdgeLineProcessor
-
- processMinibatch(DataSet, MultiLayerNetwork, boolean) - Method in interface org.deeplearning4j.spark.api.TrainingWorker
-
Process (fit) a minibatch for a MultiLayerNetwork
- processMinibatch(DataSet, ComputationGraph, boolean) - Method in interface org.deeplearning4j.spark.api.TrainingWorker
-
Process (fit) a minibatch for a ComputationGraph
- processMinibatch(MultiDataSet, ComputationGraph, boolean) - Method in interface org.deeplearning4j.spark.api.TrainingWorker
-
Process (fit) a minibatch for a ComputationGraph using a MultiDataSet
- processMinibatch(DataSet, MultiLayerNetwork, boolean) - Method in class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingWorker
-
- processMinibatch(DataSet, ComputationGraph, boolean) - Method in class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingWorker
-
- processMinibatch(MultiDataSet, ComputationGraph, boolean) - Method in class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingWorker
-
- processMinibatchWithStats(DataSet, MultiLayerNetwork, boolean) - Method in interface org.deeplearning4j.spark.api.TrainingWorker
-
- processMinibatchWithStats(DataSet, ComputationGraph, boolean) - Method in interface org.deeplearning4j.spark.api.TrainingWorker
-
- processMinibatchWithStats(MultiDataSet, ComputationGraph, boolean) - Method in interface org.deeplearning4j.spark.api.TrainingWorker
-
- processMinibatchWithStats(DataSet, MultiLayerNetwork, boolean) - Method in class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingWorker
-
- processMinibatchWithStats(DataSet, ComputationGraph, boolean) - Method in class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingWorker
-
- processMinibatchWithStats(MultiDataSet, ComputationGraph, boolean) - Method in class org.deeplearning4j.spark.impl.paramavg.ParameterAveragingTrainingWorker
-
- processor(Processor) - Method in class org.deeplearning4j.streaming.routes.CamelKafkaRouteBuilder.Builder
-
- productArity() - Method in class org.deeplearning4j.streaming.embedded.StringOption
-
- productElement(int) - Method in class org.deeplearning4j.streaming.embedded.StringOption
-
- ProgressLog - Class in com.atilika.kuromoji.compile
-
Simple progress logger
- ProgressLog() - Constructor for class com.atilika.kuromoji.compile.ProgressLog
-
- promptPassphrase(String) - Method in class org.deeplearning4j.aws.ec2.provision.HostProvisioner
-
- promptPassword(String) - Method in class org.deeplearning4j.aws.ec2.provision.HostProvisioner
-
- promptYesNo(String) - Method in class org.deeplearning4j.aws.ec2.provision.HostProvisioner
-
- PRONUNCIATION - Static variable in class com.atilika.kuromoji.ipadic.compile.DictionaryEntry
-
- propDown(INDArray) - Method in class org.deeplearning4j.nn.layers.feedforward.rbm.RBM
-
Calculates the activation of the hidden:
activation(h * W + vbias)
- propUp(INDArray) - Method in class org.deeplearning4j.nn.layers.feedforward.rbm.RBM
-
Calculates the activation of the visible :
sigmoid(v * W + hbias)
- propUp(INDArray, boolean) - Method in class org.deeplearning4j.nn.layers.feedforward.rbm.RBM
-
Calculates the activation of the visible :
sigmoid(v * W + hbias)
- propUpDerivative(INDArray) - Method in class org.deeplearning4j.nn.layers.feedforward.rbm.RBM
-
- pruneKeysBelowThreshold(double) - Method in class org.deeplearning4j.berkeley.Counter
-
- publish(INDArray[]) - Method in class org.deeplearning4j.streaming.kafka.NDArrayPublisher
-
Publish an ndarray
- publish(INDArray) - Method in class org.deeplearning4j.streaming.kafka.NDArrayPublisher
-
Publish an ndarray
- put(String, V) - Method in class com.atilika.kuromoji.trie.PatriciaTrie
-
Puts value into trie identifiable by key into this trie (key should be non-null)
- put(E, double, boolean) - Method in class org.deeplearning4j.berkeley.Counter
-
Set the count for the given key if it is larger than the previous one;
- put(E, double) - Method in class org.deeplearning4j.berkeley.PriorityQueue
-
- put(E, double) - Method in interface org.deeplearning4j.berkeley.PriorityQueueInterface
-
Adds a key to the queue with the given priority.
- put(DataSet) - Method in class org.deeplearning4j.parallelism.MagicQueue
-
- put(Pair<K, T>, V) - Method in class org.deeplearning4j.util.MultiDimensionalMap
-
Associates the specified value with the specified key in this map
(optional operation).
- put(K, T, V) - Method in class org.deeplearning4j.util.MultiDimensionalMap
-
- putAll(Map<? extends String, ? extends V>) - Method in class com.atilika.kuromoji.trie.PatriciaTrie
-
Inserts all key and value entries in a map into this trie
- putAll(Map<? extends Pair<K, T>, ? extends V>) - Method in class org.deeplearning4j.util.MultiDimensionalMap
-
Copies all of the mappings from the specified map to this map
(optional operation).
- putCode(int, INDArray) - Method in class org.deeplearning4j.models.embeddings.inmemory.InMemoryLookupTable
-
- putCode(int, INDArray) - Method in interface org.deeplearning4j.models.embeddings.WeightLookupTable
-
- putCost(short, short, short) - Method in class com.atilika.kuromoji.compile.ConnectionCostsCompiler
-
- putDataSetMetaDataClassName(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- putDataSetMetaDataClassName(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- putDeviceDescription(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.HwDeviceInfoGroupEncoder
-
- putDeviceDescription(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.HwDeviceInfoGroupEncoder
-
- putEntries(List<BufferEntry>) - Method in class com.atilika.kuromoji.compile.TokenInfoBufferCompiler
-
- putEnvKey(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.SwEnvironmentInfoEncoder
-
- putEnvKey(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.SwEnvironmentInfoEncoder
-
- putEnvValue(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.SwEnvironmentInfoEncoder
-
- putEnvValue(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.SwEnvironmentInfoEncoder
-
- putGcName(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.GcStatsEncoder
-
- putGcName(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.GcStatsEncoder
-
- putHwHardwareUID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putHwHardwareUID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putInitTypeClass(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder
-
- putInitTypeClass(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder
-
- putLayerName(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.LayerNamesEncoder
-
- putLayerName(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.LayerNamesEncoder
-
- putMap(TreeMap<Integer, String>) - Method in class com.atilika.kuromoji.buffer.StringValueMapBuffer
-
- putModelConfigClassName(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putModelConfigClassName(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putModelConfigJson(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putModelConfigJson(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putModelParamNames(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.ModelParamNamesEncoder
-
- putModelParamNames(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.ModelParamNamesEncoder
-
- putParamName(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.ParamNamesEncoder
-
- putParamName(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.ParamNamesEncoder
-
- putSessionID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSessionID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSessionID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder
-
- putSessionID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder
-
- putSessionID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- putSessionID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- putStaticInfo(Persistable) - Method in class org.deeplearning4j.api.storage.impl.CollectionStatsStorageRouter
-
- putStaticInfo(Collection<? extends Persistable>) - Method in class org.deeplearning4j.api.storage.impl.CollectionStatsStorageRouter
-
- putStaticInfo(Persistable) - Method in class org.deeplearning4j.api.storage.impl.RemoteUIStatsStorageRouter
-
- putStaticInfo(Collection<? extends Persistable>) - Method in class org.deeplearning4j.api.storage.impl.RemoteUIStatsStorageRouter
-
- putStaticInfo(Persistable) - Method in interface org.deeplearning4j.api.storage.StatsStorageRouter
-
Static info: reported once per session, upon initialization
- putStaticInfo(Collection<? extends Persistable>) - Method in interface org.deeplearning4j.api.storage.StatsStorageRouter
-
Static info: reported once per session, upon initialization
- putStaticInfo(Persistable) - Method in class org.deeplearning4j.spark.impl.listeners.VanillaStatsStorageRouter
-
- putStaticInfo(Collection<? extends Persistable>) - Method in class org.deeplearning4j.spark.impl.listeners.VanillaStatsStorageRouter
-
- putStaticInfo(Persistable) - Method in class org.deeplearning4j.ui.storage.BaseCollectionStatsStorage
-
- putStaticInfo(Collection<? extends Persistable>) - Method in class org.deeplearning4j.ui.storage.BaseCollectionStatsStorage
-
- putStaticInfo(Persistable) - Method in class org.deeplearning4j.ui.storage.InMemoryStatsStorage
-
- putStaticInfo(Persistable) - Method in class org.deeplearning4j.ui.storage.mapdb.MapDBStatsStorage
-
- putStaticInfo(Persistable) - Method in class org.deeplearning4j.ui.storage.sqlite.J7FileStatsStorage
-
- putStaticInfo(Collection<? extends Persistable>) - Method in class org.deeplearning4j.ui.storage.sqlite.J7FileStatsStorage
-
- putStorageMetaData(StorageMetaData) - Method in class org.deeplearning4j.api.storage.impl.CollectionStatsStorageRouter
-
- putStorageMetaData(Collection<? extends StorageMetaData>) - Method in class org.deeplearning4j.api.storage.impl.CollectionStatsStorageRouter
-
- putStorageMetaData(StorageMetaData) - Method in class org.deeplearning4j.api.storage.impl.RemoteUIStatsStorageRouter
-
- putStorageMetaData(Collection<? extends StorageMetaData>) - Method in class org.deeplearning4j.api.storage.impl.RemoteUIStatsStorageRouter
-
- putStorageMetaData(StorageMetaData) - Method in interface org.deeplearning4j.api.storage.StatsStorageRouter
-
Method to store some additional metadata for each session.
- putStorageMetaData(Collection<? extends StorageMetaData>) - Method in interface org.deeplearning4j.api.storage.StatsStorageRouter
-
- putStorageMetaData(StorageMetaData) - Method in class org.deeplearning4j.spark.impl.listeners.VanillaStatsStorageRouter
-
- putStorageMetaData(Collection<? extends StorageMetaData>) - Method in class org.deeplearning4j.spark.impl.listeners.VanillaStatsStorageRouter
-
- putStorageMetaData(StorageMetaData) - Method in class org.deeplearning4j.ui.storage.BaseCollectionStatsStorage
-
- putStorageMetaData(Collection<? extends StorageMetaData>) - Method in class org.deeplearning4j.ui.storage.BaseCollectionStatsStorage
-
- putStorageMetaData(StorageMetaData) - Method in class org.deeplearning4j.ui.storage.InMemoryStatsStorage
-
- putStorageMetaData(StorageMetaData) - Method in class org.deeplearning4j.ui.storage.mapdb.MapDBStatsStorage
-
- putStorageMetaData(StorageMetaData) - Method in class org.deeplearning4j.ui.storage.sqlite.J7FileStatsStorage
-
- putStorageMetaData(Collection<? extends StorageMetaData>) - Method in class org.deeplearning4j.ui.storage.sqlite.J7FileStatsStorage
-
- putSwArch(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwArch(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwHostName(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwHostName(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwJvmName(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwJvmName(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwJvmSpecVersion(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwJvmSpecVersion(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwJvmUID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwJvmUID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwJvmVersion(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwJvmVersion(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwNd4jBackendClass(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwNd4jBackendClass(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwNd4jDataTypeName(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwNd4jDataTypeName(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwOsName(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putSwOsName(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putTypeID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putTypeID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putTypeID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder
-
- putTypeID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder
-
- putTypeID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- putTypeID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- putUpdate(Persistable) - Method in class org.deeplearning4j.api.storage.impl.CollectionStatsStorageRouter
-
- putUpdate(Collection<? extends Persistable>) - Method in class org.deeplearning4j.api.storage.impl.CollectionStatsStorageRouter
-
- putUpdate(Persistable) - Method in class org.deeplearning4j.api.storage.impl.RemoteUIStatsStorageRouter
-
- putUpdate(Collection<? extends Persistable>) - Method in class org.deeplearning4j.api.storage.impl.RemoteUIStatsStorageRouter
-
- putUpdate(Persistable) - Method in interface org.deeplearning4j.api.storage.StatsStorageRouter
-
Updates: stored multiple times per session (periodically, for example)
- putUpdate(Collection<? extends Persistable>) - Method in interface org.deeplearning4j.api.storage.StatsStorageRouter
-
Updates: stored multiple times per session (periodically, for example)
- putUpdate(Persistable) - Method in class org.deeplearning4j.spark.impl.listeners.VanillaStatsStorageRouter
-
- putUpdate(Collection<? extends Persistable>) - Method in class org.deeplearning4j.spark.impl.listeners.VanillaStatsStorageRouter
-
- putUpdate(Persistable) - Method in class org.deeplearning4j.ui.storage.BaseCollectionStatsStorage
-
- putUpdate(Collection<? extends Persistable>) - Method in class org.deeplearning4j.ui.storage.BaseCollectionStatsStorage
-
- putUpdate(Persistable) - Method in class org.deeplearning4j.ui.storage.InMemoryStatsStorage
-
- putUpdate(Persistable) - Method in class org.deeplearning4j.ui.storage.mapdb.MapDBStatsStorage
-
- putUpdate(Persistable) - Method in class org.deeplearning4j.ui.storage.sqlite.J7FileStatsStorage
-
- putUpdate(Collection<? extends Persistable>) - Method in class org.deeplearning4j.ui.storage.sqlite.J7FileStatsStorage
-
- putUpdateTypeClass(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder
-
- putUpdateTypeClass(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder
-
- putVector(String, INDArray) - Method in class org.deeplearning4j.models.embeddings.inmemory.InMemoryLookupTable
-
Inserts a word vector
- putVector(String, INDArray) - Method in interface org.deeplearning4j.models.embeddings.WeightLookupTable
-
Inserts a word vector
- putVocabWord(String) - Method in class org.deeplearning4j.models.word2vec.wordstore.inmemory.AbstractCache
-
Deprecated.
- putVocabWord(String) - Method in class org.deeplearning4j.models.word2vec.wordstore.inmemory.InMemoryLookupCache
-
Deprecated.
- putVocabWord(String) - Method in interface org.deeplearning4j.models.word2vec.wordstore.VocabCache
-
Deprecated.
- putWorkerID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putWorkerID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder
-
- putWorkerID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder
-
- putWorkerID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder
-
- putWorkerID(DirectBuffer, int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- putWorkerID(byte[], int, int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder
-
- PXZ_B - Static variable in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
-
Key for bias parameters connecting the last decoder layer and p(data|z) (according to whatever
ReconstructionDistribution
is set for the VAE)
- PXZ_PREFIX - Static variable in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
-
- PXZ_W - Static variable in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
-
Key for weight parameters connecting the last decoder layer and p(data|z) (according to whatever
ReconstructionDistribution
is set for the VAE)
- PZX_LOGSTD2_B - Static variable in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
-
Key for bias parameters for log(sigma^2) in p(z|data)
- PZX_LOGSTD2_PREFIX - Static variable in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
-
- PZX_LOGSTD2_W - Static variable in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
-
Key for weight parameters connecting the last encoder layer and the log(sigma^2) values for p(z|data)
- PZX_MEAN_B - Static variable in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
-
Key for bias parameters for the mean values for p(z|data)
- PZX_MEAN_PREFIX - Static variable in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
-
- PZX_MEAN_W - Static variable in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
-
Key for weight parameters connecting the last encoder layer and the mean values for p(z|data)
- PZX_PREFIX - Static variable in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
-
- pzxActivationFn(IActivation) - Method in class org.deeplearning4j.nn.conf.layers.variational.VariationalAutoencoder.Builder
-
Activation function for the input to P(z|data).
Care should be taken with this, as some activation functions (relu, etc) are not suitable due to being
bounded in range [0,infinity).
- pzxActivationFn - Variable in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
-
- pzxActivationFunction(String) - Method in class org.deeplearning4j.nn.conf.layers.variational.VariationalAutoencoder.Builder
-
- pzxActivationFunction(Activation) - Method in class org.deeplearning4j.nn.conf.layers.variational.VariationalAutoencoder.Builder
-
Activation function for the input to P(z|data).
Care should be taken with this, as some activation functions (relu, etc) are not suitable due to being
bounded in range [0,infinity).