Object/Class

org.apache.flink.ml.recommendation

ALS

Related Docs: class ALS | package recommendation

Permalink

object ALS

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ALS
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. class BlockIDGenerator extends Serializable

    Permalink
  2. class BlockIDPartitioner extends Partitioner[Int]

    Permalink
  3. case class BlockRating(ratings: Array[(Array[Int], Array[Double])]) extends Product with Serializable

    Permalink
  4. case class BlockedFactorization(userFactors: DataSet[(Int, Array[Array[Double]])], itemFactors: DataSet[(Int, Array[Array[Double]])]) extends Product with Serializable

    Permalink
  5. case class Factorization(userFactors: DataSet[Factors], itemFactors: DataSet[Factors]) extends Product with Serializable

    Permalink
  6. case class Factors(id: Long, factors: Array[Double]) extends Product with Serializable

    Permalink

    Latent factor model vector

  7. case class InBlockInformation(elementIDs: Array[Long], ratingsForBlock: Array[BlockRating]) extends Product with Serializable

    Permalink
  8. case class OutBlockInformation(elementIDs: Array[Long], outLinks: OutLinks) extends Product with Serializable

    Permalink
  9. class OutLinks extends Value

    Permalink
  10. case class Rating(user: Long, item: Long, rating: Double) extends Product with Serializable

    Permalink

    Representation of a user-item rating

    Representation of a user-item rating

    user

    User ID of the rating user

    item

    Item iD of the rated item

    rating

    Rating value

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. object Blocks extends Parameter[Int] with Product with Serializable

    Permalink
  5. val ITEM_FACTORS_FILE: String

    Permalink
  6. object Iterations extends Parameter[Int] with Product with Serializable

    Permalink
  7. object Lambda extends Parameter[Double] with Product with Serializable

    Permalink
  8. object NumFactors extends Parameter[Int] with Product with Serializable

    Permalink
  9. object Seed extends Parameter[Long] with Product with Serializable

    Permalink
  10. object TemporaryPath extends Parameter[String] with Product with Serializable

    Permalink
  11. val USER_FACTORS_FILE: String

    Permalink
  12. def apply(): ALS

    Permalink
  13. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  14. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  15. def createBlockInformation(userBlocks: Int, itemBlocks: Int, ratings: DataSet[(Int, Rating)], blockIDPartitioner: BlockIDPartitioner): (DataSet[(Int, InBlockInformation)], DataSet[(Int, OutBlockInformation)])

    Permalink

    Creates the meta information needed to route the item and user vectors to the respective user and item blocks.

    Creates the meta information needed to route the item and user vectors to the respective user and item blocks. * @param userBlocks

  16. def createInBlockInformation(ratings: DataSet[(Int, Rating)], usersPerBlock: DataSet[(Int, Array[Long])], blockIDGenerator: BlockIDGenerator): DataSet[(Int, InBlockInformation)]

    Permalink

    Creates the incoming block information

    Creates the incoming block information

    Creates for every user block the incoming block information. The incoming block information contains the userIDs of the users in the respective block and for every item block a BlockRating instance. The BlockRating instance describes for every incoming set of item vectors of an item block, which user rated these items and what the rating was. For that purpose it contains for every incoming item vector a tuple of an id array us and a rating array rs. The array us contains the indices of the users having rated the respective item vector with the ratings in rs.

  17. def createOutBlockInformation(ratings: DataSet[(Int, Rating)], usersPerBlock: DataSet[(Int, Array[Long])], itemBlocks: Int, blockIDGenerator: BlockIDGenerator): DataSet[(Int, OutBlockInformation)]

    Permalink

    Creates the outgoing block information

    Creates the outgoing block information

    Creates for every user block the outgoing block information. The out block information contains for every item block a scala.collection.mutable.BitSet which indicates which user vector has to be sent to this block. If a vector v has to be sent to a block b, then bitsets(b)'s bit v is set to 1, otherwise 0. Additionally the user IDataSet are replaced by the user vector's index value.

  18. def createUsersPerBlock(ratings: DataSet[(Int, Rating)]): DataSet[(Int, Array[Long])]

    Permalink

    Calculates the userIDs in ascending order of each user block

  19. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  20. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  21. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  22. implicit val fitALS: FitOperation[ALS, (Long, Long, Double)]

    Permalink

    Calculates the matrix factorization for the given ratings.

    Calculates the matrix factorization for the given ratings. A rating is defined as a tuple of user ID, item ID and the corresponding rating.

    returns

    Factorization containing the user and item matrix

  23. implicit val fitALSInt: FitOperation[ALS, (Int, Int, Double)]

    Permalink
  24. def generateFullMatrix(triangularMatrix: Array[Double], fullMatrix: Array[Double], factors: Int): Unit

    Permalink
  25. def generateRandomMatrix(users: DataSet[Int], factors: Int, seed: Long): DataSet[Factors]

    Permalink
  26. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  27. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  28. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  29. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  30. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  31. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  32. def outerProduct(vector: Array[Double], matrix: Array[Double], factors: Int): Unit

    Permalink
  33. implicit val predictRating: PredictDataSetOperation[ALS, (Long, Long), (Long, Long, Double)]

    Permalink

    Predict operation which calculates the matrix entry for the given indices

  34. implicit val predictRatingInt: PredictDataSetOperation[ALS, (Int, Int), (Int, Int, Double)]

    Permalink
  35. def randomFactors(factors: Int, random: Random): Array[Double]

    Permalink
  36. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  37. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  38. def unblock(users: DataSet[(Int, Array[Array[Double]])], outInfo: DataSet[(Int, OutBlockInformation)], blockIDPartitioner: BlockIDPartitioner): DataSet[Factors]

    Permalink

    Unblocks the blocked user and item matrix representation so that it is at DataSet of column vectors.

  39. def updateFactors(numUserBlocks: Int, items: DataSet[(Int, Array[Array[Double]])], itemOut: DataSet[(Int, OutBlockInformation)], userIn: DataSet[(Int, InBlockInformation)], factors: Int, lambda: Double, blockIDPartitioner: Partitioner[Int]): DataSet[(Int, Array[Array[Double]])]

    Permalink

    Calculates a single half step of the ALS optimization.

    Calculates a single half step of the ALS optimization. The result is the new value for either the user or item matrix, depending with which matrix the method was called.

    numUserBlocks

    Number of blocks in the respective dimension

    items

    Fixed matrix value for the half step

    itemOut

    Out information to know where to send the vectors

    userIn

    In information for the cogroup step

    factors

    Number of latent factors

    lambda

    Regularization constant

    blockIDPartitioner

    Custom Flink partitioner

    returns

    New value for the optimized matrix (either user or item)

  40. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  41. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  42. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from AnyRef

Inherited from Any

Ungrouped