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

A

AbstractConsoleResource - Class in com.cloudera.oryx.app.serving
Superclass of web resources that contain a small console for a Serving Layer application.
AbstractConsoleResource() - Constructor for class com.cloudera.oryx.app.serving.AbstractConsoleResource
 
AbstractOryxResource - Class in com.cloudera.oryx.app.serving
Superclass of all Serving Layer application endpoints.
AbstractOryxResource() - Constructor for class com.cloudera.oryx.app.serving.AbstractOryxResource
 
AbstractRescorerProvider - Class in com.cloudera.oryx.app.als
Abstract implementation of RescorerProvider which implements all methods to return null.
AbstractRescorerProvider() - Constructor for class com.cloudera.oryx.app.als.AbstractRescorerProvider
 
AbstractServingModelManager<U> - Class in com.cloudera.oryx.api.serving
Convenience implementation of ServingModelManager that provides several default implementations.
AbstractServingModelManager(Config) - Constructor for class com.cloudera.oryx.api.serving.AbstractServingModelManager
 
AbstractSparkLayer<K,M> - Class in com.cloudera.oryx.lambda
Encapsulates commonality between Spark-based layer processes, BatchLayer and SpeedLayer
AbstractSparkLayer(Config) - Constructor for class com.cloudera.oryx.lambda.AbstractSparkLayer
 
AbstractSpeedModelManager<K,M,U> - Class in com.cloudera.oryx.api.speed
Convenience implementation of SpeedModelManager that provides default implementations.
AbstractSpeedModelManager() - Constructor for class com.cloudera.oryx.api.speed.AbstractSpeedModelManager
 
Add - Class in com.cloudera.oryx.app.serving.clustering
Responds to POST request to /add.
Add() - Constructor for class com.cloudera.oryx.app.serving.clustering.Add
 
Add - Class in com.cloudera.oryx.example.serving
Responds to a POST request to /add/[line].
Add() - Constructor for class com.cloudera.oryx.example.serving.Add
 
add(String) - Method in class com.cloudera.oryx.example.serving.Add
 
addAllIDsTo(Collection<String>) - Method in interface com.cloudera.oryx.app.als.FeatureVectors
Adds all IDs that are mapped to a feature vector to a given collection
addAllIDsTo(Collection<String>) - Method in class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
addAllIDsTo(Collection<String>) - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
addAllRecentTo(Collection<String>) - Method in interface com.cloudera.oryx.app.als.FeatureVectors
Add all recently set IDs to the given collection
addAllRecentTo(Collection<String>) - Method in class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
addAllRecentTo(Collection<String>) - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
addCloseable(Closeable) - Method in class com.cloudera.oryx.common.lang.OryxShutdownHook
 
addExtension(PMML, String, Object) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
addExtensionContent(PMML, String, Collection<?>) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
AllItemIDs - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /item/allIDs.
AllItemIDs() - Constructor for class com.cloudera.oryx.app.serving.als.AllItemIDs
 
AllUserIDs - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /user/allIDs.
AllUserIDs() - Constructor for class com.cloudera.oryx.app.serving.als.AllUserIDs
 
ALSServingModel - Class in com.cloudera.oryx.app.serving.als.model
Contains all data structures needed to serve real-time requests for an ALS-based recommender.
ALSServingModelManager - Class in com.cloudera.oryx.app.serving.als.model
A ServingModelManager that manages and provides access to an ALSServingModel for the ALS Serving Layer application.
ALSServingModelManager(Config) - Constructor for class com.cloudera.oryx.app.serving.als.model.ALSServingModelManager
 
ALSSpeedModel - Class in com.cloudera.oryx.app.speed.als
Contains all data structures needed to create near-real-time updates for an ALS-based recommender.
ALSSpeedModelManager - Class in com.cloudera.oryx.app.speed.als
Implementation of SpeedModelManager that maintains and updates an ALS model in memory.
ALSSpeedModelManager(Config) - Constructor for class com.cloudera.oryx.app.speed.als.ALSSpeedModelManager
 
ALSUpdate - Class in com.cloudera.oryx.app.batch.mllib.als
A specialization of MLUpdate that creates a matrix factorization model of its input, using the Alternating Least Squares algorithm.
ALSUpdate(Config) - Constructor for class com.cloudera.oryx.app.batch.mllib.als.ALSUpdate
 
ALSUtils - Class in com.cloudera.oryx.app.als
ALS-related utility methods for the app tier.
applyAsDouble(double[], double[]) - Method in class com.cloudera.oryx.app.kmeans.EuclideanDistanceFn
 
applyAsDouble(float[]) - Method in class com.cloudera.oryx.app.serving.als.CosineAverageFunction
 
applyAsDouble(float[]) - Method in class com.cloudera.oryx.app.serving.als.DotsFunction
 
applyAsDouble(T, double) - Method in interface com.cloudera.oryx.common.lang.ToDoubleObjDoubleBiFunction
Applies this function to the given arguments.
AppPMMLUtils - Class in com.cloudera.oryx.app.pmml
General app tier PMML-related utility methods.
around(double, double) - Static method in class com.cloudera.oryx.ml.param.HyperParams
 
around(int, int) - Static method in class com.cloudera.oryx.ml.param.HyperParams
 
asRunnable() - Method in class com.cloudera.oryx.common.lang.LoggingCallable
 
Assign - Class in com.cloudera.oryx.app.serving.clustering
Responds to a GET request to /assign/[datum], or a POST to /assign containing several data points, one on each line.
Assign() - Constructor for class com.cloudera.oryx.app.serving.clustering.Assign
 
authenticate(String, String) - Method in class com.cloudera.oryx.lambda.serving.InMemoryRealm
 
AutoLock - Class in com.cloudera.oryx.common.lang
Makes a Lock into an AutoCloseable for use with try-with-resources: {@code Lock lock = ...; ...
AutoLock() - Constructor for class com.cloudera.oryx.common.lang.AutoLock
Manages a new ReentrantLock.
AutoLock(Lock) - Constructor for class com.cloudera.oryx.common.lang.AutoLock
 
autoLock() - Method in class com.cloudera.oryx.common.lang.AutoLock
 
autoReadLock() - Method in class com.cloudera.oryx.common.lang.AutoReadWriteLock
 
AutoReadWriteLock - Class in com.cloudera.oryx.common.lang
AutoReadWriteLock() - Constructor for class com.cloudera.oryx.common.lang.AutoReadWriteLock
Manages a new ReentrantReadWriteLock.
AutoReadWriteLock(ReadWriteLock) - Constructor for class com.cloudera.oryx.common.lang.AutoReadWriteLock
 
autoWriteLock() - Method in class com.cloudera.oryx.common.lang.AutoReadWriteLock
 
await() - Method in class com.cloudera.oryx.lambda.batch.BatchLayer
 
await() - Method in class com.cloudera.oryx.lambda.serving.ServingLayer
Blocks and waits until the server shuts down.
await() - Method in class com.cloudera.oryx.lambda.speed.SpeedLayer
 

B

BatchLayer<K,M,U> - Class in com.cloudera.oryx.lambda.batch
Main entry point for Oryx Batch Layer.
BatchLayer(Config) - Constructor for class com.cloudera.oryx.lambda.batch.BatchLayer
 
BatchLayerUpdate<K,M,U> - Interface in com.cloudera.oryx.api.batch
Implementations of this interface define the update process for an instance of the batch layer.
Because - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /because/[userID]/[itemID](?howMany=n)(&offset=o).
Because() - Constructor for class com.cloudera.oryx.app.serving.als.Because
 
buildCategoricalValueEncodings(DataDictionary) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
buildDataDictionary(InputSchema, CategoricalValueEncodings) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
buildInputDStream(JavaStreamingContext) - Method in class com.cloudera.oryx.lambda.AbstractSparkLayer
 
buildMiningSchema(InputSchema) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
buildMiningSchema(InputSchema, double[]) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
buildModel(JavaSparkContext, JavaRDD<String>, List<?>, Path) - Method in class com.cloudera.oryx.app.batch.mllib.als.ALSUpdate
 
buildModel(JavaSparkContext, JavaRDD<String>, List<?>, Path) - Method in class com.cloudera.oryx.app.batch.mllib.kmeans.KMeansUpdate
 
buildModel(JavaSparkContext, JavaRDD<String>, List<?>, Path) - Method in class com.cloudera.oryx.app.batch.mllib.rdf.RDFUpdate
 
buildModel(JavaSparkContext, JavaRDD<M>, List<?>, Path) - Method in class com.cloudera.oryx.ml.MLUpdate
 
buildSkeletonPMML() - Static method in class com.cloudera.oryx.common.pmml.PMMLUtils
 
buildStreamingContext() - Method in class com.cloudera.oryx.lambda.AbstractSparkLayer
 
buildUpdates(JavaPairRDD<K, M>) - Method in interface com.cloudera.oryx.api.speed.SpeedModelManager
 
buildUpdates(JavaPairRDD<String, String>) - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModelManager
 
buildUpdates(JavaPairRDD<String, String>) - Method in class com.cloudera.oryx.app.speed.kmeans.KMeansSpeedModelManager
 
buildUpdates(JavaPairRDD<String, String>) - Method in class com.cloudera.oryx.app.speed.rdf.RDFSpeedModelManager
 
buildUpdates(JavaPairRDD<String, String>) - Method in class com.cloudera.oryx.example.speed.ExampleSpeedModelManager
 
buildUpdates(JavaPairRDD<K, M>) - Method in class com.cloudera.oryx.lambda.speed.ScalaSpeedModelManagerAdapter
 

C

call() - Method in class com.cloudera.oryx.common.lang.LoggingCallable
 
call(T) - Method in class com.cloudera.oryx.lambda.DeleteOldDataFn
 
call(JavaRDD<T>) - Method in class com.cloudera.oryx.lambda.UpdateOffsetsFn
 
canPublishAdditionalModelData() - Method in class com.cloudera.oryx.app.batch.mllib.als.ALSUpdate
 
canPublishAdditionalModelData() - Method in class com.cloudera.oryx.ml.MLUpdate
 
CategoricalDecision - Class in com.cloudera.oryx.app.rdf.decision
Represents a decision over a categorical feature.
CategoricalDecision(int, BitSet, boolean) - Constructor for class com.cloudera.oryx.app.rdf.decision.CategoricalDecision
 
CategoricalFeature - Class in com.cloudera.oryx.app.classreg.example
Represents a value of a categorical feature -- one that takes on discrete, unordered values like {male,female} rather than a continuous or discrete numeric value.
CategoricalPrediction - Class in com.cloudera.oryx.app.classreg.predict
Represents a prediction of the value of a categorical target.
CategoricalPrediction(int[]) - Constructor for class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
CategoricalPrediction(double[]) - Constructor for class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
CategoricalValueEncodings - Class in com.cloudera.oryx.app.schema
Encapsulates a two-way mapping between the set of values for one categorical feature as strings, and their encodings as integers.
CategoricalValueEncodings(Map<Integer, ? extends Collection<String>>) - Constructor for class com.cloudera.oryx.app.schema.CategoricalValueEncodings
 
check(boolean, Response.Status, String) - Static method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
check(boolean, String) - Static method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
checkExists(boolean, String) - Static method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
checkNotReadOnly() - Method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
checkUniqueIDs(Collection<ClusterInfo>) - Static method in class com.cloudera.oryx.app.kmeans.KMeansUtils
 
chooseFreePort() - Static method in class com.cloudera.oryx.common.io.IOUtils
Binds to a free ephemeral port, and then releases it.
chooseHyperParameterCombos(List<HyperParamValues<?>>, String, int) - Static method in class com.cloudera.oryx.ml.param.HyperParams
 
classExists(String) - Static method in class com.cloudera.oryx.common.lang.ClassUtils
 
ClassificationDistribution - Class in com.cloudera.oryx.app.serving.rdf
Responds to a GET request to /classificationDistribution/[datum].
ClassificationDistribution() - Constructor for class com.cloudera.oryx.app.serving.rdf.ClassificationDistribution
 
ClassificationRegressionServingModel - Interface in com.cloudera.oryx.app.serving.classreg.model
Implementations are ServingModels that specifically support classification or regression problems.
ClassUtils - Class in com.cloudera.oryx.common.lang
Class-related utility methods.
clear() - Method in class com.cloudera.oryx.common.math.DoubleWeightedMean
 
close() - Method in interface com.cloudera.oryx.api.serving.ServingModelManager
 
close() - Method in interface com.cloudera.oryx.api.speed.SpeedModelManager
 
close() - Method in interface com.cloudera.oryx.api.TopicProducer
 
close() - Method in interface com.cloudera.oryx.common.collection.CloseableIterator
 
close() - Method in class com.cloudera.oryx.common.lang.AutoLock
Unlocks the underlying Lock.
close() - Method in class com.cloudera.oryx.kafka.util.ConsumeDataIterator
 
close() - Method in class com.cloudera.oryx.lambda.batch.BatchLayer
 
close() - Method in class com.cloudera.oryx.lambda.serving.ModelManagerListener
 
close() - Method in class com.cloudera.oryx.lambda.serving.ScalaServingModelManagerAdapter
 
close() - Method in class com.cloudera.oryx.lambda.serving.ServingLayer
 
close() - Method in class com.cloudera.oryx.lambda.serving.TopicProducerImpl
 
close() - Method in class com.cloudera.oryx.lambda.speed.ScalaSpeedModelManagerAdapter
 
close() - Method in class com.cloudera.oryx.lambda.speed.SpeedLayer
 
close() - Method in class com.cloudera.oryx.lambda.TopicProducerImpl
 
CloseableIterator<T> - Interface in com.cloudera.oryx.common.collection
Implementations are Iterators that are also Closeable.
closeAtShutdown(Closeable) - Static method in class com.cloudera.oryx.common.lang.JVMUtils
Adds a shutdown hook that tries to call Closeable.close() on the given argument at JVM shutdown.
closeAtShutdown(Closeable) - Static method in class com.cloudera.oryx.lambda.HadoopUtils
Adds a shutdown hook that tries to call Closeable.close() on the given argument at JVM shutdown.
closeQuietly(Closeable) - Static method in class com.cloudera.oryx.common.io.IOUtils
Closes a Closeable and logs the exception, if any.
closestCluster(List<ClusterInfo>, DistanceFn<double[]>, double[]) - Static method in class com.cloudera.oryx.app.kmeans.KMeansUtils
 
closestCluster(double[]) - Method in class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModel
 
closestCluster(double[]) - Method in class com.cloudera.oryx.app.speed.kmeans.KMeansSpeedModel
 
ClusterInfo - Class in com.cloudera.oryx.app.kmeans
Encapsulates a cluster, including its center and number of points assigned to the cluster.
ClusterInfo(int, double[], long) - Constructor for class com.cloudera.oryx.app.kmeans.ClusterInfo
 
ClusteringServingModel - Interface in com.cloudera.oryx.app.serving.clustering.model
Implementations are ServingModels that specifically support clustering problems.
collectInParallel(int, int, boolean, Function<Integer, T>, Collector<T, ?, R>) - Static method in class com.cloudera.oryx.common.lang.ExecUtils
 
com.cloudera.oryx.api - package com.cloudera.oryx.api
Application API interface classes common to all Layers.
com.cloudera.oryx.api.batch - package com.cloudera.oryx.api.batch
Application API interface classes for the Batch Layer.
com.cloudera.oryx.api.serving - package com.cloudera.oryx.api.serving
Application API interface classes for the Serving Layer.
com.cloudera.oryx.api.speed - package com.cloudera.oryx.api.speed
Application API interface classes for the Speed Layer.
com.cloudera.oryx.app.als - package com.cloudera.oryx.app.als
Support code for rALS recommender application functionality common to several layers.
com.cloudera.oryx.app.batch.mllib.als - package com.cloudera.oryx.app.batch.mllib.als
Contains an app tier implementation of a Batch Layer, for ALS recommendations, using Spark MLlib.
com.cloudera.oryx.app.batch.mllib.kmeans - package com.cloudera.oryx.app.batch.mllib.kmeans
Contains an app tier implementation of a Batch Layer, for k-means clustering, using Spark MLlib.
com.cloudera.oryx.app.batch.mllib.rdf - package com.cloudera.oryx.app.batch.mllib.rdf
Contains an app tier implementation of a Batch Layer, for random decision forest-based clustering and regression, using Spark MLlib.
com.cloudera.oryx.app.classreg.example - package com.cloudera.oryx.app.classreg.example
Representations of features and training / test examples that are used inside a classification or regression process.
com.cloudera.oryx.app.classreg.predict - package com.cloudera.oryx.app.classreg.predict
Representations of the output of a classification or regression process.
com.cloudera.oryx.app.common.fn - package com.cloudera.oryx.app.common.fn
Contains Java Functions useful across ML tier implementations.
com.cloudera.oryx.app.kmeans - package com.cloudera.oryx.app.kmeans
Support code for the k-means application functionality common to several layers.
com.cloudera.oryx.app.pmml - package com.cloudera.oryx.app.pmml
Utility code related to parsing, writing and manipulating PMML representations of models, specific to applications.
com.cloudera.oryx.app.rdf - package com.cloudera.oryx.app.rdf
Support code for random decision forest application functionality common to several layers, mostly the scoring support.
com.cloudera.oryx.app.rdf.decision - package com.cloudera.oryx.app.rdf.decision
Supports decisions on features that are used inside a decision tree scoring process.
com.cloudera.oryx.app.rdf.tree - package com.cloudera.oryx.app.rdf.tree
Abstractions representing forests, trees, nodes and paths in decision forests.
com.cloudera.oryx.app.schema - package com.cloudera.oryx.app.schema
Encapsulation of basic input schema-related information common to many applications.
com.cloudera.oryx.app.serving - package com.cloudera.oryx.app.serving
Contains common code supporting several implementations of an app-tier Serving Layer.
com.cloudera.oryx.app.serving.als - package com.cloudera.oryx.app.serving.als
Contains an app tier implementation of a Serving Layer, for ALS recommendation.
com.cloudera.oryx.app.serving.als.model - package com.cloudera.oryx.app.serving.als.model
Data model support for the ALS recommender Serving Layer app.
com.cloudera.oryx.app.serving.classreg - package com.cloudera.oryx.app.serving.classreg
Contains app tier support code for implementations of classification and regression in the Serving Layer.
com.cloudera.oryx.app.serving.classreg.model - package com.cloudera.oryx.app.serving.classreg.model
 
com.cloudera.oryx.app.serving.clustering - package com.cloudera.oryx.app.serving.clustering
 
com.cloudera.oryx.app.serving.clustering.model - package com.cloudera.oryx.app.serving.clustering.model
Contains app tier support code for implementations of clustering in the Serving Layer.
com.cloudera.oryx.app.serving.kmeans - package com.cloudera.oryx.app.serving.kmeans
Contains an app tier implementation of a Serving Layer, for k-means clustering.
com.cloudera.oryx.app.serving.kmeans.model - package com.cloudera.oryx.app.serving.kmeans.model
Data model support for the k-means clustering Serving Layer app.
com.cloudera.oryx.app.serving.rdf - package com.cloudera.oryx.app.serving.rdf
Contains an app tier implementation of a Serving Layer, for random decision forest classification and regression.
com.cloudera.oryx.app.serving.rdf.model - package com.cloudera.oryx.app.serving.rdf.model
Data model support for the random decision forest Serving Layer app.
com.cloudera.oryx.app.speed.als - package com.cloudera.oryx.app.speed.als
Contains an app tier implementation of a Speed Layer, for ALS recommendation.
com.cloudera.oryx.app.speed.kmeans - package com.cloudera.oryx.app.speed.kmeans
Contains an app tier implementation of a Speed Layer, for ALS recommendation.
com.cloudera.oryx.app.speed.rdf - package com.cloudera.oryx.app.speed.rdf
Contains an app tier implementation of a Speed Layer, for random decision forest classification and regression.
com.cloudera.oryx.batch - package com.cloudera.oryx.batch
Contains the actual Batch Layer packaged application.
com.cloudera.oryx.common - package com.cloudera.oryx.common
Contains utility code common to all implementation modules.
com.cloudera.oryx.common.collection - package com.cloudera.oryx.common.collection
Collection-related utility methods and support classes.
com.cloudera.oryx.common.io - package com.cloudera.oryx.common.io
Utility code and methods on top of Java's I/O packages that relate to input/output, files, readers and writers.
com.cloudera.oryx.common.lang - package com.cloudera.oryx.common.lang
Contains utility code related to the JVM, classes, logging and other concerns closely related to the core language.
com.cloudera.oryx.common.math - package com.cloudera.oryx.common.math
General mathematical functions and related support code, including basic vector and matrix operations.
com.cloudera.oryx.common.pmml - package com.cloudera.oryx.common.pmml
Utility code related to parsing, writing and manipulating PMML representations of models.
com.cloudera.oryx.common.random - package com.cloudera.oryx.common.random
Utility code related to generating randomness and managing random state.
com.cloudera.oryx.common.settings - package com.cloudera.oryx.common.settings
Utility code pertaining to application configuration management.
com.cloudera.oryx.common.text - package com.cloudera.oryx.common.text
Contains simple utility functions related to text parsing and formatting.
com.cloudera.oryx.example.batch - package com.cloudera.oryx.example.batch
Contains a minimal example of what a user application would create to implement a Batch Layer.
com.cloudera.oryx.example.serving - package com.cloudera.oryx.example.serving
Contains a minimal example of what a user application would create to implement a Serving Layer.
com.cloudera.oryx.example.speed - package com.cloudera.oryx.example.speed
Contains a minimal example of what a user application would create to implement a Speed Layer.
com.cloudera.oryx.kafka.util - package com.cloudera.oryx.kafka.util
Kafka-related utility code and command-line applications.
com.cloudera.oryx.lambda - package com.cloudera.oryx.lambda
Code used across the Lambda tier.
com.cloudera.oryx.lambda.batch - package com.cloudera.oryx.lambda.batch
Contains the core support for the Lambda tier of the Batch Layers.
com.cloudera.oryx.lambda.serving - package com.cloudera.oryx.lambda.serving
Contains the core support for the Lambda tier of the Serving Layers.
com.cloudera.oryx.lambda.speed - package com.cloudera.oryx.lambda.speed
Contains the core support for the Lambda tier of the Speed Layers.
com.cloudera.oryx.ml - package com.cloudera.oryx.ml
Contains the core support for the ML tier of the Batch and Speed layers.
com.cloudera.oryx.ml.param - package com.cloudera.oryx.ml.param
This package supports defining hyperparameter ranges and selecting combinations of hyperparameter values from these ranges.
com.cloudera.oryx.serving - package com.cloudera.oryx.serving
Contains the actual Serving Layer packaged application.
com.cloudera.oryx.speed - package com.cloudera.oryx.speed
Contains the actual Speed Layer packaged application.
compute() - Method in class com.cloudera.oryx.app.als.SolverCache
Proactively try to compute the solver asynchronously, if not already computed.
computeNext() - Method in class com.cloudera.oryx.kafka.util.ConsumeDataIterator
 
computeTargetQui(boolean, double, double) - Static method in class com.cloudera.oryx.app.als.ALSUtils
Computes how the estimated strength of interaction in the model should change -- to what target value -- in response to a new interaction.
computeUpdatedXu(Solver, double, float[], float[], boolean) - Static method in class com.cloudera.oryx.app.als.ALSUtils
Computes how a user vector Xu changes in response to interaction with an item vector Yi.
ConfigToProperties - Class in com.cloudera.oryx.common.settings
Utility that outputs all configuration as key-value pairs (as in a .properties file) to stdout.
ConfigUtils - Class in com.cloudera.oryx.common.settings
Utilities for retrieving Config instances.
Console - Class in com.cloudera.oryx.app.serving.als
ALS app Serving Layer console.
Console() - Constructor for class com.cloudera.oryx.app.serving.als.Console
 
Console - Class in com.cloudera.oryx.app.serving.kmeans
k-means app Serving Layer console.
Console() - Constructor for class com.cloudera.oryx.app.serving.kmeans.Console
 
Console - Class in com.cloudera.oryx.app.serving.rdf
Random decision forest app Serving Layer console.
Console() - Constructor for class com.cloudera.oryx.app.serving.rdf.Console
 
consume(Iterator<KeyMessage<String, U>>, Configuration) - Method in class com.cloudera.oryx.api.serving.AbstractServingModelManager
 
consume(Iterator<KeyMessage<String, U>>, Configuration) - Method in interface com.cloudera.oryx.api.serving.ServingModelManager
Called by the framework to initiate a continuous process of reading models, and reading from the input topic and updating model state in memory, and issuing updates to the update topic.
consume(Iterator<KeyMessage<String, U>>, Configuration) - Method in class com.cloudera.oryx.api.speed.AbstractSpeedModelManager
 
consume(Iterator<KeyMessage<String, U>>, Configuration) - Method in interface com.cloudera.oryx.api.speed.SpeedModelManager
Called by the framework to initiate a continuous process of reading models, and reading from the input topic and updating model state in memory, and issuing updates to the update topic.
consume(Iterator<KeyMessage<String, U>>, Configuration) - Method in class com.cloudera.oryx.lambda.serving.ScalaServingModelManagerAdapter
 
consume(Iterator<KeyMessage<String, U>>, Configuration) - Method in class com.cloudera.oryx.lambda.speed.ScalaSpeedModelManagerAdapter
 
ConsumeDataIterator<K,V> - Class in com.cloudera.oryx.kafka.util
An iterator over records in a Kafka topic.
ConsumeDataIterator(KafkaConsumer<K, V>) - Constructor for class com.cloudera.oryx.kafka.util.ConsumeDataIterator
 
consumeKeyMessage(String, U, Configuration) - Method in class com.cloudera.oryx.api.serving.AbstractServingModelManager
Convenience method that is called by the default implementation of AbstractServingModelManager.consume(Iterator, Configuration), to process one key-message pair.
consumeKeyMessage(String, U, Configuration) - Method in class com.cloudera.oryx.api.speed.AbstractSpeedModelManager
Convenience method that is called by the default implementation of AbstractSpeedModelManager.consume(Iterator, Configuration), to process one key-message pair.
consumeKeyMessage(String, String, Configuration) - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModelManager
 
consumeKeyMessage(String, String, Configuration) - Method in class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModelManager
 
consumeKeyMessage(String, String, Configuration) - Method in class com.cloudera.oryx.app.serving.rdf.model.RDFServingModelManager
 
consumeKeyMessage(String, String, Configuration) - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModelManager
 
consumeKeyMessage(String, String, Configuration) - Method in class com.cloudera.oryx.app.speed.kmeans.KMeansSpeedModelManager
 
consumeKeyMessage(String, String, Configuration) - Method in class com.cloudera.oryx.app.speed.rdf.RDFSpeedModelManager
 
consumeKeyMessage(String, String, Configuration) - Method in class com.cloudera.oryx.example.serving.ExampleServingModelManager
 
consumeKeyMessage(String, String, Configuration) - Method in class com.cloudera.oryx.example.speed.ExampleSpeedModelManager
 
contextDestroyed(ServletContextEvent) - Method in class com.cloudera.oryx.lambda.serving.ModelManagerListener
 
contextInitialized(ServletContextEvent) - Method in class com.cloudera.oryx.lambda.serving.ModelManagerListener
 
convertViaJSON(Object, Class<T>) - Static method in class com.cloudera.oryx.common.text.TextUtils
 
copy() - Method in class com.cloudera.oryx.common.math.DoubleWeightedMean
 
CosineAverageFunction - Class in com.cloudera.oryx.app.serving.als
Computes the cosine of the angle between a target vector and other vectors.
CosineAverageFunction(float[]) - Constructor for class com.cloudera.oryx.app.serving.als.CosineAverageFunction
 
CosineAverageFunction(float[][]) - Constructor for class com.cloudera.oryx.app.serving.als.CosineAverageFunction
 
CosineDistanceSensitiveFunction - Interface in com.cloudera.oryx.app.serving.als
Implementations of this type of function return a value that depends on cosine distance to a target vector and thus makes sense to use with the locality-sensitive hash logic in ALSServingModel.
cosineSimilarity(float[], float[], double) - Static method in class com.cloudera.oryx.common.math.VectorMath
Computes cosine similarity of values in two given arrays, when the norm of one array is known in advance, which is a not-uncommon case.
countDistinctOtherWords(JavaPairRDD<String, String>) - Static method in class com.cloudera.oryx.example.batch.ExampleBatchLayerUpdate
 
CSVMessageBodyWriter - Class in com.cloudera.oryx.lambda.serving
A MessageBodyWriter that can produce CSV (text/csv).
CSVMessageBodyWriter() - Constructor for class com.cloudera.oryx.lambda.serving.CSVMessageBodyWriter
 

D

dataToExample(String[], InputSchema, CategoricalValueEncodings) - Static method in class com.cloudera.oryx.app.classreg.example.ExampleUtils
 
Decision - Class in com.cloudera.oryx.app.rdf.decision
Subclasses represent a binary yes/no positive/negative decision based on the value of a feature in an example.
DecisionForest - Class in com.cloudera.oryx.app.rdf.tree
An ensemble classifier based on many DecisionTrees.
DecisionForest(DecisionTree[], double[], double[]) - Constructor for class com.cloudera.oryx.app.rdf.tree.DecisionForest
 
DecisionNode - Class in com.cloudera.oryx.app.rdf.tree
Represents an internal node in a DecisionTree, which encapsulates a binary decision over a feature in an example.
DecisionNode(String, Decision, TreeNode, TreeNode) - Constructor for class com.cloudera.oryx.app.rdf.tree.DecisionNode
 
DecisionTree - Class in com.cloudera.oryx.app.rdf.tree
A decision-tree classifier.
DecisionTree(TreeNode) - Constructor for class com.cloudera.oryx.app.rdf.tree.DecisionTree
 
delete(String, String) - Method in class com.cloudera.oryx.app.serving.als.Preference
 
DeleteOldDataFn<T> - Class in com.cloudera.oryx.lambda
Function that deletes old data, if applicable, at each batch interval.
DeleteOldDataFn(Configuration, String, Pattern, int) - Constructor for class com.cloudera.oryx.lambda.DeleteOldDataFn
 
deleteRecursively(Path) - Static method in class com.cloudera.oryx.common.io.IOUtils
Deletes the given path, and if it is a directory, all files and subdirectories within it.
deleteTopic(String, String) - Static method in class com.cloudera.oryx.kafka.util.KafkaUtils
 
deserialize(String) - Static method in class com.cloudera.oryx.common.settings.ConfigUtils
 
DistanceFn<T> - Interface in com.cloudera.oryx.app.kmeans
A function that returns a distance between things.
DistanceToNearest - Class in com.cloudera.oryx.app.serving.kmeans
Responds to a GET request to /distanceToNearest/[datum].
DistanceToNearest() - Constructor for class com.cloudera.oryx.app.serving.kmeans.DistanceToNearest
 
Distinct - Class in com.cloudera.oryx.example.serving
Responds to a GET request to /distinct.
Distinct() - Constructor for class com.cloudera.oryx.example.serving.Distinct
 
doInParallel(int, Consumer<Integer>) - Static method in class com.cloudera.oryx.common.lang.ExecUtils
 
doInParallel(int, int, boolean, Consumer<Integer>) - Static method in class com.cloudera.oryx.common.lang.ExecUtils
 
dot(float[], float[]) - Static method in class com.cloudera.oryx.common.math.VectorMath
 
DotsFunction - Class in com.cloudera.oryx.app.serving.als
Computes the dot product of a target vector and other vectors.
DotsFunction(float[]) - Constructor for class com.cloudera.oryx.app.serving.als.DotsFunction
 
DotsFunction(float[][]) - Constructor for class com.cloudera.oryx.app.serving.als.DotsFunction
 
DoubleWeightedMean - Class in com.cloudera.oryx.common.math
A weighted mean implementation for floating-point weights, following the Commons Math3 framework.
DoubleWeightedMean() - Constructor for class com.cloudera.oryx.common.math.DoubleWeightedMean
 

E

equals(Object) - Method in class com.cloudera.oryx.api.KeyMessageImpl
 
equals(Object) - Method in class com.cloudera.oryx.app.classreg.example.CategoricalFeature
 
equals(Object) - Method in class com.cloudera.oryx.app.classreg.example.Example
 
equals(Object) - Method in class com.cloudera.oryx.app.classreg.example.NumericFeature
 
equals(Object) - Method in class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
equals(Object) - Method in class com.cloudera.oryx.app.classreg.predict.NumericPrediction
 
equals(Object) - Method in class com.cloudera.oryx.app.rdf.decision.CategoricalDecision
 
equals(Object) - Method in class com.cloudera.oryx.app.rdf.decision.NumericDecision
 
equals(Object) - Method in class com.cloudera.oryx.app.rdf.tree.DecisionNode
 
equals(Object) - Method in class com.cloudera.oryx.app.rdf.tree.TerminalNode
 
equals(Object) - Method in class com.cloudera.oryx.common.collection.Pair
 
equals(Object) - Method in class com.cloudera.oryx.common.math.DoubleWeightedMean
 
errorEmpty(HttpServletRequest) - Method in class com.cloudera.oryx.lambda.serving.ErrorResource
 
errorHTML(HttpServletRequest) - Method in class com.cloudera.oryx.lambda.serving.ErrorResource
 
ErrorResource - Class in com.cloudera.oryx.lambda.serving
Constructs a simple HTML error page from error info in the request.
ErrorResource() - Constructor for class com.cloudera.oryx.lambda.serving.ErrorResource
 
errorText(HttpServletRequest) - Method in class com.cloudera.oryx.lambda.serving.ErrorResource
 
Estimate - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /estimate/[userID]/[itemID].
Estimate() - Constructor for class com.cloudera.oryx.app.serving.als.Estimate
 
EstimateForAnonymous - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /estimateForAnonymous/[toItemID]/[itemID1(=value1)](/[itemID2(=value2)]/...).
EstimateForAnonymous() - Constructor for class com.cloudera.oryx.app.serving.als.EstimateForAnonymous
 
EuclideanDistanceFn - Class in com.cloudera.oryx.app.kmeans
Returns the Euclidean distance between two double[].
EuclideanDistanceFn() - Constructor for class com.cloudera.oryx.app.kmeans.EuclideanDistanceFn
 
evaluate(JavaSparkContext, PMML, Path, JavaRDD<String>, JavaRDD<String>) - Method in class com.cloudera.oryx.app.batch.mllib.als.ALSUpdate
 
evaluate(JavaSparkContext, PMML, Path, JavaRDD<String>, JavaRDD<String>) - Method in class com.cloudera.oryx.app.batch.mllib.kmeans.KMeansUpdate
 
evaluate(JavaSparkContext, PMML, Path, JavaRDD<String>, JavaRDD<String>) - Method in class com.cloudera.oryx.app.batch.mllib.rdf.RDFUpdate
 
evaluate(JavaSparkContext, PMML, Path, JavaRDD<M>, JavaRDD<M>) - Method in class com.cloudera.oryx.ml.MLUpdate
 
Example - Class in com.cloudera.oryx.app.classreg.example
Encapsulates one example, or data point: a set of features that predict a target feature.
Example(Feature, Feature...) - Constructor for class com.cloudera.oryx.app.classreg.example.Example
 
ExampleBatchLayerUpdate - Class in com.cloudera.oryx.example.batch
Input keys are ignored.
ExampleBatchLayerUpdate() - Constructor for class com.cloudera.oryx.example.batch.ExampleBatchLayerUpdate
 
ExampleServingModel - Class in com.cloudera.oryx.example.serving
ExampleServingModelManager - Class in com.cloudera.oryx.example.serving
Reads models and updates produced by the Batch Layer and Speed Layer.
ExampleServingModelManager(Config) - Constructor for class com.cloudera.oryx.example.serving.ExampleServingModelManager
 
ExampleSpeedModelManager - Class in com.cloudera.oryx.example.speed
Also counts and emits counts of number of distinct words that occur with words.
ExampleSpeedModelManager() - Constructor for class com.cloudera.oryx.example.speed.ExampleSpeedModelManager
 
ExampleUtils - Class in com.cloudera.oryx.app.classreg.example
Utility methods supporting the Example class, like factory methods.
ExecUtils - Class in com.cloudera.oryx.common.lang
Utility methods for executing tasks in parallel, possibly returning a result and possibly using a private pool, using Java 8 abstractions.

F

Feature - Interface in com.cloudera.oryx.app.classreg.example
Implementations represent the value of one feature in an Example.
FeatureImportance - Class in com.cloudera.oryx.app.serving.rdf
Responds to a GET request to /feature/importance or /feature/importance/[feature number].
FeatureImportance() - Constructor for class com.cloudera.oryx.app.serving.rdf.FeatureImportance
 
featuresFromTokens(String[], InputSchema) - Static method in class com.cloudera.oryx.app.kmeans.KMeansUtils
 
featureToPredictorIndex(int) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
FeatureType - Enum in com.cloudera.oryx.app.classreg.example
Represents the type of a Feature.
FeatureVectors - Interface in com.cloudera.oryx.app.als
Encapsulates a feature vectors, keyed by an ID, and associated data structures.
FeatureVectorsPartition - Class in com.cloudera.oryx.app.als
Encapsulates a feature vectors, keyed by an ID, and associated data structures.
FeatureVectorsPartition() - Constructor for class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
findByID(String) - Method in class com.cloudera.oryx.app.rdf.tree.DecisionTree
 
findTargetIndex(MiningSchema) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
findTerminal(Example) - Method in class com.cloudera.oryx.app.rdf.tree.DecisionTree
 
fixed(double) - Static method in class com.cloudera.oryx.ml.param.HyperParams
 
fixed(int) - Static method in class com.cloudera.oryx.ml.param.HyperParams
 
forEach(BiConsumer<String, float[]>) - Method in class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
forEncoding(int) - Static method in class com.cloudera.oryx.app.classreg.example.CategoricalFeature
 
forValue(double) - Static method in class com.cloudera.oryx.app.classreg.example.NumericFeature
 
fromConfig(Config, String) - Static method in class com.cloudera.oryx.ml.param.HyperParams
 
fromString(String) - Static method in class com.cloudera.oryx.common.pmml.PMMLUtils
 

G

get(boolean) - Method in class com.cloudera.oryx.app.als.SolverCache
 
get() - Method in class com.cloudera.oryx.app.serving.als.AllItemIDs
 
get() - Method in class com.cloudera.oryx.app.serving.als.AllUserIDs
 
get(String, String, int, int) - Method in class com.cloudera.oryx.app.serving.als.Because
 
get(String, List<PathSegment>) - Method in class com.cloudera.oryx.app.serving.als.Estimate
 
get(String, List<PathSegment>) - Method in class com.cloudera.oryx.app.serving.als.EstimateForAnonymous
 
get(String) - Method in class com.cloudera.oryx.app.serving.als.KnownItems
 
get(int, int, List<String>) - Method in class com.cloudera.oryx.app.serving.als.MostActiveUsers
 
get(int, int, List<String>) - Method in class com.cloudera.oryx.app.serving.als.MostPopularItems
 
get(String, int, int) - Method in class com.cloudera.oryx.app.serving.als.MostSurprising
 
get() - Method in class com.cloudera.oryx.app.serving.als.PopularRepresentativeItems
 
get(String, int, int, boolean, List<String>) - Method in class com.cloudera.oryx.app.serving.als.Recommend
 
get(List<PathSegment>, int, int, List<String>) - Method in class com.cloudera.oryx.app.serving.als.RecommendToAnonymous
 
get(List<PathSegment>, int, int, boolean, List<String>) - Method in class com.cloudera.oryx.app.serving.als.RecommendToMany
 
get(String, List<PathSegment>, int, int, boolean, List<String>) - Method in class com.cloudera.oryx.app.serving.als.RecommendWithContext
 
get(List<PathSegment>, int, int, List<String>) - Method in class com.cloudera.oryx.app.serving.als.Similarity
 
get(String, List<PathSegment>) - Method in class com.cloudera.oryx.app.serving.als.SimilarityToItem
 
get(String) - Method in class com.cloudera.oryx.app.serving.classreg.Predict
 
get(String) - Method in class com.cloudera.oryx.app.serving.clustering.Assign
 
get(String) - Method in class com.cloudera.oryx.app.serving.kmeans.DistanceToNearest
 
get(String) - Method in class com.cloudera.oryx.app.serving.rdf.ClassificationDistribution
 
get() - Method in class com.cloudera.oryx.app.serving.Ready
 
get() - Method in interface com.cloudera.oryx.common.lang.LoggingCallable.AllowExceptionSupplier
 
get() - Method in class com.cloudera.oryx.example.serving.Distinct
 
get(String) - Method in class com.cloudera.oryx.example.serving.Distinct
 
getActiveCategoryEncodings() - Method in class com.cloudera.oryx.app.rdf.decision.CategoricalDecision
 
getAllImportances() - Method in class com.cloudera.oryx.app.serving.rdf.FeatureImportance
 
getAllItemIDs() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getAllUserIDs() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getApparentRank() - Method in exception com.cloudera.oryx.common.math.SingularMatrixSolverException
 
getCategoryCounts() - Method in class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
getCategoryCounts() - Method in class com.cloudera.oryx.app.schema.CategoricalValueEncodings
 
getCategoryProbabilities() - Method in class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
getCenter() - Method in class com.cloudera.oryx.app.kmeans.ClusterInfo
 
getClasses() - Method in class com.cloudera.oryx.lambda.serving.OryxApplication
 
getCluster(int) - Method in class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModel
 
getCluster(int) - Method in class com.cloudera.oryx.app.speed.kmeans.KMeansSpeedModel
 
getConfig() - Method in class com.cloudera.oryx.api.serving.AbstractServingModelManager
 
getConfig() - Method in interface com.cloudera.oryx.api.serving.ServingModelManager
 
getConfig() - Method in class com.cloudera.oryx.lambda.AbstractSparkLayer
 
getConfig() - Method in class com.cloudera.oryx.lambda.serving.ScalaServingModelManagerAdapter
 
getConfigGroup() - Method in class com.cloudera.oryx.lambda.AbstractSparkLayer
 
getConfigGroup() - Method in class com.cloudera.oryx.lambda.batch.BatchLayer
 
getConfigGroup() - Method in class com.cloudera.oryx.lambda.speed.SpeedLayer
 
getConsoleResource() - Method in class com.cloudera.oryx.app.serving.AbstractConsoleResource
 
getConsoleResource() - Method in class com.cloudera.oryx.app.serving.als.Console
 
getConsoleResource() - Method in class com.cloudera.oryx.app.serving.kmeans.Console
 
getConsoleResource() - Method in class com.cloudera.oryx.app.serving.rdf.Console
 
getContext() - Method in class com.cloudera.oryx.lambda.serving.ServingLayer
 
getCount() - Method in class com.cloudera.oryx.app.classreg.predict.Prediction
 
getCount() - Method in class com.cloudera.oryx.app.kmeans.ClusterInfo
 
getCount() - Method in class com.cloudera.oryx.app.rdf.tree.TerminalNode
 
getCount() - Method in class com.cloudera.oryx.app.serving.IDCount
 
getDecision() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionNode
 
getDefault() - Static method in class com.cloudera.oryx.common.settings.ConfigUtils
Returns the default Config object for this app, based on config in the JAR file or otherwise specified to the library.
getDefaultDecision() - Method in class com.cloudera.oryx.app.rdf.decision.CategoricalDecision
 
getDefaultDecision() - Method in class com.cloudera.oryx.app.rdf.decision.Decision
 
getDefaultDecision() - Method in class com.cloudera.oryx.app.rdf.decision.NumericDecision
 
getEncoding() - Method in class com.cloudera.oryx.app.classreg.example.CategoricalFeature
 
getEncodings() - Method in class com.cloudera.oryx.app.serving.rdf.model.RDFServingModel
 
getEncodings() - Method in class com.cloudera.oryx.app.speed.rdf.RDFSpeedModel
 
getEncodingValueMap(int) - Method in class com.cloudera.oryx.app.schema.CategoricalValueEncodings
 
getEpsilon() - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
getExtensionContent(PMML, String) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
getExtensionValue(PMML, String) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
getFeature(int) - Method in class com.cloudera.oryx.app.classreg.example.Example
 
getFeatureImportances() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionForest
 
getFeatureNames(MiningSchema) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
getFeatureNames(DataDictionary) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
getFeatureNames() - Method in class com.cloudera.oryx.app.schema.InputSchema
 
getFeatureNumber() - Method in class com.cloudera.oryx.app.rdf.decision.Decision
 
getFeatures() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getFeatures() - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
getFeatureType() - Method in class com.cloudera.oryx.app.classreg.example.CategoricalFeature
 
getFeatureType() - Method in interface com.cloudera.oryx.app.classreg.example.Feature
 
getFeatureType() - Method in class com.cloudera.oryx.app.classreg.example.NumericFeature
 
getFeatureType() - Method in class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
getFeatureType() - Method in class com.cloudera.oryx.app.classreg.predict.NumericPrediction
 
getFeatureType() - Method in class com.cloudera.oryx.app.classreg.predict.Prediction
 
getFirst() - Method in class com.cloudera.oryx.common.collection.Pair
 
getForest() - Method in class com.cloudera.oryx.app.serving.rdf.model.RDFServingModel
 
getForest() - Method in class com.cloudera.oryx.app.speed.rdf.RDFSpeedModel
 
getFractionLoaded() - Method in interface com.cloudera.oryx.api.serving.ServingModel
 
getFractionLoaded() - Method in interface com.cloudera.oryx.api.speed.SpeedModel
 
getFractionLoaded() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getFractionLoaded() - Method in class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModel
 
getFractionLoaded() - Method in class com.cloudera.oryx.app.serving.rdf.model.RDFServingModel
 
getFractionLoaded() - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
getFractionLoaded() - Method in class com.cloudera.oryx.app.speed.kmeans.KMeansSpeedModel
 
getFractionLoaded() - Method in class com.cloudera.oryx.app.speed.rdf.RDFSpeedModel
 
getFractionLoaded() - Method in class com.cloudera.oryx.example.serving.ExampleServingModel
 
getGroupID() - Method in class com.cloudera.oryx.lambda.AbstractSparkLayer
 
getHTML(HttpServletResponse) - Method in class com.cloudera.oryx.app.serving.AbstractConsoleResource
 
getHyperParameterValues() - Method in class com.cloudera.oryx.app.batch.mllib.als.ALSUpdate
 
getHyperParameterValues() - Method in class com.cloudera.oryx.app.batch.mllib.kmeans.KMeansUpdate
 
getHyperParameterValues() - Method in class com.cloudera.oryx.app.batch.mllib.rdf.RDFUpdate
 
getHyperParameterValues() - Method in class com.cloudera.oryx.ml.MLUpdate
 
getID() - Method in class com.cloudera.oryx.app.kmeans.ClusterInfo
 
getID() - Method in class com.cloudera.oryx.app.rdf.tree.TreeNode
 
getID() - Method in class com.cloudera.oryx.lambda.AbstractSparkLayer
 
getImportance(int) - Method in class com.cloudera.oryx.app.serving.rdf.FeatureImportance
 
getInputProducer() - Method in class com.cloudera.oryx.api.serving.OryxResource
 
getInputSchema() - Method in class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModel
 
getInputSchema() - Method in class com.cloudera.oryx.app.serving.rdf.model.RDFServingModel
 
getInputTopicLockMaster() - Method in class com.cloudera.oryx.lambda.AbstractSparkLayer
 
getItemCounts() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getItemVector(String) - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getItemVector(String) - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
getKey() - Method in interface com.cloudera.oryx.api.KeyMessage
 
getKey() - Method in class com.cloudera.oryx.api.KeyMessageImpl
 
getKeyClass() - Method in class com.cloudera.oryx.lambda.AbstractSparkLayer
 
getKnownItems(String) - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getKnownItemVectorsForUser(String) - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getLayerName() - Method in class com.cloudera.oryx.lambda.AbstractSparkLayer
 
getLayerName() - Method in class com.cloudera.oryx.lambda.batch.BatchLayer
 
getLayerName() - Method in class com.cloudera.oryx.lambda.speed.SpeedLayer
 
getLeft() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionNode
 
getMessage() - Method in interface com.cloudera.oryx.api.KeyMessage
 
getMessage() - Method in class com.cloudera.oryx.api.KeyMessageImpl
 
getMessageClass() - Method in class com.cloudera.oryx.lambda.AbstractSparkLayer
 
getModel() - Method in interface com.cloudera.oryx.api.serving.ServingModelManager
 
getModel() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModelManager
 
getModel() - Method in class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModelManager
 
getModel() - Method in class com.cloudera.oryx.app.serving.rdf.model.RDFServingModelManager
 
getModel() - Method in class com.cloudera.oryx.example.serving.ExampleServingModelManager
 
getModel() - Method in class com.cloudera.oryx.lambda.serving.ScalaServingModelManagerAdapter
 
getMostActiveUsersRescorer(List<String>) - Method in class com.cloudera.oryx.app.als.AbstractRescorerProvider
 
getMostActiveUsersRescorer(List<String>) - Method in class com.cloudera.oryx.app.als.MultiRescorerProvider
 
getMostActiveUsersRescorer(List<String>) - Method in interface com.cloudera.oryx.app.als.RescorerProvider
 
getMostPopularItemsRescorer(List<String>) - Method in class com.cloudera.oryx.app.als.AbstractRescorerProvider
 
getMostPopularItemsRescorer(List<String>) - Method in class com.cloudera.oryx.app.als.MultiRescorerProvider
 
getMostPopularItemsRescorer(List<String>) - Method in interface com.cloudera.oryx.app.als.RescorerProvider
 
getMostProbableCategoryEncoding() - Method in class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
getMostSimilarItemsRescorer(List<String>) - Method in class com.cloudera.oryx.app.als.AbstractRescorerProvider
 
getMostSimilarItemsRescorer(List<String>) - Method in class com.cloudera.oryx.app.als.MultiRescorerProvider
 
getMostSimilarItemsRescorer(List<String>) - Method in interface com.cloudera.oryx.app.als.RescorerProvider
 
getN() - Method in class com.cloudera.oryx.common.math.DoubleWeightedMean
 
getNumClusters() - Method in class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModel
 
getNumDistinctValues() - Method in interface com.cloudera.oryx.ml.param.HyperParamValues
 
getNumFeatures() - Method in class com.cloudera.oryx.app.schema.InputSchema
 
getNumItems() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getNumPredictors() - Method in class com.cloudera.oryx.app.schema.InputSchema
 
getNumUsers() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getOptionalDouble(Config, String) - Static method in class com.cloudera.oryx.common.settings.ConfigUtils
 
getOptionalString(Config, String) - Static method in class com.cloudera.oryx.common.settings.ConfigUtils
 
getOptionalStringList(Config, String) - Static method in class com.cloudera.oryx.common.settings.ConfigUtils
 
getPassword(String) - Method in class com.cloudera.oryx.lambda.serving.InMemoryRealm
 
getPrediction() - Method in class com.cloudera.oryx.app.classreg.predict.NumericPrediction
 
getPrediction() - Method in class com.cloudera.oryx.app.rdf.tree.TerminalNode
 
getPrincipal(String) - Method in class com.cloudera.oryx.lambda.serving.InMemoryRealm
 
getRandom() - Static method in class com.cloudera.oryx.common.random.RandomManager
 
getRandom(long) - Static method in class com.cloudera.oryx.common.random.RandomManager
 
getRandomValue(RandomDataGenerator) - Method in interface com.cloudera.oryx.ml.param.HyperParamValues
 
getRecommendRescorer(List<String>, List<String>) - Method in class com.cloudera.oryx.app.als.AbstractRescorerProvider
 
getRecommendRescorer(List<String>, List<String>) - Method in class com.cloudera.oryx.app.als.MultiRescorerProvider
 
getRecommendRescorer(List<String>, List<String>) - Method in interface com.cloudera.oryx.app.als.RescorerProvider
 
getRecommendToAnonymousRescorer(List<String>, List<String>) - Method in class com.cloudera.oryx.app.als.AbstractRescorerProvider
 
getRecommendToAnonymousRescorer(List<String>, List<String>) - Method in class com.cloudera.oryx.app.als.MultiRescorerProvider
 
getRecommendToAnonymousRescorer(List<String>, List<String>) - Method in interface com.cloudera.oryx.app.als.RescorerProvider
 
getRescorerProvider() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getResult() - Method in class com.cloudera.oryx.common.math.DoubleWeightedMean
 
getRight() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionNode
 
getSecond() - Method in class com.cloudera.oryx.common.collection.Pair
 
getServingModel() - Method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
getServingModelManager() - Method in class com.cloudera.oryx.api.serving.OryxResource
 
getSize(Object, Class<?>, Type, Annotation[], MediaType) - Method in class com.cloudera.oryx.lambda.serving.CSVMessageBodyWriter
 
getSolver(double[]) - Static method in class com.cloudera.oryx.common.math.LinearSystemSolver
 
getStatusCode() - Method in exception com.cloudera.oryx.api.serving.OryxServingException
 
getTarget() - Method in class com.cloudera.oryx.app.classreg.example.Example
 
getTargetFeature() - Method in class com.cloudera.oryx.app.schema.InputSchema
 
getTargetFeatureIndex() - Method in class com.cloudera.oryx.app.schema.InputSchema
 
getTargetVector() - Method in class com.cloudera.oryx.app.serving.als.CosineAverageFunction
 
getTargetVector() - Method in interface com.cloudera.oryx.app.serving.als.CosineDistanceSensitiveFunction
 
getTargetVector() - Method in class com.cloudera.oryx.app.serving.als.DotsFunction
 
getTestFraction() - Method in class com.cloudera.oryx.ml.MLUpdate
 
getThreshold() - Method in class com.cloudera.oryx.app.rdf.decision.NumericDecision
 
getTopic() - Method in interface com.cloudera.oryx.api.TopicProducer
 
getTopic() - Method in class com.cloudera.oryx.lambda.serving.TopicProducerImpl
 
getTopic() - Method in class com.cloudera.oryx.lambda.TopicProducerImpl
 
getTrees() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionForest
 
getTrialValues(int) - Method in interface com.cloudera.oryx.ml.param.HyperParamValues
 
getType() - Method in class com.cloudera.oryx.app.rdf.decision.CategoricalDecision
 
getType() - Method in class com.cloudera.oryx.app.rdf.decision.Decision
 
getType() - Method in class com.cloudera.oryx.app.rdf.decision.NumericDecision
 
getUpdateBroker() - Method in interface com.cloudera.oryx.api.TopicProducer
 
getUpdateBroker() - Method in class com.cloudera.oryx.lambda.serving.TopicProducerImpl
 
getUpdateBroker() - Method in class com.cloudera.oryx.lambda.TopicProducerImpl
 
getUsedMemory() - Static method in class com.cloudera.oryx.common.lang.JVMUtils
 
getUserCounts() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getUserVector(String) - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getUserVector(String) - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
getValue() - Method in class com.cloudera.oryx.app.classreg.example.NumericFeature
 
getValue() - Method in class com.cloudera.oryx.app.serving.IDValue
 
getValueCount(int) - Method in class com.cloudera.oryx.app.schema.CategoricalValueEncodings
 
getValueEncodingMap(int) - Method in class com.cloudera.oryx.app.schema.CategoricalValueEncodings
 
getVector(String) - Method in interface com.cloudera.oryx.app.als.FeatureVectors
 
getVector(String) - Method in class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
getVector(String) - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
getVTV(boolean) - Method in interface com.cloudera.oryx.app.als.FeatureVectors
 
getVTV(boolean) - Method in class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
getVTV(boolean) - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
getWeights() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionForest
 
getWords() - Method in class com.cloudera.oryx.example.serving.ExampleServingModel
 
getXTXSolver() - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
getYTYSolver() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
getYTYSolver() - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 

H

HadoopUtils - Class in com.cloudera.oryx.lambda
Hadoop-related utility methods.
HasCSV - Interface in com.cloudera.oryx.api.serving
Implementations of this interface can produce a CSV representation.
hashCode() - Method in class com.cloudera.oryx.api.KeyMessageImpl
 
hashCode() - Method in class com.cloudera.oryx.app.classreg.example.CategoricalFeature
 
hashCode() - Method in class com.cloudera.oryx.app.classreg.example.Example
 
hashCode() - Method in class com.cloudera.oryx.app.classreg.example.NumericFeature
 
hashCode() - Method in class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
hashCode() - Method in class com.cloudera.oryx.app.classreg.predict.NumericPrediction
 
hashCode() - Method in class com.cloudera.oryx.app.rdf.decision.CategoricalDecision
 
hashCode() - Method in class com.cloudera.oryx.app.rdf.decision.NumericDecision
 
hashCode() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionNode
 
hashCode() - Method in class com.cloudera.oryx.app.rdf.tree.TerminalNode
 
hashCode() - Method in class com.cloudera.oryx.common.collection.Pair
 
hashCode() - Method in class com.cloudera.oryx.common.math.DoubleWeightedMean
 
hasTarget() - Method in class com.cloudera.oryx.app.schema.InputSchema
 
head() - Method in class com.cloudera.oryx.app.serving.Ready
 
HyperParams - Class in com.cloudera.oryx.ml.param
Utility methods related to expressing and selecting hyperparameter values.
HyperParamValues<T> - Interface in com.cloudera.oryx.ml.param
Encapsulates a range or set of values for a hyperparameter, from which a subset can be selected.

I

IDCount - Class in com.cloudera.oryx.app.serving
Encapsulates a String ID and a count.
IDCount() - Constructor for class com.cloudera.oryx.app.serving.IDCount
 
IDCount(String, int) - Constructor for class com.cloudera.oryx.app.serving.IDCount
 
IDValue - Class in com.cloudera.oryx.app.serving
Encapsulates a String ID and a floating-point value.
IDValue() - Constructor for class com.cloudera.oryx.app.serving.IDValue
 
IDValue(String, double) - Constructor for class com.cloudera.oryx.app.serving.IDValue
 
increment(double) - Method in class com.cloudera.oryx.common.math.DoubleWeightedMean
 
increment(double, double) - Method in class com.cloudera.oryx.common.math.DoubleWeightedMean
 
Ingest - Class in com.cloudera.oryx.app.serving.als
Responds to a POST to /ingest.
Ingest() - Constructor for class com.cloudera.oryx.app.serving.als.Ingest
 
init() - Method in class com.cloudera.oryx.api.serving.OryxResource
 
InMemoryRealm - Class in com.cloudera.oryx.lambda.serving
Adapted from Tomcat's MemoryRealm.
InMemoryRealm() - Constructor for class com.cloudera.oryx.lambda.serving.InMemoryRealm
 
INPUT_PRODUCER_KEY - Static variable in class com.cloudera.oryx.api.serving.OryxResource
 
InputSchema - Class in com.cloudera.oryx.app.schema
Represents the essential schema information needed for some learning problems.
InputSchema(Config) - Constructor for class com.cloudera.oryx.app.schema.InputSchema
 
IOUtils - Class in com.cloudera.oryx.common.io
I/O-related utility methods.
isActive(String) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isActive(int) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isCategorical(String) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isCategorical(int) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isClassification() - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isFiltered(String) - Method in class com.cloudera.oryx.app.als.MultiRescorer
 
isFiltered(String) - Method in interface com.cloudera.oryx.app.als.Rescorer
 
isID(String) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isID(int) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isImplicit() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
isImplicit() - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
isLogStrength() - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
isNumeric(String) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isNumeric(int) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isPositive(Example) - Method in class com.cloudera.oryx.app.rdf.decision.CategoricalDecision
 
isPositive(Example) - Method in class com.cloudera.oryx.app.rdf.decision.Decision
 
isPositive(Example) - Method in class com.cloudera.oryx.app.rdf.decision.NumericDecision
 
isReadOnly() - Method in class com.cloudera.oryx.api.serving.AbstractServingModelManager
 
isReadOnly() - Method in interface com.cloudera.oryx.api.serving.ServingModelManager
 
isReadOnly() - Method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
isReadOnly() - Method in class com.cloudera.oryx.lambda.serving.ScalaServingModelManagerAdapter
 
isTarget(String) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isTarget(int) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
isTerminal() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionNode
 
isTerminal() - Method in class com.cloudera.oryx.app.rdf.tree.TerminalNode
 
isTerminal() - Method in class com.cloudera.oryx.app.rdf.tree.TreeNode
 
isWriteable(Class<?>, Type, Annotation[], MediaType) - Method in class com.cloudera.oryx.lambda.serving.CSVMessageBodyWriter
 

J

joinDelimited(Iterable<?>, char) - Static method in class com.cloudera.oryx.common.text.TextUtils
 
joinJSON(Iterable<?>) - Static method in class com.cloudera.oryx.common.text.TextUtils
 
joinPMMLDelimited(Iterable<?>) - Static method in class com.cloudera.oryx.common.text.TextUtils
 
joinPMMLDelimitedNumbers(Iterable<? extends Number>) - Static method in class com.cloudera.oryx.common.text.TextUtils
 
JVMUtils - Class in com.cloudera.oryx.common.lang
JVM-related utility methods.

K

KafkaUtils - Class in com.cloudera.oryx.kafka.util
Kafka-related utility methods.
KeyMessage<K,M> - Interface in com.cloudera.oryx.api
Simple interface encapsulating a key and message in a topic.
KeyMessageImpl<K,M> - Class in com.cloudera.oryx.api
Simple value class encapsulating a key and message in a topic.
KeyMessageImpl(K, M) - Constructor for class com.cloudera.oryx.api.KeyMessageImpl
 
keyValueToProperties(Object...) - Static method in class com.cloudera.oryx.common.settings.ConfigUtils
 
KMeansEvalStrategy - Enum in com.cloudera.oryx.app.batch.mllib.kmeans
Evaluation metrics for k-means clustering.
KMeansPMMLUtils - Class in com.cloudera.oryx.app.kmeans
Utility methods related to PMML serialization of k-means clustering models.
KMeansServingModel - Class in com.cloudera.oryx.app.serving.kmeans.model
Contains all data structures needed to serve queries for a k-means clustering application.
KMeansServingModelManager - Class in com.cloudera.oryx.app.serving.kmeans.model
A ServingModelManager that manages and provides access to an KMeansServingModel for the k-means Serving Layer application.
KMeansServingModelManager(Config) - Constructor for class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModelManager
 
KMeansSpeedModel - Class in com.cloudera.oryx.app.speed.kmeans
Contains all data structures needed to create near-real-time updates for a k-means clustering model.
KMeansSpeedModel(List<ClusterInfo>) - Constructor for class com.cloudera.oryx.app.speed.kmeans.KMeansSpeedModel
 
KMeansSpeedModelManager - Class in com.cloudera.oryx.app.speed.kmeans
Implementation of SpeedModelManager that maintains and updates an k-means clustering model in memory.
KMeansSpeedModelManager(Config) - Constructor for class com.cloudera.oryx.app.speed.kmeans.KMeansSpeedModelManager
 
KMeansUpdate - Class in com.cloudera.oryx.app.batch.mllib.kmeans
Update function that builds and evaluates k-means models in the Batch Layer.
KMeansUpdate(Config) - Constructor for class com.cloudera.oryx.app.batch.mllib.kmeans.KMeansUpdate
 
KMeansUtils - Class in com.cloudera.oryx.app.kmeans
K-means-related utility methods for the app tier.
KnownItems - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /knownItems/[userID].
KnownItems() - Constructor for class com.cloudera.oryx.app.serving.als.KnownItems
 

L

LinearSystemSolver - Class in com.cloudera.oryx.common.math
An implementation based on RRQRDecomposition from Commons Math.
listFiles(Path, String) - Static method in class com.cloudera.oryx.common.io.IOUtils
 
loadClass(String) - Static method in class com.cloudera.oryx.common.lang.ClassUtils
 
loadClass(String, Class<T>) - Static method in class com.cloudera.oryx.common.lang.ClassUtils
 
loadHTML() - Method in class com.cloudera.oryx.app.serving.AbstractConsoleResource
 
loadInstanceOf(Class<T>) - Static method in class com.cloudera.oryx.common.lang.ClassUtils
Like ClassUtils.loadInstanceOf(String, Class) where the reference returned is of the same type as the class being loaded -- not any supertype.
loadInstanceOf(String, Class<T>) - Static method in class com.cloudera.oryx.common.lang.ClassUtils
loadInstanceOf(String, Class<T>, Class<?>[], Object[]) - Static method in class com.cloudera.oryx.common.lang.ClassUtils
Loads and instantiates a named implementation class, a subclass of a given supertype, whose constructor takes the given arguments.
lock() - Method in class com.cloudera.oryx.common.lang.AutoLock
 
lockInterruptibly() - Method in class com.cloudera.oryx.common.lang.AutoLock
 
log(Callable<V>) - Static method in class com.cloudera.oryx.common.lang.LoggingCallable
 
log(LoggingCallable.AllowExceptionSupplier) - Static method in class com.cloudera.oryx.common.lang.LoggingCallable
 
LoggingCallable<V> - Class in com.cloudera.oryx.common.lang
A Callable that logs errors thrown from LoggingCallable.call().
LoggingCallable.AllowExceptionSupplier - Interface in com.cloudera.oryx.common.lang
Like Supplier but allows Exception from Supplier.get().

M

Main - Class in com.cloudera.oryx.batch
Runs BatchLayer from the command line.
main(String[]) - Static method in class com.cloudera.oryx.batch.Main
 
main(String[]) - Static method in class com.cloudera.oryx.common.settings.ConfigToProperties
 
Main - Class in com.cloudera.oryx.serving
Runs ServingLayer from the command line.
main(String[]) - Static method in class com.cloudera.oryx.serving.Main
 
Main - Class in com.cloudera.oryx.speed
Runs SpeedLayer from the command line.
main(String[]) - Static method in class com.cloudera.oryx.speed.Main
 
makePrediction(String[]) - Method in class com.cloudera.oryx.app.serving.rdf.model.RDFServingModel
 
mapPartitionsParallel(Function<FeatureVectorsPartition, Stream<T>>, boolean) - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
mapPartitionsParallel(Function<FeatureVectorsPartition, Stream<T>>, int[], boolean) - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
maybeBuffer(InputStream) - Static method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
maybeBuffer(Reader) - Static method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
maybeCreateTopic(String, String, int) - Static method in class com.cloudera.oryx.kafka.util.KafkaUtils
 
maybeCreateTopic(String, String, int, Properties) - Static method in class com.cloudera.oryx.kafka.util.KafkaUtils
 
maybeDecompress(Part) - Static method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
MLFunctions - Class in com.cloudera.oryx.app.common.fn
Contains some reusable functions that are useful for ML-related apps from this project itself, and based on MLlib too.
MLUpdate<M> - Class in com.cloudera.oryx.ml
A specialization of BatchLayerUpdate for machine learning-oriented update processes.
MLUpdate(Config) - Constructor for class com.cloudera.oryx.ml.MLUpdate
 
MODEL_FILE_NAME - Static variable in class com.cloudera.oryx.ml.MLUpdate
 
MODEL_MANAGER_KEY - Static variable in class com.cloudera.oryx.api.serving.OryxResource
 
ModelManagerListener<K,M,U> - Class in com.cloudera.oryx.lambda.serving
ServletContextListener that initializes a ServingModelManager at web app startup time in the Serving Layer.
ModelManagerListener() - Constructor for class com.cloudera.oryx.lambda.serving.ModelManagerListener
 
MostActiveUsers - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /mostActiveUsers(?howMany=n)(&offset=o)(&rescorerParams=...)
MostActiveUsers() - Constructor for class com.cloudera.oryx.app.serving.als.MostActiveUsers
 
MostPopularItems - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /mostPopularItems(?howMany=n)(&offset=o)(&rescorerParams=...)
MostPopularItems() - Constructor for class com.cloudera.oryx.app.serving.als.MostPopularItems
 
MostSurprising - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /mostSurprising/[userID](?howMany=n)(?offset=o).
MostSurprising() - Constructor for class com.cloudera.oryx.app.serving.als.MostSurprising
 
MultiRescorer - Class in com.cloudera.oryx.app.als
Convenience implementation that will aggregate the behavior of multiple Rescorers.
MultiRescorerProvider - Class in com.cloudera.oryx.app.als
Convenience implementation that will aggregate the behavior of RescorerProviders.

N

nearestClusterID(String[]) - Method in interface com.cloudera.oryx.app.serving.clustering.model.ClusteringServingModel
 
nearestClusterID(String[]) - Method in class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModel
 
newCondition() - Method in class com.cloudera.oryx.common.lang.AutoLock
 
norm(float[]) - Static method in class com.cloudera.oryx.common.math.VectorMath
 
norm(double[]) - Static method in class com.cloudera.oryx.common.math.VectorMath
 
NumericDecision - Class in com.cloudera.oryx.app.rdf.decision
Represents a decision over a numeric feature.
NumericDecision(int, double, boolean) - Constructor for class com.cloudera.oryx.app.rdf.decision.NumericDecision
 
NumericFeature - Class in com.cloudera.oryx.app.classreg.example
Represents the value of a numeric feature -- one that takes on a real value, whether conceptually discrete or continuous.
NumericPrediction - Class in com.cloudera.oryx.app.classreg.predict
Represents a predicted value of a numeric target.
NumericPrediction(double, int) - Constructor for class com.cloudera.oryx.app.classreg.predict.NumericPrediction
 

O

of(Rescorer...) - Static method in class com.cloudera.oryx.app.als.MultiRescorer
 
of(RescorerProvider...) - Static method in class com.cloudera.oryx.app.als.MultiRescorerProvider
 
orderByFirst(Pairs.SortOrder) - Static method in class com.cloudera.oryx.common.collection.Pairs
 
orderBySecond(Pairs.SortOrder) - Static method in class com.cloudera.oryx.common.collection.Pairs
 
OryxApplication - Class in com.cloudera.oryx.lambda.serving
The single JAX-RS app for the serving-layer.
OryxApplication() - Constructor for class com.cloudera.oryx.lambda.serving.OryxApplication
 
OryxExceptionMapper - Class in com.cloudera.oryx.lambda.serving
Maps OryxServingException types to an HTTP Response.
OryxExceptionMapper() - Constructor for class com.cloudera.oryx.lambda.serving.OryxExceptionMapper
 
OryxResource - Class in com.cloudera.oryx.api.serving
A utility class that can serve as a superclass of Serving Layer application endpoints.
OryxResource() - Constructor for class com.cloudera.oryx.api.serving.OryxResource
 
OryxServingException - Exception in com.cloudera.oryx.api.serving
Thrown by Serving Layer endpoints to indicate an error in processing.
OryxServingException(Response.Status) - Constructor for exception com.cloudera.oryx.api.serving.OryxServingException
 
OryxServingException(Response.Status, String) - Constructor for exception com.cloudera.oryx.api.serving.OryxServingException
 
OryxShutdownHook - Class in com.cloudera.oryx.common.lang
Intended for use with Runtime.addShutdownHook(Thread) or similar mechanisms, this is a Runnable that is configured with a list of Closeables that are to be closed at shutdown, when its OryxShutdownHook.run() is called.
OryxShutdownHook() - Constructor for class com.cloudera.oryx.common.lang.OryxShutdownHook
 
overlayOn(Map<String, ?>, Config) - Static method in class com.cloudera.oryx.common.settings.ConfigUtils
 

P

Pair<A,B> - Class in com.cloudera.oryx.common.collection
Encapsulates a pair of objects.
Pair(A, B) - Constructor for class com.cloudera.oryx.common.collection.Pair
 
Pairs - Class in com.cloudera.oryx.common.collection
Pair-related utilities.
Pairs.SortOrder - Enum in com.cloudera.oryx.common.collection
Sort ordering for Pairs.
PARSE_FN - Static variable in class com.cloudera.oryx.app.common.fn.MLFunctions
Parses a CSV or JSON array to String[]
parseDelimited(String, char) - Static method in class com.cloudera.oryx.common.text.TextUtils
 
parseJSONArray(String) - Static method in class com.cloudera.oryx.common.text.TextUtils
 
parseMultipart(HttpServletRequest) - Method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
parsePMMLDelimited(String) - Static method in class com.cloudera.oryx.common.text.TextUtils
 
parseVector(String[]) - Static method in class com.cloudera.oryx.common.math.VectorMath
 
PartitionedFeatureVectors - Class in com.cloudera.oryx.app.als
Encapsulates a feature vectors, keyed by an ID, and associated data structures.
PartitionedFeatureVectors(int, ExecutorService) - Constructor for class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
PartitionedFeatureVectors(int, ExecutorService, ToIntBiFunction<String, float[]>) - Constructor for class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
PMMLUtils - Class in com.cloudera.oryx.common.pmml
PMML-related utility methods.
PopularRepresentativeItems - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /popularRepresentativeItems.
PopularRepresentativeItems() - Constructor for class com.cloudera.oryx.app.serving.als.PopularRepresentativeItems
 
post(Reader) - Method in class com.cloudera.oryx.app.serving.als.Ingest
 
post(HttpServletRequest) - Method in class com.cloudera.oryx.app.serving.als.Ingest
 
post(String, String, Reader) - Method in class com.cloudera.oryx.app.serving.als.Preference
 
post(Reader) - Method in class com.cloudera.oryx.app.serving.classreg.Predict
 
post(HttpServletRequest) - Method in class com.cloudera.oryx.app.serving.classreg.Predict
 
post(Reader) - Method in class com.cloudera.oryx.app.serving.classreg.Train
 
post(String) - Method in class com.cloudera.oryx.app.serving.classreg.Train
 
post(HttpServletRequest) - Method in class com.cloudera.oryx.app.serving.classreg.Train
 
post(Reader) - Method in class com.cloudera.oryx.app.serving.clustering.Add
 
post(String) - Method in class com.cloudera.oryx.app.serving.clustering.Add
 
post(HttpServletRequest) - Method in class com.cloudera.oryx.app.serving.clustering.Add
 
post(Reader) - Method in class com.cloudera.oryx.app.serving.clustering.Assign
 
post(HttpServletRequest) - Method in class com.cloudera.oryx.app.serving.clustering.Assign
 
post(Reader) - Method in class com.cloudera.oryx.example.serving.Add
 
predict(Example) - Method in class com.cloudera.oryx.app.rdf.tree.DecisionForest
 
predict(Example) - Method in class com.cloudera.oryx.app.rdf.tree.DecisionTree
 
predict(Example) - Method in interface com.cloudera.oryx.app.rdf.tree.TreeBasedClassifier
 
predict(String[]) - Method in interface com.cloudera.oryx.app.serving.classreg.model.ClassificationRegressionServingModel
 
Predict - Class in com.cloudera.oryx.app.serving.classreg
Responds to a GET request to /predict/[datum], or a POST to /predict containing several data points, one on each line.
Predict() - Constructor for class com.cloudera.oryx.app.serving.classreg.Predict
 
predict(String[]) - Method in class com.cloudera.oryx.app.serving.rdf.model.RDFServingModel
 
Prediction - Class in com.cloudera.oryx.app.classreg.predict
Subclasses represent the predicted value of the target.
predictorToFeatureIndex(int) - Method in class com.cloudera.oryx.app.schema.InputSchema
 
Preference - Class in com.cloudera.oryx.app.serving.als
Responds to a POST request to /pref/[userID]/[itemID].
Preference() - Constructor for class com.cloudera.oryx.app.serving.als.Preference
 
prettyPrint(Config) - Static method in class com.cloudera.oryx.common.settings.ConfigUtils
 
publishAdditionalModelData(JavaSparkContext, PMML, JavaRDD<String>, JavaRDD<String>, Path, TopicProducer<String, String>) - Method in class com.cloudera.oryx.app.batch.mllib.als.ALSUpdate
 
publishAdditionalModelData(JavaSparkContext, PMML, JavaRDD<M>, JavaRDD<M>, Path, TopicProducer<String, String>) - Method in class com.cloudera.oryx.ml.MLUpdate
Optionally, publish additional model-related information to the update topic, after the model has been written.

R

RandomManager - Class in com.cloudera.oryx.common.random
Manages random number generation.
randomVectorF(int, RandomGenerator) - Static method in class com.cloudera.oryx.common.math.VectorMath
 
range(double, double) - Static method in class com.cloudera.oryx.ml.param.HyperParams
 
range(int, int) - Static method in class com.cloudera.oryx.ml.param.HyperParams
 
RateLimitCheck - Class in com.cloudera.oryx.common.lang
A utility that exposes a RateLimitCheck.test() method which returns true first, and then return false for all subsequent invocations within the given time interval afterwards.
RateLimitCheck(long, TimeUnit) - Constructor for class com.cloudera.oryx.common.lang.RateLimitCheck
 
RDFPMMLUtils - Class in com.cloudera.oryx.app.rdf
Utility methods related to PMML serialization of random decision forest classification and regression models.
RDFServingModel - Class in com.cloudera.oryx.app.serving.rdf.model
Contains all data structures needed to serve queries for a random decision forest-based classifier or regressor.
RDFServingModelManager - Class in com.cloudera.oryx.app.serving.rdf.model
A ServingModelManager that manages and provides access to an RDFServingModel for the random decision forest Serving Layer application.
RDFServingModelManager(Config) - Constructor for class com.cloudera.oryx.app.serving.rdf.model.RDFServingModelManager
 
RDFSpeedModel - Class in com.cloudera.oryx.app.speed.rdf
Contains all data structures needed to create near-real-time updates for a random decision forest-based classifier or regressor.
RDFSpeedModelManager - Class in com.cloudera.oryx.app.speed.rdf
Implementation of SpeedModelManager that maintains and updates a random decision forest model in memory.
RDFSpeedModelManager(Config) - Constructor for class com.cloudera.oryx.app.speed.rdf.RDFSpeedModelManager
 
RDFUpdate - Class in com.cloudera.oryx.app.batch.mllib.rdf
Update function that builds and evaluates random decision forest models in the Batch Layer.
RDFUpdate(Config) - Constructor for class com.cloudera.oryx.app.batch.mllib.rdf.RDFUpdate
 
read(PMML) - Static method in class com.cloudera.oryx.app.kmeans.KMeansPMMLUtils
 
read(PMML) - Static method in class com.cloudera.oryx.app.rdf.RDFPMMLUtils
 
read(Path) - Static method in class com.cloudera.oryx.common.pmml.PMMLUtils
 
read(InputStream) - Static method in class com.cloudera.oryx.common.pmml.PMMLUtils
 
readJSON(String, Class<T>) - Static method in class com.cloudera.oryx.common.text.TextUtils
 
readLock() - Method in class com.cloudera.oryx.common.lang.AutoReadWriteLock
 
readPMMLFromUpdateKeyMessage(String, String, Configuration) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
Ready - Class in com.cloudera.oryx.app.serving
Responds to a HEAD or GET request to /ready and returns Response.Status#OK or Response.Status#SERVICE_UNAVAILABLE status depending or whether the model is available or not.
Ready() - Constructor for class com.cloudera.oryx.app.serving.Ready
 
Recommend - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /recommend/[userID](?howMany=n)(&offset=o)(&considerKnownItems=c)(&rescorerParams=...)
Recommend() - Constructor for class com.cloudera.oryx.app.serving.als.Recommend
 
RecommendToAnonymous - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /recommendToAnonymous/[itemID1(=value1)](/[itemID2(=value2)]/...)(?howMany=n)(&offset=o)(&rescorerParams=...)
RecommendToAnonymous() - Constructor for class com.cloudera.oryx.app.serving.als.RecommendToAnonymous
 
RecommendToMany - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /recommendToMany/[userID1](/[userID2]/...)(?howMany=n)(&offset=o)(&considerKnownItems=c)(&rescorerParams=...)
RecommendToMany() - Constructor for class com.cloudera.oryx.app.serving.als.RecommendToMany
 
RecommendWithContext - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /recommendWithContext/[userID]/([itemID1(=value1)]/...) (?howMany=n)(&offset=o)(&considerKnownItems=c)(&rescorerParams=...)
RecommendWithContext() - Constructor for class com.cloudera.oryx.app.serving.als.RecommendWithContext
 
removeAllIDsFrom(Collection<String>) - Method in interface com.cloudera.oryx.app.als.FeatureVectors
Removes all IDs that are mapped to a feature vector from a given collection
removeAllIDsFrom(Collection<String>) - Method in class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
removeAllIDsFrom(Collection<String>) - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
rescore(String, double) - Method in class com.cloudera.oryx.app.als.MultiRescorer
 
rescore(String, double) - Method in interface com.cloudera.oryx.app.als.Rescorer
 
Rescorer - Interface in com.cloudera.oryx.app.als
Implementations of this interface can "rescore" the recommender's score for a item that is a candidate for recommendation.
RescorerProvider - Interface in com.cloudera.oryx.app.als
Implementations of this interface provide, optionally, objects that can be used to modify and influence the results of endpoints like Recommend, Similarity, etc.
retainRecentAndIDs(Collection<String>) - Method in interface com.cloudera.oryx.app.als.FeatureVectors
Given IDs that are part of a new model, and whose values are going to be sent later, retain only IDs that are also in the new model (or have been recently seen -- possibly since last model was built), and remove the rest.
retainRecentAndIDs(Collection<String>) - Method in class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
retainRecentAndIDs(Collection<String>) - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
retainRecentAndItemIDs(Collection<String>) - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
retainRecentAndUserIDs(Collection<String>) - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
run() - Method in class com.cloudera.oryx.common.lang.OryxShutdownHook
 
runUpdate(JavaSparkContext, long, JavaPairRDD<K, M>, JavaPairRDD<K, M>, String, TopicProducer<String, U>) - Method in interface com.cloudera.oryx.api.batch.BatchLayerUpdate
 
runUpdate(JavaSparkContext, long, JavaPairRDD<String, String>, JavaPairRDD<String, String>, String, TopicProducer<String, String>) - Method in class com.cloudera.oryx.example.batch.ExampleBatchLayerUpdate
 
runUpdate(JavaSparkContext, long, JavaPairRDD<K, M>, JavaPairRDD<K, M>, String, TopicProducer<String, U>) - Method in class com.cloudera.oryx.lambda.batch.ScalaBatchLayerUpdateAdapter
 
runUpdate(JavaSparkContext, long, JavaPairRDD<Object, M>, JavaPairRDD<Object, M>, String, TopicProducer<String, String>) - Method in class com.cloudera.oryx.ml.MLUpdate
 

S

ScalaBatchLayerUpdateAdapter<K,M,U> - Class in com.cloudera.oryx.lambda.batch
Adapts a ScalaBatchLayerUpdate to be a Java BatchLayerUpdate.
ScalaBatchLayerUpdateAdapter(ScalaBatchLayerUpdate<K, M, U>) - Constructor for class com.cloudera.oryx.lambda.batch.ScalaBatchLayerUpdateAdapter
 
ScalaServingModelManagerAdapter<U> - Class in com.cloudera.oryx.lambda.serving
Adapts a ScalaServingModelManager to be a Java ServingModelManager.
ScalaServingModelManagerAdapter(ScalaServingModelManager<U>) - Constructor for class com.cloudera.oryx.lambda.serving.ScalaServingModelManagerAdapter
 
ScalaSpeedModelManagerAdapter<K,M,U> - Class in com.cloudera.oryx.lambda.speed
Adapts a ScalaSpeedModelManager to be a Java SpeedModelManager.
ScalaSpeedModelManagerAdapter(ScalaSpeedModelManager<K, M, U>) - Constructor for class com.cloudera.oryx.lambda.speed.ScalaSpeedModelManagerAdapter
 
send(K, M) - Method in interface com.cloudera.oryx.api.TopicProducer
 
send(K, M) - Method in class com.cloudera.oryx.lambda.serving.TopicProducerImpl
 
send(K, M) - Method in class com.cloudera.oryx.lambda.TopicProducerImpl
 
sendInput(String) - Method in class com.cloudera.oryx.app.serving.AbstractOryxResource
 
serialize(Config) - Static method in class com.cloudera.oryx.common.settings.ConfigUtils
 
ServingLayer - Class in com.cloudera.oryx.lambda.serving
Top-level implementation of the Serving Layer process.
ServingLayer(Config) - Constructor for class com.cloudera.oryx.lambda.serving.ServingLayer
Creates a new instance with the given configuration.
ServingModel - Interface in com.cloudera.oryx.api.serving
Interface that all Serving Layer in-memory models implement.
ServingModelManager<U> - Interface in com.cloudera.oryx.api.serving
Implementations of this interface maintain, in memory, the current state of a model in the serving layer.
set(Map<String, Object>, String, Path) - Static method in class com.cloudera.oryx.common.settings.ConfigUtils
Helper to set a Path value correctly for use with ConfigUtils.overlayOn(Map,Config).
setCluster(int, ClusterInfo) - Method in class com.cloudera.oryx.app.speed.kmeans.KMeansSpeedModel
 
setDirty() - Method in class com.cloudera.oryx.app.als.SolverCache
Indicates that the underlying FeatureVectors have changed and so the resulting Solver should be recomputed.
setItemVector(String, float[]) - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
setOffsets(String, String, Map<Pair<String, Integer>, Long>) - Static method in class com.cloudera.oryx.kafka.util.KafkaUtils
 
setUserVector(String, float[]) - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
setVector(String, float[]) - Method in interface com.cloudera.oryx.app.als.FeatureVectors
Sets the value of a feature vector for an ID.
setVector(String, float[]) - Method in class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
setVector(String, float[]) - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
Similarity - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /similarity/[itemID1](/[itemID2]/...)(?howMany=n)(&offset=o)(&rescorerParams=...)
Similarity() - Constructor for class com.cloudera.oryx.app.serving.als.Similarity
 
SimilarityToItem - Class in com.cloudera.oryx.app.serving.als
Responds to a GET request to /similarityToItem/[toItemID]/[itemID1](/[itemID2]/...).
SimilarityToItem() - Constructor for class com.cloudera.oryx.app.serving.als.SimilarityToItem
 
SingularMatrixSolverException - Exception in com.cloudera.oryx.common.math
Throws when a system can't be solved because the input matrix is singular or near-singular.
SingularMatrixSolverException(int, String) - Constructor for exception com.cloudera.oryx.common.math.SingularMatrixSolverException
 
size() - Method in interface com.cloudera.oryx.app.als.FeatureVectors
 
size() - Method in class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
size() - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
solveDToD(double[]) - Method in class com.cloudera.oryx.common.math.Solver
 
solveFToF(float[]) - Method in class com.cloudera.oryx.common.math.Solver
 
Solver - Class in com.cloudera.oryx.common.math
Encapsulates a DecompositionSolver from Commons Math.
SolverCache - Class in com.cloudera.oryx.app.als
A cache around a Solver that manages computing it when necessary from FeatureVectors, tracking when it must be recomputed, and doing so correctly in the presence of multiple threads.
SolverCache(Executor, FeatureVectors) - Constructor for class com.cloudera.oryx.app.als.SolverCache
 
SpeedLayer<K,M,U> - Class in com.cloudera.oryx.lambda.speed
Main entry point for Oryx Speed Layer.
SpeedLayer(Config) - Constructor for class com.cloudera.oryx.lambda.speed.SpeedLayer
 
SpeedModel - Interface in com.cloudera.oryx.api.speed
Interface that all Speed Layer in-memory models implement.
SpeedModelManager<K,M,U> - Interface in com.cloudera.oryx.api.speed
Implementations of this interface maintain, in memory, the current state of a model in the speed layer.
splitNewDataToTrainTest(JavaRDD<String>) - Method in class com.cloudera.oryx.app.batch.mllib.als.ALSUpdate
Implementation which splits based solely on time.
splitNewDataToTrainTest(JavaRDD<M>) - Method in class com.cloudera.oryx.ml.MLUpdate
Default implementation which randomly splits new data into train/test sets.
start() - Method in class com.cloudera.oryx.lambda.batch.BatchLayer
 
start() - Method in class com.cloudera.oryx.lambda.serving.ServingLayer
 
start() - Method in class com.cloudera.oryx.lambda.speed.SpeedLayer
 
SUM_WITH_NAN - Static variable in class com.cloudera.oryx.app.common.fn.MLFunctions
 

T

TerminalNode - Class in com.cloudera.oryx.app.rdf.tree
Represents a leaf node in a DecisionTree, which contains a Prediction for a target rather than a decision over an example.
TerminalNode(String, Prediction) - Constructor for class com.cloudera.oryx.app.rdf.tree.TerminalNode
 
test() - Method in class com.cloudera.oryx.common.lang.RateLimitCheck
 
TextUtils - Class in com.cloudera.oryx.common.text
Text and parsing related utility methods.
TO_TIMESTAMP_FN - Static variable in class com.cloudera.oryx.app.common.fn.MLFunctions
Parses as if with PARSE_FN and returns fourth field as timestamp
toArray(double...) - Static method in class com.cloudera.oryx.app.pmml.AppPMMLUtils
 
toCSV() - Method in interface com.cloudera.oryx.api.serving.HasCSV
 
ToDoubleObjDoubleBiFunction<T> - Interface in com.cloudera.oryx.common.lang
Analogous to both ToDoubleBiFunction and ObjDoubleConsumer, combined.
topicExists(String, String) - Static method in class com.cloudera.oryx.kafka.util.KafkaUtils
 
TopicProducer<K,M> - Interface in com.cloudera.oryx.api
Wraps access to a message topic Producer, including logic to instantiate the object.
TopicProducerImpl<K,M> - Class in com.cloudera.oryx.lambda.serving
Wraps access to a Kafka message topic Producer.
TopicProducerImpl(String, String) - Constructor for class com.cloudera.oryx.lambda.serving.TopicProducerImpl
 
TopicProducerImpl<K,M> - Class in com.cloudera.oryx.lambda
Wraps access to a Kafka message topic Producer.
TopicProducerImpl(String, String, boolean) - Constructor for class com.cloudera.oryx.lambda.TopicProducerImpl
 
topN(CosineDistanceSensitiveFunction, ToDoubleObjDoubleBiFunction<String>, int, Predicate<String>) - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
toResponse(OryxServingException) - Method in class com.cloudera.oryx.lambda.serving.OryxExceptionMapper
 
toString() - Method in class com.cloudera.oryx.api.KeyMessageImpl
 
toString() - Method in class com.cloudera.oryx.app.als.FeatureVectorsPartition
 
toString() - Method in class com.cloudera.oryx.app.als.PartitionedFeatureVectors
 
toString() - Method in class com.cloudera.oryx.app.classreg.example.CategoricalFeature
 
toString() - Method in class com.cloudera.oryx.app.classreg.example.Example
 
toString() - Method in class com.cloudera.oryx.app.classreg.example.NumericFeature
 
toString() - Method in class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
toString() - Method in class com.cloudera.oryx.app.classreg.predict.NumericPrediction
 
toString() - Method in class com.cloudera.oryx.app.classreg.predict.Prediction
 
toString() - Method in class com.cloudera.oryx.app.kmeans.ClusterInfo
 
toString() - Method in class com.cloudera.oryx.app.rdf.decision.CategoricalDecision
 
toString() - Method in class com.cloudera.oryx.app.rdf.decision.Decision
 
toString() - Method in class com.cloudera.oryx.app.rdf.decision.NumericDecision
 
toString() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionForest
 
toString() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionNode
 
toString() - Method in class com.cloudera.oryx.app.rdf.tree.DecisionTree
 
toString() - Method in class com.cloudera.oryx.app.rdf.tree.TerminalNode
 
toString() - Method in class com.cloudera.oryx.app.rdf.tree.TreeNode
 
toString() - Method in class com.cloudera.oryx.app.schema.CategoricalValueEncodings
 
toString() - Method in class com.cloudera.oryx.app.schema.InputSchema
 
toString() - Method in class com.cloudera.oryx.app.serving.als.model.ALSServingModel
 
toString() - Method in class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModel
 
toString() - Method in class com.cloudera.oryx.app.serving.rdf.model.RDFServingModel
 
toString() - Method in class com.cloudera.oryx.app.speed.als.ALSSpeedModel
 
toString() - Method in class com.cloudera.oryx.app.speed.kmeans.KMeansSpeedModel
 
toString() - Method in class com.cloudera.oryx.app.speed.rdf.RDFSpeedModel
 
toString() - Method in class com.cloudera.oryx.common.collection.Pair
 
toString() - Method in class com.cloudera.oryx.common.lang.AutoLock
 
toString() - Method in class com.cloudera.oryx.common.lang.AutoReadWriteLock
 
toString() - Method in class com.cloudera.oryx.common.math.DoubleWeightedMean
 
toString() - Method in class com.cloudera.oryx.common.math.Solver
 
toString(PMML) - Static method in class com.cloudera.oryx.common.pmml.PMMLUtils
 
Train - Class in com.cloudera.oryx.app.serving.classreg
Responds to POST request to /train.
Train() - Constructor for class com.cloudera.oryx.app.serving.classreg.Train
 
transposeTimesSelf(Collection<float[]>) - Static method in class com.cloudera.oryx.common.math.VectorMath
 
TreeBasedClassifier - Interface in com.cloudera.oryx.app.rdf.tree
Base interface for decision-tree-based classifiers in this package, whether they be a single DecisionTree or a collection of them as a DecisionForest.
TreeNode - Class in com.cloudera.oryx.app.rdf.tree
Implementations of this interface represent nodes in a DecisionTree, whether leaves (TerminalNode) or internal nodes (DecisionNode).
tryLock() - Method in class com.cloudera.oryx.common.lang.AutoLock
 
tryLock(long, TimeUnit) - Method in class com.cloudera.oryx.common.lang.AutoLock
 

U

unlock() - Method in class com.cloudera.oryx.common.lang.AutoLock
 
unorderedFromValues(Collection<T>) - Static method in class com.cloudera.oryx.ml.param.HyperParams
 
update(Example) - Method in class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
update(int, int) - Method in class com.cloudera.oryx.app.classreg.predict.CategoricalPrediction
 
update(Example) - Method in class com.cloudera.oryx.app.classreg.predict.NumericPrediction
 
update(double, int) - Method in class com.cloudera.oryx.app.classreg.predict.NumericPrediction
 
update(Example) - Method in class com.cloudera.oryx.app.classreg.predict.Prediction
 
update(double[], long) - Method in class com.cloudera.oryx.app.kmeans.ClusterInfo
 
update(Example) - Method in class com.cloudera.oryx.app.rdf.tree.DecisionForest
 
update(Example) - Method in class com.cloudera.oryx.app.rdf.tree.DecisionTree
 
update(Example) - Method in class com.cloudera.oryx.app.rdf.tree.TerminalNode
 
update(Example) - Method in interface com.cloudera.oryx.app.rdf.tree.TreeBasedClassifier
Requests that the implementation update its internal state to reflect a new Example.
update(int, double[], long) - Method in class com.cloudera.oryx.app.serving.kmeans.model.KMeansServingModel
 
UpdateOffsetsFn<T> - Class in com.cloudera.oryx.lambda
Function that reads offset range from latest RDD in a streaming job, and updates Zookeeper/Kafka with the latest offset consumed.
UpdateOffsetsFn(String, String) - Constructor for class com.cloudera.oryx.lambda.UpdateOffsetsFn
 
useTestSeed() - Static method in class com.cloudera.oryx.common.random.RandomManager
Only call in test code. Causes all known instances of RandomGenerator, and future ones, to be started from a fixed seed.

V

validatePMMLVsSchema(PMML, InputSchema) - Static method in class com.cloudera.oryx.app.kmeans.KMeansPMMLUtils
Validates that the encoded PMML model received matches expected schema.
validatePMMLVsSchema(PMML, InputSchema) - Static method in class com.cloudera.oryx.app.rdf.RDFPMMLUtils
Validates that the encoded PMML model received matches expected schema.
valueOf(String) - Static method in enum com.cloudera.oryx.app.batch.mllib.kmeans.KMeansEvalStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.oryx.app.classreg.example.FeatureType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.cloudera.oryx.common.collection.Pairs.SortOrder
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.cloudera.oryx.app.batch.mllib.kmeans.KMeansEvalStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.oryx.app.classreg.example.FeatureType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.cloudera.oryx.common.collection.Pairs.SortOrder
Returns an array containing the constants of this enum type, in the order they are declared.
valueString() - Method in class com.cloudera.oryx.app.serving.IDCount
 
valueString() - Method in class com.cloudera.oryx.app.serving.IDValue
 
VectorMath - Class in com.cloudera.oryx.common.math
Utility class with simple vector-related operations.
VERSION - Static variable in class com.cloudera.oryx.common.pmml.PMMLUtils
 
voteOnFeature(List<T>, double[]) - Static method in class com.cloudera.oryx.app.classreg.predict.WeightedPrediction
 

W

WeightedPrediction - Class in com.cloudera.oryx.app.classreg.predict
A utility class with methods for combining the results of many TreeBasedClassifiers into one prediction -- in particular, it is used by DecisionForest to combine the results of many DecisionTrees.
write(PMML, Path) - Static method in class com.cloudera.oryx.common.pmml.PMMLUtils
 
write(PMML, OutputStream) - Static method in class com.cloudera.oryx.common.pmml.PMMLUtils
 
writeLock() - Method in class com.cloudera.oryx.common.lang.AutoReadWriteLock
 
writeTo(Object, Class<?>, Type, Annotation[], MediaType, MultivaluedMap<String, Object>, OutputStream) - Method in class com.cloudera.oryx.lambda.serving.CSVMessageBodyWriter
 
A B C D E F G H I J K L M N O P R S T U V W 
Skip navigation links

Copyright © 2014–2018. All rights reserved.