You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mahout.apache.org by dl...@apache.org on 2015/10/20 07:36:52 UTC

[09/32] mahout git commit: MAHOUT-1570: rebased to latest upstream

MAHOUT-1570: rebased to latest upstream


Project: http://git-wip-us.apache.org/repos/asf/mahout/repo
Commit: http://git-wip-us.apache.org/repos/asf/mahout/commit/de732d4b
Tree: http://git-wip-us.apache.org/repos/asf/mahout/tree/de732d4b
Diff: http://git-wip-us.apache.org/repos/asf/mahout/diff/de732d4b

Branch: refs/heads/flink-binding
Commit: de732d4bc7fae9d4719ecba54decd14376551344
Parents: df1db7c
Author: Alexey Grigorev <al...@gmail.com>
Authored: Thu May 28 15:03:17 2015 +0200
Committer: Alexey Grigorev <al...@gmail.com>
Committed: Fri Sep 25 17:41:46 2015 +0200

----------------------------------------------------------------------
 .../mahout/flinkbindings/FlinkEngine.scala      | 23 +++++---------------
 1 file changed, 5 insertions(+), 18 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/mahout/blob/de732d4b/flink/src/main/scala/org/apache/mahout/flinkbindings/FlinkEngine.scala
----------------------------------------------------------------------
diff --git a/flink/src/main/scala/org/apache/mahout/flinkbindings/FlinkEngine.scala b/flink/src/main/scala/org/apache/mahout/flinkbindings/FlinkEngine.scala
index 6696152..f174871 100644
--- a/flink/src/main/scala/org/apache/mahout/flinkbindings/FlinkEngine.scala
+++ b/flink/src/main/scala/org/apache/mahout/flinkbindings/FlinkEngine.scala
@@ -46,6 +46,7 @@ import org.apache.mahout.math.drm.logical.OpRowRange
 import org.apache.mahout.math.drm.logical.OpTimesRightMatrix
 import org.apache.flink.api.common.functions.MapFunction
 import org.apache.flink.api.common.functions.ReduceFunction
+import org.apache.mahout.math.indexeddataset.BiDictionary
 
 object FlinkEngine extends DistributedEngine {
 
@@ -196,23 +197,9 @@ object FlinkEngine extends DistributedEngine {
   override def drmParallelizeEmptyLong(nrow: Long, ncol: Int, numPartitions: Int = 10)
                                       (implicit sc: DistributedContext): CheckpointedDrm[Long] = ???
 
-  /**
-   * Load IndexedDataset from text delimited format.
-   * @param src comma delimited URIs to read from
-   * @param schema defines format of file(s)
-   */
-  override def indexedDatasetDFSRead(src: String,
-                   schema: Schema = DefaultIndexedDatasetReadSchema, 
-                   existingRowIDs: BiMap[String, Int] = HashBiMap.create())
-            (implicit sc: DistributedContext): IndexedDataset = ???
+  override def indexedDatasetDFSRead(src: String, schema: Schema, existingRowIDs: Option[BiDictionary])
+                                    (implicit sc: DistributedContext): IndexedDataset = ???
 
-  /**
-   * Load IndexedDataset from text delimited format, one element per line
-   * @param src comma delimited URIs to read from
-   * @param schema defines format of file(s)
-   */
-  override def indexedDatasetDFSReadElements(src: String,
-                    schema: Schema = DefaultIndexedDatasetElementReadSchema,
-                    existingRowIDs: BiMap[String, Int] = HashBiMap.create())
-             (implicit sc: DistributedContext): IndexedDataset = ???
+  override def indexedDatasetDFSReadElements(src: String,schema: Schema, existingRowIDs: Option[BiDictionary])
+                                            (implicit sc: DistributedContext): IndexedDataset = ???
 }
\ No newline at end of file