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

N

n(double) - Method in class org.deeplearning4j.nn.conf.layers.LocalResponseNormalization.Builder
Number of adjacent kernel maps to use when doing LRN.
n - Variable in class org.deeplearning4j.nn.conf.layers.LocalResponseNormalization
 
N_GRAMS - Static variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2VecVariables
Deprecated.
 
N_OUT - Static variable in class org.deeplearning4j.nn.modelimport.keras.KerasLayerTest
 
name(String) - Method in class org.deeplearning4j.nn.conf.layers.ConvolutionLayer.Builder
Layer name assigns layer string name.
name(String) - Method in class org.deeplearning4j.nn.conf.layers.Layer.Builder
Layer name assigns layer string name.
NAME_SPACE - Static variable in class org.deeplearning4j.spark.models.embeddings.glove.GlovePerformer
 
NAME_SPACE - Static variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2VecPerformerVoid
Deprecated.
 
NAME_SPACE - Static variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2VecVariables
Deprecated.
 
NAN_REPLACEMENT_VALUE - Static variable in class org.deeplearning4j.ui.module.train.TrainModule
 
nBins() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder.HistogramsDecoder
 
nBins(int) - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerParameterStatsEncoder.HistogramsEncoder
 
nBinsId() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder.HistogramsDecoder
 
nBinsMaxValue() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder.HistogramsDecoder
 
nBinsMaxValue() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerParameterStatsEncoder.HistogramsEncoder
 
nBinsMetaAttribute(MetaAttribute) - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder.HistogramsDecoder
 
nBinsMinValue() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder.HistogramsDecoder
 
nBinsMinValue() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerParameterStatsEncoder.HistogramsEncoder
 
nBinsNullValue() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder.HistogramsDecoder
 
nBinsNullValue() - Static method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerParameterStatsEncoder.HistogramsEncoder
 
nChooseK(int, int) - Static method in class org.deeplearning4j.berkeley.SloppyMath
Computes n choose k in an efficient way.
NDARRAY_TYPE - Static variable in class org.deeplearning4j.streaming.kafka.NDArrayPublisher
 
NDARRAY_TYPE_HEADER - Static variable in class org.deeplearning4j.streaming.kafka.NDArrayKafkaClient
 
NDArrayConsumer - Class in org.deeplearning4j.streaming.kafka
NDArray consumer for receiving ndarrays off of kafka
NDArrayConsumer() - Constructor for class org.deeplearning4j.streaming.kafka.NDArrayConsumer
 
NDArrayHDF5Reader - Class in org.deeplearning4j.keras
Reads and INDArray from a HDF5 dataset.
NDArrayHDF5Reader() - Constructor for class org.deeplearning4j.keras.NDArrayHDF5Reader
 
NDArrayKafkaClient - Class in org.deeplearning4j.streaming.kafka
Created by agibsonccc on 7/31/16.
NDArrayKafkaClient() - Constructor for class org.deeplearning4j.streaming.kafka.NDArrayKafkaClient
 
NDArrayPublisher - Class in org.deeplearning4j.streaming.kafka
Send an ndarray to a kafka topic
NDArrayPublisher() - Constructor for class org.deeplearning4j.streaming.kafka.NDArrayPublisher
 
NDArrayPublisherTests - Class in org.deeplearning4j.streaming.kafka
Created by agibsonccc on 7/30/16.
NDArrayPublisherTests() - Constructor for class org.deeplearning4j.streaming.kafka.NDArrayPublisherTests
 
NDArrayPubSubRoute - Class in org.deeplearning4j.streaming.kafka
Created by agibsonccc on 7/31/16.
NDArrayPubSubRoute() - Constructor for class org.deeplearning4j.streaming.kafka.NDArrayPubSubRoute
 
NDArrayRecordToNDArray - Class in org.deeplearning4j.streaming.conversion.ndarray
Assumes all records in the given batch are of type @link{NDArrayWritable} It extracts the underlying arrays and returns a concatenated array.
NDArrayRecordToNDArray() - Constructor for class org.deeplearning4j.streaming.conversion.ndarray.NDArrayRecordToNDArray
 
NDArrayType - Enum in org.deeplearning4j.streaming.kafka
Used for headers to distinguish the type of ndarray message being sent.
nearestCluster(Point) - Method in class org.deeplearning4j.clustering.cluster.ClusterSet
 
nearestLabels(LabelledDocument, int) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
This method returns top N labels nearest to specified document
nearestLabels(String, int) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
This method returns top N labels nearest to specified text
nearestLabels(Collection<VocabWord>, int) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
This method returns top N labels nearest to specified set of vocab words
nearestLabels(INDArray, int) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
This method returns top N labels nearest to specified features vector
NearestNeighborsQuery - Class in org.deeplearning4j.ui.nearestneighbors.word2vec
 
NearestNeighborsQuery(String, int) - Constructor for class org.deeplearning4j.ui.nearestneighbors.word2vec.NearestNeighborsQuery
 
NearestNeighborsQuery() - Constructor for class org.deeplearning4j.ui.nearestneighbors.word2vec.NearestNeighborsQuery
 
NearestVertexWalker<V extends SequenceElement> - Class in org.deeplearning4j.models.sequencevectors.graph.walkers.impl
This walker represents connections of a given node + their neighborhoods up to certain depth.
NearestVertexWalker() - Constructor for class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.NearestVertexWalker
 
NearestVertexWalker.Builder<V extends SequenceElement> - Class in org.deeplearning4j.models.sequencevectors.graph.walkers.impl
 
NearestVertexWalker.VertexComparator<V extends SequenceElement,E extends java.lang.Number> - Class in org.deeplearning4j.models.sequencevectors.graph.walkers.impl
 
negative() - Method in class org.deeplearning4j.eval.Evaluation
Total negatives true negatives + false negatives
negative - Variable in class org.deeplearning4j.models.embeddings.inmemory.InMemoryLookupTable.Builder
 
negative(double) - Method in class org.deeplearning4j.models.embeddings.inmemory.InMemoryLookupTable.Builder
 
negative - Variable in class org.deeplearning4j.models.embeddings.inmemory.InMemoryLookupTable
 
negative - Variable in class org.deeplearning4j.models.embeddings.learning.impl.elements.CBOW
 
negative - Variable in class org.deeplearning4j.models.embeddings.learning.impl.elements.SkipGram
 
negative - Variable in class org.deeplearning4j.models.embeddings.learning.impl.sequence.DBOW
 
negative - Variable in class org.deeplearning4j.models.embeddings.learning.impl.sequence.DM
 
negative - Variable in class org.deeplearning4j.models.embeddings.wordvectors.WordVectorsImpl
 
negative(double) - Method in class org.deeplearning4j.models.glove.GloveWeightLookupTable.Builder
Deprecated.
 
negative - Variable in class org.deeplearning4j.models.sequencevectors.SequenceVectors.Builder
 
negative(double) - Method in class org.deeplearning4j.spark.models.embeddings.glove.GloveParam.Builder
 
negative - Variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2Vec.Builder
 
negative(int) - Method in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2Vec.Builder
Specifies negative sampling
negative(double) - Method in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2VecParam.Builder
Deprecated.
 
NEGATIVE - Static variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2VecPerformerVoid
Deprecated.
 
NEGATIVE - Static variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2VecVariables
Deprecated.
 
NegativeDefaultStepFunction - Class in org.deeplearning4j.nn.conf.stepfunctions
Inverse step function
NegativeDefaultStepFunction() - Constructor for class org.deeplearning4j.nn.conf.stepfunctions.NegativeDefaultStepFunction
 
NegativeDefaultStepFunction - Class in org.deeplearning4j.optimize.stepfunctions
Inverse step function
NegativeDefaultStepFunction() - Constructor for class org.deeplearning4j.optimize.stepfunctions.NegativeDefaultStepFunction
 
NegativeGradientStepFunction - Class in org.deeplearning4j.nn.conf.stepfunctions
Subtract the line
NegativeGradientStepFunction() - Constructor for class org.deeplearning4j.nn.conf.stepfunctions.NegativeGradientStepFunction
 
NegativeGradientStepFunction - Class in org.deeplearning4j.optimize.stepfunctions
Subtract the line
NegativeGradientStepFunction() - Constructor for class org.deeplearning4j.optimize.stepfunctions.NegativeGradientStepFunction
 
NegativeHolder - Class in org.deeplearning4j.spark.models.embeddings.word2vec
Simple singleton holder class for w2v negative sampling, to avoid syn1Neg creation for each spark node
negativeSample(double) - Method in class org.deeplearning4j.models.glove.Glove.Builder
Deprecated.
negativeSample(double) - Method in class org.deeplearning4j.models.node2vec.Node2Vec.Builder
Deprecated.
 
negativeSample(double) - Method in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors.Builder
This method defines whether negative sampling should be used or not
negativeSample(double) - Method in class org.deeplearning4j.models.sequencevectors.SequenceVectors.Builder
This method defines negative sampling value for skip-gram algorithm.
negativeSample(double) - Method in class org.deeplearning4j.models.word2vec.Word2Vec.Builder
This method defines whether negative sampling should be used or not
negativeSampling(long) - Method in class org.deeplearning4j.spark.models.sequencevectors.SparkSequenceVectors.Builder
 
negativeSampling(long) - Method in class org.deeplearning4j.spark.models.word2vec.SparkWord2Vec.Builder
 
negLogProbability(INDArray, INDArray, boolean) - Method in class org.deeplearning4j.nn.conf.layers.variational.BernoulliReconstructionDistribution
 
negLogProbability(INDArray, INDArray, boolean) - Method in class org.deeplearning4j.nn.conf.layers.variational.CompositeReconstructionDistribution
 
negLogProbability(INDArray, INDArray, boolean) - Method in class org.deeplearning4j.nn.conf.layers.variational.ExponentialReconstructionDistribution
 
negLogProbability(INDArray, INDArray, boolean) - Method in class org.deeplearning4j.nn.conf.layers.variational.GaussianReconstructionDistribution
 
negLogProbability(INDArray, INDArray, boolean) - Method in class org.deeplearning4j.nn.conf.layers.variational.LossFunctionWrapper
 
negLogProbability(INDArray, INDArray, boolean) - Method in interface org.deeplearning4j.nn.conf.layers.variational.ReconstructionDistribution
Calculate the negative log probability (summed or averaged over each example in the minibatch)
NetBroadcastTuple - Class in org.deeplearning4j.spark.api.worker
A simple class for storing configurations, parameters and updaters in one class (so they can be broadcast together)
NetBroadcastTuple(MultiLayerConfiguration, INDArray, INDArray) - Constructor for class org.deeplearning4j.spark.api.worker.NetBroadcastTuple
 
NetBroadcastTuple(ComputationGraphConfiguration, INDArray, INDArray) - Constructor for class org.deeplearning4j.spark.api.worker.NetBroadcastTuple
 
NetBroadcastTuple(MultiLayerConfiguration, ComputationGraphConfiguration, INDArray, INDArray) - Constructor for class org.deeplearning4j.spark.api.worker.NetBroadcastTuple
 
NetBroadcastTuple(MultiLayerConfiguration, ComputationGraphConfiguration, INDArray, INDArray, AtomicInteger) - Constructor for class org.deeplearning4j.spark.api.worker.NetBroadcastTuple
 
NetworkInformation - Class in org.deeplearning4j.spark.models.sequencevectors.primitives
 
NetworkInformation() - Constructor for class org.deeplearning4j.spark.models.sequencevectors.primitives.NetworkInformation
 
networkInputs - Variable in class org.deeplearning4j.nn.conf.ComputationGraphConfiguration.GraphBuilder
 
networkInputs - Variable in class org.deeplearning4j.nn.conf.ComputationGraphConfiguration
List of inputs to the network, by name
networkInputTypes - Variable in class org.deeplearning4j.nn.conf.ComputationGraphConfiguration.GraphBuilder
 
networkMask - Variable in class org.deeplearning4j.spark.models.sequencevectors.utils.NetworkOrganizer
 
NetworkOrganizer - Class in org.deeplearning4j.spark.models.sequencevectors.utils
Utility class that provides
NetworkOrganizer(Collection<NetworkInformation>) - Constructor for class org.deeplearning4j.spark.models.sequencevectors.utils.NetworkOrganizer
This constructor is NOT implemented yet
NetworkOrganizer(Collection<NetworkInformation>, String) - Constructor for class org.deeplearning4j.spark.models.sequencevectors.utils.NetworkOrganizer
 
NetworkOrganizer.VirtualNode - Class in org.deeplearning4j.spark.models.sequencevectors.utils
 
NetworkOrganizer.VirtualTree - Class in org.deeplearning4j.spark.models.sequencevectors.utils
 
NetworkOrganizerTest - Class in org.deeplearning4j.spark.models.sequencevectors.utils
 
NetworkOrganizerTest() - Constructor for class org.deeplearning4j.spark.models.sequencevectors.utils.NetworkOrganizerTest
 
networkOutputs - Variable in class org.deeplearning4j.nn.conf.ComputationGraphConfiguration.GraphBuilder
 
networkOutputs - Variable in class org.deeplearning4j.nn.conf.ComputationGraphConfiguration
List of network outputs, by name
NeuralNetConfiguration - Class in org.deeplearning4j.nn.conf
A Serializable configuration for neural nets that covers per layer parameters
NeuralNetConfiguration() - Constructor for class org.deeplearning4j.nn.conf.NeuralNetConfiguration
 
NeuralNetConfiguration.Builder - Class in org.deeplearning4j.nn.conf
 
NeuralNetConfiguration.ListBuilder - Class in org.deeplearning4j.nn.conf
Fluent interface for building a list of configurations
NeuralNetConfigurationTest - Class in org.deeplearning4j.nn.conf
Created by agibsonccc on 11/27/14.
NeuralNetConfigurationTest() - Constructor for class org.deeplearning4j.nn.conf.NeuralNetConfigurationTest
 
NeuralNetworkReader - Class in org.deeplearning4j.keras
Reads the neural network model from Keras, specified by the parameters.
NeuralNetworkReader() - Constructor for class org.deeplearning4j.keras.NeuralNetworkReader
 
newEpoch - Variable in class org.deeplearning4j.datasets.iterator.MultipleEpochsIterator
 
newExecutorService() - Static method in class org.deeplearning4j.util.MultiThreadUtils
 
newHashBackedMap() - Static method in class org.deeplearning4j.util.MultiDimensionalMap
Thread safe hash map impl
newInstance(ResourceResolver) - Static method in class com.atilika.kuromoji.dict.CharacterDefinitions
 
newInstance(ResourceResolver) - Static method in class com.atilika.kuromoji.dict.ConnectionCosts
 
newInstance(ResourceResolver) - Static method in class com.atilika.kuromoji.dict.TokenInfoDictionary
 
newInstance(ResourceResolver, CharacterDefinitions, int) - Static method in class com.atilika.kuromoji.dict.UnknownDictionary
 
newInstance(ResourceResolver) - Static method in class com.atilika.kuromoji.trie.DoubleArrayTrie
 
newInstance(Object...) - Method in class org.deeplearning4j.berkeley.Factory.DefaultFactory
 
newInstance(Object...) - Method in interface org.deeplearning4j.berkeley.Factory
 
newIterable(Iterator<T>) - Static method in class org.deeplearning4j.berkeley.Iterators
Wraps an iterator as an iterable
newPair(S, T) - Static method in class org.deeplearning4j.berkeley.Pair
 
newThreadSafeHashBackedMap() - Static method in class org.deeplearning4j.util.MultiDimensionalMap
Thread safe hash map implementation
newThreadSafeTreeBackedMap() - Static method in class org.deeplearning4j.util.MultiDimensionalMap
Thread safe sorted map implementation
newTreeBackedMap() - Static method in class org.deeplearning4j.util.MultiDimensionalMap
Tree map implementation
next() - Method in class org.deeplearning4j.aws.s3.reader.BucketIterator
 
next() - Method in class org.deeplearning4j.berkeley.Iterators.FilteredIterator
 
next() - Method in class org.deeplearning4j.berkeley.Iterators.IteratorIterator
 
next() - Method in class org.deeplearning4j.berkeley.Iterators.Transform
 
next() - Method in class org.deeplearning4j.berkeley.Iterators.TransformingIterator
 
next() - Method in class org.deeplearning4j.berkeley.PriorityQueue
 
next() - Method in interface org.deeplearning4j.berkeley.PriorityQueueInterface
Returns the element in the queue with highest priority, and pops it from the queue.
next(int) - Method in class org.deeplearning4j.datasets.datavec.RecordReaderDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.datavec.RecordReaderDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.datavec.RecordReaderMultiDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.datavec.RecordReaderMultiDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.datavec.SequenceRecordReaderDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.datavec.SequenceRecordReaderDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.fetchers.BaseDataFetcher
 
next() - Method in class org.deeplearning4j.datasets.fetchers.MnistDataFetcher
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.AbstractDataSetIterator
Like the standard next method but allows a customizable number of examples returned
next() - Method in class org.deeplearning4j.datasets.iterator.AbstractDataSetIterator
Returns the next element in the iteration.
next() - Method in class org.deeplearning4j.datasets.iterator.AbstractDataSetIteratorTest
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.AsyncDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.iterator.AsyncDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.AsyncMultiDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.iterator.AsyncMultiDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.iterator.BaseDatasetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.BaseDatasetIterator
 
next() - Method in interface org.deeplearning4j.datasets.iterator.DataSetFetcher
Deprecated.
Returns the next data applyTransformToDestination
next(int) - Method in class org.deeplearning4j.datasets.iterator.ExistingDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.iterator.ExistingDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.impl.CifarDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.iterator.impl.ListDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.impl.ListDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.impl.MultiDataSetIteratorAdapter
 
next() - Method in class org.deeplearning4j.datasets.iterator.impl.MultiDataSetIteratorAdapter
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.impl.SingletonMultiDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.iterator.impl.SingletonMultiDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.iterator.IteratorDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.IteratorDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.iterator.IteratorMultiDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.IteratorMultiDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.MultipleEpochsIterator
Like the standard next method but allows a customizable number of examples returned
next() - Method in class org.deeplearning4j.datasets.iterator.MultipleEpochsIterator
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.ReconstructionDataSetIterator
Like the standard next method but allows a customizable number of examples returned
next() - Method in class org.deeplearning4j.datasets.iterator.ReconstructionDataSetIterator
Returns the next element in the iteration.
next() - Method in class org.deeplearning4j.datasets.iterator.SamplingDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.iterator.SamplingDataSetIterator
 
next() - Method in class org.deeplearning4j.datasets.mnist.MnistDbFile
Move to the next entry.
next() - Method in class org.deeplearning4j.datasets.test.TestDataSetIterator
 
next(int) - Method in class org.deeplearning4j.datasets.test.TestDataSetIterator
 
next() - Method in class org.deeplearning4j.graph.graph.VertexSequence
 
next() - Method in interface org.deeplearning4j.graph.iterator.GraphWalkIterator
Get the next vertex sequence.
next() - Method in class org.deeplearning4j.graph.iterator.RandomWalkIterator
 
next() - Method in class org.deeplearning4j.graph.iterator.WeightedRandomWalkIterator
 
next() - Method in class org.deeplearning4j.iterator.CnnSentenceDataSetIterator
 
next(int) - Method in class org.deeplearning4j.iterator.CnnSentenceDataSetIterator
 
next() - Method in class org.deeplearning4j.keras.HDF5MiniBatchDataSetIterator
 
next(int) - Method in class org.deeplearning4j.keras.HDF5MiniBatchDataSetIterator
 
next() - Method in class org.deeplearning4j.models.embeddings.inmemory.InMemoryLookupTable.WeightIterator
 
next() - Method in class org.deeplearning4j.models.embeddings.loader.WordVectorSerializer.BinaryReader
 
next() - Method in class org.deeplearning4j.models.embeddings.loader.WordVectorSerializer.CSVReader
 
next() - Method in interface org.deeplearning4j.models.embeddings.loader.WordVectorSerializer.Reader
 
next() - Method in interface org.deeplearning4j.models.sequencevectors.graph.walkers.GraphWalker
This method returns next walk sequence from this graph
next() - Method in class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.NearestVertexWalker
 
next() - Method in class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.PopularityWalker
This method returns next walk sequence from this graph
next() - Method in class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.RandomWalker
This method returns next walk sequence from this graph
next() - Method in class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.WeightedWalker
This method returns next walk sequence from this graph
next() - Method in class org.deeplearning4j.models.sequencevectors.transformers.impl.iterables.BasicTransformerIterator
 
next() - Method in class org.deeplearning4j.models.sequencevectors.transformers.impl.iterables.ParallelTransformerIterator
 
next() - Method in class org.deeplearning4j.models.word2vec.iterator.Word2VecDataFetcher
 
next(int) - Method in class org.deeplearning4j.models.word2vec.iterator.Word2VecDataSetIterator
Like the standard next method but allows a customizable number of examples returned
next() - Method in class org.deeplearning4j.models.word2vec.iterator.Word2VecDataSetIterator
Returns the next element in the iteration.
next() - Method in class org.deeplearning4j.parallelism.AsyncIterator
 
next(int) - Method in class org.deeplearning4j.spark.iterator.BaseDataSetIterator
 
next() - Method in class org.deeplearning4j.spark.iterator.PathSparkDataSetIterator
 
next(int) - Method in class org.deeplearning4j.spark.iterator.PathSparkMultiDataSetIterator
 
next() - Method in class org.deeplearning4j.spark.iterator.PathSparkMultiDataSetIterator
 
next() - Method in class org.deeplearning4j.spark.iterator.PortableDataStreamDataSetIterator
 
next(int) - Method in class org.deeplearning4j.spark.iterator.PortableDataStreamMultiDataSetIterator
 
next() - Method in class org.deeplearning4j.spark.iterator.PortableDataStreamMultiDataSetIterator
 
next() - Method in class org.deeplearning4j.text.corpora.treeparser.TreeIterator
Returns the next element in the iteration.
next() - Method in class org.deeplearning4j.text.documentiterator.AsyncLabelAwareIterator
 
next() - Method in class org.deeplearning4j.text.documentiterator.BasicLabelAwareIterator
 
next() - Method in class org.deeplearning4j.text.documentiterator.FileLabelAwareIterator
 
next() - Method in class org.deeplearning4j.text.documentiterator.FilenamesLabelAwareIterator
 
next() - Method in class org.deeplearning4j.text.documentiterator.interoperability.DocumentIteratorConverter
 
next() - Method in class org.deeplearning4j.text.documentiterator.SimpleLabelAwareIterator
 
next() - Method in class org.deeplearning4j.text.sentenceiterator.interoperability.SentenceIteratorConverter
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoDecoder.HwDeviceInfoGroupDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoDecoder.ModelParamNamesDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoDecoder.SwEnvironmentInfoDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.HwDeviceInfoGroupEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.ModelParamNamesEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.StaticInfoEncoder.SwEnvironmentInfoEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataDecoder.ExtraMetaDataBytesDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.StorageMetaDataEncoder.ExtraMetaDataBytesEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.DataSetMetaDataBytesDecoder.MetaDataBytesDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.DataSetMetaDataBytesDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.GcStatsDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.LayerNamesDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.MemoryUseDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.ParamNamesDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerformanceDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder.HistogramsDecoder.HistogramCountsDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder.HistogramsDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateDecoder.PerParameterStatsDecoder.SummaryStatDecoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.DataSetMetaDataBytesEncoder.MetaDataBytesEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.DataSetMetaDataBytesEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.GcStatsEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.LayerNamesEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.MemoryUseEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.ParamNamesEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerformanceEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerParameterStatsEncoder.HistogramsEncoder.HistogramCountsEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerParameterStatsEncoder.HistogramsEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerParameterStatsEncoder
 
next() - Method in class org.deeplearning4j.ui.stats.sbe.UpdateEncoder.PerParameterStatsEncoder.SummaryStatEncoder
 
nextBoolean() - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns the next pseudorandom, uniformly distributed boolean value from the Math.random() sequence.
nextBoolean(Random) - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns the next pseudorandom, uniformly distributed boolean value from the given random sequence.
nextBucket() - Method in class org.deeplearning4j.aws.s3.reader.BaseS3DataSetIterator
 
nextBucket - Variable in class org.deeplearning4j.parallelism.MagicQueue
 
nextDocument() - Method in class org.deeplearning4j.text.documentiterator.AsyncLabelAwareIterator
 
nextDocument() - Method in class org.deeplearning4j.text.documentiterator.AsyncLabelAwareIteratorTest
 
nextDocument() - Method in class org.deeplearning4j.text.documentiterator.BasicLabelAwareIterator
This method returns next LabelledDocument
nextDocument() - Method in interface org.deeplearning4j.text.documentiterator.DocumentIterator
Get the next document
nextDocument() - Method in class org.deeplearning4j.text.documentiterator.FileDocumentIterator
 
nextDocument() - Method in class org.deeplearning4j.text.documentiterator.FileLabelAwareIterator
 
nextDocument() - Method in class org.deeplearning4j.text.documentiterator.FilenamesLabelAwareIterator
 
nextDocument() - Method in class org.deeplearning4j.text.documentiterator.interoperability.DocumentIteratorConverter
 
nextDocument() - Method in interface org.deeplearning4j.text.documentiterator.LabelAwareIterator
 
nextDocument() - Method in class org.deeplearning4j.text.documentiterator.SimpleLabelAwareIterator
This method returns next LabelledDocument from underlying iterator
nextDocument() - Method in class org.deeplearning4j.text.sentenceiterator.interoperability.SentenceIteratorConverter
 
nextDouble() - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns the next pseudorandom, uniformly distributed float value between 0.0 and 1.0 from the Math.random() sequence.
nextDouble(Random) - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns the next pseudorandom, uniformly distributed float value between 0.0 and 1.0 from the given Random sequence.
nextElement - Variable in class org.deeplearning4j.parallelism.AsyncIterator
 
nextFloat() - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns the next pseudorandom, uniformly distributed float value between 0.0 and 1.0 from the Math.random() sequence.
nextFloat(Random) - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns the next pseudorandom, uniformly distributed float value between 0.0 and 1.0 from the given Random sequence.
nextImage() - Method in class org.deeplearning4j.datasets.mnist.MnistImageFile
Move the cursor to the next image.
nextInt() - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns the next pseudorandom, uniformly distributed int value from the Math.random() sequence.
nextInt(Random) - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns the next pseudorandom, uniformly distributed int value from the given random sequence.
nextInt(int) - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns a pseudorandom, uniformly distributed int value between 0 (inclusive) and the specified value (exclusive), from the Math.random() sequence.
nextInt(Random, int) - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns a pseudorandom, uniformly distributed int value between 0 (inclusive) and the specified value (exclusive), from the given Random sequence.
nextLabel() - Method in class org.deeplearning4j.text.documentiterator.LabelsSource
Returns next label.
nextLabel() - Method in interface org.deeplearning4j.text.labels.LabelsProvider
 
nextList(ObjectListing) - Method in class org.deeplearning4j.aws.s3.reader.S3Downloader
Iterator style one list at a time
nextList(List<Iterator<T>>) - Static method in class org.deeplearning4j.berkeley.Iterators
 
nextLong() - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns the next pseudorandom, uniformly distributed long value from the Math.random() sequence.
nextLong(Random) - Static method in class org.deeplearning4j.models.embeddings.learning.impl.elements.RandomUtils
Returns the next pseudorandom, uniformly distributed long value from the given Random sequence.
nextObject() - Method in class org.deeplearning4j.aws.s3.reader.BaseS3DataSetIterator
 
nextObject() - Method in class org.deeplearning4j.models.glove.count.ASCIICoOccurrenceReader
Returns next CoOccurrenceWeight object PLEASE NOTE: This method can return null value.
nextObject() - Method in class org.deeplearning4j.models.glove.count.BinaryCoOccurrenceReader
 
nextObject() - Method in interface org.deeplearning4j.models.glove.count.CoOccurenceReader
 
nextPowOf2(long) - Static method in class org.deeplearning4j.util.MathUtils
See: http://stackoverflow.com/questions/466204/rounding-off-to-nearest-power-of-2
nextRandom - Variable in class org.deeplearning4j.spark.models.sequencevectors.learning.elements.BaseSparkLearningAlgorithm
 
nextSentence() - Method in interface org.deeplearning4j.iterator.LabeledSentenceProvider
 
nextSentence() - Method in class org.deeplearning4j.iterator.provider.CollectionLabeledSentenceProvider
 
nextSentence() - Method in class org.deeplearning4j.iterator.provider.FileLabeledSentenceProvider
 
nextSentence() - Method in class org.deeplearning4j.iterator.provider.LabelAwareConverter
 
nextSentence() - Method in class org.deeplearning4j.models.sequencevectors.SequenceVectors.AsyncSequencer
 
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.AggregatingSentenceIterator
 
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.BasicLineIterator
 
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.BasicResultSetIterator
 
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.CollectionSentenceIterator
 
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.FileSentenceIterator
 
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.labelaware.LabelAwareListSentenceIterator
Gets the next sentence or null if there's nothing left (Do yourself a favor and check hasNext() )
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.LineSentenceIterator
 
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.MutipleEpochsSentenceIterator
 
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.PrefetchingSentenceIterator
Deprecated.
 
nextSentence() - Method in interface org.deeplearning4j.text.sentenceiterator.SentenceIterator
Gets the next sentence or null if there's nothing left (Do yourself a favor and check hasNext() )
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.StreamLineIterator
 
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.SynchronizedSentenceIterator
 
nextSentence() - Method in class org.deeplearning4j.text.sentenceiterator.UimaSentenceIterator
 
nextSequence() - Method in interface org.deeplearning4j.models.sequencevectors.interfaces.SequenceIterator
 
nextSequence() - Method in class org.deeplearning4j.models.sequencevectors.iterators.AbstractSequenceIterator
Returns next sequence out of iterator
nextSequence() - Method in class org.deeplearning4j.models.sequencevectors.iterators.FilteredSequenceIterator
Returns filtered sequence, that contains sequence elements from vocabulary only.
nextSequence() - Method in class org.deeplearning4j.models.sequencevectors.iterators.SynchronizedSequenceIterator
Returns next sequence from data source
nextToken() - Method in class org.deeplearning4j.text.tokenization.tokenizer.DefaultStreamTokenizer
This method returns next token from prebuffered list of tokens or underlying InputStream
nextToken() - Method in class org.deeplearning4j.text.tokenization.tokenizer.DefaultTokenizer
 
nextToken() - Method in class org.deeplearning4j.text.tokenization.tokenizer.JapaneseTokenizer
 
nextToken() - Method in class org.deeplearning4j.text.tokenization.tokenizer.KoreanTokenizer
 
nextToken() - Method in class org.deeplearning4j.text.tokenization.tokenizer.NGramTokenizer
 
nextToken() - Method in class org.deeplearning4j.text.tokenization.tokenizer.PosUimaTokenizer
 
nextToken() - Method in interface org.deeplearning4j.text.tokenization.tokenizer.Tokenizer
The next token (word usually) in the string
nextToken() - Method in class org.deeplearning4j.text.tokenization.tokenizer.UimaTokenizer
 
nextWord - Variable in class org.deeplearning4j.models.embeddings.loader.WordVectorSerializer.BinaryReader
 
nGrams - Variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2Vec.Builder
 
NGramTokenizer - Class in org.deeplearning4j.text.tokenization.tokenizer
 
NGramTokenizer(Tokenizer, Integer, Integer) - Constructor for class org.deeplearning4j.text.tokenization.tokenizer.NGramTokenizer
 
NGramTokenizerFactory - Class in org.deeplearning4j.text.tokenization.tokenizerfactory
 
NGramTokenizerFactory(TokenizerFactory, Integer, Integer) - Constructor for class org.deeplearning4j.text.tokenization.tokenizerfactory.NGramTokenizerFactory
 
NGramTokenizerTest - Class in org.deeplearning4j.text.tokenization.tokenizer
 
NGramTokenizerTest() - Constructor for class org.deeplearning4j.text.tokenization.tokenizer.NGramTokenizerTest
 
nIn(int) - Method in class org.deeplearning4j.nn.conf.layers.ConvolutionLayer.Builder
 
nIn - Variable in class org.deeplearning4j.nn.conf.layers.FeedForwardLayer.Builder
 
nIn(int) - Method in class org.deeplearning4j.nn.conf.layers.FeedForwardLayer.Builder
 
nIn - Variable in class org.deeplearning4j.nn.conf.layers.FeedForwardLayer
 
nIn(int) - Method in class org.deeplearning4j.nn.conf.layers.LossLayer.Builder
 
nIn - Variable in class org.deeplearning4j.nn.updater.TestUpdaters
 
nIn - Variable in class org.deeplearning4j.spark.BaseSparkTest
 
nInsPerLayer - Variable in class org.deeplearning4j.nn.conf.layers.setup.ConvolutionLayerSetup
Deprecated.
 
nn(INDArray) - Method in class org.deeplearning4j.clustering.kdtree.KDTree
Query for nearest neighbor.
NO_TRUNCATED_BPTT - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasInput
 
Node() - Constructor for class com.atilika.kuromoji.trie.Trie.Node
Constructor
Node(char) - Constructor for class com.atilika.kuromoji.trie.Trie.Node
Constructor
Node(int, double) - Constructor for class org.deeplearning4j.clustering.vptree.VPTree.Node
 
Node2Vec<V extends SequenceElement,E extends java.lang.Number> - Class in org.deeplearning4j.models.node2vec
Deprecated.
Node2Vec() - Constructor for class org.deeplearning4j.models.node2vec.Node2Vec
Deprecated.
 
Node2Vec.Builder<V extends SequenceElement,E extends java.lang.Number> - Class in org.deeplearning4j.models.node2vec
Deprecated.
 
NODE_RATIO - Static variable in class org.deeplearning4j.clustering.sptree.SpTree
 
NodeReport - Class in org.deeplearning4j.ui.flow.beans
Unified node state report: weights/gradients as distribution
NodeReport() - Constructor for class org.deeplearning4j.ui.flow.beans.NodeReport
 
nodes - Variable in class org.deeplearning4j.spark.models.sequencevectors.utils.NetworkOrganizer.VirtualNode
 
nodes - Variable in class org.deeplearning4j.spark.models.sequencevectors.utils.NetworkOrganizer.VirtualTree
 
NodeTest - Class in com.atilika.kuromoji.trie
 
NodeTest() - Constructor for class com.atilika.kuromoji.trie.NodeTest
 
NoEdgeHandling - Enum in org.deeplearning4j.graph.api
When walking a graph, how should we handle disconnected nodes? i.e., those without any outgoing (directed) or undirected edges
NoEdgeHandling - Enum in org.deeplearning4j.models.sequencevectors.graph.enums
This enum describes different behaviors for cases when GraphWalker don't have next hop within current walk.
noEdgeHandling - Variable in class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.RandomWalker.Builder
 
noEdgeHandling - Variable in class org.deeplearning4j.models.sequencevectors.graph.walkers.impl.RandomWalker
 
NoEdgesException - Exception in org.deeplearning4j.graph.exception
Unchecked exception, thrown to signify that an operation (usually on a vertex) cannot be completed because there are no edges for that vertex.
NoEdgesException() - Constructor for exception org.deeplearning4j.graph.exception.NoEdgesException
 
NoEdgesException(String) - Constructor for exception org.deeplearning4j.graph.exception.NoEdgesException
 
NoEdgesException(String, Exception) - Constructor for exception org.deeplearning4j.graph.exception.NoEdgesException
 
NoEdgesException - Exception in org.deeplearning4j.models.sequencevectors.graph.exception
Unchecked exception, thrown to signify that an operation (usually on a vertex) cannot be completed because there are no edges for that vertex.
NoEdgesException() - Constructor for exception org.deeplearning4j.models.sequencevectors.graph.exception.NoEdgesException
 
NoEdgesException(String) - Constructor for exception org.deeplearning4j.models.sequencevectors.graph.exception.NoEdgesException
 
NoEdgesException(String, Exception) - Constructor for exception org.deeplearning4j.models.sequencevectors.graph.exception.NoEdgesException
 
noNaNDivide(double, double) - Static method in class org.deeplearning4j.berkeley.SloppyMath
 
none() - Static method in class org.deeplearning4j.models.word2vec.VocabWord
 
NONE - Static variable in class org.deeplearning4j.util.StringGrid
 
Norm2Termination - Class in org.deeplearning4j.optimize.terminations
Terminate if the norm2 of the gradient is < a certain tolerance
Norm2Termination(double) - Constructor for class org.deeplearning4j.optimize.terminations.Norm2Termination
 
NormalDistribution - Class in org.deeplearning4j.nn.conf.distribution
A normal distribution.
NormalDistribution(double, double) - Constructor for class org.deeplearning4j.nn.conf.distribution.NormalDistribution
Create a normal distribution with the given mean and std
normalize() - Method in class org.deeplearning4j.berkeley.Counter
Destructively normalize this Counter in place.
normalize() - Method in class org.deeplearning4j.berkeley.CounterMap
 
normalize(boolean) - Method in class org.deeplearning4j.plot.BarnesHutTsne.Builder
 
normalize - Variable in class org.deeplearning4j.plot.BarnesHutTsne
 
normalize - Variable in class org.deeplearning4j.plot.Tsne.Builder
 
normalize(boolean) - Method in class org.deeplearning4j.plot.Tsne.Builder
 
normalize - Variable in class org.deeplearning4j.plot.Tsne
 
normalize(double, double, double) - Static method in class org.deeplearning4j.util.MathUtils
Normalize a value (val - min) / (max - min)
normalize(double[], double) - Static method in class org.deeplearning4j.util.MathUtils
Normalizes the doubles in the array using the given value.
normalized - Variable in class org.deeplearning4j.models.embeddings.reader.impl.BasicModelUtils
 
normalizedLabels - Variable in class org.deeplearning4j.models.paragraphvectors.ParagraphVectors
 
NORMALIZER_BIN - Static variable in class org.deeplearning4j.util.ModelSerializer
 
normalizeToOne(double[]) - Static method in class org.deeplearning4j.util.MathUtils
 
normalizeWithDiscount(double) - Method in class org.deeplearning4j.berkeley.CounterMap
 
notify(StatsStorageEvent) - Method in interface org.deeplearning4j.api.storage.StatsStorageListener
Notify will be called whenever an event (new information posted, etc) occurs.
notify(StatsStorageEvent) - Method in class org.deeplearning4j.ui.storage.impl.QueuePairStatsStorageListener
 
notify(StatsStorageEvent) - Method in class org.deeplearning4j.ui.storage.impl.QueueStatsStorageListener
 
notifyListeners(List<StatsStorageEvent>) - Method in class org.deeplearning4j.ui.storage.BaseCollectionStatsStorage
 
notifyListeners(List<StatsStorageEvent>) - Method in class org.deeplearning4j.ui.storage.sqlite.J7FileStatsStorage
 
nOut(int) - Method in class org.deeplearning4j.nn.conf.layers.ConvolutionLayer.Builder
 
nOut - Variable in class org.deeplearning4j.nn.conf.layers.FeedForwardLayer.Builder
 
nOut(int) - Method in class org.deeplearning4j.nn.conf.layers.FeedForwardLayer.Builder
 
nOut - Variable in class org.deeplearning4j.nn.conf.layers.FeedForwardLayer
 
nOut(int) - Method in class org.deeplearning4j.nn.conf.layers.LossLayer.Builder
 
nOut(int) - Method in class org.deeplearning4j.nn.conf.layers.variational.VariationalAutoencoder.Builder
Set the size of the VAE state Z.
nOut - Variable in class org.deeplearning4j.nn.updater.TestUpdaters
 
nOut - Variable in class org.deeplearning4j.spark.BaseSparkTest
 
nOutReplace(int, int, WeightInit) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.Builder
Modify the architecture of a layer by changing nOut Note this will also affect the layer that follows the layer specified, unless it is the output layer
nOutReplace(int, int, Distribution) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.Builder
Modify the architecture of a layer by changing nOut Note this will also affect the layer that follows the layer specified, unless it is the output layer
nOutReplace(int, int, WeightInit, WeightInit) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.Builder
Modify the architecture of a layer by changing nOut Note this will also affect the layer that follows the layer specified, unless it is the output layer Can specify different weight init schemes for the specified layer and the layer that follows it.
nOutReplace(int, int, Distribution, Distribution) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.Builder
Modify the architecture of a layer by changing nOut Note this will also affect the layer that follows the layer specified, unless it is the output layer Can specify different weight init schemes for the specified layer and the layer that follows it.
nOutReplace(int, int, WeightInit, Distribution) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.Builder
Modify the architecture of a layer by changing nOut Note this will also affect the layer that follows the layer specified, unless it is the output layer Can specify different weight init schemes for the specified layer and the layer that follows it.
nOutReplace(int, int, Distribution, WeightInit) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.Builder
Modify the architecture of a layer by changing nOut Note this will also affect the layer that follows the layer specified, unless it is the output layer Can specify different weight init schemes for the specified layer and the layer that follows it.
nOutReplace(String, int, WeightInit) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.GraphBuilder
Modify the architecture of a vertex layer by changing nOut Note this will also affect the vertex layer that follows the layer specified, unless it is the output layer Currently does not support modifying nOut of layers that feed into non-layer vertices like merge, subset etc To modify nOut for such vertices use remove vertex, followed by add vertex Can specify different weight init schemes for the specified layer and the layer that follows it.
nOutReplace(String, int, Distribution) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.GraphBuilder
Modify the architecture of a vertex layer by changing nOut Note this will also affect the vertex layer that follows the layer specified, unless it is the output layer Currently does not support modifying nOut of layers that feed into non-layer vertices like merge, subset etc To modify nOut for such vertices use remove vertex, followed by add vertex Can specify different weight init schemes for the specified layer and the layer that follows it.
nOutReplace(String, int, Distribution, Distribution) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.GraphBuilder
Modified nOut of specified layer.
nOutReplace(String, int, WeightInit, Distribution) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.GraphBuilder
 
nOutReplace(String, int, Distribution, WeightInit) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.GraphBuilder
 
nOutReplace(String, int, WeightInit, WeightInit) - Method in class org.deeplearning4j.nn.transferlearning.TransferLearning.GraphBuilder
 
nOutsPerLayer - Variable in class org.deeplearning4j.nn.conf.layers.setup.ConvolutionLayerSetup
Deprecated.
 
nRows - Variable in class org.deeplearning4j.spark.BaseSparkTest
 
nthIndex(String, char, int) - Static method in class org.deeplearning4j.berkeley.StringUtils
Returns the index of the nth occurrence of ch in s, or -1 if there are less than n occurrences of ch.
NTP_SOURCE_SERVER_PROPERTY - Static variable in class org.deeplearning4j.spark.time.NTPTimeSource
 
NTP_SOURCE_UPDATE_FREQUENCY_MS_PROPERTY - Static variable in class org.deeplearning4j.spark.time.NTPTimeSource
 
NTPTimeSource - Class in org.deeplearning4j.spark.time
A TimeSource that utilize Network Time Protocol to determine the system clock offset
Instances should be obtained via NTPTimeSource.getInstance() or TimeSourceProvider; one instance may be used per machine
Specifically, the implementation uses Apache Commons Net (already a dependency in Spark) to query a NTP server.
NUM_EXAMPLES - Static variable in class org.deeplearning4j.datasets.fetchers.IrisDataFetcher
 
NUM_EXAMPLES - Static variable in class org.deeplearning4j.datasets.fetchers.MnistDataFetcher
 
NUM_EXAMPLES_TEST - Static variable in class org.deeplearning4j.datasets.fetchers.MnistDataFetcher
 
NUM_TRAINABLE_PARAMS - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasBatchNormalization
 
NUM_TRAINABLE_PARAMS - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasConvolution
 
NUM_TRAINABLE_PARAMS - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasDense
 
NUM_TRAINABLE_PARAMS - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasEmbedding
 
NUM_TRAINABLE_PARAMS - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasLstm
 
NUM_WEIGHTS_IN_KERAS_LSTM - Static variable in class org.deeplearning4j.nn.modelimport.keras.layers.KerasLstm
 
NUM_WORDS - Static variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2VecPerformerVoid
Deprecated.
 
NUM_WORDS - Static variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2VecVariables
Deprecated.
 
numberOfBuckets - Variable in class org.deeplearning4j.parallelism.MagicQueue
 
numChannels(int[]) - Static method in class org.deeplearning4j.util.ConvolutionUtils
Returns the number of feature maps for a given shape (must be at least 3 dimensions
numColumns() - Method in class org.deeplearning4j.eval.RegressionEvaluation
 
numDimension(int) - Method in class org.deeplearning4j.plot.BarnesHutTsne.Builder
 
numDocuments() - Method in interface org.deeplearning4j.text.invertedindex.InvertedIndex
Returns the number of documents
numEpochs - Variable in class org.deeplearning4j.datasets.iterator.MultipleEpochsIterator
 
numEpochs - Variable in class org.deeplearning4j.models.embeddings.wordvectors.WordVectorsImpl
 
numEpochs - Variable in class org.deeplearning4j.models.sequencevectors.SequenceVectors.Builder
 
numEpochs - Variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2Vec.Builder
 
numExamples() - Method in class org.deeplearning4j.datasets.datavec.RecordReaderDataSetIterator
 
numExamples() - Method in class org.deeplearning4j.datasets.datavec.SequenceRecordReaderDataSetIterator
 
numExamples() - Method in class org.deeplearning4j.datasets.iterator.AbstractDataSetIterator
Total number of examples in the dataset
numExamples() - Method in class org.deeplearning4j.datasets.iterator.AsyncDataSetIterator
 
numExamples - Variable in class org.deeplearning4j.datasets.iterator.BaseDatasetIterator
 
numExamples() - Method in class org.deeplearning4j.datasets.iterator.BaseDatasetIterator
 
numExamples() - Method in class org.deeplearning4j.datasets.iterator.ExistingDataSetIterator
 
numExamples - Variable in class org.deeplearning4j.datasets.iterator.impl.CifarDataSetIterator
 
numExamples() - Method in class org.deeplearning4j.datasets.iterator.impl.ListDataSetIterator
 
numExamples() - Method in class org.deeplearning4j.datasets.iterator.IteratorDataSetIterator
 
numExamples() - Method in class org.deeplearning4j.datasets.iterator.MultipleEpochsIterator
Total number of examples in the dataset
numExamples() - Method in class org.deeplearning4j.datasets.iterator.ReconstructionDataSetIterator
Total number of examples in the dataset
numExamples() - Method in class org.deeplearning4j.datasets.iterator.SamplingDataSetIterator
 
numExamples() - Method in class org.deeplearning4j.datasets.test.TestDataSetIterator
 
numExamples() - Method in class org.deeplearning4j.iterator.CnnSentenceDataSetIterator
 
numExamples() - Method in class org.deeplearning4j.keras.HDF5MiniBatchDataSetIterator
 
numExamples() - Method in class org.deeplearning4j.models.word2vec.iterator.Word2VecDataSetIterator
 
numExamples() - Method in class org.deeplearning4j.spark.iterator.BaseDataSetIterator
 
numExecutors() - Method in class org.deeplearning4j.spark.BaseSparkTest
 
numFeatureMap(NeuralNetConfiguration) - Static method in class org.deeplearning4j.util.ConvolutionUtils
 
numHistogramBins(StatsType) - Method in interface org.deeplearning4j.ui.stats.api.StatsUpdateConfiguration
Get the number of histogram bins to use for the given type (for use with StatsUpdateConfiguration.collectHistograms(StatsType)
numHistogramBins(int) - Method in class org.deeplearning4j.ui.stats.impl.DefaultStatsUpdateConfiguration.Builder
 
numHistogramBins(StatsType) - Method in class org.deeplearning4j.ui.stats.impl.DefaultStatsUpdateConfiguration
 
numInGroup() - Method in class org.deeplearning4j.ui.stats.sbe.GroupSizeEncodingDecoder
 
numInGroup(int) - Method in class org.deeplearning4j.ui.stats.sbe.GroupSizeEncodingEncoder
 
numInGroupMaxValue() - Static method in class org.deeplearning4j.ui.stats.sbe.GroupSizeEncodingDecoder
 
numInGroupMaxValue() - Static method in class org.deeplearning4j.ui.stats.sbe.GroupSizeEncodingEncoder
 
numInGroupMinValue() - Static method in class org.deeplearning4j.ui.stats.sbe.GroupSizeEncodingDecoder
 
numInGroupMinValue() - Static method in class org.deeplearning4j.ui.stats.sbe.GroupSizeEncodingEncoder
 
numInGroupNullValue() - Static method in class org.deeplearning4j.ui.stats.sbe.GroupSizeEncodingDecoder
 
numInGroupNullValue() - Static method in class org.deeplearning4j.ui.stats.sbe.GroupSizeEncodingEncoder
 
numIterations - Variable in class org.deeplearning4j.models.embeddings.wordvectors.WordVectorsImpl
 
numIterations - Variable in class org.deeplearning4j.nn.conf.NeuralNetConfiguration.Builder
 
numIterations - Variable in class org.deeplearning4j.nn.conf.NeuralNetConfiguration
 
numIterations - Variable in class org.deeplearning4j.nn.transferlearning.FineTuneConfiguration
 
numIterations - Variable in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2Vec.Builder
 
numLabelClasses() - Method in interface org.deeplearning4j.iterator.LabeledSentenceProvider
Equivalent to allLabels().size()
numLabelClasses() - Method in class org.deeplearning4j.iterator.provider.CollectionLabeledSentenceProvider
 
numLabelClasses() - Method in class org.deeplearning4j.iterator.provider.FileLabeledSentenceProvider
 
numLabelClasses() - Method in class org.deeplearning4j.iterator.provider.LabelAwareConverter
 
numLabels() - Method in class org.deeplearning4j.eval.EvaluationBinary
Returns the number of labels - (i.e., size of the prediction/labels arrays) - if known.
numLabels() - Method in class org.deeplearning4j.eval.ROCBinary
Returns the number of labels - (i.e., size of the prediction/labels arrays) - if known.
numLabels() - Method in interface org.deeplearning4j.nn.api.Classifier
Returns the number of possible labels
numLabels() - Method in class org.deeplearning4j.nn.layers.BaseOutputLayer
Returns the number of possible labels
numLabels() - Method in class org.deeplearning4j.nn.layers.LossLayer
Returns the number of possible labels
numLabels() - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
Returns the number of possible labels
numLayers - Variable in class org.deeplearning4j.nn.conf.layers.setup.ConvolutionLayerSetup
Deprecated.
 
numOutcomes - Variable in class org.deeplearning4j.datasets.fetchers.BaseDataFetcher
 
numParams() - Method in interface org.deeplearning4j.nn.api.Model
the number of parameters for the model
numParams(boolean) - Method in interface org.deeplearning4j.nn.api.Model
the number of parameters for the model
numParams(NeuralNetConfiguration) - Method in interface org.deeplearning4j.nn.api.ParamInitializer
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.ComputationGraphConfigurationTest.StaticInnerGraphVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.ElementWiseVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.GraphVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.L2NormalizeVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.L2Vertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.LayerVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.MergeVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.PreprocessorVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.rnn.DuplicateToTimeSeriesVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.rnn.LastTimeStepVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.ScaleVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.StackVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.SubsetVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.graph.UnstackVertex
 
numParams(boolean) - Method in class org.deeplearning4j.nn.conf.misc.TestGraphVertex
 
numParams() - Method in class org.deeplearning4j.nn.graph.ComputationGraph
 
numParams(boolean) - Method in class org.deeplearning4j.nn.graph.ComputationGraph
 
numParams() - Method in class org.deeplearning4j.nn.layers.BaseLayer
The number of parameters for the model
numParams(boolean) - Method in class org.deeplearning4j.nn.layers.BaseLayer
 
numParams(boolean) - Method in class org.deeplearning4j.nn.layers.BasePretrainNetwork
 
numParams() - Method in class org.deeplearning4j.nn.layers.BasePretrainNetwork
The number of parameters for the model, for backprop (i.e., excluding visible bias)
numParams() - Method in class org.deeplearning4j.nn.layers.convolution.subsampling.SubsamplingLayer
 
numParams() - Method in class org.deeplearning4j.nn.layers.FrozenLayer
 
numParams(boolean) - Method in class org.deeplearning4j.nn.layers.FrozenLayer
 
numParams() - Method in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
 
numParams(boolean) - Method in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
 
numParams() - 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 and output layer
numParams(boolean) - Method in class org.deeplearning4j.nn.multilayer.MultiLayerNetwork
 
numParams(NeuralNetConfiguration) - Method in class org.deeplearning4j.nn.params.BatchNormalizationParamInitializer
 
numParams(NeuralNetConfiguration) - Method in class org.deeplearning4j.nn.params.CenterLossParamInitializer
 
numParams(NeuralNetConfiguration) - Method in class org.deeplearning4j.nn.params.ConvolutionParamInitializer
 
numParams(NeuralNetConfiguration) - Method in class org.deeplearning4j.nn.params.DefaultParamInitializer
 
numParams(NeuralNetConfiguration) - Method in class org.deeplearning4j.nn.params.EmptyParamInitializer
 
numParams(NeuralNetConfiguration) - Method in class org.deeplearning4j.nn.params.GravesBidirectionalLSTMParamInitializer
 
numParams(NeuralNetConfiguration) - Method in class org.deeplearning4j.nn.params.GravesLSTMParamInitializer
 
numParams(NeuralNetConfiguration) - Method in class org.deeplearning4j.nn.params.PretrainParamInitializer
 
numParams(NeuralNetConfiguration) - Method in class org.deeplearning4j.nn.params.VariationalAutoencoderParamInitializer
 
numParams() - Method in class org.deeplearning4j.plot.BarnesHutTsne
 
numParams(boolean) - Method in class org.deeplearning4j.plot.BarnesHutTsne
 
numPartitions() - Method in class org.deeplearning4j.spark.data.shuffle.IntPartitioner
 
numPartitions() - Method in class org.deeplearning4j.spark.impl.common.repartition.BalancedPartitioner
 
numPossibleLabels - Variable in class org.deeplearning4j.datasets.datavec.RecordReaderDataSetIterator
 
numRowCounter - Variable in class org.deeplearning4j.eval.Evaluation
 
numSamples(int) - Method in class org.deeplearning4j.nn.conf.layers.variational.VariationalAutoencoder.Builder
Set the number of samples per data point (from VAE state Z) used when doing pretraining.
numSamples - Variable in class org.deeplearning4j.nn.layers.variational.VariationalAutoencoder
 
numVertices() - Method in interface org.deeplearning4j.graph.api.IGraph
Number of vertices in the graph
numVertices() - Method in class org.deeplearning4j.graph.graph.Graph
 
numVertices() - Method in class org.deeplearning4j.graph.models.embeddings.GraphVectorsImpl
 
numVertices() - Method in interface org.deeplearning4j.graph.models.GraphVectors
 
numVertices() - Method in class org.deeplearning4j.models.sequencevectors.graph.primitives.Graph
 
numVertices() - Method in interface org.deeplearning4j.models.sequencevectors.graph.primitives.IGraph
Number of vertices in the graph
numWords - Variable in class org.deeplearning4j.models.embeddings.loader.WordVectorSerializer.BinaryReader
 
numWords() - Method in class org.deeplearning4j.models.word2vec.wordstore.inmemory.AbstractCache
Returns number of elements in this vocabulary
numWords() - Method in class org.deeplearning4j.models.word2vec.wordstore.inmemory.InMemoryLookupCache
Deprecated.
Returns the number of words in the cache
numWords() - Method in interface org.deeplearning4j.models.word2vec.wordstore.VocabCache
Returns the number of words in the cache
numWords() - Method in class org.deeplearning4j.models.word2vec.wordstore.VocabularyHolder
 
numWords(int) - Method in class org.deeplearning4j.spark.models.embeddings.word2vec.Word2VecParam.Builder
Deprecated.
 
numWordsEncountered() - Method in class org.deeplearning4j.bagofwords.vectorizer.BaseTextVectorizer
Returns the number of words encountered so far
numWordsEncountered() - Method in interface org.deeplearning4j.bagofwords.vectorizer.TextVectorizer
Returns the number of words encountered so far
nVertices - Variable in class org.deeplearning4j.graph.models.embeddings.InMemoryGraphLookupTable
 
A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
Skip navigation links